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 

A

A - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
abort() - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter
 
abort() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
 
abort() - Method in interface org.apache.drill.exec.store.RecordWriter
 
abort() - Method in class org.apache.drill.exec.store.text.DrillTextRecordWriter
 
ABS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ABSOLUTE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
AbstractBase - Class in org.apache.drill.exec.physical.base
 
AbstractBase() - Constructor for class org.apache.drill.exec.physical.base.AbstractBase
 
AbstractBase(String) - Constructor for class org.apache.drill.exec.physical.base.AbstractBase
 
AbstractBase(AbstractBase) - Constructor for class org.apache.drill.exec.physical.base.AbstractBase
 
AbstractBinaryRecordBatch<T extends PhysicalOperator> - Class in org.apache.drill.exec.record
 
AbstractBinaryRecordBatch(T, FragmentContext, RecordBatch, RecordBatch) - Constructor for class org.apache.drill.exec.record.AbstractBinaryRecordBatch
 
AbstractBinaryRecordBatch(T, FragmentContext, boolean, RecordBatch, RecordBatch) - Constructor for class org.apache.drill.exec.record.AbstractBinaryRecordBatch
 
AbstractClassCompiler - Class in org.apache.drill.exec.compile
 
AbstractClientConnection - Class in org.apache.drill.exec.rpc
 
AbstractClientConnection(SocketChannel, String, EncryptionContext) - Constructor for class org.apache.drill.exec.rpc.AbstractClientConnection
 
AbstractClientConnection(SocketChannel, String) - Constructor for class org.apache.drill.exec.rpc.AbstractClientConnection
 
AbstractConnectionConfig - Class in org.apache.drill.exec.rpc
 
AbstractConnectionConfig(BufferAllocator, BootStrapContext) - Constructor for class org.apache.drill.exec.rpc.AbstractConnectionConfig
 
AbstractDataCollector - Class in org.apache.drill.exec.work.batch
 
AbstractDataCollector(AtomicInteger, int, BitControl.Collector, int, FragmentContext) - Constructor for class org.apache.drill.exec.work.batch.AbstractDataCollector
 
AbstractDeMuxExchange - Class in org.apache.drill.exec.physical.config
DeMuxExchange is opposite of MuxExchange.
AbstractDeMuxExchange(PhysicalOperator, LogicalExpression) - Constructor for class org.apache.drill.exec.physical.config.AbstractDeMuxExchange
 
AbstractDisposableUserClientConnection - Class in org.apache.drill.exec.rpc
Helps to run a query and await on the results.
AbstractDisposableUserClientConnection() - Constructor for class org.apache.drill.exec.rpc.AbstractDisposableUserClientConnection
 
AbstractExchange - Class in org.apache.drill.exec.physical.base
 
AbstractExchange(PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.base.AbstractExchange
 
AbstractFileGroupScan - Class in org.apache.drill.exec.physical.base
 
AbstractFileGroupScan(String) - Constructor for class org.apache.drill.exec.physical.base.AbstractFileGroupScan
 
AbstractFileGroupScan(AbstractFileGroupScan) - Constructor for class org.apache.drill.exec.physical.base.AbstractFileGroupScan
 
AbstractFragmentManager - Class in org.apache.drill.exec.work.fragment
 
AbstractFragmentManager(BitControl.PlanFragment, FragmentExecutor, FragmentStatusReporter, FragmentRoot) - Constructor for class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
AbstractFragmentManager(BitControl.PlanFragment, FragmentExecutor, FragmentStatusReporter) - Constructor for class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
AbstractFuncHolder - Class in org.apache.drill.exec.expr.fn
 
AbstractFuncHolder() - Constructor for class org.apache.drill.exec.expr.fn.AbstractFuncHolder
 
AbstractGroupScan - Class in org.apache.drill.exec.physical.base
 
AbstractGroupScan(String) - Constructor for class org.apache.drill.exec.physical.base.AbstractGroupScan
 
AbstractGroupScan(AbstractGroupScan) - Constructor for class org.apache.drill.exec.physical.base.AbstractGroupScan
 
AbstractMultiple - Class in org.apache.drill.exec.physical.base
Describes an operator that expects more than one children operators as its input.
AbstractMultiple(List<PhysicalOperator>) - Constructor for class org.apache.drill.exec.physical.base.AbstractMultiple
 
AbstractMuxExchange - Class in org.apache.drill.exec.physical.config
Multiplexing Exchange (MuxExchange) is used when results from multiple minor fragments belonging to the same major fragment running on a node need to be collected at one fragment on the same node before distributing the results further.
AbstractMuxExchange(PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.config.AbstractMuxExchange
 
AbstractOpWrapperVisitor<RET,EXCEP extends Throwable> - Class in org.apache.drill.exec.planner
 
AbstractOpWrapperVisitor() - Constructor for class org.apache.drill.exec.planner.AbstractOpWrapperVisitor
 
AbstractPartitionDescriptor - Class in org.apache.drill.exec.planner
Abstract base class for file system based partition descriptors and Hive partition descriptors.
AbstractPartitionDescriptor() - Constructor for class org.apache.drill.exec.planner.AbstractPartitionDescriptor
 
AbstractPhysicalVisitor<T,X,E extends Throwable> - Class in org.apache.drill.exec.physical.base
 
AbstractPhysicalVisitor() - Constructor for class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
AbstractPojoRecordReader<T> - Class in org.apache.drill.exec.store.pojo
Parent class for all pojo readers.
AbstractPojoRecordReader(List<T>) - Constructor for class org.apache.drill.exec.store.pojo.AbstractPojoRecordReader
 
AbstractPojoWriter<V extends ValueVector> - Class in org.apache.drill.exec.store.pojo
Parent class for all pojo writers created for each field.
AbstractPojoWriter(String, TypeProtos.MajorType) - Constructor for class org.apache.drill.exec.store.pojo.AbstractPojoWriter
 
AbstractReceiver - Class in org.apache.drill.exec.physical.base
 
AbstractReceiver(int, List<MinorFragmentEndpoint>, boolean) - Constructor for class org.apache.drill.exec.physical.base.AbstractReceiver
 
AbstractRecordBatch<T extends PhysicalOperator> - Class in org.apache.drill.exec.record
 
AbstractRecordBatch(T, FragmentContext) - Constructor for class org.apache.drill.exec.record.AbstractRecordBatch
 
AbstractRecordBatch(T, FragmentContext, boolean) - Constructor for class org.apache.drill.exec.record.AbstractRecordBatch
 
AbstractRecordBatch(T, FragmentContext, boolean, OperatorContext) - Constructor for class org.apache.drill.exec.record.AbstractRecordBatch
 
AbstractRecordBatch.BatchState - Enum in org.apache.drill.exec.record
 
AbstractRecordReader - Class in org.apache.drill.exec.store
 
AbstractRecordReader() - Constructor for class org.apache.drill.exec.store.AbstractRecordReader
 
AbstractRecordWriter - Class in org.apache.drill.exec.store
 
AbstractRecordWriter() - Constructor for class org.apache.drill.exec.store.AbstractRecordWriter
 
AbstractResourceManager - Class in org.apache.drill.exec.work.foreman.rm
Abstract base class for a resource manager.
AbstractResourceManager(DrillbitContext) - Constructor for class org.apache.drill.exec.work.foreman.rm.AbstractResourceManager
 
AbstractRpcMetrics - Class in org.apache.drill.exec.rpc
 
AbstractRpcMetrics() - Constructor for class org.apache.drill.exec.rpc.AbstractRpcMetrics
 
AbstractSchema - Class in org.apache.drill.exec.store
 
AbstractSchema(List<String>, String) - Constructor for class org.apache.drill.exec.store.AbstractSchema
 
AbstractSender - Class in org.apache.drill.exec.physical.base
 
AbstractSender(int, PhysicalOperator, List<MinorFragmentEndpoint>) - Constructor for class org.apache.drill.exec.physical.base.AbstractSender
 
AbstractServerConnection<S extends ServerConnection<S>> - Class in org.apache.drill.exec.rpc
 
AbstractServerConnection(SocketChannel, String, ConnectionConfig, RequestHandler<S>) - Constructor for class org.apache.drill.exec.rpc.AbstractServerConnection
 
AbstractServerConnection(SocketChannel, ConnectionConfig, RequestHandler<S>) - Constructor for class org.apache.drill.exec.rpc.AbstractServerConnection
 
AbstractSingle - Class in org.apache.drill.exec.physical.base
Describes an operator that expects a single child operator as its input.
AbstractSingle(PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.base.AbstractSingle
 
AbstractSingleRecordBatch<T extends PhysicalOperator> - Class in org.apache.drill.exec.record
 
AbstractSingleRecordBatch(T, FragmentContext, RecordBatch) - Constructor for class org.apache.drill.exec.record.AbstractSingleRecordBatch
 
AbstractSqlAccessor - Class in org.apache.drill.exec.vector.accessor
 
AbstractSqlAccessor() - Constructor for class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
AbstractSqlHandler - Class in org.apache.drill.exec.planner.sql.handlers
 
AbstractSqlHandler() - Constructor for class org.apache.drill.exec.planner.sql.handlers.AbstractSqlHandler
 
AbstractSqlPatternMatcher - Class in org.apache.drill.exec.expr.fn.impl
To get good performance for most commonly used pattern matches CONSTANT('ABC') SqlPatternConstantMatcher STARTSWITH('%ABC') SqlPatternStartsWithMatcher ENDSWITH('ABC%') SqlPatternEndsWithMatcher CONTAINS('%ABC%') SqlPatternContainsMatcher we have simple pattern matchers.
AbstractSqlPatternMatcher(String) - Constructor for class org.apache.drill.exec.expr.fn.impl.AbstractSqlPatternMatcher
 
AbstractStoragePlugin - Class in org.apache.drill.exec.store
Abstract class for StorePlugin implementations.
AbstractStoragePlugin() - Constructor for class org.apache.drill.exec.store.AbstractStoragePlugin
 
AbstractStore - Class in org.apache.drill.exec.physical.base
 
AbstractStore(PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.base.AbstractStore
 
AbstractStreamSerializable - Class in org.apache.drill.exec.cache
 
AbstractStreamSerializable() - Constructor for class org.apache.drill.exec.cache.AbstractStreamSerializable
 
AbstractSubScan - Class in org.apache.drill.exec.physical.base
 
AbstractSubScan(String) - Constructor for class org.apache.drill.exec.physical.base.AbstractSubScan
 
AbstractWriter - Class in org.apache.drill.exec.physical.base
 
AbstractWriter(PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.base.AbstractWriter
 
accept(MethodVisitor) - Method in class org.apache.drill.exec.compile.bytecode.TrackingInstructionList
 
accept(ExprVisitor<T, V, E>, V) - Method in class org.apache.drill.exec.expr.HoldingContainerExpression
 
accept(ExprVisitor<T, V, E>, V) - Method in class org.apache.drill.exec.expr.stat.ParquetPredicates.ParquetBooleanPredicate
 
accept(ExprVisitor<T, V, E>, V) - Method in class org.apache.drill.exec.expr.stat.ParquetPredicates.ParquetCompPredicate
 
accept(ExprVisitor<T, V, E>, V) - Method in class org.apache.drill.exec.expr.stat.TypedFieldExpr
 
accept(ExprVisitor<T, V, E>, V) - Method in class org.apache.drill.exec.expr.ValueVectorReadExpression
 
accept(ExprVisitor<T, V, E>, V) - Method in class org.apache.drill.exec.expr.ValueVectorWriteExpression
 
accept(T) - Method in interface org.apache.drill.exec.ops.Consumer
 
accept(GraphVisitor<PhysicalOperator>) - Method in class org.apache.drill.exec.physical.base.AbstractBase
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.base.AbstractExchange
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.base.AbstractReceiver
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.base.AbstractSender
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.base.AbstractStore
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.base.AbstractSubScan
 
accept(GraphVisitor<PhysicalOperator>) - Method in class org.apache.drill.exec.physical.base.AbstractSubScan
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.base.AbstractWriter
 
accept(PhysicalVisitor<T, X, E>, X) - Method in interface org.apache.drill.exec.physical.base.PhysicalOperator
Provides capability to build a set of output based on traversing a query graph tree.
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.BroadcastSender
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.ComplexToJson
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.Filter
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.FlattenPOP
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.HashAggregate
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.HashPartitionSender
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.IteratorValidator
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.Limit
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.MergeJoinPOP
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.MergingReceiverPOP
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.NestedLoopJoinPOP
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.OrderedPartitionSender
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.ProducerConsumer
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.Project
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.Screen
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.SelectionVectorRemover
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.SingleSender
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.Sort
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.StreamingAggregate
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.TopN
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.Trace
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.UnionAll
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.UnorderedReceiver
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.Values
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.physical.config.WindowPOP
 
accept(ExprVisitor<T, V, E>, V) - Method in class org.apache.drill.exec.physical.impl.filter.ReturnValueExpression
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.AggPrelBase
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.ComplexToJsonPrel
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.ExchangePrel
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.FilterPrel
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.JoinPrel
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.LimitPrel
 
accept(PrelVisitor<T, X, E>, X) - Method in interface org.apache.drill.exec.planner.physical.Prel
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.ProducerConsumerPrel
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.ProjectPrel
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.ScanPrel
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.ScreenPrel
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.SinglePrel
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.SortPrel
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.StreamAggPrel
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.UnionPrel
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.ValuesPrel
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.WindowPrel
 
accept(PrelVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.planner.physical.WriterPrel
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.store.mock.MockSubScanPOP
 
accept(PhysicalVisitor<T, X, E>, X) - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
 
access(Path, FsAction) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
accessible(String) - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory
Checks whether the given user has permission to list files/directories under the workspace directory.
accessible(DrillFileSystem) - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory
Checks whether a FileSystem object has the permission to list/read workspace directory
accessibleScopes - Variable in class org.apache.drill.exec.server.options.OptionValue
 
accessibleScopes - Variable in class org.apache.drill.exec.store.sys.ExtendedOptionIterator.ExtendedOptionValueWrapper
 
accessibleScopes - Variable in class org.apache.drill.exec.store.sys.OptionIterator.OptionValueWrapper
 
accessTime - Variable in class org.apache.drill.exec.planner.sql.handlers.ShowFilesCommandResult
 
AccountingDataTunnel - Class in org.apache.drill.exec.ops
Wrapper around a DataTunnel that tracks the status of batches sent to to other Drillbits.
AccountingDataTunnel(DataTunnel, SendingAccountor, RpcOutcomeListener<GeneralRPCProtos.Ack>) - Constructor for class org.apache.drill.exec.ops.AccountingDataTunnel
 
AccountingUserConnection - Class in org.apache.drill.exec.ops
Wrapper around a UserClientConnection that tracks the status of batches sent to User.
AccountingUserConnection(UserClientConnection, SendingAccountor, RpcOutcomeListener<GeneralRPCProtos.Ack>) - Constructor for class org.apache.drill.exec.ops.AccountingUserConnection
 
AckSender - Class in org.apache.drill.exec.rpc.data
Utility class that allows a group of receivers to confirm reception of a record batch as a single unit.
AckSender(ResponseSender) - Constructor for class org.apache.drill.exec.rpc.data.AckSender
 
acquire(long, TimeUnit) - Method in interface org.apache.drill.exec.coord.DistributedSemaphore
 
acquire(long, TimeUnit) - Method in class org.apache.drill.exec.coord.local.LocalClusterCoordinator.LocalSemaphore
 
acquire(long, TimeUnit) - Method in class org.apache.drill.exec.coord.zk.ZkDistributedSemaphore
 
action - Variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager.MergeTask
 
ACTION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ACTIVE_FRAGMENT_OVERVIEW_COLUMNS - Static variable in class org.apache.drill.exec.server.rest.profile.FragmentWrapper
 
ACTIVE_FRAGMENT_OVERVIEW_COLUMNS_TOOLTIP - Static variable in class org.apache.drill.exec.server.rest.profile.FragmentWrapper
 
activeRM() - Method in class org.apache.drill.exec.work.foreman.rm.DynamicResourceManager
 
ACTUAL_LENGTH_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
actualPartitions - Variable in class org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec
 
actualSize() - Method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
 
ADA - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
add() - Method in interface org.apache.drill.exec.expr.DrillAggFunc
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.BitAggregateErrorFunctions
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.NullableBitAggregateErrorFunctions
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.NullableVarCharAggregateErrorFunctions
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.VarCharAggregateErrorFunctions
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.BitBooleanAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.BitBooleanOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.NullableBitBooleanAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.NullableBitBooleanOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.BigIntAvg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.Float4Avg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.Float8Avg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.IntAvg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableBigIntAvg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableFloat4Avg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableFloat8Avg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableIntAvg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.IntervalAvg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.IntervalDayAvg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.IntervalYearAvg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.NullableIntervalAvg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.NullableIntervalDayAvg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.NullableIntervalYearAvg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.BigIntBitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.IntBitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableBigIntBitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableIntBitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableSmallIntBitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableTinyIntBitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt1BitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt2BitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt4BitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt8BitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.SmallIntBitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.TinyIntBitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt1BitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt2BitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt4BitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt8BitwiseAnd
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.BigIntBitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.IntBitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableBigIntBitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableIntBitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableSmallIntBitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableTinyIntBitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt1BitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt2BitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt4BitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt8BitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.SmallIntBitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.TinyIntBitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt1BitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt2BitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt4BitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt8BitwiseOr
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.BigIntCorrelation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.Float4Correlation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.Float8Correlation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.IntCorrelation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableBigIntCorrelation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableFloat4Correlation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableFloat8Correlation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableIntCorrelation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableSmallIntCorrelation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableTinyIntCorrelation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt1Correlation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt2Correlation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt4Correlation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt8Correlation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.SmallIntCorrelation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.TinyIntCorrelation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt1Correlation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt2Correlation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt4Correlation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt8Correlation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.BigIntCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.BitCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.DateCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal18CountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal28SparseCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal38SparseCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal9CountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Float4CountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Float8CountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntervalCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntervalDayCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntervalYearCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.ListCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.MapCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableBigIntCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableBitCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDateCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal18CountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal28SparseCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal38SparseCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal9CountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableFloat4CountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableFloat8CountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntervalCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntervalDayCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntervalYearCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableTimeCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableTimeStampCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableVarBinaryCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableVarCharCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedBigIntCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedBitCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDateCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal18CountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal28SparseCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal38SparseCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal9CountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedFloat4CountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedFloat8CountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntervalCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntervalDayCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntervalYearCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedListCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedMapCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedTimeCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedTimeStampCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedVarBinaryCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedVarCharCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.TimeCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.TimeStampCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.VarBinaryCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.VarCharCountFunction
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.BigIntCoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.Float4CoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.Float8CoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.IntCoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableBigIntCoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableFloat4CoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableFloat8CoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableIntCoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableSmallIntCoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableTinyIntCoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt1CoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt2CoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt4CoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt8CoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.SmallIntCoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.TinyIntCoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt1CoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt2CoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt4CoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt8CoVariancePopulation
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.BigIntCoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.Float4CoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.Float8CoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.IntCoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableBigIntCoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableFloat4CoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableFloat8CoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableIntCoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableSmallIntCoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableTinyIntCoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt1CoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt2CoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt4CoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt8CoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.SmallIntCoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.TinyIntCoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt1CoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt2CoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt4CoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt8CoVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal18Avg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal28SparseAvg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal38SparseAvg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal9Avg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal18Avg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal28SparseAvg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal38SparseAvg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal9Avg
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal18Max
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal28SparseMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal38SparseMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal9Max
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal18Max
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal28SparseMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal38SparseMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal9Max
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal18Min
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal28SparseMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal38SparseMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal9Min
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal18Min
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal28SparseMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal38SparseMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal9Min
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal18Sum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal28SparseSum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal38SparseSum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal9Sum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal18Sum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal28SparseSum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal38SparseSum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal9Sum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.DateMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.IntervalDayMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.IntervalMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.IntervalYearMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableDateMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableIntervalDayMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableIntervalMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableIntervalYearMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableTimeMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableTimeStampMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.TimeMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.TimeStampMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.BigIntMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.Float4Max
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.Float8Max
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.IntMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableBigIntMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableFloat4Max
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableFloat8Max
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableIntMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.NullableVarBinaryMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.NullableVarCharMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.VarBinaryMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.VarCharMax
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.DateMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.IntervalDayMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.IntervalMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.IntervalYearMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableDateMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableIntervalDayMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableIntervalMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableIntervalYearMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableTimeMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableTimeStampMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.TimeMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.TimeStampMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.BigIntMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.BitMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.Float4Min
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.Float8Min
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.IntMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableBigIntMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableBitMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableFloat4Min
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableFloat8Min
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableIntMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.NullableVarBinaryMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.NullableVarCharMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.VarBinaryMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.VarCharMin
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.BigIntStdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.Float4StdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.Float8StdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.IntStdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableBigIntStdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableFloat4StdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableFloat8StdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableIntStdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableSmallIntStdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableTinyIntStdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt1StdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt2StdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt4StdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt8StdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.SmallIntStdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.TinyIntStdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt1StdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt2StdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt4StdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt8StdDevPop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.BigIntStdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.Float4StdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.Float8StdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.IntStdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableBigIntStdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableFloat4StdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableFloat8StdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableIntStdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableSmallIntStdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableTinyIntStdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt1StdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt2StdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt4StdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt8StdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.SmallIntStdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.TinyIntStdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt1StdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt2StdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt4StdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt8StdDevSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.IntervalDaySum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.IntervalSum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.IntervalYearSum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.NullableIntervalDaySum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.NullableIntervalSum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.NullableIntervalYearSum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.BigIntSum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.Float4Sum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.Float8Sum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.IntSum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableBigIntSum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableFloat4Sum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableFloat8Sum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableIntSum
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.BigIntSumZero
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.BitSumZero
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.Float4SumZero
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.Float8SumZero
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.IntSumZero
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableBigIntSumZero
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableBitSumZero
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableFloat4SumZero
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableFloat8SumZero
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableIntSumZero
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.BigIntVariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.Float4VariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.Float8VariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.IntVariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableBigIntVariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableFloat4VariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableFloat8VariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableIntVariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableSmallIntVariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableTinyIntVariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt1VariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt2VariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt4VariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt8VariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.SmallIntVariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.TinyIntVariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt1VariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt2VariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt4VariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt8VariancePop
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.BigIntVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.Float4VarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.Float8VarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.IntVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableBigIntVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableFloat4VarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableFloat8VarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableIntVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableSmallIntVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableTinyIntVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt1VarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt2VarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt4VarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt8VarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.SmallIntVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.TinyIntVarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt1VarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt2VarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt4VarianceSample
 
add() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt8VarianceSample
 
add(VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.sort.SortRecordBatchBuilder
Add another record batch to the set of record batches.
add(RecordBatchData) - Method in class org.apache.drill.exec.physical.impl.sort.SortRecordBatchBuilder
 
add(RecordBatchData) - Method in interface org.apache.drill.exec.physical.impl.TopN.PriorityQueue
The elements in the given batch are added to the priority queue.
add(RecordBatchData) - Method in class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
 
add(VectorAccessible, long) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BufferedBatches
 
add(ParallelizationInfo) - Method in class org.apache.drill.exec.planner.fragment.ParallelizationInfo.ParallelizationInfoCollector
 
ADD - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
add(RecordBatch, boolean) - Method in class org.apache.drill.exec.record.selection.SelectionVector4Builder
 
add(ValueVector) - Method in class org.apache.drill.exec.record.VectorContainer
 
add(ValueVector[]) - Method in class org.apache.drill.exec.record.VectorContainer
 
add(ValueVector[], boolean) - Method in class org.apache.drill.exec.record.VectorContainer
 
add(CoordinationProtos.DrillbitEndpoint, long) - Method in interface org.apache.drill.exec.store.schedule.EndpointByteMap
 
add(CoordinationProtos.DrillbitEndpoint, long) - Method in class org.apache.drill.exec.store.schedule.EndpointByteMapImpl
 
add(T) - Method in interface org.apache.drill.exec.work.batch.BaseRawBatchBuffer.BufferQueue
 
add_escapes(String) - Method in exception org.apache.drill.exec.planner.sql.parser.impl.ParseException
Used to convert raw characters to their escaped version when these raw version cannot be used as part of an ASCII string literal.
addAffinity(double) - Method in class org.apache.drill.exec.physical.EndpointAffinity
Add given affinity value to existing affinity value.
addAllMetrics(UserBitShared.OperatorProfile.Builder) - Method in class org.apache.drill.exec.ops.OperatorStats
 
addAllocation(PhysicalOperator) - Method in class org.apache.drill.exec.planner.fragment.Materializer.IndexedFragmentNode
 
addAllocation(PhysicalOperator) - Method in class org.apache.drill.exec.planner.fragment.Wrapper
 
addAttributesToHelper(Objects.ToStringHelper) - Method in class org.apache.drill.exec.schema.Field
 
addAttributesToHelper(Objects.ToStringHelper) - Method in class org.apache.drill.exec.schema.NamedField
 
addAttributesToHelper(Objects.ToStringHelper) - Method in class org.apache.drill.exec.schema.OrderedField
 
addBatch(VectorContainer) - Method in class org.apache.drill.exec.physical.impl.xsort.BatchGroup
 
addBatch(VectorContainer) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.SpilledRun
 
addBatch(VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl
Process the converted incoming batch by adding it to the in-memory store of data, or spilling data to disk when necessary.
addBatch(VectorAccessible) - Method in class org.apache.drill.exec.record.ExpandableHyperContainer
 
addBinary(Binary) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillBinaryToDecimal28Converter
 
addBinary(Binary) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillBinaryToDecimal38Converter
 
addBinary(Binary) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillFixedBinaryToTimeStampConverter
 
addBinary(Binary) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillFixedBinaryToVarbinaryConverter
 
addBinary(Binary) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillFixedLengthByteArrayToInterval
 
addBinary(Binary) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillVarBinaryConverter
 
addBinary(Binary) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillVarCharConverter
 
addBoolean(boolean) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillBoolConverter
 
addCastExpression(LogicalExpression, TypeProtos.MajorType, FunctionLookupContext, ErrorCollector) - Static method in class org.apache.drill.exec.expr.ExpressionTreeMaterializer
 
addCastExpression(LogicalExpression, TypeProtos.MajorType, FunctionLookupContext, ErrorCollector, boolean) - Static method in class org.apache.drill.exec.expr.ExpressionTreeMaterializer
 
addChild(RexNode) - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions.OpState
 
addClass(String, byte[]) - Method in class org.apache.drill.exec.compile.CachedClassLoader
 
addClasses(Map<String, byte[]>) - Method in class org.apache.drill.exec.compile.CachedClassLoader
 
addCollection(Iterable<ValueVector>) - Method in class org.apache.drill.exec.record.VectorContainer
 
addColumn(ColumnDescriptor, ColumnChunkMetaData) - Method in class org.apache.parquet.hadoop.ColumnChunkIncReadStore
 
addComplexToJsonPrel(Prel) - Static method in class org.apache.drill.exec.planner.physical.visitor.ComplexToJsonPrelVisitor
 
addComplexWriter(BaseWriter.ComplexWriter) - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenRecordBatch
 
addComplexWriter(BaseWriter.ComplexWriter) - Method in class org.apache.drill.exec.physical.impl.project.ProjectRecordBatch
 
addConnectionCount() - Method in class org.apache.drill.exec.rpc.control.ControlRpcMetrics
 
addConnectionCount() - Method in class org.apache.drill.exec.rpc.data.DataRpcMetrics
 
addConnectionCount() - Method in class org.apache.drill.exec.rpc.user.UserRpcMetrics
 
addCost(double) - Method in class org.apache.drill.exec.planner.fragment.Stats
 
addData(int, Object, boolean) - Method in class org.apache.drill.exec.schema.DataRecord
 
addDelegationTokens(String, Credentials) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
addDouble(double) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillFloat8Converter
 
addDoubleMetrics(UserBitShared.OperatorProfile.Builder) - Method in class org.apache.drill.exec.ops.OperatorStats
 
addDoubleStat(MetricDef, double) - Method in interface org.apache.drill.exec.ops.OperatorStatReceiver
Add a double value to the existing value.
addDoubleStat(MetricDef, double) - Method in class org.apache.drill.exec.ops.OperatorStats
 
addDrillbitStatusListener(DrillbitStatusListener) - Method in class org.apache.drill.exec.coord.ClusterCoordinator
Register a DrillbitStatusListener.
addEndpointAffinities(List<EndpointAffinity>) - Method in class org.apache.drill.exec.planner.fragment.ParallelizationInfo.ParallelizationInfoCollector
 
addEndpointAffinities(List<EndpointAffinity>) - Method in class org.apache.drill.exec.planner.fragment.Stats
 
addEscapes(String) - Static method in error org.apache.drill.exec.planner.sql.parser.impl.TokenMgrError
Replaces unprintable characters by their espaced (or unicode escaped) equivalents in the given string
addExpr(LogicalExpression) - Method in class org.apache.drill.exec.expr.ClassGenerator
 
addExpr(LogicalExpression, ClassGenerator.BlkCreateMode) - Method in class org.apache.drill.exec.expr.ClassGenerator
 
addExpr(LogicalExpression, ClassGenerator<?>) - Method in class org.apache.drill.exec.expr.EvaluationVisitor
 
addField(MaterializedField, Class<T>) - Method in interface org.apache.drill.exec.physical.impl.OutputMutator
Add a ValueVector for new (or existing) field.
addField(MaterializedField, Class<T>) - Method in class org.apache.drill.exec.physical.impl.ScanBatch.Mutator
 
addField(MaterializedField) - Method in class org.apache.drill.exec.record.SchemaBuilder
 
addField(Field) - Method in class org.apache.drill.exec.schema.ListSchema
 
addField(Field) - Method in class org.apache.drill.exec.schema.ObjectSchema
 
addField(Field) - Method in interface org.apache.drill.exec.schema.RecordSchema
 
addField(Parser<HttpdLogRecord>, BaseWriter.MapWriter, EnumSet<Casts>, String, String) - Method in class org.apache.drill.exec.store.httpd.HttpdLogRecord
This record will be used with a single parser.
addField(int, String) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
addField(int, String) - Method in class org.apache.drill.exec.store.text.DrillTextRecordWriter
 
addFields(Iterable<MaterializedField>) - Method in class org.apache.drill.exec.record.SchemaBuilder
 
addFinalColumnOrdering(Prel) - Static method in class org.apache.drill.exec.planner.physical.visitor.FinalColumnReorderer
 
addFinalSummary(TableBuilder) - Method in class org.apache.drill.exec.server.rest.profile.FragmentWrapper
 
addFloat(float) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillFloat4Converter
 
addFragmentDependency(Wrapper) - Method in class org.apache.drill.exec.planner.fragment.Wrapper
Add a parallelization dependency on given fragment.
addFragmentManager(FragmentManager) - Method in class org.apache.drill.exec.rpc.control.WorkEventBus
 
addFragmentRunner(FragmentExecutor) - Method in class org.apache.drill.exec.work.WorkManager.WorkerBee
Currently used to start a root fragment that is not blocked on data, and leaf fragments.
addFragmentStatusListener(UserBitShared.QueryId, FragmentStatusListener) - Method in class org.apache.drill.exec.rpc.control.WorkEventBus
 
AddFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
AddFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.AddFunctions
 
addFunctions(Collection<DrillFuncHolder>) - Method in class org.apache.drill.exec.planner.sql.DrillSqlAggOperator.DrillSqlAggOperatorBuilder
 
addFunctions(Collection<DrillFuncHolder>) - Method in class org.apache.drill.exec.planner.sql.DrillSqlOperator.DrillSqlOperatorBuilder
 
AddFunctions.BigIntBigIntAdd - Class in org.apache.drill.exec.expr.fn.impl
 
AddFunctions.BigIntBigIntAdd() - Constructor for class org.apache.drill.exec.expr.fn.impl.AddFunctions.BigIntBigIntAdd
 
AddFunctions.Float4Float4Add - Class in org.apache.drill.exec.expr.fn.impl
 
AddFunctions.Float4Float4Add() - Constructor for class org.apache.drill.exec.expr.fn.impl.AddFunctions.Float4Float4Add
 
AddFunctions.Float8Float8Add - Class in org.apache.drill.exec.expr.fn.impl
 
AddFunctions.Float8Float8Add() - Constructor for class org.apache.drill.exec.expr.fn.impl.AddFunctions.Float8Float8Add
 
AddFunctions.IntIntAdd - Class in org.apache.drill.exec.expr.fn.impl
 
AddFunctions.IntIntAdd() - Constructor for class org.apache.drill.exec.expr.fn.impl.AddFunctions.IntIntAdd
 
AddFunctions.SmallIntSmallIntAdd - Class in org.apache.drill.exec.expr.fn.impl
 
AddFunctions.SmallIntSmallIntAdd() - Constructor for class org.apache.drill.exec.expr.fn.impl.AddFunctions.SmallIntSmallIntAdd
 
AddFunctions.TinyIntTinyIntAdd - Class in org.apache.drill.exec.expr.fn.impl
 
AddFunctions.TinyIntTinyIntAdd() - Constructor for class org.apache.drill.exec.expr.fn.impl.AddFunctions.TinyIntTinyIntAdd
 
AddFunctions.UInt1UInt1Add - Class in org.apache.drill.exec.expr.fn.impl
 
AddFunctions.UInt1UInt1Add() - Constructor for class org.apache.drill.exec.expr.fn.impl.AddFunctions.UInt1UInt1Add
 
AddFunctions.UInt2UInt2Add - Class in org.apache.drill.exec.expr.fn.impl
 
AddFunctions.UInt2UInt2Add() - Constructor for class org.apache.drill.exec.expr.fn.impl.AddFunctions.UInt2UInt2Add
 
AddFunctions.UInt4UInt4Add - Class in org.apache.drill.exec.expr.fn.impl
 
AddFunctions.UInt4UInt4Add() - Constructor for class org.apache.drill.exec.expr.fn.impl.AddFunctions.UInt4UInt4Add
 
AddFunctions.UInt8UInt8Add - Class in org.apache.drill.exec.expr.fn.impl
 
AddFunctions.UInt8UInt8Add() - Constructor for class org.apache.drill.exec.expr.fn.impl.AddFunctions.UInt8UInt8Add
 
addHyperList(List<ValueVector>) - Method in class org.apache.drill.exec.record.VectorContainer
 
addHyperList(List<ValueVector>, boolean) - Method in class org.apache.drill.exec.record.VectorContainer
 
addId(int) - Method in class org.apache.drill.exec.record.TypedFieldId.Builder
 
addIndex(int, SqlParserPos) - Method in class org.apache.drill.exec.planner.sql.parser.DrillCompoundIdentifier.Builder
 
addInt(int) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.CorruptionDetectingDateConverter
 
addInt(int) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillCorruptedDateConverter
 
addInt(int) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillDateConverter
 
addInt(int) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillDecimal9Converter
 
addInt(int) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillIntConverter
 
addInt(int) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillTimeConverter
 
addJars(Map<String, List<FunctionHolder>>, long) - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
Adds jars to the function registry.
addLeastRestrictiveCasts(LogicalExpression[], VectorAccessible, LogicalExpression[], VectorAccessible, FragmentContext) - Static method in class org.apache.drill.exec.physical.impl.join.JoinUtils
Utility method used by joins to add implicit casts on one of the sides of the join condition in case the two expressions have different types.
addListener(TransientStoreListener) - Method in class org.apache.drill.exec.coord.store.BaseTransientStore
 
addListener(TransientStoreListener) - Method in interface org.apache.drill.exec.coord.store.TransientStore
Adds a listener that observes store events.
addLong(long) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillBigIntConverter
 
addLong(long) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillDecimal18Converter
 
addLong(long) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillTimeStampConverter
 
addLongMetrics(UserBitShared.OperatorProfile.Builder) - Method in class org.apache.drill.exec.ops.OperatorStats
 
addLongStat(MetricDef, long) - Method in interface org.apache.drill.exec.ops.OperatorStatReceiver
Add a long value to the existing value.
addLongStat(MetricDef, long) - Method in class org.apache.drill.exec.ops.OperatorStats
 
addMaxWidth(int) - Method in class org.apache.drill.exec.planner.fragment.ParallelizationInfo.ParallelizationInfoCollector
 
addMaxWidth(int) - Method in class org.apache.drill.exec.planner.fragment.Stats
 
addMetadata(Prel, PhysicalOperator) - Method in class org.apache.drill.exec.planner.physical.PhysicalPlanCreator
 
addMetricsToStatus(UserBitShared.MinorFragmentProfile.Builder) - Method in class org.apache.drill.exec.ops.FragmentStats
 
addMinWidth(int) - Method in class org.apache.drill.exec.planner.fragment.ParallelizationInfo.ParallelizationInfoCollector
 
addMinWidth(int) - Method in class org.apache.drill.exec.planner.fragment.Stats
 
addNewBatch(int) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelper
 
addNewForeman(Foreman) - Method in class org.apache.drill.exec.work.WorkManager.WorkerBee
 
addNewWork(Runnable) - Method in class org.apache.drill.exec.work.WorkManager.WorkerBee
Add a self contained runnable work to executor service.
addOomBatch(RawFragmentBatch) - Method in interface org.apache.drill.exec.work.batch.BaseRawBatchBuffer.BufferQueue
 
addOperator(PhysicalOperator) - Method in class org.apache.drill.exec.planner.fragment.Fragment
Set the given operator as root operator of this fragment.
addOperatorStats(OperatorStats) - Method in class org.apache.drill.exec.ops.FragmentStats
 
addOperatorWithInference(String, SqlOperator) - Method in class org.apache.drill.exec.planner.sql.DrillOperatorTable
When the option planner.type_inference.enable is turned on, the operators which are added via this method will be used.
addOperatorWithoutInference(String, SqlOperator) - Method in class org.apache.drill.exec.planner.sql.DrillOperatorTable
When the option planner.type_inference.enable is turned off, the operators which are added via this method will be used.
addOrGet(String, TypeProtos.MajorType, Class<T>) - Method in class org.apache.drill.exec.record.VectorAccessibleComplexWriter
 
addOrGet(MaterializedField) - Method in class org.apache.drill.exec.record.VectorContainer
 
addOrGet(MaterializedField, SchemaChangeCallBack) - Method in class org.apache.drill.exec.record.VectorContainer
 
addOrGet(String, TypeProtos.MajorType, Class<T>) - Method in class org.apache.drill.exec.record.VectorContainer
 
addParallelizationInfo(ParallelizationInfo) - Method in class org.apache.drill.exec.planner.fragment.Stats
 
addPlugin(String, StoragePlugin) - Method in interface org.apache.drill.exec.store.StoragePluginRegistry
Add a plugin to the registry using the provided name.
addPlugin(String, StoragePlugin) - Method in class org.apache.drill.exec.store.StoragePluginRegistryImpl
 
addProducerConsumerToScans(Prel, int) - Static method in class org.apache.drill.exec.planner.physical.visitor.ProducerConsumerPrelVisitor
 
addProjected(SchemaPath) - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer.FieldList
 
addProjected(Collection<SchemaPath>) - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer.FieldList
 
addProtectedBlock(ClassGenerator<?>, JBlock, String, ClassGenerator.HoldingContainer[], JVar[], boolean) - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
addReceiveExchange(Exchange, Fragment) - Method in class org.apache.drill.exec.planner.fragment.Fragment
 
addRecord(int) - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
 
addReferenced(SchemaPath) - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer.FieldList
 
addReferenced(Collection<SchemaPath>) - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer.FieldList
 
addRemovedField(Field) - Method in class org.apache.drill.exec.schema.DiffSchema
 
addRenamedProject(DrillRel, RelDataType) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
 
address - Variable in class org.apache.drill.exec.testing.Injection
 
addSelectionRemoversWhereNecessary(Prel) - Static method in class org.apache.drill.exec.planner.physical.visitor.SelectionVectorPrelVisitor
 
addSendExchange(Exchange, Fragment) - Method in class org.apache.drill.exec.planner.fragment.Fragment
 
addSerializedFields(Iterable<UserBitShared.SerializedField>) - Method in class org.apache.drill.exec.record.SchemaBuilder
 
addStartIndexBatch() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelper
 
addStats(HashTableStats) - Method in class org.apache.drill.exec.physical.impl.common.HashTableStats
 
addStreamProfile(UserBitShared.OperatorProfile.Builder) - Method in class org.apache.drill.exec.ops.OperatorStats
 
addString(String, SqlParserPos) - Method in class org.apache.drill.exec.planner.sql.parser.DrillCompoundIdentifier.Builder
 
addSummary(TableBuilder) - Method in class org.apache.drill.exec.server.rest.profile.FragmentWrapper
 
addSummary(TableBuilder, HashMap<String, Long>, long) - Method in class org.apache.drill.exec.server.rest.profile.OperatorWrapper
 
addToEventQueue(UserBitShared.QueryResult.QueryState, Exception) - Method in class org.apache.drill.exec.work.foreman.Foreman
Tells the foreman to move to a new state.
This will be added to the end of the event queue and will be processed once the foreman is ready to accept external events.
addToJars(String, RemoteFunctionRegistry.Action) - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
 
addToStringBuilder(StringBuffer) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem.DebugStackTrace
 
addVector(ValueVector) - Method in class org.apache.drill.exec.record.HyperVectorWrapper
 
addVectors(ValueVector[]) - Method in class org.apache.drill.exec.record.HyperVectorWrapper
 
adjustBeginLineColumn(int, int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
Method to adjust line and column numbers for the start of a token.
adjustWaitNanos(long) - Method in class org.apache.drill.exec.ops.OperatorStats
Adjust waitNanos based on client calculations
ADMIN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ADMIN_PRINCIPALS - Static variable in class org.apache.drill.exec.server.rest.auth.DrillUserPrincipal
 
ADMIN_ROLE - Static variable in class org.apache.drill.exec.server.rest.auth.DrillUserPrincipal
 
ADMIN_USER_GROUPS_KEY - Static variable in class org.apache.drill.exec.ExecConstants
Option whose value is a comma separated list of admin usergroups.
ADMIN_USER_GROUPS_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
ADMIN_USER_ROLES - Static variable in class org.apache.drill.exec.server.rest.auth.DrillUserPrincipal
 
ADMIN_USERS_KEY - Static variable in class org.apache.drill.exec.ExecConstants
Option whose value is a comma separated list of admin usernames.
ADMIN_USERS_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
admit() - Method in class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager.DefaultQueryResourceManager
 
admit() - Method in interface org.apache.drill.exec.work.foreman.rm.QueryResourceManager
Admit the query into the cluster.
admit() - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedQueryResourceManager
 
AFFINITY_FACTOR - Static variable in class org.apache.drill.exec.ExecConstants
 
AFFINITY_FACTOR_KEY - Static variable in class org.apache.drill.exec.ExecConstants
Factor by which a node with endpoint affinity will be favored while creating assignment
AffinityCreator - Class in org.apache.drill.exec.store.schedule
 
AffinityCreator() - Constructor for class org.apache.drill.exec.store.schedule.AffinityCreator
 
AFTER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
AGG_ON_PROJ_ON_SCAN - Static variable in class org.apache.drill.exec.planner.physical.ConvertCountToDirectScan
 
AGG_ON_SCAN - Static variable in class org.apache.drill.exec.planner.physical.ConvertCountToDirectScan
 
aggExprs - Variable in class org.apache.drill.exec.planner.physical.AggPrelBase
 
AggPrelBase - Class in org.apache.drill.exec.planner.physical
 
AggPrelBase(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>, AggPrelBase.OperatorPhase) - Constructor for class org.apache.drill.exec.planner.physical.AggPrelBase
 
AggPrelBase.OperatorPhase - Enum in org.apache.drill.exec.planner.physical
 
AggPrelBase.SqlSumCountAggFunction - Class in org.apache.drill.exec.planner.physical
Specialized aggregate function for SUMing the COUNTs.
AggPrelBase.SqlSumCountAggFunction(RelDataType) - Constructor for class org.apache.drill.exec.planner.physical.AggPrelBase.SqlSumCountAggFunction
 
AggPruleBase - Class in org.apache.drill.exec.planner.physical
 
AggPruleBase(RelOptRuleOperand, String) - Constructor for class org.apache.drill.exec.planner.physical.AggPruleBase
 
AggregateErrorFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
AggregateErrorFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions
 
AggregateErrorFunctions.BitAggregateErrorFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
AggregateErrorFunctions.BitAggregateErrorFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.BitAggregateErrorFunctions
 
AggregateErrorFunctions.NullableBitAggregateErrorFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
AggregateErrorFunctions.NullableBitAggregateErrorFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.NullableBitAggregateErrorFunctions
 
AggregateErrorFunctions.NullableVarCharAggregateErrorFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
AggregateErrorFunctions.NullableVarCharAggregateErrorFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.NullableVarCharAggregateErrorFunctions
 
AggregateErrorFunctions.VarCharAggregateErrorFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
AggregateErrorFunctions.VarCharAggregateErrorFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.VarCharAggregateErrorFunctions
 
ALL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ALL - Static variable in enum org.apache.drill.exec.record.BatchSchema.SelectionVectorMode
 
ALL_COLUMNS - Static variable in interface org.apache.drill.exec.physical.base.GroupScan
columns list in GroupScan : 1) empty_column is for skipAll query.
ALL_VALID - Static variable in class org.apache.drill.exec.vector.complex.fn.FieldSelection
 
allFieldsFixedLength() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetSchema
 
allFlushed() - Method in interface org.apache.drill.exec.physical.impl.aggregate.HashAggregator
 
allFlushed() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
 
alloc() - Method in class org.apache.drill.exec.record.DeadBuf
 
allocate(int) - Method in interface org.apache.drill.exec.physical.impl.OutputMutator
 
allocate(int) - Method in class org.apache.drill.exec.physical.impl.ScanBatch.Mutator
 
ALLOCATE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
allocate(Map<String, ValueVector>) - Method in class org.apache.drill.exec.store.AbstractRecordReader
 
allocate(Map<String, ValueVector>) - Method in class org.apache.drill.exec.store.mock.ExtendedMockRecordReader
 
allocate(Map<String, ValueVector>) - Method in class org.apache.drill.exec.store.mock.MockRecordReader
 
allocate(Map<String, ValueVector>) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
allocate(int) - Method in class org.apache.drill.exec.store.parquet.ParquetDirectByteBufferAllocator
 
allocate(Map<String, ValueVector>) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetReader
 
allocate(Map<String, ValueVector>) - Method in class org.apache.drill.exec.store.pojo.AbstractPojoRecordReader
 
allocate() - Method in class org.apache.drill.exec.store.pojo.AbstractPojoWriter
 
allocate() - Method in interface org.apache.drill.exec.store.pojo.PojoWriter
Allocates new buffer for value vector.
allocate(Map<String, ValueVector>) - Method in interface org.apache.drill.exec.store.RecordReader
 
allocate() - Method in class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
 
allocateBatch(VectorAccessible, int) - Method in class org.apache.drill.exec.record.VectorInitializer
 
allocateNew(int) - Method in class org.apache.drill.exec.record.selection.SelectionVector2
 
allocateNew() - Method in class org.apache.drill.exec.record.VectorContainer
 
allocateNewSafe(int) - Method in class org.apache.drill.exec.record.selection.SelectionVector2
 
allocateNewSafe() - Method in class org.apache.drill.exec.record.VectorContainer
 
allocateVectors(VectorAccessible, int) - Static method in class org.apache.drill.exec.record.VectorAccessibleUtilities
 
allocateVectors(Iterable<ValueVector>, int) - Static method in class org.apache.drill.exec.util.VectorUtil
 
allocator - Variable in class org.apache.drill.exec.ops.BaseOperatorContext
 
allocator - Variable in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
allocator - Variable in class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
ALLOCATOR_INITIAL_RESERVATION - Static variable in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
 
ALLOCATOR_INITIAL_RESERVATION - Static variable in interface org.apache.drill.exec.store.RecordReader
 
ALLOCATOR_INITIAL_RESERVATION - Static variable in class org.apache.drill.exec.work.batch.SpoolingRawBatchBuffer
 
ALLOCATOR_MAX_RESERVATION - Static variable in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
 
ALLOCATOR_MAX_RESERVATION - Static variable in interface org.apache.drill.exec.store.RecordReader
 
ALLOCATOR_MAX_RESERVATION - Static variable in class org.apache.drill.exec.work.batch.SpoolingRawBatchBuffer
 
ALLOCATOR_METRICS_PREFIX - Static variable in class org.apache.drill.exec.rpc.AbstractRpcMetrics
 
ALLOW - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
allowAccessOutsideWorkspace() - Method in class org.apache.drill.exec.store.dfs.WorkspaceConfig
 
allowsFraming() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
AloadPopRemover - Class in org.apache.drill.exec.compile.bytecode
Remove any adjacent ALOAD-POP instruction pairs.
AloadPopRemover(int) - Constructor for class org.apache.drill.exec.compile.bytecode.AloadPopRemover
Constructor.
AloadPopRemover(int, MethodVisitor) - Constructor for class org.apache.drill.exec.compile.bytecode.AloadPopRemover
Constructor.
alreadyContainsKey(Object) - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
ALTER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Alternator - Class in org.apache.drill.exec.expr.fn.impl
 
Alternator() - Constructor for class org.apache.drill.exec.expr.fn.impl.Alternator
 
Alternator.Alternate2 - Class in org.apache.drill.exec.expr.fn.impl
 
Alternator.Alternate2() - Constructor for class org.apache.drill.exec.expr.fn.impl.Alternator.Alternate2
 
Alternator.Alternate3 - Class in org.apache.drill.exec.expr.fn.impl
 
Alternator.Alternate3() - Constructor for class org.apache.drill.exec.expr.fn.impl.Alternator.Alternate3
 
ALWAYS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
analyze(RexNode) - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
 
AND - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ANONYMOUS_COLUMN_PREFIX - Static variable in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
Prefix used to create numbered columns for missing headers.
ANONYMOUS_USER - Static variable in class org.apache.drill.exec.server.rest.auth.DrillUserPrincipal
 
any(Class<? extends RelNode>, RelTrait) - Static method in class org.apache.drill.exec.planner.logical.RelOptHelper
 
any(Class<? extends RelNode>) - Static method in class org.apache.drill.exec.planner.logical.RelOptHelper
 
any(Class<? extends RelNode>, Class<? extends RelNode>) - Static method in class org.apache.drill.exec.planner.logical.RelOptHelper
 
ANY - Static variable in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
 
ANY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
append(String) - Method in class org.apache.drill.exec.expr.DebugStringBuilder
 
append(Path, int, Progressable) - Method in class org.apache.drill.exec.store.ClassPathFileSystem
 
append(Path, int, Progressable) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
append(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
append(Path, int) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
append(byte) - Method in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
 
append(Path, int, Progressable) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem
 
appendBytes(long) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendBytes(long, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendBytes(long, String, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendCell(String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendCell(String, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendCell(String, String, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendCell(String, String, String, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendCell(String, Map<String, String>) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendCell(String, String, String, String, Map<String, String>) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendFormattedInteger(long) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendFormattedInteger(long, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendFormattedInteger(long, String, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendFormattedNumber(Number) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendFormattedNumber(Number, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendFormattedNumber(Number, String, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendInteger(long, String, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendMillis(long) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendMillis(long, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendMillis(long, String, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendNanos(long) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendNanos(long, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendNanos(long, String, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendPercent(double) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendPercent(double, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendPercent(double, String, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendRepeated(String, String, int) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendRepeated(String, String, int, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendTime(long) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendTime(long, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendTime(long, String, String) - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
appendVectorAccessibleContent(VectorAccessible, StringBuilder, String, boolean) - Static method in class org.apache.drill.exec.util.VectorUtil
 
applyAssignments(List<CoordinationProtos.DrillbitEndpoint>) - Method in interface org.apache.drill.exec.physical.base.GroupScan
 
applyAssignments(List<CoordinationProtos.DrillbitEndpoint>) - Method in interface org.apache.drill.exec.physical.base.Store
Inform the Store node about the actual decided DrillbitEndpoint assignments desired for storage purposes.
applyAssignments(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.physical.config.Screen
 
applyAssignments(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
applyAssignments(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.store.direct.DirectGroupScan
 
applyAssignments(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaGroupScan
 
applyAssignments(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.store.mock.MockGroupScanPOP
 
applyAssignments(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.store.mock.MockStorePOP
 
applyAssignments(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
applyAssignments(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.store.sys.SystemTableScan
 
applyFilter(LogicalExpression, UdfUtilities, FunctionImplementationRegistry, OptionManager) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
applyLimit(long) - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
By default, return null to indicate rowcount based prune is not supported.
applyLimit(long) - Method in interface org.apache.drill.exec.physical.base.GroupScan
Apply rowcount based prune for "LIMIT n" query.
applyLimit(long) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
applyPlan(PhysicalPlanReader) - Method in class org.apache.drill.exec.work.QueryWorkUnit
 
applyPlan(PhysicalPlanReader) - Method in class org.apache.drill.exec.work.QueryWorkUnit.MinorFragmentDefn
 
applySv2() - Method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
 
applyToFile(FileSystem, Path) - Method in class org.apache.drill.exec.store.StorageStrategy
Applies storage strategy to file: sets permission and adds to file system delete on exit list if needed.
APPROX_NUMERIC_LITERAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ApproximateStringMatcher - Class in org.apache.drill.exec.util
 
ApproximateStringMatcher() - Constructor for class org.apache.drill.exec.util.ApproximateStringMatcher
 
ARE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
areCorruptDatesAutoCorrected() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatConfig
 
areRowTypesCompatible(RelDataType, RelDataType, boolean, boolean) - Static method in class org.apache.drill.exec.planner.common.DrillRelOptUtil
 
Arg(List, SqlAbstractParserImpl.ExprContext) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
Arg0(List, SqlAbstractParserImpl.ExprContext) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
argConstantOnly(int) - Method in class org.apache.drill.exec.expr.DrillFuncHolderExpr
 
args - Variable in class org.apache.drill.exec.store.ischema.InfoSchemaFilter.FunctionExprNode
 
argumentMustBeScalar(int) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
argumentMustBeScalar(int) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
argumentMustBeScalar(int) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
ARP_PROTOCOL - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
ARRAY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
array() - Method in class org.apache.drill.exec.record.DeadBuf
 
ARRAY_TYPE - Static variable in class org.apache.drill.exec.schema.json.jackson.JacksonHelper
 
ArrayConstructor() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses an ARRAY constructor
arrayOffset() - Method in class org.apache.drill.exec.record.DeadBuf
 
ArrayWrappedIntIntMap - Class in org.apache.drill.exec.util
Simple Map type data structure for storing entries of (int -> int) mappings where the max key value is below 2^16 to avoid hashing keys and use direct array index reference for retrieving the values.
ArrayWrappedIntIntMap() - Constructor for class org.apache.drill.exec.util.ArrayWrappedIntIntMap
 
AS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ASC - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ASENSITIVE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ASM_API_VERSION - Static variable in class org.apache.drill.exec.compile.CompilationConfig
 
AsmUtil - Class in org.apache.drill.exec.compile
Utilities commonly used with ASM.
ASSERTION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
asSet(List<String>) - Static method in class org.apache.drill.exec.rpc.security.AuthStringUtil
 
assignEndpoints(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.planner.fragment.Wrapper
 
assignFiles(List<? extends Metadata.ParquetFileMetadata>) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v1
 
assignFiles(List<? extends Metadata.ParquetFileMetadata>) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
assignFiles(List<? extends Metadata.ParquetFileMetadata>) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
assignFiles(List<? extends Metadata.ParquetFileMetadata>) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataBase
 
ASSIGNMENT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
AssignmentCreator<T extends CompleteWork> - Class in org.apache.drill.exec.store.schedule
The AssignmentCreator is responsible for assigning a set of work units to the available slices.
assignSchemaIfNull(RecordSchema) - Method in class org.apache.drill.exec.schema.Field
 
associate(ReplacingBasicValue) - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
Associate this value with another.
ASYMMETRIC - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
AT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ATOMIC - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
AtomicRowExpression() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses an atomic row expression.
ATTRIBUTE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ATTRIBUTES - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
AuthDynamicFeature - Class in org.apache.drill.exec.server.rest.auth
Implementation of DynamicFeature.
AuthDynamicFeature() - Constructor for class org.apache.drill.exec.server.rest.auth.AuthDynamicFeature
 
authenticate(String, String) - Method in class org.apache.drill.exec.rpc.user.security.Pam4jUserAuthenticator
 
authenticate(String, String) - Method in class org.apache.drill.exec.rpc.user.security.PamUserAuthenticator
 
authenticate(String, String) - Method in interface org.apache.drill.exec.rpc.user.security.UserAuthenticator
Authenticate the given user and password combination.
AUTHENTICATED_ROLE - Static variable in class org.apache.drill.exec.server.rest.auth.DrillUserPrincipal
 
AUTHENTICATION_MECHANISMS - Static variable in class org.apache.drill.exec.ExecConstants
 
AUTHENTICATION_V6 - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
AuthenticationOutcomeListener<T extends com.google.protobuf.Internal.EnumLite,C extends ClientConnection,HS extends com.google.protobuf.MessageLite,HR extends com.google.protobuf.MessageLite> - Class in org.apache.drill.exec.rpc.security
Handles SASL exchange, on the client-side.
AuthenticationOutcomeListener(BasicClient<T, C, HS, HR>, C, T, UserGroupInformation, RpcOutcomeListener<?>) - Constructor for class org.apache.drill.exec.rpc.security.AuthenticationOutcomeListener
 
AuthenticatorFactory - Interface in org.apache.drill.exec.rpc.security
An implementation of this factory will be initialized once at startup, if the authenticator is enabled (see AuthenticatorFactory.getSimpleName()).
AuthenticatorProvider - Interface in org.apache.drill.exec.rpc.security
 
AuthenticatorProviderImpl - Class in org.apache.drill.exec.rpc.security
 
AuthenticatorProviderImpl(DrillConfig, ScanResult) - Constructor for class org.apache.drill.exec.rpc.security.AuthenticatorProviderImpl
 
AUTHORIZATION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
AuthStringUtil - Class in org.apache.drill.exec.rpc.security
 
autoCorrectCorruptDates - Variable in class org.apache.drill.exec.store.parquet.ParquetFormatConfig
 
autoCorrectCorruptedDate(int) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
 
available() - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
available() - Method in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
 
AVERAGE_FIELD_WIDTH - Static variable in class org.apache.drill.exec.ExecConstants
 
AVERAGE_FIELD_WIDTH_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
AVG - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
AVG_FIELD_WIDTH - Static variable in class org.apache.drill.exec.planner.cost.DrillCostBase
 
avgDensity() - Method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
 
AvgFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions
 
AvgFunctions.BigIntAvg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgFunctions.BigIntAvg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.BigIntAvg
 
AvgFunctions.Float4Avg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgFunctions.Float4Avg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.Float4Avg
 
AvgFunctions.Float8Avg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgFunctions.Float8Avg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.Float8Avg
 
AvgFunctions.IntAvg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgFunctions.IntAvg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.IntAvg
 
AvgFunctions.NullableBigIntAvg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgFunctions.NullableBigIntAvg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableBigIntAvg
 
AvgFunctions.NullableFloat4Avg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgFunctions.NullableFloat4Avg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableFloat4Avg
 
AvgFunctions.NullableFloat8Avg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgFunctions.NullableFloat8Avg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableFloat8Avg
 
AvgFunctions.NullableIntAvg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgFunctions.NullableIntAvg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableIntAvg
 
AvgIntervalTypeFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgIntervalTypeFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions
 
AvgIntervalTypeFunctions.IntervalAvg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgIntervalTypeFunctions.IntervalAvg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.IntervalAvg
 
AvgIntervalTypeFunctions.IntervalDayAvg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgIntervalTypeFunctions.IntervalDayAvg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.IntervalDayAvg
 
AvgIntervalTypeFunctions.IntervalYearAvg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgIntervalTypeFunctions.IntervalYearAvg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.IntervalYearAvg
 
AvgIntervalTypeFunctions.NullableIntervalAvg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgIntervalTypeFunctions.NullableIntervalAvg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.NullableIntervalAvg
 
AvgIntervalTypeFunctions.NullableIntervalDayAvg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgIntervalTypeFunctions.NullableIntervalDayAvg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.NullableIntervalDayAvg
 
AvgIntervalTypeFunctions.NullableIntervalYearAvg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
AvgIntervalTypeFunctions.NullableIntervalYearAvg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.NullableIntervalYearAvg
 
AvroDrillTable - Class in org.apache.drill.exec.store.avro
 
AvroDrillTable(String, FileSystemPlugin, String, FormatSelection) - Constructor for class org.apache.drill.exec.store.avro.AvroDrillTable
 
AvroFormatConfig - Class in org.apache.drill.exec.store.avro
Format plugin config for Avro data files.
AvroFormatConfig() - Constructor for class org.apache.drill.exec.store.avro.AvroFormatConfig
 
AvroFormatPlugin - Class in org.apache.drill.exec.store.avro
Format plugin for Avro data files.
AvroFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig) - Constructor for class org.apache.drill.exec.store.avro.AvroFormatPlugin
 
AvroFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig, AvroFormatConfig) - Constructor for class org.apache.drill.exec.store.avro.AvroFormatPlugin
 
AvroRecordReader - Class in org.apache.drill.exec.store.avro
A RecordReader implementation for Avro data files.
AvroRecordReader(FragmentContext, String, long, long, FileSystem, List<SchemaPath>, String) - Constructor for class org.apache.drill.exec.store.avro.AvroRecordReader
 
AvroTypeHelper - Class in org.apache.drill.exec.store.avro
Utility class for working with Avro data types.
await(long) - Method in class org.apache.drill.exec.rpc.AbstractDisposableUserClientConnection
Wait until the query has completed or timeout is passed.
await() - Method in class org.apache.drill.exec.rpc.AbstractDisposableUserClientConnection
Wait indefinitely until the query is completed.
await() - Method in class org.apache.drill.exec.rpc.user.AwaitableUserResultsListener
 
await() - Method in interface org.apache.drill.exec.testing.CountDownLatchInjection
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted.
await() - Method in class org.apache.drill.exec.testing.CountDownLatchInjectionImpl
 
AwaitableUserResultsListener - Class in org.apache.drill.exec.rpc.user
General mechanism for waiting on the query to be executed
AwaitableUserResultsListener(UserResultsListener) - Constructor for class org.apache.drill.exec.rpc.user.AwaitableUserResultsListener
 
awaitUninterruptibly() - Method in interface org.apache.drill.exec.testing.CountDownLatchInjection
Await without interruption.
awaitUninterruptibly() - Method in class org.apache.drill.exec.testing.CountDownLatchInjectionImpl
 

B

BACK_QUOTED_IDENTIFIER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
BackedRecord - Class in org.apache.drill.exec.schema
 
BackedRecord(DiffSchema, DataRecord) - Constructor for class org.apache.drill.exec.schema.BackedRecord
 
backup(int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
BASE_CPU_COST - Static variable in class org.apache.drill.exec.planner.cost.DrillCostBase
NOTE: the multiplication factors below are not calibrated yet...these are chosen based on approximations for now.
BaseFragmentContext - Class in org.apache.drill.exec.ops
Common implementation for both the test and production versions of the fragment context.
BaseFragmentContext(FunctionImplementationRegistry) - Constructor for class org.apache.drill.exec.ops.BaseFragmentContext
 
BaseJsonProcessor - Class in org.apache.drill.exec.store.easy.json.reader
 
BaseJsonProcessor(DrillBuf) - Constructor for class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
 
BaseJsonProcessor.JsonExceptionProcessingState - Enum in org.apache.drill.exec.store.easy.json.reader
 
BaseOperatorContext - Class in org.apache.drill.exec.ops
Implementation of OperatorContext that provides services needed by most run-time operators.
BaseOperatorContext(FragmentContextInterface, BufferAllocator, PhysicalOperator) - Constructor for class org.apache.drill.exec.ops.BaseOperatorContext
 
BaseOptionManager - Class in org.apache.drill.exec.server.options
This OptionManager implements some the basic methods and should be extended by concrete implementations.
BaseOptionManager() - Constructor for class org.apache.drill.exec.server.options.BaseOptionManager
 
BasePersistentStore<V> - Class in org.apache.drill.exec.store.sys
 
BasePersistentStore() - Constructor for class org.apache.drill.exec.store.sys.BasePersistentStore
 
BasePersistentStoreProvider - Class in org.apache.drill.exec.store.sys.store.provider
 
BasePersistentStoreProvider() - Constructor for class org.apache.drill.exec.store.sys.store.provider.BasePersistentStoreProvider
 
BasePrelVisitor<RETURN,EXTRA,EXCEP extends Throwable> - Class in org.apache.drill.exec.planner.physical.visitor
 
BasePrelVisitor() - Constructor for class org.apache.drill.exec.planner.physical.visitor.BasePrelVisitor
 
BaseRawBatchBuffer<T> - Class in org.apache.drill.exec.work.batch
 
BaseRawBatchBuffer(FragmentContext, int) - Constructor for class org.apache.drill.exec.work.batch.BaseRawBatchBuffer
 
BaseRawBatchBuffer.BufferQueue<T> - Interface in org.apache.drill.exec.work.batch
 
BaseRootExec - Class in org.apache.drill.exec.physical.impl
 
BaseRootExec(FragmentContext, PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.impl.BaseRootExec
 
BaseRootExec(FragmentContext, OperatorContext, PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.impl.BaseRootExec
 
BaseSortWrapper - Class in org.apache.drill.exec.physical.impl.xsort.managed
Base wrapper for algorithms that use sort comparisons.
BaseSortWrapper(OperatorContext) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.BaseSortWrapper
 
BaseTransientStore<V> - Class in org.apache.drill.exec.coord.store
 
BaseTransientStore(TransientStoreConfig<V>) - Constructor for class org.apache.drill.exec.coord.store.BaseTransientStore
 
BaseWrapper - Class in org.apache.drill.exec.physical.impl.xsort.managed
Base class for code-generation-based tasks.
BaseWrapper(OperatorContext) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.BaseWrapper
 
BasicFormatMatcher - Class in org.apache.drill.exec.store.dfs
 
BasicFormatMatcher(FormatPlugin, List<Pattern>, List<MagicString>) - Constructor for class org.apache.drill.exec.store.dfs.BasicFormatMatcher
 
BasicFormatMatcher(FormatPlugin, Configuration, List<String>, boolean) - Constructor for class org.apache.drill.exec.store.dfs.BasicFormatMatcher
 
BasicJsonOutput - Class in org.apache.drill.exec.vector.complex.fn
A JSON output class that generates standard JSON.
BasicJsonOutput(JsonGenerator) - Constructor for class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
BasicJsonOutput(JsonGenerator, DateOutputFormat) - Constructor for class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
BasicOptimizer - Class in org.apache.drill.exec.opt
 
BasicOptimizer(QueryContext, UserClientConnection) - Constructor for class org.apache.drill.exec.opt.BasicOptimizer
 
BasicOptimizer.BasicOptimizationContext - Class in org.apache.drill.exec.opt
 
BasicOptimizer.BasicOptimizationContext(QueryContext) - Constructor for class org.apache.drill.exec.opt.BasicOptimizer.BasicOptimizationContext
 
BATCH_MASK - Static variable in interface org.apache.drill.exec.physical.impl.common.HashTable
 
BATCH_PURGE_THRESHOLD - Static variable in class org.apache.drill.exec.ExecConstants
 
BATCH_SIZE - Static variable in interface org.apache.drill.exec.physical.impl.common.HashTable
The batch size used for internal batch holders
batchArrived(ConnectionThrottle, ByteBuf, ByteBuf) - Method in class org.apache.drill.exec.rpc.user.QueryResultHandler
Maps internal low-level API protocol to UserResultsListener-level API protocol.
batchArrived(int, RawFragmentBatch) - Method in class org.apache.drill.exec.work.batch.AbstractDataCollector
 
batchArrived(IncomingDataBatch) - Method in class org.apache.drill.exec.work.batch.IncomingBuffers
 
BatchCreator<T extends PhysicalOperator> - Interface in org.apache.drill.exec.physical.impl
 
batchesReceivedByInput - Variable in class org.apache.drill.exec.ops.OperatorStats
 
BatchExceededException - Exception in org.apache.drill.exec.store
 
BatchExceededException(int, int) - Constructor for exception org.apache.drill.exec.store.BatchExceededException
 
BatchGroup - Class in org.apache.drill.exec.physical.impl.xsort
 
BatchGroup(VectorContainer, SelectionVector2, OperatorContext) - Constructor for class org.apache.drill.exec.physical.impl.xsort.BatchGroup
 
BatchGroup(VectorContainer, FileSystem, String, OperatorContext) - Constructor for class org.apache.drill.exec.physical.impl.xsort.BatchGroup
 
BatchGroup - Class in org.apache.drill.exec.physical.impl.xsort.managed
Represents a group of batches spilled to disk.
BatchGroup(VectorContainer, BufferAllocator) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
BatchGroup.InputBatch - Class in org.apache.drill.exec.physical.impl.xsort.managed
The input batch group gathers batches buffered in memory before spilling.
BatchGroup.InputBatch(VectorContainer, SelectionVector2, BufferAllocator, long) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.InputBatch
 
BatchGroup.SpilledRun - Class in org.apache.drill.exec.physical.impl.xsort.managed
Holds a set of spilled batches, represented by a file on disk.
BatchGroup.SpilledRun(SpillSet, String, BufferAllocator) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.SpilledRun
 
batchId - Variable in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch.Node
 
BatchIterator - Interface in org.apache.drill.exec.physical.impl.aggregate
 
BatchPrinter - Class in org.apache.drill.exec.util
This is a tool for printing the content of record batches to screen.
BatchPrinter() - Constructor for class org.apache.drill.exec.util.BatchPrinter
 
BatchReader - Class in org.apache.drill.exec.store.parquet.columnreaders
Base strategy for reading a batch of Parquet records.
BatchReader(ReadState) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.BatchReader
 
BatchReader.FixedWidthReader - Class in org.apache.drill.exec.store.parquet.columnreaders
Strategy for reading a record batch when all columns are fixed-width.
BatchReader.FixedWidthReader(ReadState) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.BatchReader.FixedWidthReader
 
BatchReader.MockBatchReader - Class in org.apache.drill.exec.store.parquet.columnreaders
Strategy for reading mock records.
BatchReader.MockBatchReader(ReadState) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.BatchReader.MockBatchReader
 
BatchReader.VariableWidthReader - Class in org.apache.drill.exec.store.parquet.columnreaders
Strategy for reading a record batch when at last one column is variable width.
BatchReader.VariableWidthReader(ReadState) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.BatchReader.VariableWidthReader
 
batchReceived(int, long, boolean) - Method in class org.apache.drill.exec.ops.OperatorStats
 
BatchReference - Class in org.apache.drill.exec.expr
Holder class that contains batch naming, batch and record index.
BatchReference(String, String) - Constructor for class org.apache.drill.exec.expr.BatchReference
 
BatchReference(String, String, String) - Constructor for class org.apache.drill.exec.expr.BatchReference
 
BatchSchema - Class in org.apache.drill.exec.record
 
BatchSchema(BatchSchema.SelectionVectorMode, List<MaterializedField>) - Constructor for class org.apache.drill.exec.record.BatchSchema
 
BatchSchema.SelectionVectorMode - Enum in org.apache.drill.exec.record
 
BatchValidator - Class in org.apache.drill.exec.physical.impl.validate
Validate a batch of value vectors.
BatchValidator(VectorAccessible) - Constructor for class org.apache.drill.exec.physical.impl.validate.BatchValidator
 
BatchValidator(VectorAccessible, boolean) - Constructor for class org.apache.drill.exec.physical.impl.validate.BatchValidator
 
BEFORE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
beforeFirst - Variable in class org.apache.drill.exec.store.sys.VersionIterator
 
BEGIN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
beginColumn - Variable in class org.apache.drill.exec.planner.sql.parser.impl.Token
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
beginLine - Variable in class org.apache.drill.exec.planner.sql.parser.impl.Token
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
BeginToken() - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
BEL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
BERNOULLI - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
BETWEEN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
BIGINT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
BigIntAccessor - Class in org.apache.drill.exec.vector.accessor
 
BigIntAccessor(BigIntVector) - Constructor for class org.apache.drill.exec.vector.accessor.BigIntAccessor
 
BigIntBEConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
BigIntBEConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.BigIntBEConvertFrom
 
BigIntBEConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
BigIntBEConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.BigIntBEConvertTo
 
BigIntConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
BigIntConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.BigIntConvertFrom
 
BigIntConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
BigIntConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.BigIntConvertTo
 
BigIntVLongConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
BigIntVLongConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.BigIntVLongConvertFrom
 
BigIntVLongConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
BigIntVLongConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.BigIntVLongConvertTo
 
BINARY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
BINARY - Static variable in interface org.apache.drill.exec.vector.complex.fn.ExtendedTypeName
 
BINARY_STRING_LITERAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
BinaryMultisetOperator() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a binary multiset operator.
binaryOperation(AbstractInsnNode, BasicValue, BasicValue) - Method in class org.apache.drill.exec.compile.bytecode.ReplacingInterpreter
 
BinaryQueryOperator() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a binary query operator like UNION.
BinaryRowOperator() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a binary row operator like AND.
BIT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
BIT_AUTHENTICATION_ENABLED - Static variable in class org.apache.drill.exec.ExecConstants
 
BIT_AUTHENTICATION_MECHANISM - Static variable in class org.apache.drill.exec.ExecConstants
 
BIT_ENCRYPTION_SASL_ENABLED - Static variable in class org.apache.drill.exec.ExecConstants
 
BIT_ENCRYPTION_SASL_MAX_WRAPPED_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
BIT_RETRY_DELAY - Static variable in class org.apache.drill.exec.ExecConstants
 
BIT_RETRY_TIMES - Static variable in class org.apache.drill.exec.ExecConstants
 
BIT_RPC_TIMEOUT - Static variable in class org.apache.drill.exec.ExecConstants
 
BIT_SERVER_RPC_THREADS - Static variable in class org.apache.drill.exec.ExecConstants
 
BIT_TIMEOUT - Static variable in class org.apache.drill.exec.ExecConstants
 
BitAccessor - Class in org.apache.drill.exec.vector.accessor
 
BitAccessor(BitVector) - Constructor for class org.apache.drill.exec.vector.accessor.BitAccessor
 
BitComException - Exception in org.apache.drill.exec.exception
 
BitComException() - Constructor for exception org.apache.drill.exec.exception.BitComException
 
BitComException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.drill.exec.exception.BitComException
 
BitComException(String, Throwable) - Constructor for exception org.apache.drill.exec.exception.BitComException
 
BitComException(String) - Constructor for exception org.apache.drill.exec.exception.BitComException
 
BitComException(Throwable) - Constructor for exception org.apache.drill.exec.exception.BitComException
 
BitConnectionConfig - Class in org.apache.drill.exec.rpc
 
BitConnectionConfig(BufferAllocator, BootStrapContext) - Constructor for class org.apache.drill.exec.rpc.BitConnectionConfig
 
BitFunctions - Class in org.apache.drill.exec.expr.fn.impl
Function templates for Bit/BOOLEAN functions other than comparison functions.
BitFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.BitFunctions
 
BitFunctions.BitAnd - Class in org.apache.drill.exec.expr.fn.impl
 
BitFunctions.BitAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.BitFunctions.BitAnd
 
BitFunctions.BitOr - Class in org.apache.drill.exec.expr.fn.impl
 
BitFunctions.BitOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.BitFunctions.BitOr
 
BitFunctions.IntXor - Class in org.apache.drill.exec.expr.fn.impl
 
BitFunctions.IntXor() - Constructor for class org.apache.drill.exec.expr.fn.impl.BitFunctions.IntXor
 
BitwiseAndFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions
 
BitwiseAndFunctions.BigIntBitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.BigIntBitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.BigIntBitwiseAnd
 
BitwiseAndFunctions.IntBitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.IntBitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.IntBitwiseAnd
 
BitwiseAndFunctions.NullableBigIntBitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.NullableBigIntBitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableBigIntBitwiseAnd
 
BitwiseAndFunctions.NullableIntBitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.NullableIntBitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableIntBitwiseAnd
 
BitwiseAndFunctions.NullableSmallIntBitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.NullableSmallIntBitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableSmallIntBitwiseAnd
 
BitwiseAndFunctions.NullableTinyIntBitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.NullableTinyIntBitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableTinyIntBitwiseAnd
 
BitwiseAndFunctions.NullableUInt1BitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.NullableUInt1BitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt1BitwiseAnd
 
BitwiseAndFunctions.NullableUInt2BitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.NullableUInt2BitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt2BitwiseAnd
 
BitwiseAndFunctions.NullableUInt4BitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.NullableUInt4BitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt4BitwiseAnd
 
BitwiseAndFunctions.NullableUInt8BitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.NullableUInt8BitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt8BitwiseAnd
 
BitwiseAndFunctions.SmallIntBitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.SmallIntBitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.SmallIntBitwiseAnd
 
BitwiseAndFunctions.TinyIntBitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.TinyIntBitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.TinyIntBitwiseAnd
 
BitwiseAndFunctions.UInt1BitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.UInt1BitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt1BitwiseAnd
 
BitwiseAndFunctions.UInt2BitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.UInt2BitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt2BitwiseAnd
 
BitwiseAndFunctions.UInt4BitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.UInt4BitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt4BitwiseAnd
 
BitwiseAndFunctions.UInt8BitwiseAnd - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseAndFunctions.UInt8BitwiseAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt8BitwiseAnd
 
BitwiseOrFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions
 
BitwiseOrFunctions.BigIntBitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.BigIntBitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.BigIntBitwiseOr
 
BitwiseOrFunctions.IntBitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.IntBitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.IntBitwiseOr
 
BitwiseOrFunctions.NullableBigIntBitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.NullableBigIntBitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableBigIntBitwiseOr
 
BitwiseOrFunctions.NullableIntBitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.NullableIntBitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableIntBitwiseOr
 
BitwiseOrFunctions.NullableSmallIntBitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.NullableSmallIntBitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableSmallIntBitwiseOr
 
BitwiseOrFunctions.NullableTinyIntBitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.NullableTinyIntBitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableTinyIntBitwiseOr
 
BitwiseOrFunctions.NullableUInt1BitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.NullableUInt1BitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt1BitwiseOr
 
BitwiseOrFunctions.NullableUInt2BitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.NullableUInt2BitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt2BitwiseOr
 
BitwiseOrFunctions.NullableUInt4BitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.NullableUInt4BitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt4BitwiseOr
 
BitwiseOrFunctions.NullableUInt8BitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.NullableUInt8BitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt8BitwiseOr
 
BitwiseOrFunctions.SmallIntBitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.SmallIntBitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.SmallIntBitwiseOr
 
BitwiseOrFunctions.TinyIntBitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.TinyIntBitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.TinyIntBitwiseOr
 
BitwiseOrFunctions.UInt1BitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.UInt1BitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt1BitwiseOr
 
BitwiseOrFunctions.UInt2BitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.UInt2BitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt2BitwiseOr
 
BitwiseOrFunctions.UInt4BitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.UInt4BitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt4BitwiseOr
 
BitwiseOrFunctions.UInt8BitwiseOr - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
BitwiseOrFunctions.UInt8BitwiseOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt8BitwiseOr
 
BLOB - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
blob() - Method in class org.apache.drill.exec.store.sys.PersistentStoreConfig.StoreConfigBuilder
 
BlockMapBuilder - Class in org.apache.drill.exec.store.schedule
 
BlockMapBuilder(FileSystem, Collection<CoordinationProtos.DrillbitEndpoint>) - Constructor for class org.apache.drill.exec.store.schedule.BlockMapBuilder
 
bool_val - Variable in class org.apache.drill.exec.server.options.OptionValue
 
bool_val - Variable in class org.apache.drill.exec.store.sys.OptionIterator.OptionValueWrapper
 
BOOLEAN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
BOOLEAN_TYPE - Static variable in class org.apache.drill.exec.schema.json.jackson.JacksonHelper
 
BooleanAggrFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
BooleanAggrFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions
 
BooleanAggrFunctions.BitBooleanAnd - Class in org.apache.drill.exec.expr.fn.impl
 
BooleanAggrFunctions.BitBooleanAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.BitBooleanAnd
 
BooleanAggrFunctions.BitBooleanOr - Class in org.apache.drill.exec.expr.fn.impl
 
BooleanAggrFunctions.BitBooleanOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.BitBooleanOr
 
BooleanAggrFunctions.NullableBitBooleanAnd - Class in org.apache.drill.exec.expr.fn.impl
 
BooleanAggrFunctions.NullableBitBooleanAnd() - Constructor for class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.NullableBitBooleanAnd
 
BooleanAggrFunctions.NullableBitBooleanOr - Class in org.apache.drill.exec.expr.fn.impl
 
BooleanAggrFunctions.NullableBitBooleanOr() - Constructor for class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.NullableBitBooleanOr
 
BooleanByteConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
BooleanByteConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.BooleanByteConvertFrom
 
BooleanByteConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
BooleanByteConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.BooleanByteConvertTo
 
BooleanGen - Class in org.apache.drill.exec.store.mock
 
BooleanGen() - Constructor for class org.apache.drill.exec.store.mock.BooleanGen
 
BooleanType - Enum in org.apache.drill.exec.expr
Enum that contains two boolean types: TRUE and FALSE.
bootDefaultFor(String) - Static method in class org.apache.drill.exec.ExecConstants
 
BOOTSTRAP_STORAGE_PLUGINS_FILE - Static variable in class org.apache.drill.exec.ExecConstants
 
BootStrapContext - Class in org.apache.drill.exec.server
 
BootStrapContext(DrillConfig, CaseInsensitiveMap<OptionDefinition>, ScanResult) - Constructor for class org.apache.drill.exec.server.BootStrapContext
 
BOTH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
BoundCheckingAccessor - Class in org.apache.drill.exec.vector.accessor
A decorating accessor that returns null for indices that is beyond underlying vector's capacity.
BoundCheckingAccessor(ValueVector, SqlAccessor) - Constructor for class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
BRACKET_QUOTED_IDENTIFIER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
BREADTH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
BROADCAST - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
BROADCAST_FACTOR - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
BROADCAST_INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.HashJoinPrule
 
BROADCAST_INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.MergeJoinPrule
 
BROADCAST_THRESHOLD - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
BroadcastExchange - Class in org.apache.drill.exec.physical.config
 
BroadcastExchange(PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.config.BroadcastExchange
 
BroadcastExchangePrel - Class in org.apache.drill.exec.planner.physical
 
BroadcastExchangePrel(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.drill.exec.planner.physical.BroadcastExchangePrel
 
BroadcastSender - Class in org.apache.drill.exec.physical.config
 
BroadcastSender(int, PhysicalOperator, List<MinorFragmentEndpoint>) - Constructor for class org.apache.drill.exec.physical.config.BroadcastSender
 
BroadcastSenderCreator - Class in org.apache.drill.exec.physical.impl.broadcastsender
 
BroadcastSenderCreator() - Constructor for class org.apache.drill.exec.physical.impl.broadcastsender.BroadcastSenderCreator
 
BroadcastSenderRootExec - Class in org.apache.drill.exec.physical.impl.broadcastsender
Broadcast Sender broadcasts incoming batches to all receivers (one or more).
BroadcastSenderRootExec(FragmentContext, RecordBatch, BroadcastSender) - Constructor for class org.apache.drill.exec.physical.impl.broadcastsender.BroadcastSenderRootExec
 
BroadcastSenderRootExec.Metric - Enum in org.apache.drill.exec.physical.impl.broadcastsender
 
BsonRecordReader - Class in org.apache.drill.exec.store.bson
 
BsonRecordReader(DrillBuf, boolean, boolean) - Constructor for class org.apache.drill.exec.store.bson.BsonRecordReader
 
BsonRecordReader(DrillBuf, List<SchemaPath>, boolean) - Constructor for class org.apache.drill.exec.store.bson.BsonRecordReader
 
BTID - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
bufcolumn - Variable in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
buffer - Variable in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
BUFFER_FROM_PAYLOAD - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
Given a data size, this is the multiplier to create the buffer size estimate.
BufferedBatches - Class in org.apache.drill.exec.physical.impl.xsort.managed
Represents the set of in-memory batches accumulated by the external sort.
BufferedBatches(OperatorContext) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.BufferedBatches
 
BufferedDirectBufInputStream - Class in org.apache.drill.exec.util.filereader
BufferedDirectBufInputStream reads from the underlying InputStream in blocks of data, into an internal buffer.
BufferedDirectBufInputStream(InputStream, BufferAllocator, String, long, long, boolean, boolean) - Constructor for class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
Creates a BufferedDirectBufInputStream with the default (8 MiB) buffer size.
BufferedDirectBufInputStream(InputStream, BufferAllocator, String, long, long, int, boolean, boolean) - Constructor for class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
Creates a BufferedDirectBufInputStream with the specified buffer size.
bufferedReadSize - Variable in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
BufferManagerImpl - Class in org.apache.drill.exec.ops
 
BufferManagerImpl(BufferAllocator) - Constructor for class org.apache.drill.exec.ops.BufferManagerImpl
 
bufferQueue - Variable in class org.apache.drill.exec.work.batch.BaseRawBatchBuffer
 
buffers - Variable in class org.apache.drill.exec.work.batch.AbstractDataCollector
 
buffers - Variable in class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
bufferSizePerSocket - Variable in class org.apache.drill.exec.work.batch.BaseRawBatchBuffer
 
bufline - Variable in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
bufpos - Variable in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
build() - Method in class org.apache.drill.exec.cache.DistributedCache.CacheConfigBuilder
 
build() - Method in class org.apache.drill.exec.compile.ClassBodyBuilder
 
build() - Method in class org.apache.drill.exec.coord.store.TransientStoreConfigBuilder
 
build(FragmentContext, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.sort.SortRecordBatchBuilder
 
build(VectorContainer) - Method in class org.apache.drill.exec.physical.impl.sort.SortRecordBatchBuilder
 
build(Prel, boolean) - Method in class org.apache.drill.exec.planner.physical.PhysicalPlanCreator
 
build() - Method in class org.apache.drill.exec.planner.sql.DrillSqlAggOperator.DrillSqlAggOperatorBuilder
 
build() - Method in class org.apache.drill.exec.planner.sql.DrillSqlOperator.DrillSqlOperatorBuilder
 
build() - Method in class org.apache.drill.exec.planner.sql.parser.DrillCompoundIdentifier.Builder
 
build() - Method in class org.apache.drill.exec.record.SchemaBuilder
Generate a new BatchSchema object based on the current state of the builder.
build() - Method in class org.apache.drill.exec.record.TypedFieldId.Builder
 
build() - Method in class org.apache.drill.exec.rpc.user.UserSession.Builder
 
build(ResourceManager) - Static method in class org.apache.drill.exec.server.rest.DrillRoot.QueueInfo
 
build() - Method in class org.apache.drill.exec.server.rest.profile.OperatorPathBuilder
 
build() - Method in class org.apache.drill.exec.server.rest.profile.TableBuilder
 
build() - Method in class org.apache.drill.exec.ssl.SSLConfigBuilder
 
build() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilterBuilder
 
build() - Method in class org.apache.drill.exec.store.SchemaConfig.Builder
 
build() - Method in class org.apache.drill.exec.store.sys.PersistentStoreConfig.StoreConfigBuilder
 
build() - Method in class org.apache.drill.exec.work.foreman.rm.ResourceManagerBuilder
 
build_email - Variable in class org.apache.drill.exec.store.sys.VersionIterator.VersionInfo
 
build_time - Variable in class org.apache.drill.exec.store.sys.VersionIterator.VersionInfo
 
buildComplete() - Method in interface org.apache.drill.exec.physical.impl.aggregate.HashAggregator
 
buildComplete() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
 
buildJoinConditions(List<JoinCondition>, List<String>, List<String>, List<Integer>, List<Integer>) - Method in class org.apache.drill.exec.planner.physical.JoinPrel
Build the list of join conditions for this join.
buildParquetFilterPredicate(LogicalExpression, Set<LogicalExpression>, UdfUtilities) - Static method in class org.apache.drill.exec.store.parquet.ParquetFilterBuilder
 
buildReader(ParquetRecordReader, OutputMutator) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
Create the readers needed to read columns: fixed-length or variable length.
buildSchema() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggBatch
 
buildSchema() - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggBatch
 
buildSchema() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
 
buildSchema() - Method in class org.apache.drill.exec.physical.impl.join.MergeJoinBatch
 
buildSchema() - Method in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch
Builds the output container's schema.
buildSchema() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
buildSchema() - Method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
buildSchema() - Method in class org.apache.drill.exec.physical.impl.union.UnionAllRecordBatch
 
buildSchema() - Method in class org.apache.drill.exec.physical.impl.window.WindowFrameRecordBatch
 
buildSchema() - Method in class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch
 
buildSchema() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
Called by AbstractRecordBatch as a fast-path to obtain the first record batch and setup the schema of this batch in order to quickly return the schema to the client.
buildSchema() - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
buildSchema(BatchSchema.SelectionVectorMode) - Method in class org.apache.drill.exec.record.VectorContainer
 
buildSchema(long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetSchema
Build the schema for this read as a combination of the schema specified in the Parquet footer and the list of columns selected in the query.
buildVectorInitializer() - Method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
The column size information gathered here represents empirically-derived schema metadata.
BUILT_IN - Static variable in class org.apache.drill.exec.expr.fn.registry.LocalFunctionRegistry
 
BuiltinFunctionCall() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a call to a builtin function with special syntax.
BULK_LOAD_TABLE_LIST_BULK_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
BULK_LOAD_TABLE_LIST_BULK_SIZE_KEY - Static variable in class org.apache.drill.exec.ExecConstants
When getting Hive Table information with exec.enable_bulk_load_table_list set to true, use the exec.bulk_load_table_list.bulk_size to determine how many tables to fetch from HiveMetaStore at a time.
busy_threads - Variable in class org.apache.drill.exec.store.sys.ThreadsIterator.ThreadsInfo
 
BY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
BYTE_DISK_READ_COST - Static variable in class org.apache.drill.exec.planner.cost.DrillCostBase
 
BYTE_NETWORK_COST - Static variable in class org.apache.drill.exec.planner.cost.DrillCostBase
 
ByteBufUtil - Class in org.apache.drill.exec.util
 
ByteBufUtil() - Constructor for class org.apache.drill.exec.util.ByteBufUtil
 
ByteBufUtil.HadoopWritables - Class in org.apache.drill.exec.util
Modeled after org.apache.hadoop.io.WritableUtils.
ByteBufUtil.HadoopWritables() - Constructor for class org.apache.drill.exec.util.ByteBufUtil.HadoopWritables
 
bytesBefore(byte) - Method in class org.apache.drill.exec.record.DeadBuf
 
bytesBefore(int, byte) - Method in class org.apache.drill.exec.record.DeadBuf
 
bytesBefore(int, int, byte) - Method in class org.apache.drill.exec.record.DeadBuf
 
ByteSubstring - Class in org.apache.drill.exec.expr.fn.impl
Evaluate a substring expression for a given value; specifying the start position, and optionally the end position.
ByteSubstring() - Constructor for class org.apache.drill.exec.expr.fn.impl.ByteSubstring
 

C

C - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
cachedBatches() - Method in class org.apache.drill.exec.record.RecordIterator
 
CachedClassLoader - Class in org.apache.drill.exec.compile
Class loader for "plain-old Java" generated classes.
CachedClassLoader() - Constructor for class org.apache.drill.exec.compile.CachedClassLoader
 
CachedVectorContainer - Class in org.apache.drill.exec.cache
 
CachedVectorContainer(WritableBatch, BufferAllocator) - Constructor for class org.apache.drill.exec.cache.CachedVectorContainer
 
CachedVectorContainer(BufferAllocator) - Constructor for class org.apache.drill.exec.cache.CachedVectorContainer
 
CachedVectorContainer(byte[], BufferAllocator) - Constructor for class org.apache.drill.exec.cache.CachedVectorContainer
 
cacheFileRoot - Variable in class org.apache.drill.exec.store.dfs.FileSelection
root path for the metadata cache file (if any)
CachingPersistentStoreProvider - Class in org.apache.drill.exec.store.sys.store.provider
 
CachingPersistentStoreProvider(PersistentStoreProvider) - Constructor for class org.apache.drill.exec.store.sys.store.provider.CachingPersistentStoreProvider
 
CachingTransientStoreFactory - Class in org.apache.drill.exec.coord.store
 
CachingTransientStoreFactory(TransientStoreFactory) - Constructor for class org.apache.drill.exec.coord.store.CachingTransientStoreFactory
 
CALC_INSTANCE_DRILL - Static variable in class org.apache.drill.exec.planner.logical.DrillReduceExpressionsRule
 
CALL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
callBack - Variable in class org.apache.drill.exec.record.AbstractSingleRecordBatch
 
CALLED - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
cancel() - Method in class org.apache.drill.exec.work.foreman.Foreman
Cancel the query.
cancel - Variable in class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
cancel() - Method in class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
cancel() - Method in class org.apache.drill.exec.work.fragment.FragmentExecutor
Cancel the execution of this fragment is in an appropriate state.
cancel() - Method in interface org.apache.drill.exec.work.fragment.FragmentManager
 
cancel() - Method in class org.apache.drill.exec.work.fragment.NonRootFragmentManager
 
cancelAndRemoveFragmentManagerIfExists(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.rpc.control.WorkEventBus
Cancels and removes fragment manager (for the corresponding the handle) from the work event bus, Currently, used for fragments waiting on data (root and intermediate).
cancelDeleteOnExit(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
cancelFragment(RpcOutcomeListener<GeneralRPCProtos.Ack>, ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel
 
cancelQuery(UserBitShared.QueryId) - Method in class org.apache.drill.exec.client.DrillClient
 
cancelQuery(String) - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources
 
cancelQuery(UserBitShared.QueryId) - Method in class org.apache.drill.exec.work.user.UserWorker
 
canConvert(RelOptPlanner, DrillDistributionTrait, DrillDistributionTrait) - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTraitDef
 
canDoWork(int, WindowPOP, boolean, boolean) - Method in class org.apache.drill.exec.physical.impl.window.WindowFunction
 
canDrop(RangeExprEvaluator) - Method in interface org.apache.drill.exec.expr.stat.ParquetFilterPredicate
 
canDrop(RangeExprEvaluator) - Method in class org.apache.drill.exec.expr.stat.ParquetPredicates.AndPredicate
 
canDrop(RangeExprEvaluator) - Method in class org.apache.drill.exec.expr.stat.ParquetPredicates.EqualPredicate
Semantics of canDrop() is very similar to what is implemented in Parquet library's org.apache.parquet.filter2.statisticslevel.StatisticsFilter and FilterPredicate Main difference : 1.
canDrop(RangeExprEvaluator) - Method in class org.apache.drill.exec.expr.stat.ParquetPredicates.GEPredicate
 
canDrop(RangeExprEvaluator) - Method in class org.apache.drill.exec.expr.stat.ParquetPredicates.GTPredicate
 
canDrop(RangeExprEvaluator) - Method in class org.apache.drill.exec.expr.stat.ParquetPredicates.LEPredicate
 
canDrop(RangeExprEvaluator) - Method in class org.apache.drill.exec.expr.stat.ParquetPredicates.LTPredicate
 
canDrop(RangeExprEvaluator) - Method in class org.apache.drill.exec.expr.stat.ParquetPredicates.NEPredicate
 
canDrop(RangeExprEvaluator) - Method in class org.apache.drill.exec.expr.stat.ParquetPredicates.OrPredicate
 
canDrop(ParquetFilterPredicate, Map<SchemaPath, ColumnStatistics>, long) - Static method in class org.apache.drill.exec.store.parquet.ParquetRGFilterEvaluator
 
canDrop(LogicalExpression, Map<SchemaPath, ColumnStatistics>, long, UdfUtilities, FunctionImplementationRegistry) - Static method in class org.apache.drill.exec.store.parquet.ParquetRGFilterEvaluator
 
canManageProfileOf(String) - Method in class org.apache.drill.exec.server.rest.auth.DrillUserPrincipal
Is the user identified by this user principal can manage (read) the profile owned by the given user?
canManageQueryOf(String) - Method in class org.apache.drill.exec.server.rest.auth.DrillUserPrincipal
Is the user identified by this user principal can manage (cancel) the query issued by the given user?
canPushdownProjects(List<SchemaPath>) - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
canPushdownProjects(List<SchemaPath>) - Method in interface org.apache.drill.exec.physical.base.GroupScan
GroupScan should check the list of columns, and see if it could support all the columns in the list.
canPushdownProjects(List<SchemaPath>) - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
canPushdownProjects(List<SchemaPath>) - Method in class org.apache.drill.exec.store.mock.MockGroupScanPOP
 
canPushdownProjects(List<SchemaPath>) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
capacity() - Method in class org.apache.drill.exec.record.DeadBuf
 
capacity(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
capacity() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
capacity() - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
 
capacity() - Method in class org.apache.drill.exec.store.parquet.columnreaders.NullableVarLengthValuesColumn
 
capacity() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.Decimal28Column
 
capacity() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.Decimal38Column
 
capacity() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.NullableDecimal28Column
 
capacity() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.NullableDecimal38Column
 
capacity() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.NullableVarBinaryColumn
 
capacity() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.NullableVarCharColumn
 
capacity() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.VarBinaryColumn
 
capacity() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.VarCharColumn
 
CARDINALITY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CASCADE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CASCADED - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CASE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CaseExpression() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
caseSensitive() - Method in class org.apache.drill.exec.planner.sql.DrillParserConfig
 
CAST - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CAST_TO_NULLABLE_NUMERIC - Static variable in class org.apache.drill.exec.ExecConstants
 
CAST_TO_NULLABLE_NUMERIC_OPTION - Static variable in class org.apache.drill.exec.ExecConstants
 
CastBigIntDate - Class in org.apache.drill.exec.expr.fn.impl
 
CastBigIntDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.CastBigIntDate
 
CastBigIntDecimal18 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastBigIntDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntDecimal18
 
CastBigIntDecimal28Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastBigIntDecimal28Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntDecimal28Sparse
 
CastBigIntDecimal38Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastBigIntDecimal38Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntDecimal38Sparse
 
CastBigIntDecimal9 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastBigIntDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntDecimal9
 
CastBigIntFloat4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastBigIntFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntFloat4
 
CastBigIntFloat8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastBigIntFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntFloat8
 
CastBigIntInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastBigIntInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntInt
 
CastBigIntTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
CastBigIntTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.CastBigIntTimeStamp
 
CastBigIntVarBinary - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastBigIntVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntVarBinary
 
CastBigIntVarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastBigIntVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntVarChar
 
CastBitTinyInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastBitTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastBitTinyInt
 
CastDateToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDateToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDateToTimeStamp
 
CastDateToVarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDateToVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDateToVarChar
 
CastDecimal18BigInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal18BigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18BigInt
 
CastDecimal18Decimal28Dense - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal18Decimal28Dense() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Decimal28Dense
 
CastDecimal18Decimal28Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal18Decimal28Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Decimal28Sparse
 
CastDecimal18Decimal38Dense - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal18Decimal38Dense() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Decimal38Dense
 
CastDecimal18Decimal38Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal18Decimal38Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Decimal38Sparse
 
CastDecimal18Decimal9 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal18Decimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Decimal9
 
CastDecimal18Float4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal18Float4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Float4
 
CastDecimal18Float8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal18Float8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Float8
 
CastDecimal18Int - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal18Int() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Int
 
CastDecimal18VarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal18VarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18VarChar
 
CastDecimal28DenseDecimal28Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal28DenseDecimal28Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28DenseDecimal28Sparse
 
CastDecimal28DenseDecimal38Dense - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal28DenseDecimal38Dense() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28DenseDecimal38Dense
 
CastDecimal28DenseDecimal38Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal28DenseDecimal38Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28DenseDecimal38Sparse
 
CastDecimal28DenseFloat4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal28DenseFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28DenseFloat4
 
CastDecimal28DenseFloat8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal28DenseFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28DenseFloat8
 
CastDecimal28SparseBigInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal28SparseBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseBigInt
 
CastDecimal28SparseDecimal28Dense - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal28SparseDecimal28Dense() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseDecimal28Dense
 
CastDecimal28SparseDecimal38Dense - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal28SparseDecimal38Dense() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseDecimal38Dense
 
CastDecimal28SparseDecimal38Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal28SparseDecimal38Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseDecimal38Sparse
 
CastDecimal28SparseFloat4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal28SparseFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseFloat4
 
CastDecimal28SparseFloat8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal28SparseFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseFloat8
 
CastDecimal28SparseInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal28SparseInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseInt
 
CastDecimal28SparseVarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal28SparseVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseVarChar
 
CastDecimal38DenseDecimal38Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal38DenseDecimal38Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38DenseDecimal38Sparse
 
CastDecimal38DenseFloat4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal38DenseFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38DenseFloat4
 
CastDecimal38DenseFloat8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal38DenseFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38DenseFloat8
 
CastDecimal38SparseBigInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal38SparseBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseBigInt
 
CastDecimal38SparseDecimal18 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal38SparseDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseDecimal18
 
CastDecimal38SparseDecimal28Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal38SparseDecimal28Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseDecimal28Sparse
 
CastDecimal38SparseDecimal38Dense - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal38SparseDecimal38Dense() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseDecimal38Dense
 
CastDecimal38SparseDecimal9 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal38SparseDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseDecimal9
 
CastDecimal38SparseFloat4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal38SparseFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseFloat4
 
CastDecimal38SparseFloat8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal38SparseFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseFloat8
 
CastDecimal38SparseInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal38SparseInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseInt
 
CastDecimal38SparseVarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal38SparseVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseVarChar
 
CastDecimal9BigInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal9BigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9BigInt
 
CastDecimal9Decimal18 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal9Decimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Decimal18
 
CastDecimal9Decimal28Dense - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal9Decimal28Dense() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Decimal28Dense
 
CastDecimal9Decimal28Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal9Decimal28Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Decimal28Sparse
 
CastDecimal9Decimal38Dense - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal9Decimal38Dense() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Decimal38Dense
 
CastDecimal9Decimal38Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal9Decimal38Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Decimal38Sparse
 
CastDecimal9Float4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal9Float4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Float4
 
CastDecimal9Float8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal9Float8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Float8
 
CastDecimal9Int - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal9Int() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Int
 
CastDecimal9VarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastDecimal9VarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9VarChar
 
CastEmptyStringNullableVar16CharToNullableBigInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringNullableVar16CharToNullableBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableBigInt
 
CastEmptyStringNullableVar16CharToNullableDecimal18 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringNullableVar16CharToNullableDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableDecimal18
 
CastEmptyStringNullableVar16CharToNullableDecimal28Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringNullableVar16CharToNullableDecimal28Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableDecimal28Sparse
 
CastEmptyStringNullableVar16CharToNullableDecimal38Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringNullableVar16CharToNullableDecimal38Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableDecimal38Sparse
 
CastEmptyStringNullableVar16CharToNullableDecimal9 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringNullableVar16CharToNullableDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableDecimal9
 
CastEmptyStringNullableVar16CharToNullableFloat4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringNullableVar16CharToNullableFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableFloat4
 
CastEmptyStringNullableVar16CharToNullableFloat8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringNullableVar16CharToNullableFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableFloat8
 
CastEmptyStringNullableVar16CharToNullableInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringNullableVar16CharToNullableInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableInt
 
CastEmptyStringNullableVarBinaryToNullableBigInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringNullableVarBinaryToNullableBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableBigInt
 
CastEmptyStringNullableVarBinaryToNullableDecimal18 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringNullableVarBinaryToNullableDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableDecimal18
 
CastEmptyStringNullableVarBinaryToNullableDecimal28Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringNullableVarBinaryToNullableDecimal28Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableDecimal28Sparse
 
CastEmptyStringNullableVarBinaryToNullableDecimal38Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringNullableVarBinaryToNullableDecimal38Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableDecimal38Sparse
 
CastEmptyStringNullableVarBinaryToNullableDecimal9 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringNullableVarBinaryToNullableDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableDecimal9
 
CastEmptyStringNullableVarBinaryToNullableFloat4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringNullableVarBinaryToNullableFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableFloat4
 
CastEmptyStringNullableVarBinaryToNullableFloat8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringNullableVarBinaryToNullableFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableFloat8
 
CastEmptyStringNullableVarBinaryToNullableInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringNullableVarBinaryToNullableInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableInt
 
CastEmptyStringNullableVarCharToNullableBigInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringNullableVarCharToNullableBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableBigInt
 
CastEmptyStringNullableVarCharToNullableDecimal18 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringNullableVarCharToNullableDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableDecimal18
 
CastEmptyStringNullableVarCharToNullableDecimal28Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringNullableVarCharToNullableDecimal28Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableDecimal28Sparse
 
CastEmptyStringNullableVarCharToNullableDecimal38Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringNullableVarCharToNullableDecimal38Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableDecimal38Sparse
 
CastEmptyStringNullableVarCharToNullableDecimal9 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringNullableVarCharToNullableDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableDecimal9
 
CastEmptyStringNullableVarCharToNullableFloat4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringNullableVarCharToNullableFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableFloat4
 
CastEmptyStringNullableVarCharToNullableFloat8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringNullableVarCharToNullableFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableFloat8
 
CastEmptyStringNullableVarCharToNullableInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringNullableVarCharToNullableInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableInt
 
CastEmptyStringVarCharToNullableBigInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringVarCharToNullableBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableBigInt
 
CastEmptyStringVarCharToNullableDecimal18 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringVarCharToNullableDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableDecimal18
 
CastEmptyStringVarCharToNullableDecimal28Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringVarCharToNullableDecimal28Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableDecimal28Sparse
 
CastEmptyStringVarCharToNullableDecimal38Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringVarCharToNullableDecimal38Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableDecimal38Sparse
 
CastEmptyStringVarCharToNullableDecimal9 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastEmptyStringVarCharToNullableDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableDecimal9
 
CastEmptyStringVarCharToNullableFloat4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringVarCharToNullableFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableFloat4
 
CastEmptyStringVarCharToNullableFloat8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringVarCharToNullableFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableFloat8
 
CastEmptyStringVarCharToNullableInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
This file is generated with Freemarker using the template exec/java-exec/src/main/codegen/templates/CastEmptyStringVarTypesToNullableNumeric.java
CastEmptyStringVarCharToNullableInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableInt
 
CastFloat4BigInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat4BigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4BigInt
 
CastFloat4Decimal18 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat4Decimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Decimal18
 
CastFloat4Decimal28Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat4Decimal28Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Decimal28Sparse
 
CastFloat4Decimal38Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat4Decimal38Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Decimal38Sparse
 
CastFloat4Decimal9 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat4Decimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Decimal9
 
CastFloat4Float8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat4Float8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Float8
 
CastFloat4Int - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat4Int() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Int
 
CastFloat4VarBinary - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat4VarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4VarBinary
 
CastFloat4VarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat4VarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4VarChar
 
CastFloat8BigInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat8BigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8BigInt
 
CastFloat8Decimal18 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat8Decimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Decimal18
 
CastFloat8Decimal28Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat8Decimal28Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Decimal28Sparse
 
CastFloat8Decimal38Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat8Decimal38Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Decimal38Sparse
 
CastFloat8Decimal9 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat8Decimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Decimal9
 
CastFloat8Float4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat8Float4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Float4
 
CastFloat8Int - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat8Int() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Int
 
CastFloat8VarBinary - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat8VarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8VarBinary
 
CastFloat8VarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastFloat8VarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8VarChar
 
CastHighFunctions - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastHighFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions
 
CastHighFunctions.CastHighBigInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastHighFunctions.CastHighBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighBigInt
 
CastHighFunctions.CastHighDecimal18 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastHighFunctions.CastHighDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighDecimal18
 
CastHighFunctions.CastHighDecimal28Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastHighFunctions.CastHighDecimal28Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighDecimal28Sparse
 
CastHighFunctions.CastHighDecimal38Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastHighFunctions.CastHighDecimal38Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighDecimal38Sparse
 
CastHighFunctions.CastHighDecimal9 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastHighFunctions.CastHighDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighDecimal9
 
CastHighFunctions.CastHighFloat4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastHighFunctions.CastHighFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighFloat4
 
CastHighFunctions.CastHighFloat8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastHighFunctions.CastHighFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighFloat8
 
CastHighFunctions.CastHighInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastHighFunctions.CastHighInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighInt
 
CastIntBigInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntBigInt
 
CastIntDecimal18 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntDecimal18
 
CastIntDecimal28Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntDecimal28Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntDecimal28Sparse
 
CastIntDecimal38Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntDecimal38Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntDecimal38Sparse
 
CastIntDecimal9 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntDecimal9
 
CastIntervalDayToInterval - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntervalDayToInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalDayToInterval
 
CastIntervalDayToVarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntervalDayToVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalDayToVarChar
 
CastIntervalToIntervalDay - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntervalToIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalToIntervalDay
 
CastIntervalToIntervalYear - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntervalToIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalToIntervalYear
 
CastIntervalToVarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntervalToVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalToVarChar
 
CastIntervalYearToInterval - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntervalYearToInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalYearToInterval
 
CastIntervalYearToVarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntervalYearToVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalYearToVarChar
 
CastIntFloat4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntFloat4
 
CastIntFloat8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntFloat8
 
CastIntTime - Class in org.apache.drill.exec.expr.fn.impl
 
CastIntTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.CastIntTime
 
CastIntVarBinary - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntVarBinary
 
CastIntVarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastIntVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastIntVarChar
 
CastTimeStampToDate - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastTimeStampToDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastTimeStampToDate
 
CastTimeStampToVarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastTimeStampToVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastTimeStampToVarChar
 
CastTimeToVarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastTimeToVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastTimeToVarChar
 
CastTinyIntBit - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastTinyIntBit() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastTinyIntBit
 
CastVarBinaryBigInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarBinaryBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryBigInt
 
CastVarBinaryFloat4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarBinaryFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryFloat4
 
CastVarBinaryFloat8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarBinaryFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryFloat8
 
CastVarBinaryInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarBinaryInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryInt
 
CastVarBinaryToDate - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarBinaryToDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryToDate
 
CastVarBinaryToTime - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarBinaryToTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryToTime
 
CastVarBinaryToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarBinaryToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryToTimeStamp
 
CastVarBinaryVarBinary - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarBinaryVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryVarBinary
 
CastVarBinaryVarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarBinaryVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryVarChar
 
CastVarCharBigInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharBigInt
 
CastVarCharDecimal18 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharDecimal18
 
CastVarCharDecimal28Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharDecimal28Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharDecimal28Sparse
 
CastVarCharDecimal38Sparse - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharDecimal38Sparse() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharDecimal38Sparse
 
CastVarCharDecimal9 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharDecimal9
 
CastVarCharFloat4 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharFloat4
 
CastVarCharFloat8 - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharFloat8
 
CastVarCharInt - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharInt
 
CastVarCharToDate - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharToDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToDate
 
CastVarCharToInterval - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharToInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToInterval
 
CastVarCharToIntervalDay - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharToIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToIntervalDay
 
CastVarCharToIntervalYear - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharToIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToIntervalYear
 
CastVarCharToTime - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharToTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToTime
 
CastVarCharToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToTimeStamp
 
CastVarCharVar16Char - Class in org.apache.drill.exec.expr.fn.impl
 
CastVarCharVar16Char() - Constructor for class org.apache.drill.exec.expr.fn.impl.CastVarCharVar16Char
 
CastVarCharVarBinary - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharVarBinary
 
CastVarCharVarChar - Class in org.apache.drill.exec.expr.fn.impl.gcast
 
CastVarCharVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharVarChar
 
CATALOG - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CATALOG_CONNECT - Variable in class org.apache.drill.exec.store.ischema.Records.Catalog
 
CATALOG_DESCRIPTION - Variable in class org.apache.drill.exec.store.ischema.Records.Catalog
 
CATALOG_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CATALOG_NAME - Variable in class org.apache.drill.exec.store.ischema.Records.Catalog
 
CATALOG_NAME - Variable in class org.apache.drill.exec.store.ischema.Records.Schema
 
catalogs(UserSession, DrillbitContext, UserProtos.GetCatalogsReq, ResponseSender) - Static method in class org.apache.drill.exec.work.metadata.MetadataProvider
 
CATS_COL_CATALOG_CONNECT - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
CATS_COL_CATALOG_DESCRIPTION - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
CATS_COL_CATALOG_NAME - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
CEIL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CEILING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CHAIN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ChainedHashTable - Class in org.apache.drill.exec.physical.impl.common
 
ChainedHashTable(HashTableConfig, FragmentContext, BufferAllocator, RecordBatch, RecordBatch, RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.common.ChainedHashTable
 
changeHandlerTo(RequestHandler<S>) - Method in class org.apache.drill.exec.rpc.AbstractServerConnection
 
channelClosed(RpcException) - Method in class org.apache.drill.exec.rpc.AbstractClientConnection
 
channelClosed(RpcException) - Method in class org.apache.drill.exec.rpc.AbstractServerConnection
 
channelClosed(RpcException) - Method in class org.apache.drill.exec.rpc.control.ControlConnection
 
CHAR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CHAR_LENGTH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CHARACTER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CHARACTER_LENGTH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CHARACTER_MAXIMUM_LENGTH - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
CHARACTER_OCTET_LENGTH - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
CHARACTER_SET_CATALOG - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CHARACTER_SET_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CHARACTER_SET_SCHEMA - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CHARACTERISTICS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CHARACTERS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
charAt(int) - Method in class org.apache.drill.exec.expr.fn.impl.CharSequenceWrapper
 
CharSequenceWrapper - Class in org.apache.drill.exec.expr.fn.impl
A CharSequence is a readable sequence of char values.
CharSequenceWrapper() - Constructor for class org.apache.drill.exec.expr.fn.impl.CharSequenceWrapper
 
CharSequenceWrapper(int, int, DrillBuf) - Constructor for class org.apache.drill.exec.expr.fn.impl.CharSequenceWrapper
 
CHARSET - Static variable in class org.apache.drill.exec.planner.sql.parser.DrillParserUtil
 
CHARSETNAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CharSubstring - Class in org.apache.drill.exec.expr.fn.impl
Evaluate a substring expression for a given UTF-8 value; specifying the start position, and optionally the end position.
CharSubstring() - Constructor for class org.apache.drill.exec.expr.fn.impl.CharSubstring
 
CHECK - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
checkAndReturnSupportedJoinComparator(JoinCondition) - Static method in class org.apache.drill.exec.physical.impl.join.JoinUtils
 
checkBackPaths(String, String, String) - Static method in class org.apache.drill.exec.store.dfs.FileSelection
Check if the path is a valid sub path under the parent after removing backpaths.
checkBroadcastConditions(RelOptPlanner, DrillJoinRel, RelNode, RelNode) - Method in class org.apache.drill.exec.planner.physical.JoinPruleBase
 
checkBufferLength(DrillBuf, int, int, int) - Static method in class org.apache.drill.exec.util.ByteBufUtil
Verifies that the the space provided in the buffer is of specified size.
checkCartesianJoin(RelNode, List<Integer>, List<Integer>, List<Boolean>) - Static method in class org.apache.drill.exec.physical.impl.join.JoinUtils
Check if the given RelNode contains any Cartesian join.
checkClass(Class<?>) - Method in enum org.apache.drill.exec.cache.DistributedCache.SerializationMode
 
CheckClassVisitorFsm - Class in org.apache.drill.exec.compile
A ClassVisitor that verifies the required call sequence described in http://asm.ow2.org/asm50/javadoc/user/org/objectweb/asm/ClassVisitor.html .
CheckClassVisitorFsm(int, ClassVisitor) - Constructor for class org.apache.drill.exec.compile.CheckClassVisitorFsm
See ClassVisitor.ClassVisitor(int, ClassVisitor).
checkDecimalTypeEnabled(OptionManager) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
 
checkForCorruptDateValuesInStatistics(ParquetMetadata, List<SchemaPath>, boolean) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
Detect corrupt date values by looking at the min/max values in the metadata.
checkForNewPartition(int) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
checkForNewPartition(int) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
 
checkForNewPartition(int) - Method in interface org.apache.drill.exec.store.RecordWriter
Check if the writer should start a new partition, and if so, start a new partition
checkForOutOfMemory() - Method in interface org.apache.drill.exec.work.batch.BaseRawBatchBuffer.BufferQueue
 
checkInputStreamState() - Method in class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
CheckMethodVisitorFsm - Class in org.apache.drill.exec.compile
A MethodVisitor that verifies the required call sequence according to http://asm.ow2.org/asm50/javadoc/user/org/objectweb/asm/MethodVisitor.html .
CheckMethodVisitorFsm(int, MethodVisitor) - Constructor for class org.apache.drill.exec.compile.CheckMethodVisitorFsm
See MethodVisitor.MethodVisitor(int, MethodVisitor).
checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
checkOperandTypes(SqlCallBinding, boolean) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
checkPrecisionRange() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
checkPrecisionRange() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
 
checkPreconditions(DrillJoinRel, RelNode, RelNode, PlannerSettings) - Method in class org.apache.drill.exec.planner.physical.JoinPruleBase
 
checkPreconditions(DrillJoinRel, RelNode, RelNode, PlannerSettings) - Method in class org.apache.drill.exec.planner.physical.NestedLoopJoinPrule
 
checkStreamSupportsByteBuffer() - Method in class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
checkTableExistence() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropTable
 
checkTableNonExistence() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateTable
 
checkVectorCapacityReached() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
checkVectorCapacityReached() - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
 
checkViewExistence() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropView
 
child - Variable in class org.apache.drill.exec.physical.base.AbstractSingle
 
childEvent(CuratorFramework, PathChildrenCacheEvent) - Method in class org.apache.drill.exec.coord.zk.EventDispatcher
 
children - Variable in class org.apache.drill.exec.physical.base.AbstractMultiple
 
CLASS_ORIGIN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ClassBodyBuilder - Class in org.apache.drill.exec.compile
 
ClassBuilder - Class in org.apache.drill.exec.compile
Implements the "plain Java" method of code generation and compilation.
ClassBuilder(DrillConfig, OptionSet) - Constructor for class org.apache.drill.exec.compile.ClassBuilder
 
ClassCompilerSelector - Class in org.apache.drill.exec.compile
Selects between the two supported Java compilers: Janino and the build-in Java compiler.
ClassCompilerSelector(ClassLoader, DrillConfig, OptionSet) - Constructor for class org.apache.drill.exec.compile.ClassCompilerSelector
 
ClassCompilerSelector.CompilerPolicy - Enum in org.apache.drill.exec.compile
 
CLASSES - Static variable in class org.apache.drill.exec.compile.bytecode.ScalarReplacementTypes
 
classFromBytes(byte[], int) - Static method in class org.apache.drill.exec.compile.AsmUtil
Create a ClassNode from bytecode.
ClassGenerator<T> - Class in org.apache.drill.exec.expr
 
ClassGenerator.BlkCreateMode - Enum in org.apache.drill.exec.expr
 
ClassGenerator.BlockType - Enum in org.apache.drill.exec.expr
 
ClassGenerator.HoldingContainer - Class in org.apache.drill.exec.expr
Represents a (Nullable)?(Type)Holder instance.
ClassGenerator.HoldingContainer(TypeProtos.MajorType, JVar, JFieldRef, JFieldRef) - Constructor for class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
 
ClassGenerator.HoldingContainer(TypeProtos.MajorType, JVar, JFieldRef, JFieldRef, boolean, boolean) - Constructor for class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
 
ClassPathFileSystem - Class in org.apache.drill.exec.store
 
ClassPathFileSystem() - Constructor for class org.apache.drill.exec.store.ClassPathFileSystem
 
ClassTransformationException - Exception in org.apache.drill.exec.exception
 
ClassTransformationException() - Constructor for exception org.apache.drill.exec.exception.ClassTransformationException
 
ClassTransformationException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.drill.exec.exception.ClassTransformationException
 
ClassTransformationException(String, Throwable) - Constructor for exception org.apache.drill.exec.exception.ClassTransformationException
 
ClassTransformationException(String) - Constructor for exception org.apache.drill.exec.exception.ClassTransformationException
 
ClassTransformationException(Throwable) - Constructor for exception org.apache.drill.exec.exception.ClassTransformationException
 
ClassTransformer - Class in org.apache.drill.exec.compile
Compiles generated code, merges the resulting class with the template class, and performs byte-code cleanup on the resulting byte codes.
ClassTransformer(DrillConfig, OptionSet) - Constructor for class org.apache.drill.exec.compile.ClassTransformer
 
ClassTransformer.ClassNames - Class in org.apache.drill.exec.compile
 
ClassTransformer.ClassNames(String) - Constructor for class org.apache.drill.exec.compile.ClassTransformer.ClassNames
 
ClassTransformer.ClassSet - Class in org.apache.drill.exec.compile
 
ClassTransformer.ClassSet(ClassTransformer.ClassSet, String, String) - Constructor for class org.apache.drill.exec.compile.ClassTransformer.ClassSet
 
ClassTransformer.ScalarReplacementOption - Enum in org.apache.drill.exec.compile
 
clazz - Variable in enum org.apache.drill.exec.cache.SerializationDefinition
 
clazz - Variable in class org.apache.drill.exec.compile.ClassTransformer.ClassNames
 
clazz - Variable in class org.apache.drill.exec.expr.ClassGenerator
 
clean() - Method in class org.apache.drill.exec.exception.UnsupportedOperatorCollector
 
cleanup() - Method in interface org.apache.drill.exec.physical.impl.aggregate.HashAggregator
 
cleanup() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
 
cleanup() - Method in interface org.apache.drill.exec.physical.impl.aggregate.StreamingAggregator
 
cleanup() - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
 
cleanup() - Method in interface org.apache.drill.exec.physical.impl.TopN.PriorityQueue
Releases all the memory consumed by the priority queue.
cleanup() - Method in class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
 
cleanup() - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
 
cleanup() - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
 
cleanup() - Method in interface org.apache.drill.exec.physical.impl.window.WindowFramer
 
cleanup() - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter
 
cleanup() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
 
cleanup() - Method in class org.apache.drill.exec.store.pojo.AbstractPojoWriter
 
cleanup() - Method in interface org.apache.drill.exec.store.pojo.PojoWriter
Performs clean up if needed.
cleanup() - Method in interface org.apache.drill.exec.store.RecordWriter
 
cleanup() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
cleanup() - Method in class org.apache.drill.exec.store.text.DrillTextRecordWriter
 
cleanupSession() - Method in class org.apache.drill.exec.server.rest.WebUserConnection.AnonWebUserConnection
For anonymous WebUser after each query request is completed the WebSessionResources is cleaned up.
cleanupSession() - Method in class org.apache.drill.exec.server.rest.WebUserConnection
For authenticated WebUser no cleanup of WebSessionResources is done since it's re-used for all the queries until lifetime of the web session.
clear() - Method in class org.apache.drill.exec.cache.CachedVectorContainer
 
clear() - Method in class org.apache.drill.exec.cache.VectorAccessibleSerializable
 
clear() - Method in class org.apache.drill.exec.ops.OperatorStats
Clear stats
clear() - Method in class org.apache.drill.exec.physical.impl.aggregate.InternalBatch
 
clear() - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
 
clear() - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
clear() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelper
 
clear() - Method in interface org.apache.drill.exec.physical.impl.partitionsender.Partitioner
 
clear() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerDecorator
decorator method to call multiple Partitioners clear()
clear() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate
 
clear() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
clear() - Method in class org.apache.drill.exec.physical.impl.ScanBatch.Mutator
 
clear() - Method in class org.apache.drill.exec.physical.impl.sort.RecordBatchData
 
clear() - Method in class org.apache.drill.exec.physical.impl.sort.SortRecordBatchBuilder
 
clear() - Method in class org.apache.drill.exec.physical.impl.window.WindowDataBatch
 
clear() - Method in interface org.apache.drill.exec.physical.impl.xsort.managed.MSorter
 
clear() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MSortTemplate
 
clear() - Method in interface org.apache.drill.exec.physical.impl.xsort.MSorter
 
clear() - Method in class org.apache.drill.exec.physical.impl.xsort.MSortTemplate
 
clear() - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions.OpState
 
clear() - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
clear() - Method in class org.apache.drill.exec.record.DeadBuf
 
clear() - Method in class org.apache.drill.exec.record.HyperVectorWrapper
 
clear() - Method in class org.apache.drill.exec.record.RecordBatchLoader
Clears this loader, which clears the internal vector container (see VectorContainer.clear()) and resets the record count to zero.
clear() - Method in class org.apache.drill.exec.record.RecordIterator
 
clear() - Method in class org.apache.drill.exec.record.selection.SelectionVector2
 
clear() - Method in class org.apache.drill.exec.record.selection.SelectionVector4
 
clear() - Method in class org.apache.drill.exec.record.SimpleVectorWrapper
 
clear(VectorAccessible) - Static method in class org.apache.drill.exec.record.VectorAccessibleUtilities
 
clear() - Method in class org.apache.drill.exec.record.VectorContainer
 
clear() - Method in interface org.apache.drill.exec.record.VectorWrapper
 
clear() - Method in class org.apache.drill.exec.record.WritableBatch
 
clear() - Method in class org.apache.drill.exec.server.rest.profile.OperatorPathBuilder
 
clear() - Method in class org.apache.drill.exec.store.dfs.MetadataContext
 
clear() - Method in class org.apache.drill.exec.store.parquet.ColumnDataReader
 
clear() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
clear() - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
 
clear() - Method in class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
 
clearInflightBatches() - Method in class org.apache.drill.exec.record.RecordIterator
 
clearStatus(String) - Method in class org.apache.drill.exec.store.dfs.MetadataContext
 
CLIENT_RPC_THREADS - Static variable in class org.apache.drill.exec.ExecConstants
 
CLIENT_SUPPORT_COMPLEX_TYPES - Static variable in class org.apache.drill.exec.ExecConstants
 
ClientAuthenticatorProvider - Class in org.apache.drill.exec.rpc.security
 
CLOB - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
clone(FileSelection) - Method in class org.apache.drill.exec.physical.base.AbstractFileGroupScan
 
clone(List<SchemaPath>) - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
clone(FileSelection) - Method in interface org.apache.drill.exec.physical.base.FileGroupScan
 
clone(List<SchemaPath>) - Method in interface org.apache.drill.exec.physical.base.GroupScan
Returns a clone of GroupScan instance, except that the new GroupScan will use the provided list of columns .
clone() - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer.FieldList
 
clone() - Method in class org.apache.drill.exec.planner.physical.ScanPrel
 
clone() - Method in class org.apache.drill.exec.planner.physical.ValuesPrel
 
clone() - Method in class org.apache.drill.exec.record.BatchSchema
 
clone() - Method in class org.apache.drill.exec.record.selection.SelectionVector2
 
clone(List<SchemaPath>) - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
clone(FileSelection) - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
clone(List<SchemaPath>) - Method in class org.apache.drill.exec.store.direct.DirectGroupScan
 
clone(List<SchemaPath>) - Method in class org.apache.drill.exec.store.direct.MetadataDirectGroupScan
 
clone(List<SchemaPath>) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaGroupScan
 
clone(List<SchemaPath>) - Method in class org.apache.drill.exec.store.mock.MockGroupScanPOP
 
clone() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v1
 
clone() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
clone() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
clone() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataBase
 
clone(List<SchemaPath>) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
clone(FileSelection) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
clone(FileSelection, long) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
clone(List<SchemaPath>) - Method in class org.apache.drill.exec.store.sys.SystemTableScan
 
cloneAndTransfer(BufferAllocator) - Method in class org.apache.drill.exec.record.HyperVectorWrapper
 
cloneAndTransfer(BufferAllocator) - Method in class org.apache.drill.exec.record.SimpleVectorWrapper
 
cloneAndTransfer(BufferAllocator) - Method in interface org.apache.drill.exec.record.VectorWrapper
 
CloneVisitor - Class in org.apache.drill.exec.expr
Creates a deep copy of a LogicalExpression.
CloneVisitor() - Constructor for class org.apache.drill.exec.expr.CloneVisitor
 
cloneWithChild(int) - Method in class org.apache.drill.exec.record.TypedFieldId
 
cloneWithRemainder(PathSegment) - Method in class org.apache.drill.exec.record.TypedFieldId
 
close() - Method in class org.apache.drill.exec.client.DrillClient
Closes this client's connection to the server
close() - Method in class org.apache.drill.exec.compile.CodeCompiler
Upon close, report the effectiveness of the code cache to the log.
close() - Method in class org.apache.drill.exec.compile.LogWriter
 
close() - Method in class org.apache.drill.exec.coord.local.LocalClusterCoordinator
 
close() - Method in class org.apache.drill.exec.coord.local.MapBackedStore
 
close() - Method in class org.apache.drill.exec.coord.store.CachingTransientStoreFactory
 
close() - Method in class org.apache.drill.exec.coord.zk.ZKClusterCoordinator
 
close() - Method in class org.apache.drill.exec.coord.zk.ZkEphemeralStore
 
close() - Method in class org.apache.drill.exec.coord.zk.ZkTransientStoreFactory
 
close() - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
 
close() - Method in class org.apache.drill.exec.expr.fn.FunctionImplementationRegistry
If FunctionImplementationRegistry.deleteTmpDir is set to true, deletes generated temporary directory.
close() - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
 
close() - Method in class org.apache.drill.exec.expr.SingleClassStringWriter
 
close() - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
close() - Method in class org.apache.drill.exec.ops.BufferManagerImpl
 
close() - Method in class org.apache.drill.exec.ops.FragmentContext
 
close() - Method in interface org.apache.drill.exec.ops.OperatorContext
 
close() - Method in class org.apache.drill.exec.ops.QueryContext
 
close() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
Note: ignoring any IO errors (e.g.
close() - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.BaseRootExec
 
close() - Method in class org.apache.drill.exec.physical.impl.filter.FilterRecordBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.join.MergeJoinBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.limit.LimitRecordBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec
 
close() - Method in class org.apache.drill.exec.physical.impl.producer.ProducerConsumerBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.ScreenCreator.ScreenRoot
 
close() - Method in class org.apache.drill.exec.physical.impl.sort.SortBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.sort.SortRecordBatchBuilder
 
close() - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet
 
close() - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingInputStream
 
close() - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingOutputStream
 
close() - Method in class org.apache.drill.exec.physical.impl.svremover.RemovingRecordBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.trace.TraceRecordBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
close() - Method in class org.apache.drill.exec.physical.impl.window.WindowFrameRecordBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.WriterRecordBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.xsort.BatchGroup
 
close() - Method in class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
close() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.InputBatch
 
close() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.SpilledRun
Close resources owned by this batch group.
close() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BufferedBatches
 
close() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
Extreme paranoia to avoid leaving resources unclosed in the case of an error.
close() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MergeSortWrapper
 
close() - Method in interface org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopier
 
close() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierTemplate
 
close() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierWrapper.BatchMerger
 
close() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierWrapper
 
close() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SorterWrapper
 
close() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl
 
close() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.EmptyResults
 
close() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SingleBatchResults
 
close() - Method in interface org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SortResults
 
close() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SpilledRuns
 
close() - Method in interface org.apache.drill.exec.physical.impl.xsort.PriorityQueueCopier
 
close() - Method in class org.apache.drill.exec.physical.impl.xsort.PriorityQueueCopierTemplate
 
close() - Method in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor.RelDataTypeReader
 
CLOSE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
close() - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
close() - Method in interface org.apache.drill.exec.record.RawFragmentBatchProvider
 
close() - Method in class org.apache.drill.exec.record.RecordIterator
 
close() - Method in class org.apache.drill.exec.record.selection.SelectionVector2
 
close() - Method in class org.apache.drill.exec.record.selection.SelectionVector4
 
close() - Method in class org.apache.drill.exec.record.WritableBatch
 
close() - Method in class org.apache.drill.exec.rpc.control.ControllerImpl
 
close() - Method in class org.apache.drill.exec.rpc.data.DataConnectionCreator
 
close() - Method in interface org.apache.drill.exec.rpc.security.AuthenticatorProvider
 
close() - Method in class org.apache.drill.exec.rpc.security.AuthenticatorProviderImpl
 
close() - Method in class org.apache.drill.exec.rpc.security.ClientAuthenticatorProvider
 
close() - Method in class org.apache.drill.exec.rpc.security.kerberos.KerberosFactory
 
close() - Method in class org.apache.drill.exec.rpc.security.plain.PlainFactory
 
close() - Method in class org.apache.drill.exec.rpc.user.security.Pam4jUserAuthenticator
 
close() - Method in class org.apache.drill.exec.rpc.user.security.PamUserAuthenticator
 
close() - Method in interface org.apache.drill.exec.rpc.user.security.UserAuthenticator
Close the authenticator.
close() - Method in class org.apache.drill.exec.rpc.user.UserServer.BitToUserConnection
 
close() - Method in class org.apache.drill.exec.rpc.user.UserSession
On session close deletes all session temporary locations recursively and clears temporary locations list.
close() - Method in class org.apache.drill.exec.server.BootStrapContext
 
close() - Method in class org.apache.drill.exec.server.Drillbit
 
close() - Method in class org.apache.drill.exec.server.DrillbitContext
 
close() - Method in class org.apache.drill.exec.server.options.SystemOptionManager
 
close() - Method in class org.apache.drill.exec.server.RemoteServiceSet
 
close() - Method in class org.apache.drill.exec.server.rest.WebServer
 
close() - Method in class org.apache.drill.exec.server.rest.WebSessionResources
 
close() - Method in class org.apache.drill.exec.service.ServiceEngine
 
close() - Method in class org.apache.drill.exec.store.AbstractSchema
 
close() - Method in class org.apache.drill.exec.store.AbstractStoragePlugin
 
close() - Method in class org.apache.drill.exec.store.avro.AvroRecordReader
 
close() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
close() - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
close() - Method in class org.apache.drill.exec.store.easy.json.JSONRecordReader
 
close() - Method in class org.apache.drill.exec.store.easy.sequencefile.SequenceFileRecordReader
 
close() - Method in class org.apache.drill.exec.store.easy.text.compliant.CompliantTextRecordReader
Cleanup state once we are finished processing all the records.
close() - Method in class org.apache.drill.exec.store.mock.ExtendedMockRecordReader
 
close() - Method in class org.apache.drill.exec.store.mock.MockRecordReader
 
close() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
close() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
 
close() - Method in class org.apache.drill.exec.store.parquet2.DrillParquetReader
 
close() - Method in class org.apache.drill.exec.store.pcap.PcapRecordReader
 
close() - Method in class org.apache.drill.exec.store.pojo.AbstractPojoRecordReader
 
close() - Method in class org.apache.drill.exec.store.SchemaTreeProvider
 
close() - Method in class org.apache.drill.exec.store.StoragePluginRegistryImpl
 
close() - Method in class org.apache.drill.exec.store.sys.store.InMemoryStore
 
close() - Method in class org.apache.drill.exec.store.sys.store.LocalPersistentStore
 
close() - Method in class org.apache.drill.exec.store.sys.store.provider.BasePersistentStoreProvider
 
close() - Method in class org.apache.drill.exec.store.sys.store.provider.CachingPersistentStoreProvider
 
close() - Method in class org.apache.drill.exec.store.sys.store.provider.InMemoryStoreProvider
 
close() - Method in class org.apache.drill.exec.store.sys.store.provider.LocalPersistentStoreProvider
 
close() - Method in class org.apache.drill.exec.store.sys.store.provider.ZookeeperPersistentStoreProvider
 
close() - Method in class org.apache.drill.exec.store.sys.store.ZookeeperPersistentStore
 
close() - Method in class org.apache.drill.exec.store.text.DrillTextRecordReader
 
close() - Method in interface org.apache.drill.exec.testing.CountDownLatchInjection
Close the latch.
close() - Method in class org.apache.drill.exec.testing.CountDownLatchInjectionImpl
 
close() - Method in class org.apache.drill.exec.testing.store.NoWriteLocalStore
 
close() - Method in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
 
close() - Method in class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
close() - Method in class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
 
close() - Method in class org.apache.drill.exec.work.batch.AbstractDataCollector
 
close() - Method in class org.apache.drill.exec.work.batch.BaseRawBatchBuffer
 
close() - Method in class org.apache.drill.exec.work.batch.IncomingBuffers
 
close() - Method in class org.apache.drill.exec.work.batch.SpoolingRawBatchBuffer
 
close() - Method in class org.apache.drill.exec.work.foreman.QueryManager
 
close() - Method in class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager
 
close() - Method in class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue
 
close() - Method in class org.apache.drill.exec.work.foreman.rm.DynamicResourceManager
 
close() - Method in class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue
 
close() - Method in interface org.apache.drill.exec.work.foreman.rm.QueryQueue
 
close() - Method in interface org.apache.drill.exec.work.foreman.rm.ResourceManager
 
close() - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager
 
close() - Method in class org.apache.drill.exec.work.fragment.FragmentStatusReporter
 
close() - Method in class org.apache.drill.exec.work.WorkManager
 
close() - Method in class org.apache.parquet.hadoop.ColumnChunkIncReadStore
 
close() - Method in class org.apache.parquet.hadoop.ParquetColumnChunkPageWriteStore
 
CloseableRecordBatch - Interface in org.apache.drill.exec.record
 
closeAll(Collection<? extends BatchGroup>) - Static method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
closeOutputStream() - Method in class org.apache.drill.exec.physical.impl.xsort.BatchGroup
 
closeOutputStream() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.SpilledRun
 
closeSSL() - Method in class org.apache.drill.exec.rpc.user.UserServer
 
ClusterCoordinator - Class in org.apache.drill.exec.coord
Pluggable interface built to manage cluster coordination.
ClusterCoordinator() - Constructor for class org.apache.drill.exec.coord.ClusterCoordinator
 
ClusterCoordinator.RegistrationHandle - Interface in org.apache.drill.exec.coord
 
COALESCE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
COBOL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CODE_DIR_OPTION - Static variable in class org.apache.drill.exec.compile.ClassBuilder
 
CODE_GEN_EXP_IN_METHOD_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
CODE_GEN_EXP_IN_METHOD_SIZE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
codecFactory - Variable in class org.apache.drill.exec.store.dfs.BasicFormatMatcher
 
CodeCompiler - Class in org.apache.drill.exec.compile
Global code compiler mechanism shared by all threads and operators.
CodeCompiler(DrillConfig, OptionSet) - Constructor for class org.apache.drill.exec.compile.CodeCompiler
 
CodeCompiler.CodeGenCompiler - Class in org.apache.drill.exec.compile
Abstracts out the details of compiling code using the two available mechanisms.
CodeCompiler.CodeGenCompiler(DrillConfig, OptionSet) - Constructor for class org.apache.drill.exec.compile.CodeCompiler.CodeGenCompiler
 
CodeGenerator<T> - Class in org.apache.drill.exec.expr
A code generator is responsible for generating the Java source code required to complete the implementation of an abstract template.
CodeGeneratorArgument - Class in org.apache.drill.exec.compile.sig
 
CodeGeneratorArgument(String, Class<?>) - Constructor for class org.apache.drill.exec.compile.sig.CodeGeneratorArgument
 
CodeGeneratorMethod - Class in org.apache.drill.exec.compile.sig
 
CodeGeneratorMethod(String, Class<?>) - Constructor for class org.apache.drill.exec.compile.sig.CodeGeneratorMethod
 
CodeGeneratorMethod(Method) - Constructor for class org.apache.drill.exec.compile.sig.CodeGeneratorMethod
 
CodeGeneratorSignature - Interface in org.apache.drill.exec.compile.sig
 
coerceContainer(VectorAccessible, BatchSchema, OperatorContext) - Static method in class org.apache.drill.exec.record.SchemaUtil
Creates a copy a record batch, converting any fields as necessary to coerce it into the provided schema
coerceContainer(VectorAccessible, BatchSchema, BufferAllocator) - Static method in class org.apache.drill.exec.record.SchemaUtil
 
COL_NULL_ERROR - Static variable in class org.apache.drill.exec.util.Utilities
 
COLLATE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CollateClause() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a COLLATE clause
collation - Variable in class org.apache.drill.exec.planner.physical.TopNPrel
 
COLLATION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
COLLATION_CATALOG - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
COLLATION_ID - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
COLLATION_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
COLLATION_SCHEMA - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
COLLECT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
collectColStat(Set<SchemaPath>) - Method in interface org.apache.drill.exec.store.parquet.stat.ColumnStatCollector
Given a list of fields (SchemaPath), return mapping from field to its corresponding ColumnStatistics
collectColStat(Set<SchemaPath>) - Method in class org.apache.drill.exec.store.parquet.stat.ParquetFooterStatCollector
 
collectColStat(Set<SchemaPath>) - Method in class org.apache.drill.exec.store.parquet.stat.ParquetMetaStatCollector
 
CollectionsTypeName() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
COLON - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
COLS_COL_CHARACTER_MAXIMUM_LENGTH - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
COLS_COL_CHARACTER_OCTET_LENGTH - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
COLS_COL_COLUMN_DEFAULT - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
COLS_COL_COLUMN_NAME - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
COLS_COL_DATA_TYPE - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
COLS_COL_DATETIME_PRECISION - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
COLS_COL_INTERVAL_PRECISION - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
COLS_COL_INTERVAL_TYPE - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
COLS_COL_IS_NULLABLE - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
COLS_COL_NUMERIC_PRECISION - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
COLS_COL_NUMERIC_PRECISION_RADIX - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
COLS_COL_NUMERIC_SCALE - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
COLS_COL_ORDINAL_POSITION - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
COLUMN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
column - Variable in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
COLUMN_DEFAULT - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
COLUMN_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
COLUMN_NAME - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
COLUMN_PREFIX - Static variable in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
Prefix used to replace non-alphabetic characters at the start of a column name.
COLUMN_SIZE - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
ColumnChunkIncReadStore - Class in org.apache.parquet.hadoop
 
ColumnChunkIncReadStore(long, CodecFactory, BufferAllocator, FileSystem, Path) - Constructor for class org.apache.parquet.hadoop.ColumnChunkIncReadStore
 
ColumnChunkIncReadStore.ColumnChunkIncPageReader - Class in org.apache.parquet.hadoop
 
ColumnChunkIncReadStore.ColumnChunkIncPageReader(ColumnChunkMetaData, ColumnDescriptor, FSDataInputStream) - Constructor for class org.apache.parquet.hadoop.ColumnChunkIncReadStore.ColumnChunkIncPageReader
 
ColumnDataReader - Class in org.apache.drill.exec.store.parquet
 
ColumnDataReader(FSDataInputStream, long, long) - Constructor for class org.apache.drill.exec.store.parquet.ColumnDataReader
 
ColumnDataReader.HadoopBytesInput - Class in org.apache.drill.exec.store.parquet
 
ColumnDataReader.HadoopBytesInput(byte[]) - Constructor for class org.apache.drill.exec.store.parquet.ColumnDataReader.HadoopBytesInput
 
ColumnDef - Class in org.apache.drill.exec.store.mock
Defines a column for the "enhanced" version of the mock data source.
ColumnDef(MockTableDef.MockColumn) - Constructor for class org.apache.drill.exec.store.mock.ColumnDef
 
ColumnDef(MockTableDef.MockColumn, int) - Constructor for class org.apache.drill.exec.store.mock.ColumnDef
 
ColumnDto - Class in org.apache.drill.exec.store.pcap.dto
 
ColumnDto(String, PcapTypes) - Constructor for class org.apache.drill.exec.store.pcap.dto.ColumnDto
 
ColumnExplorer - Class in org.apache.drill.exec.store
 
ColumnExplorer(FragmentContext, List<SchemaPath>) - Constructor for class org.apache.drill.exec.store.ColumnExplorer
Helper class that encapsulates logic for sorting out columns between actual table columns, partition columns and implicit file columns.
ColumnExplorer(OptionManager, List<SchemaPath>) - Constructor for class org.apache.drill.exec.store.ColumnExplorer
Helper class that encapsulates logic for sorting out columns between actual table columns, partition columns and implicit file columns.
ColumnExplorer.ImplicitFileColumns - Enum in org.apache.drill.exec.store
Columns that give information from where file data comes from.
columnNames - Variable in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor.RelDataTypeReader
 
ColumnReader<V extends ValueVector> - Class in org.apache.drill.exec.store.parquet.columnreaders
 
ColumnReader(ParquetRecordReader, int, ColumnDescriptor, ColumnChunkMetaData, boolean, V, SchemaElement) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
ColumnReaderFactory - Class in org.apache.drill.exec.store.parquet.columnreaders
 
ColumnReaderFactory() - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.ColumnReaderFactory
 
columns() - Method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
 
columns - Variable in class org.apache.drill.exec.planner.physical.PrelUtil.ProjectPushInfo
 
columns - Variable in class org.apache.drill.exec.server.rest.QueryWrapper.QueryResult
 
columns - Variable in class org.apache.drill.exec.server.rest.WebUserConnection
 
columns - Variable in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v1
 
columns - Variable in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v2
 
columns - Variable in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v3
 
columns(UserSession, DrillbitContext, UserProtos.GetColumnsReq, ResponseSender) - Static method in class org.apache.drill.exec.work.metadata.MetadataProvider
 
ColumnStatCollector - Interface in org.apache.drill.exec.store.parquet.stat
 
ColumnStatistics - Class in org.apache.drill.exec.store.parquet.stat
 
ColumnStatistics(Statistics, TypeProtos.MajorType) - Constructor for class org.apache.drill.exec.store.parquet.stat.ColumnStatistics
 
ColumnType(List<SqlNode>) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
columnTypeInfo - Variable in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
columnTypeInfo - Variable in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
columnTypes - Variable in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor.RelDataTypeReader
 
COMMA - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
COMMAND_FUNCTION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
COMMAND_FUNCTION_CODE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
comment - Variable in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
COMMIT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
commit_id - Variable in class org.apache.drill.exec.store.sys.VersionIterator.VersionInfo
 
commit_message - Variable in class org.apache.drill.exec.store.sys.VersionIterator.VersionInfo
 
commit_time - Variable in class org.apache.drill.exec.store.sys.VersionIterator.VersionInfo
 
COMMITTED - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CommonNonReservedKeyWord() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a non-reserved keyword for use as an identifier.
compact() - Method in class org.apache.drill.exec.server.rest.profile.SimpleDurationFormat
Return a compact representation of elapsed time with only the most significant time units and no spaces
Comparator - Enum in org.apache.drill.exec.physical.impl.common
Comparator type.
compare(VarBinaryHolder, VarCharHolder) - Static method in class org.apache.drill.exec.expr.fn.impl.VarHelpers
 
compare(VarCharHolder, VarCharHolder) - Static method in class org.apache.drill.exec.expr.fn.impl.VarHelpers
 
compare(NullableVarBinaryHolder, NullableVarBinaryHolder) - Static method in class org.apache.drill.exec.expr.fn.impl.VarHelpers
 
compare(NullableVarBinaryHolder, NullableVarCharHolder) - Static method in class org.apache.drill.exec.expr.fn.impl.VarHelpers
 
compare(NullableVarCharHolder, NullableVarCharHolder) - Static method in class org.apache.drill.exec.expr.fn.impl.VarHelpers
 
compare(VarBinaryHolder, VarBinaryHolder) - Static method in class org.apache.drill.exec.expr.fn.impl.VarHelpers
 
compare(int, int) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.SampleSortTemplate
 
compare(int, int) - Method in class org.apache.drill.exec.physical.impl.sort.SortTemplate
 
compare(int, int) - Method in class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
 
compare(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MSortTemplate
 
compare(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierTemplate
 
compare(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.MSortTemplate
 
compare(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.PriorityQueueCopierTemplate
 
compare(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.SingleBatchSorterTemplate
 
COMPARE_CPU_COST - Static variable in class org.apache.drill.exec.planner.cost.DrillCostBase
 
COMPARE_TO_NULLS_HIGH - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
 
COMPARE_TO_NULLS_LOW - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
 
compareMapping - Variable in class org.apache.drill.exec.physical.impl.join.MergeJoinBatch
 
compareMapping - Static variable in interface org.apache.drill.exec.physical.impl.mergereceiver.MergingReceiverGeneratorBase
 
compareRightMapping - Variable in class org.apache.drill.exec.physical.impl.join.MergeJoinBatch
 
compareTo(ByteBuf) - Method in class org.apache.drill.exec.record.DeadBuf
 
compareTo(OptionValue) - Method in class org.apache.drill.exec.server.options.OptionValue
 
compareTo(DrillRoot.DrillbitInfo) - Method in class org.apache.drill.exec.server.rest.DrillRoot.DrillbitInfo
Method used to sort Drillbits.
compareTo(LogsResources.Log) - Method in class org.apache.drill.exec.server.rest.LogsResources.Log
 
compareTo(ProfileResources.ProfileInfo) - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.ProfileInfo
 
compareTo(MetadataVersion) - Method in class org.apache.drill.exec.store.parquet.MetadataVersion
 
compareTo(CompleteWork) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan.RowGroupInfo
 
compareTo(CompleteWork) - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork
 
compareTypes(TypeProtos.MinorType, TypeProtos.MinorType) - Static method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions
 
CompilationConfig - Class in org.apache.drill.exec.compile
 
CompilationConfig() - Constructor for class org.apache.drill.exec.compile.CompilationConfig
 
compile(ClassTransformer.ClassNames, String) - Method in class org.apache.drill.exec.compile.AbstractClassCompiler
 
compile(ClassTransformer.ClassNames, String) - Method in class org.apache.drill.exec.compile.ClassCompilerSelector
 
compile(CodeGenerator<?>) - Method in class org.apache.drill.exec.compile.CodeCompiler.CodeGenCompiler
Compile the code already generated by the code generator.
COMPILE_BASE - Static variable in class org.apache.drill.exec.compile.CodeCompiler
 
COMPILE_SCALAR_REPLACEMENT - Static variable in class org.apache.drill.exec.ExecConstants
 
COMPLETED_FRAGMENT_OVERVIEW_COLUMNS - Static variable in class org.apache.drill.exec.server.rest.profile.FragmentWrapper
 
COMPLETED_FRAGMENT_OVERVIEW_COLUMNS_TOOLTIP - Static variable in class org.apache.drill.exec.server.rest.profile.FragmentWrapper
 
CompleteFileWork - Class in org.apache.drill.exec.store.schedule
 
CompleteFileWork(EndpointByteMap, long, long, String) - Constructor for class org.apache.drill.exec.store.schedule.CompleteFileWork
 
CompleteFileWork.FileWorkImpl - Class in org.apache.drill.exec.store.schedule
 
CompleteFileWork.FileWorkImpl(long, long, String) - Constructor for class org.apache.drill.exec.store.schedule.CompleteFileWork.FileWorkImpl
 
completeLocalOutput(Path, Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
CompleteWork - Interface in org.apache.drill.exec.store.schedule
Container that holds a complete work unit.
ComplexToJson - Class in org.apache.drill.exec.physical.config
 
ComplexToJson(PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.config.ComplexToJson
 
ComplexToJsonBatchCreator - Class in org.apache.drill.exec.physical.impl.project
 
ComplexToJsonBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.project.ComplexToJsonBatchCreator
 
ComplexToJsonPrel - Class in org.apache.drill.exec.planner.physical
 
ComplexToJsonPrel(Prel) - Constructor for class org.apache.drill.exec.planner.physical.ComplexToJsonPrel
 
ComplexToJsonPrelVisitor - Class in org.apache.drill.exec.planner.physical.visitor
 
ComplexToJsonPrelVisitor() - Constructor for class org.apache.drill.exec.planner.physical.visitor.ComplexToJsonPrelVisitor
 
CompliantTextRecordReader - Class in org.apache.drill.exec.store.easy.text.compliant
 
CompliantTextRecordReader(FileSplit, DrillFileSystem, FragmentContext, TextParsingSettings, List<SchemaPath>) - Constructor for class org.apache.drill.exec.store.easy.text.compliant.CompliantTextRecordReader
 
CompoundIdentifier() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a Drill compound identifier.
CompoundIdentifierConverter - Class in org.apache.drill.exec.planner.sql.parser
Implementation of SqlVisitor that converts bracketed compound SqlIdentifier to bracket-less compound SqlIdentifier (also known as DrillCompoundIdentifier) to provide ease of use while querying complex types.
CompoundIdentifierConverter() - Constructor for class org.apache.drill.exec.planner.sql.parser.CompoundIdentifierConverter
 
compressible - Variable in class org.apache.drill.exec.store.dfs.BasicFormatMatcher
 
computeCartesianJoinCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.common.DrillJoinRelBase
 
computeHashAggCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.common.DrillAggregateRelBase
Estimate cost of hash agg.
computeHashJoinCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.common.DrillJoinRelBase
 
computeLogicalAggCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.common.DrillAggregateRelBase
 
computeLogicalJoinCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.common.DrillJoinRelBase
 
computeMaxWidth(double, long) - Method in class org.apache.drill.exec.server.options.TypeValidators.MaxWidthValidator
 
computeOperatorMemory(OptionSet, long, int) - Static method in class org.apache.drill.exec.util.MemoryAllocationUtilities
Compute per-operator memory based on the computed per-node memory, the number of operators, and the computed number of fragments (which house the operators.) Enforces a floor on the amount of memory per operator.
computeQueryMemory(DrillConfig, OptionSet, long) - Static method in class org.apache.drill.exec.util.MemoryAllocationUtilities
Per-node memory calculations based on a number of constraints.
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.common.DrillFilterRelBase
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.common.DrillJoinRelBase
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.common.DrillLimitRelBase
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.common.DrillProjectRelBase
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.common.DrillScreenRelBase
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.logical.DrillAggregateRel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.logical.DrillScanRel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.logical.DrillUnionRel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.BroadcastExchangePrel
In a BroadcastExchange, each sender is sending data to N receivers (for costing purposes we assume it is also sending to itself).
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.HashAggPrel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.HashJoinPrel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.HashToMergeExchangePrel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.HashToRandomExchangePrel
HashToRandomExchange processes M input rows and hash partitions them based on computing a hash value on the distribution fields.
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.MergeJoinPrel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.NestedLoopJoinPrel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.OrderedPartitionExchangePrel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.ScanPrel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.SingleMergeExchangePrel
A SingleMergeExchange processes a total of M rows coming from N sorted input streams (from N senders) and merges them into a single output sorted stream.
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.SortPrel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.StreamAggPrel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.TopNPrel
Cost of doing Top-N is proportional to M log N where M is the total number of input rows and N is the limit for Top-N.
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.UnionAllPrel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.UnionDistinctPrel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.UnionExchangePrel
A UnionExchange processes a total of M rows coming from N senders and combines them into a single output stream.
CONCAT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
concat(Path, Path[]) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
ConcatReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
Return type calculation implementation for functions with return type set as FunctionTemplate.ReturnType.CONCAT.
ConcatReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.ConcatReturnTypeInference
 
CONDITION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CONDITION_NUMBER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
config - Variable in class org.apache.drill.exec.coord.store.BaseTransientStore
 
config - Variable in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
 
config(DrillConfig) - Method in class org.apache.drill.exec.ssl.SSLConfigBuilder
 
config - Variable in class org.apache.drill.exec.store.dfs.FileSystemConfig
 
configure(ResourceInfo, FeatureContext) - Method in class org.apache.drill.exec.server.rest.auth.AuthDynamicFeature
 
configureFormatPlugins(StoragePluginRegistry) - Static method in class org.apache.drill.exec.util.StoragePluginTestUtils
 
configureFormatPlugins(StoragePluginRegistry, String) - Static method in class org.apache.drill.exec.util.StoragePluginTestUtils
 
connect() - Method in class org.apache.drill.exec.client.DrillClient
Connects the client to a Drillbit server
connect(Properties) - Method in class org.apache.drill.exec.client.DrillClient
 
connect(String, Properties) - Method in class org.apache.drill.exec.client.DrillClient
 
CONNECT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
connect(CoordinationProtos.DrillbitEndpoint, DrillProperties, UserBitShared.UserCredentials) - Method in class org.apache.drill.exec.rpc.user.UserClient
Connects, and if required, authenticates.
CONNECTION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
connection - Variable in class org.apache.drill.exec.store.dfs.FileSystemConfig
 
CONNECTION_COUNTER_PREFIX - Static variable in class org.apache.drill.exec.rpc.AbstractRpcMetrics
 
CONNECTION_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ConnectionConfig - Interface in org.apache.drill.exec.rpc
 
ConnectionManagerRegistry - Class in org.apache.drill.exec.rpc.control
 
ConnectionManagerRegistry(ControlConnectionConfig) - Constructor for class org.apache.drill.exec.rpc.control.ConnectionManagerRegistry
 
consolidateBatches(long, int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
Choose a consolidation option during the merge phase depending on memory available.
CONSTANT_FOLDING - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
ConstantExpressionIdentifier - Class in org.apache.drill.exec.compile.sig
 
CONSTRAINT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CONSTRAINT_CATALOG - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CONSTRAINT_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CONSTRAINT_SCHEMA - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CONSTRAINTS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CONSTRUCTOR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Consumer<T> - Interface in org.apache.drill.exec.ops
 
container - Variable in class org.apache.drill.exec.record.AbstractRecordBatch
 
CONTAINS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
contains(String, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.BasePersistentStore
By default contains with version will behave the same way as without version.
contains(String) - Method in interface org.apache.drill.exec.store.sys.PersistentStore
Checks if lookup key is present in store.
contains(String, DataChangeVersion) - Method in interface org.apache.drill.exec.store.sys.PersistentStore
Checks if lookup key is present in store.
contains(String) - Method in class org.apache.drill.exec.store.sys.store.InMemoryStore
 
contains(String, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.store.InMemoryStore
 
contains(String) - Method in class org.apache.drill.exec.store.sys.store.LocalPersistentStore
 
contains(String, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.store.LocalPersistentStore
 
contains(String) - Method in class org.apache.drill.exec.store.sys.store.ZookeeperPersistentStore
 
contains(String, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.store.ZookeeperPersistentStore
 
contains(String) - Method in class org.apache.drill.exec.testing.store.NoWriteLocalStore
 
contains(String, DataChangeVersion) - Method in class org.apache.drill.exec.testing.store.NoWriteLocalStore
 
containsDirectories(DrillFileSystem) - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
containsFactory(String) - Method in interface org.apache.drill.exec.rpc.security.AuthenticatorProvider
 
containsFactory(String) - Method in class org.apache.drill.exec.rpc.security.AuthenticatorProviderImpl
 
containsFactory(String) - Method in class org.apache.drill.exec.rpc.security.ClientAuthenticatorProvider
 
containsImplicitColumns() - Method in class org.apache.drill.exec.store.ColumnExplorer
Checks if current column selection contains implicit columns.
containsJar(String) - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
Checks is jar is present in FunctionRegistryHolder.jars.
containsKey(int, boolean) - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
 
containsKey(int, boolean) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
containsKey(Object) - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
containsLimit0(RelNode) - Static method in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor
Check if the root portion of the tree contains LIMIT(0).
containsPartitionColumns() - Method in class org.apache.drill.exec.store.ColumnExplorer
Checks if current column selection contains partition columns.
containsStarColumn(RelDataType) - Static method in class org.apache.drill.exec.planner.StarColumnHelper
 
containsStarColumnInProject(RelDataType, List<RexNode>) - Static method in class org.apache.drill.exec.planner.StarColumnHelper
 
containsValue(Object) - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
content - Variable in class org.apache.drill.exec.planner.common.DrillValuesRelBase
 
contentsHaveChangedSince(long, long) - Method in class org.apache.drill.exec.store.AbstractSchema
 
context - Variable in class org.apache.drill.exec.ops.BaseOperatorContext
 
context - Variable in class org.apache.drill.exec.physical.impl.xsort.managed.BaseWrapper
 
context - Variable in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
 
context - Variable in class org.apache.drill.exec.planner.sql.handlers.ViewHandler
 
context - Variable in class org.apache.drill.exec.record.AbstractRecordBatch
 
context - Variable in class org.apache.drill.exec.work.batch.BaseRawBatchBuffer
 
context - Variable in class org.apache.drill.exec.work.foreman.rm.AbstractResourceManager
 
context - Variable in class org.apache.drill.exec.work.fragment.FragmentStatusReporter
 
ContextFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
ContextFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.ContextFunctions
 
ContextFunctions.CurrentSchema - Class in org.apache.drill.exec.expr.fn.impl
Implement "current_schema" function.
ContextFunctions.CurrentSchema() - Constructor for class org.apache.drill.exec.expr.fn.impl.ContextFunctions.CurrentSchema
 
ContextFunctions.SessionId - Class in org.apache.drill.exec.expr.fn.impl
Implement "session_id" function.
ContextFunctions.SessionId() - Constructor for class org.apache.drill.exec.expr.fn.impl.ContextFunctions.SessionId
 
ContextFunctions.User - Class in org.apache.drill.exec.expr.fn.impl
Implement "user", "session_user" or "system_user" function.
ContextFunctions.User() - Constructor for class org.apache.drill.exec.expr.fn.impl.ContextFunctions.User
 
ContextInformation - Class in org.apache.drill.exec.ops
Provides query context information (such as query start time, query user, default schema etc.) for UDFs.
ContextInformation(UserBitShared.UserCredentials, BitControl.QueryContextInformation) - Constructor for class org.apache.drill.exec.ops.ContextInformation
 
ContextVariable() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
CONTINUE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
control_port - Variable in class org.apache.drill.exec.store.sys.DrillbitIterator.DrillbitInstance
 
ControlClient - Class in org.apache.drill.exec.rpc.control
 
ControlClient(ControlConnectionConfig, CoordinationProtos.DrillbitEndpoint, ReconnectingConnection<ControlConnection, BitControl.BitControlHandshake>.CloseHandlerCreator) - Constructor for class org.apache.drill.exec.rpc.control.ControlClient
 
ControlConnection - Class in org.apache.drill.exec.rpc.control
 
ControlConnectionManager - Class in org.apache.drill.exec.rpc.control
Maintains connection between two particular bits.
ControlConnectionManager(ControlConnectionConfig, CoordinationProtos.DrillbitEndpoint, CoordinationProtos.DrillbitEndpoint) - Constructor for class org.apache.drill.exec.rpc.control.ControlConnectionManager
 
Controller - Interface in org.apache.drill.exec.rpc.control
Service that allows one Drillbit to communicate with another.
Controller.CustomMessageHandler<REQUEST,RESPONSE> - Interface in org.apache.drill.exec.rpc.control
Defines how the Controller should handle custom messages.
Controller.CustomResponse<RESPONSE> - Interface in org.apache.drill.exec.rpc.control
A simple interface that describes the nature of the response to the custom incoming message.
Controller.CustomSerDe<MSG> - Interface in org.apache.drill.exec.rpc.control
Interface for defining how to serialize and deserialize custom message for consumer who want to use something other than Protobuf messages.
ControllerImpl - Class in org.apache.drill.exec.rpc.control
Manages communication tunnels between nodes.
ControllerImpl(BootStrapContext, BufferAllocator, ControlMessageHandler) - Constructor for class org.apache.drill.exec.rpc.control.ControllerImpl
 
ControlMessageHandler - Class in org.apache.drill.exec.work.batch
 
ControlMessageHandler(WorkManager.WorkerBee) - Constructor for class org.apache.drill.exec.work.batch.ControlMessageHandler
 
ControlProtobufLengthDecoder - Class in org.apache.drill.exec.rpc.control
Purely to simplify memory debugging.
ControlProtobufLengthDecoder(BufferAllocator, OutOfMemoryHandler) - Constructor for class org.apache.drill.exec.rpc.control.ControlProtobufLengthDecoder
 
ControlRpcConfig - Class in org.apache.drill.exec.rpc.control
 
ControlRpcConfig() - Constructor for class org.apache.drill.exec.rpc.control.ControlRpcConfig
 
ControlRpcMetrics - Class in org.apache.drill.exec.rpc.control
Holds metrics related to bit control rpc layer
ControlServer - Class in org.apache.drill.exec.rpc.control
 
ControlServer(ControlConnectionConfig, ConnectionManagerRegistry) - Constructor for class org.apache.drill.exec.rpc.control.ControlServer
 
ControlsInjector - Interface in org.apache.drill.exec.testing
 
ControlsInjectorFactory - Class in org.apache.drill.exec.testing
 
ControlsInjectorFactory() - Constructor for class org.apache.drill.exec.testing.ControlsInjectorFactory
 
controlsOptionMapper - Static variable in class org.apache.drill.exec.testing.ExecutionControls
 
ControlTunnel - Class in org.apache.drill.exec.rpc.control
 
ControlTunnel(ControlConnectionManager) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel
 
ControlTunnel.CancelQuery - Class in org.apache.drill.exec.rpc.control
 
ControlTunnel.CancelQuery(UserBitShared.QueryId) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.CancelQuery
 
ControlTunnel.CustomFuture<RECEIVE> - Class in org.apache.drill.exec.rpc.control
A class used to return a synchronous future when doing custom rpc messages.
ControlTunnel.CustomFuture(Controller.CustomSerDe<RECEIVE>, DrillRpcFuture<BitControl.CustomMessage>) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.CustomFuture
 
ControlTunnel.CustomTunnel<SEND,RECEIVE> - Class in org.apache.drill.exec.rpc.control
A special tunnel that can be used for custom types of messages.
ControlTunnel.JacksonSerDe<MSG> - Class in org.apache.drill.exec.rpc.control
 
ControlTunnel.JacksonSerDe(Class<MSG>) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.JacksonSerDe
 
ControlTunnel.JacksonSerDe(Class<MSG>, JsonSerializer<MSG>, JsonDeserializer<MSG>) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.JacksonSerDe
 
ControlTunnel.ProtoSerDe<MSG extends com.google.protobuf.MessageLite> - Class in org.apache.drill.exec.rpc.control
 
ControlTunnel.ReceiverFinished - Class in org.apache.drill.exec.rpc.control
 
ControlTunnel.ReceiverFinished(RpcOutcomeListener<GeneralRPCProtos.Ack>, BitControl.FinishedReceiver) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.ReceiverFinished
 
ControlTunnel.RequestProfile - Class in org.apache.drill.exec.rpc.control
 
ControlTunnel.RequestProfile(UserBitShared.QueryId) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.RequestProfile
 
ControlTunnel.SendFragment - Class in org.apache.drill.exec.rpc.control
 
ControlTunnel.SendFragment(RpcOutcomeListener<GeneralRPCProtos.Ack>, BitControl.InitializeFragments) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.SendFragment
 
ControlTunnel.SendFragmentStatus - Class in org.apache.drill.exec.rpc.control
 
ControlTunnel.SendFragmentStatus(BitControl.FragmentStatus) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.SendFragmentStatus
 
ControlTunnel.SignalFragment - Class in org.apache.drill.exec.rpc.control
 
ControlTunnel.SignalFragment(RpcOutcomeListener<GeneralRPCProtos.Ack>, ExecProtos.FragmentHandle, BitControl.RpcType) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.SignalFragment
 
ConversionContext - Class in org.apache.drill.exec.planner.torel
 
ConversionContext(RelOptCluster, LogicalPlan) - Constructor for class org.apache.drill.exec.planner.torel.ConversionContext
 
convert(GroupingAggregate, ConversionContext) - Static method in class org.apache.drill.exec.planner.logical.DrillAggregateRel
 
convert(Filter, ConversionContext) - Static method in class org.apache.drill.exec.planner.logical.DrillFilterRel
 
convert(Join, ConversionContext) - Static method in class org.apache.drill.exec.planner.logical.DrillJoinRel
 
convert(Limit, ConversionContext) - Static method in class org.apache.drill.exec.planner.logical.DrillLimitRel
 
convert(Project, ConversionContext) - Static method in class org.apache.drill.exec.planner.logical.DrillProjectRel
 
convert(Scan, ConversionContext) - Static method in class org.apache.drill.exec.planner.logical.DrillScanRel
 
convert(Order, ConversionContext) - Static method in class org.apache.drill.exec.planner.logical.DrillSortRel
 
convert(Union, ConversionContext) - Static method in class org.apache.drill.exec.planner.logical.DrillUnionRel
 
convert(RelNode) - Method in class org.apache.drill.exec.planner.logical.EnumerableDrillRule
 
convert(RelOptPlanner, RelNode, DrillDistributionTrait, boolean) - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTraitDef
 
convert(RelNode, RelTraitSet) - Static method in class org.apache.drill.exec.planner.physical.Prule
 
convert(RelNode) - Method in class org.apache.drill.exec.planner.physical.SortConvertPrule
 
CONVERT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
convert(JsonNode) - Method in class org.apache.drill.exec.store.pojo.DynamicPojoRecordReader.Converter
 
convertCall(SqlRexContext, SqlCall) - Method in class org.apache.drill.exec.planner.sql.DrillAvgVarianceConvertlet
 
convertCall(SqlRexContext, SqlCall) - Method in class org.apache.drill.exec.planner.sql.DrillExtractConvertlet
 
convertChild(T, RelNode) - Method in class org.apache.drill.exec.planner.physical.SubsetTransformer
 
ConvertCountToDirectScan - Class in org.apache.drill.exec.planner.physical
This rule will convert " select count(*) as mycount from table " or " select count(not-nullable-expr) as mycount from table " into
ConvertCountToDirectScan(RelOptRuleOperand, String) - Constructor for class org.apache.drill.exec.planner.physical.ConvertCountToDirectScan
Creates a SplunkPushDownRule.
convertDateStatIfNecessary(Statistics, ParquetReaderUtility.DateCorruptionStatus) - Static method in class org.apache.drill.exec.store.parquet.stat.ParquetFooterStatCollector
 
convertException() - Method in class org.apache.drill.exec.exception.UnsupportedOperatorCollector
 
convertException() - Method in class org.apache.drill.exec.planner.logical.PreProcessLogicalRel
 
convertException() - Method in class org.apache.drill.exec.planner.sql.parser.UnsupportedOperatorsVisitor
 
ConvertFromImpalaTimestamp - Class in org.apache.drill.exec.expr.fn.impl.conv
 
ConvertFromImpalaTimestamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.ConvertFromImpalaTimestamp
 
ConvertFromImpalaTimestamp.ImpalaTimestampConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
ConvertFromImpalaTimestamp.ImpalaTimestampConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.ConvertFromImpalaTimestamp.ImpalaTimestampConvertFrom
 
convertInt(byte[], int) - Static method in class org.apache.drill.exec.store.pcap.PcapFormatUtils
 
convertNext() - Method in interface org.apache.drill.exec.physical.impl.materialize.RecordMaterializer
 
convertNext() - Method in class org.apache.drill.exec.physical.impl.materialize.VectorRecordMaterializer
 
convertShort(byte[], int) - Static method in class org.apache.drill.exec.store.pcap.PcapFormatUtils
 
convertSqlOperatorBindingToFunctionCall(SqlOperatorBinding) - Static method in class org.apache.drill.exec.planner.sql.TypeInferenceUtils
Given a SqlOperatorBinding, convert it to FunctionCall
convertToDrel(RelNode) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
Return Drill Logical RelNode tree for a SELECT statement, when it is executed / explained directly.
convertToIOException(Exception) - Method in class org.apache.drill.exec.store.TimedRunnable
 
convertToNullableType(LogicalExpression, TypeProtos.MinorType, FunctionLookupContext, ErrorCollector) - Static method in class org.apache.drill.exec.expr.ExpressionTreeMaterializer
 
convertToPlan(PhysicalOperator) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
 
convertToPop(Prel) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
 
convertToPrel(RelNode, RelDataType) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
Applies physical rules and certain transformations to convert drill relational node into physical one.
convertToRawDrel(RelNode) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
Given a relNode tree for SELECT statement, convert to Drill Logical RelNode tree.
Copier - Interface in org.apache.drill.exec.physical.impl.svremover
 
COPIER_MAPPING_SET - Variable in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
CopierTemplate2 - Class in org.apache.drill.exec.physical.impl.svremover
 
CopierTemplate2() - Constructor for class org.apache.drill.exec.physical.impl.svremover.CopierTemplate2
 
CopierTemplate4 - Class in org.apache.drill.exec.physical.impl.svremover
 
CopierTemplate4() - Constructor for class org.apache.drill.exec.physical.impl.svremover.CopierTemplate4
 
copy(List<LogicalExpression>) - Method in class org.apache.drill.exec.expr.DrillFuncHolderExpr
 
copy(int) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.logical.DirPrunedEnumerableTableScan
 
copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.drill.exec.planner.logical.DrillAggregateRel
 
copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.drill.exec.planner.logical.DrillFilterRel
 
copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.drill.exec.planner.logical.DrillJoinRel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.logical.DrillLimitRel
 
copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.drill.exec.planner.logical.DrillProjectRel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.logical.DrillScreenRel
 
copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.drill.exec.planner.logical.DrillSortRel
 
copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.drill.exec.planner.logical.DrillUnionRel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.logical.DrillValuesRel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.logical.DrillWindowRel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.logical.DrillWriterRel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.BroadcastExchangePrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.ComplexToJsonPrel
 
copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.drill.exec.planner.physical.FilterPrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.FlattenPrel
 
copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.drill.exec.planner.physical.HashAggPrel
 
copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.drill.exec.planner.physical.HashJoinPrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.HashToMergeExchangePrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.HashToRandomExchangePrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.LimitPrel
 
copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.drill.exec.planner.physical.MergeJoinPrel
 
copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.drill.exec.planner.physical.NestedLoopJoinPrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.OrderedPartitionExchangePrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.ProducerConsumerPrel
 
copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.drill.exec.planner.physical.ProjectAllowDupPrel
 
copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.drill.exec.planner.physical.ProjectPrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.ScanPrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.ScreenPrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.SelectionVectorRemoverPrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.SingleMergeExchangePrel
 
copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.drill.exec.planner.physical.SortPrel
 
copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.drill.exec.planner.physical.StreamAggPrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.TopNPrel
 
copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.drill.exec.planner.physical.UnionAllPrel
 
copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.drill.exec.planner.physical.UnionDistinctPrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.UnionExchangePrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.UnorderedDeMuxExchangePrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.UnorderedMuxExchangePrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.ValuesPrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.WindowPrel
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.WriterPrel
 
copy() - Method in class org.apache.drill.exec.record.DeadBuf
 
copy(int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
copyFromInternal(int, int) - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
 
copyFromLocalFile(Path, Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
copyFromLocalFile(boolean, Path, Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
copyFromLocalFile(boolean, boolean, Path[], Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
copyFromLocalFile(boolean, boolean, Path, Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
copyLeftMapping - Variable in class org.apache.drill.exec.physical.impl.join.MergeJoinBatch
 
copyMapping - Static variable in interface org.apache.drill.exec.physical.impl.mergereceiver.MergingReceiverGeneratorBase
 
copyNext(int, int) - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
copies value(s) from inIndex row to outIndex row.
copyPrev(int, int) - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
copies value(s) from inIndex row to outIndex row.
copyRecords(int, int, int) - Method in interface org.apache.drill.exec.physical.impl.orderedpartitioner.SampleCopier
 
copyRecords(int, int, int) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.SampleCopierTemplate
 
copyRecords(int, int) - Method in interface org.apache.drill.exec.physical.impl.svremover.Copier
 
copyRecords(int, int) - Method in class org.apache.drill.exec.physical.impl.svremover.CopierTemplate2
 
copyRecords(int, int) - Method in class org.apache.drill.exec.physical.impl.svremover.CopierTemplate4
 
copyRightMappping - Variable in class org.apache.drill.exec.physical.impl.join.MergeJoinBatch
 
copyToLocalFile(Path, Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
copyToLocalFile(boolean, Path, Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
copyToLocalFile(boolean, Path, Path, boolean) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
CopyUtil - Class in org.apache.drill.exec.vector
 
CopyUtil() - Constructor for class org.apache.drill.exec.vector.CopyUtil
 
CORR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CORRECT_CORRUPT_DATE_SHIFT - Static variable in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
All old parquet files (which haven't "is.date.correct=true" or "parquet-writer.version" properties in metadata) have a corrupt date shift: 4881176L days or 2 * 2440588L
correctBinaryInMetadataCache(Metadata.ParquetTableMetadataBase) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
Checks assigns byte arrays to min/max values obtained from the deserialized string for BINARY.
correctDatesInMetadataCache(Metadata.ParquetTableMetadataBase) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
 
CorrelationFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions
 
CorrelationFunctions.BigIntCorrelation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.BigIntCorrelation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.BigIntCorrelation
 
CorrelationFunctions.Float4Correlation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.Float4Correlation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.Float4Correlation
 
CorrelationFunctions.Float8Correlation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.Float8Correlation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.Float8Correlation
 
CorrelationFunctions.IntCorrelation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.IntCorrelation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.IntCorrelation
 
CorrelationFunctions.NullableBigIntCorrelation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.NullableBigIntCorrelation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableBigIntCorrelation
 
CorrelationFunctions.NullableFloat4Correlation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.NullableFloat4Correlation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableFloat4Correlation
 
CorrelationFunctions.NullableFloat8Correlation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.NullableFloat8Correlation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableFloat8Correlation
 
CorrelationFunctions.NullableIntCorrelation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.NullableIntCorrelation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableIntCorrelation
 
CorrelationFunctions.NullableSmallIntCorrelation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.NullableSmallIntCorrelation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableSmallIntCorrelation
 
CorrelationFunctions.NullableTinyIntCorrelation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.NullableTinyIntCorrelation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableTinyIntCorrelation
 
CorrelationFunctions.NullableUInt1Correlation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.NullableUInt1Correlation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt1Correlation
 
CorrelationFunctions.NullableUInt2Correlation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.NullableUInt2Correlation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt2Correlation
 
CorrelationFunctions.NullableUInt4Correlation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.NullableUInt4Correlation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt4Correlation
 
CorrelationFunctions.NullableUInt8Correlation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.NullableUInt8Correlation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt8Correlation
 
CorrelationFunctions.SmallIntCorrelation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.SmallIntCorrelation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.SmallIntCorrelation
 
CorrelationFunctions.TinyIntCorrelation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.TinyIntCorrelation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.TinyIntCorrelation
 
CorrelationFunctions.UInt1Correlation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.UInt1Correlation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt1Correlation
 
CorrelationFunctions.UInt2Correlation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.UInt2Correlation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt2Correlation
 
CorrelationFunctions.UInt4Correlation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.UInt4Correlation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt4Correlation
 
CorrelationFunctions.UInt8Correlation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CorrelationFunctions.UInt8Correlation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt8Correlation
 
CORRESPONDING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
count - Variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager.MergeTask
 
COUNT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
count - Variable in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
The number of valid bytes in internalBuffer.
countDown() - Method in interface org.apache.drill.exec.testing.CountDownLatchInjection
Decrements the count of the latch, releasing all waiting threads if the count reaches zero.
countDown() - Method in class org.apache.drill.exec.testing.CountDownLatchInjectionImpl
 
CountDownLatchInjection - Interface in org.apache.drill.exec.testing
This class is used internally for tracking injected countdown latches.
CountDownLatchInjectionImpl - Class in org.apache.drill.exec.testing
See CountDownLatchInjection Degenerates to PauseInjection.pause(), if initialized to zero count.
Counter - Interface in org.apache.drill.exec.cache
 
CountFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions
 
CountFunctions.BigIntCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.BigIntCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.BigIntCountFunction
 
CountFunctions.BitCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.BitCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.BitCountFunction
 
CountFunctions.DateCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.DateCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.DateCountFunction
 
CountFunctions.Decimal18CountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.Decimal18CountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal18CountFunction
 
CountFunctions.Decimal28SparseCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.Decimal28SparseCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal28SparseCountFunction
 
CountFunctions.Decimal38SparseCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.Decimal38SparseCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal38SparseCountFunction
 
CountFunctions.Decimal9CountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.Decimal9CountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal9CountFunction
 
CountFunctions.Float4CountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.Float4CountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Float4CountFunction
 
CountFunctions.Float8CountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.Float8CountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Float8CountFunction
 
CountFunctions.IntCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.IntCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntCountFunction
 
CountFunctions.IntervalCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.IntervalCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntervalCountFunction
 
CountFunctions.IntervalDayCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.IntervalDayCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntervalDayCountFunction
 
CountFunctions.IntervalYearCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.IntervalYearCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntervalYearCountFunction
 
CountFunctions.ListCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.ListCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.ListCountFunction
 
CountFunctions.MapCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.MapCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.MapCountFunction
 
CountFunctions.NullableBigIntCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableBigIntCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableBigIntCountFunction
 
CountFunctions.NullableBitCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableBitCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableBitCountFunction
 
CountFunctions.NullableDateCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableDateCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDateCountFunction
 
CountFunctions.NullableDecimal18CountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableDecimal18CountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal18CountFunction
 
CountFunctions.NullableDecimal28SparseCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableDecimal28SparseCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal28SparseCountFunction
 
CountFunctions.NullableDecimal38SparseCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableDecimal38SparseCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal38SparseCountFunction
 
CountFunctions.NullableDecimal9CountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableDecimal9CountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal9CountFunction
 
CountFunctions.NullableFloat4CountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableFloat4CountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableFloat4CountFunction
 
CountFunctions.NullableFloat8CountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableFloat8CountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableFloat8CountFunction
 
CountFunctions.NullableIntCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableIntCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntCountFunction
 
CountFunctions.NullableIntervalCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableIntervalCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntervalCountFunction
 
CountFunctions.NullableIntervalDayCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableIntervalDayCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntervalDayCountFunction
 
CountFunctions.NullableIntervalYearCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableIntervalYearCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntervalYearCountFunction
 
CountFunctions.NullableTimeCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableTimeCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableTimeCountFunction
 
CountFunctions.NullableTimeStampCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableTimeStampCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableTimeStampCountFunction
 
CountFunctions.NullableVarBinaryCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableVarBinaryCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableVarBinaryCountFunction
 
CountFunctions.NullableVarCharCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.NullableVarCharCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableVarCharCountFunction
 
CountFunctions.RepeatedBigIntCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedBigIntCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedBigIntCountFunction
 
CountFunctions.RepeatedBitCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedBitCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedBitCountFunction
 
CountFunctions.RepeatedDateCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedDateCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDateCountFunction
 
CountFunctions.RepeatedDecimal18CountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedDecimal18CountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal18CountFunction
 
CountFunctions.RepeatedDecimal28SparseCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedDecimal28SparseCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal28SparseCountFunction
 
CountFunctions.RepeatedDecimal38SparseCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedDecimal38SparseCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal38SparseCountFunction
 
CountFunctions.RepeatedDecimal9CountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedDecimal9CountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal9CountFunction
 
CountFunctions.RepeatedFloat4CountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedFloat4CountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedFloat4CountFunction
 
CountFunctions.RepeatedFloat8CountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedFloat8CountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedFloat8CountFunction
 
CountFunctions.RepeatedIntCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedIntCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntCountFunction
 
CountFunctions.RepeatedIntervalCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedIntervalCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntervalCountFunction
 
CountFunctions.RepeatedIntervalDayCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedIntervalDayCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntervalDayCountFunction
 
CountFunctions.RepeatedIntervalYearCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedIntervalYearCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntervalYearCountFunction
 
CountFunctions.RepeatedListCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedListCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedListCountFunction
 
CountFunctions.RepeatedMapCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedMapCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedMapCountFunction
 
CountFunctions.RepeatedTimeCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedTimeCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedTimeCountFunction
 
CountFunctions.RepeatedTimeStampCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedTimeStampCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedTimeStampCountFunction
 
CountFunctions.RepeatedVarBinaryCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedVarBinaryCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedVarBinaryCountFunction
 
CountFunctions.RepeatedVarCharCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.RepeatedVarCharCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedVarCharCountFunction
 
CountFunctions.TimeCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.TimeCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.TimeCountFunction
 
CountFunctions.TimeStampCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.TimeStampCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.TimeStampCountFunction
 
CountFunctions.VarBinaryCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.VarBinaryCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.VarBinaryCountFunction
 
CountFunctions.VarCharCountFunction - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CountFunctions.VarCharCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.VarCharCountFunction
 
CountingJsonReader - Class in org.apache.drill.exec.store.easy.json.reader
 
CountingJsonReader(DrillBuf) - Constructor for class org.apache.drill.exec.store.easy.json.reader.CountingJsonReader
 
COVAR_POP - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
COVAR_SAMP - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CoVariancePopulationFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions
 
CoVariancePopulationFunctions.BigIntCoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.BigIntCoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.BigIntCoVariancePopulation
 
CoVariancePopulationFunctions.Float4CoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.Float4CoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.Float4CoVariancePopulation
 
CoVariancePopulationFunctions.Float8CoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.Float8CoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.Float8CoVariancePopulation
 
CoVariancePopulationFunctions.IntCoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.IntCoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.IntCoVariancePopulation
 
CoVariancePopulationFunctions.NullableBigIntCoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.NullableBigIntCoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableBigIntCoVariancePopulation
 
CoVariancePopulationFunctions.NullableFloat4CoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.NullableFloat4CoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableFloat4CoVariancePopulation
 
CoVariancePopulationFunctions.NullableFloat8CoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.NullableFloat8CoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableFloat8CoVariancePopulation
 
CoVariancePopulationFunctions.NullableIntCoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.NullableIntCoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableIntCoVariancePopulation
 
CoVariancePopulationFunctions.NullableSmallIntCoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.NullableSmallIntCoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableSmallIntCoVariancePopulation
 
CoVariancePopulationFunctions.NullableTinyIntCoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.NullableTinyIntCoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableTinyIntCoVariancePopulation
 
CoVariancePopulationFunctions.NullableUInt1CoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.NullableUInt1CoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt1CoVariancePopulation
 
CoVariancePopulationFunctions.NullableUInt2CoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.NullableUInt2CoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt2CoVariancePopulation
 
CoVariancePopulationFunctions.NullableUInt4CoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.NullableUInt4CoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt4CoVariancePopulation
 
CoVariancePopulationFunctions.NullableUInt8CoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.NullableUInt8CoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt8CoVariancePopulation
 
CoVariancePopulationFunctions.SmallIntCoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.SmallIntCoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.SmallIntCoVariancePopulation
 
CoVariancePopulationFunctions.TinyIntCoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.TinyIntCoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.TinyIntCoVariancePopulation
 
CoVariancePopulationFunctions.UInt1CoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.UInt1CoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt1CoVariancePopulation
 
CoVariancePopulationFunctions.UInt2CoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.UInt2CoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt2CoVariancePopulation
 
CoVariancePopulationFunctions.UInt4CoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.UInt4CoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt4CoVariancePopulation
 
CoVariancePopulationFunctions.UInt8CoVariancePopulation - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVariancePopulationFunctions.UInt8CoVariancePopulation() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt8CoVariancePopulation
 
CoVarianceSampleFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions
 
CoVarianceSampleFunctions.BigIntCoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.BigIntCoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.BigIntCoVarianceSample
 
CoVarianceSampleFunctions.Float4CoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.Float4CoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.Float4CoVarianceSample
 
CoVarianceSampleFunctions.Float8CoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.Float8CoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.Float8CoVarianceSample
 
CoVarianceSampleFunctions.IntCoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.IntCoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.IntCoVarianceSample
 
CoVarianceSampleFunctions.NullableBigIntCoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.NullableBigIntCoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableBigIntCoVarianceSample
 
CoVarianceSampleFunctions.NullableFloat4CoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.NullableFloat4CoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableFloat4CoVarianceSample
 
CoVarianceSampleFunctions.NullableFloat8CoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.NullableFloat8CoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableFloat8CoVarianceSample
 
CoVarianceSampleFunctions.NullableIntCoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.NullableIntCoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableIntCoVarianceSample
 
CoVarianceSampleFunctions.NullableSmallIntCoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.NullableSmallIntCoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableSmallIntCoVarianceSample
 
CoVarianceSampleFunctions.NullableTinyIntCoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.NullableTinyIntCoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableTinyIntCoVarianceSample
 
CoVarianceSampleFunctions.NullableUInt1CoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.NullableUInt1CoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt1CoVarianceSample
 
CoVarianceSampleFunctions.NullableUInt2CoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.NullableUInt2CoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt2CoVarianceSample
 
CoVarianceSampleFunctions.NullableUInt4CoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.NullableUInt4CoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt4CoVarianceSample
 
CoVarianceSampleFunctions.NullableUInt8CoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.NullableUInt8CoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt8CoVarianceSample
 
CoVarianceSampleFunctions.SmallIntCoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.SmallIntCoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.SmallIntCoVarianceSample
 
CoVarianceSampleFunctions.TinyIntCoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.TinyIntCoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.TinyIntCoVarianceSample
 
CoVarianceSampleFunctions.UInt1CoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.UInt1CoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt1CoVarianceSample
 
CoVarianceSampleFunctions.UInt2CoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.UInt2CoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt2CoVarianceSample
 
CoVarianceSampleFunctions.UInt4CoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.UInt4CoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt4CoVarianceSample
 
CoVarianceSampleFunctions.UInt8CoVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
CoVarianceSampleFunctions.UInt8CoVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt8CoVarianceSample
 
CP_PLUGIN_NAME - Static variable in class org.apache.drill.exec.util.StoragePluginTestUtils
 
CPU_LOAD_AVERAGE - Static variable in class org.apache.drill.exec.ExecConstants
 
CPU_LOAD_AVERAGE_KEY - Static variable in class org.apache.drill.exec.ExecConstants
Limits the maximum level of parallelization to this factor time the number of Drillbits
cpusPerNode() - Method in class org.apache.drill.exec.work.foreman.rm.AbstractResourceManager
 
cpusPerNode - Variable in class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager
 
cpusPerNode() - Method in class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager
 
cpusPerNode() - Method in class org.apache.drill.exec.work.foreman.rm.DynamicResourceManager
 
cpusPerNode() - Method in interface org.apache.drill.exec.work.foreman.rm.ResourceManager
 
create(Type, ValueHolderIden, int, List<ReplacingBasicValue>) - Static method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
Create a new value representing a holder (boxed value).
create(String, String, String, String) - Static method in class org.apache.drill.exec.compile.sig.GeneratorMapping
 
create(String) - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
Creates the given path without placing any data in.
create(DrillFileSystem, FileStatus) - Static method in class org.apache.drill.exec.dotdrill.DotDrillFile
 
create(int, int) - Static method in class org.apache.drill.exec.planner.fragment.ParallelizationInfo
 
create(int, int, List<EndpointAffinity>) - Static method in class org.apache.drill.exec.planner.fragment.ParallelizationInfo
 
create(RelOptCluster, RelOptTable, String) - Static method in class org.apache.drill.exec.planner.logical.DirPrunedEnumerableTableScan
Creates an DirPrunedEnumerableTableScan.
create(RelNode, RexNode) - Static method in class org.apache.drill.exec.planner.logical.DrillFilterRel
 
create(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Static method in class org.apache.drill.exec.planner.logical.DrillProjectRel
provide a public method to create an instance of DrillProjectRel.
create(RelNode, RelTraitSet, GroupScan, RelDataType) - Static method in class org.apache.drill.exec.planner.physical.ScanPrel
 
create(KEY) - Method in interface org.apache.drill.exec.planner.sql.ExpandingConcurrentMap.MapValueFactory
 
CREATE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
create(MaterializedField, T[], boolean) - Static method in class org.apache.drill.exec.record.HyperVectorWrapper
 
create(T) - Static method in class org.apache.drill.exec.record.SimpleVectorWrapper
 
create(OptionValue.AccessibleScopes, String, long, OptionValue.OptionScope) - Static method in class org.apache.drill.exec.server.options.OptionValue
 
create(OptionValue.AccessibleScopes, String, boolean, OptionValue.OptionScope) - Static method in class org.apache.drill.exec.server.options.OptionValue
 
create(OptionValue.AccessibleScopes, String, String, OptionValue.OptionScope) - Static method in class org.apache.drill.exec.server.options.OptionValue
 
create(OptionValue.AccessibleScopes, String, double, OptionValue.OptionScope) - Static method in class org.apache.drill.exec.server.options.OptionValue
 
create(OptionValue.Kind, OptionValue.AccessibleScopes, String, String, OptionValue.OptionScope) - Static method in class org.apache.drill.exec.server.options.OptionValue
 
create(OptionValue.AccessibleScopes, String, Object, OptionValue.OptionScope) - Static method in class org.apache.drill.exec.server.options.OptionValue
 
create(boolean, String, SecurityContext) - Static method in class org.apache.drill.exec.server.rest.ViewableWithPermissions
Create the web page using the given template and SecurityContext after authentication is done.
create(boolean, String, SecurityContext, Object) - Static method in class org.apache.drill.exec.server.rest.ViewableWithPermissions
Create a web page using the given template, SecurityContext and model data.
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.drill.exec.store.ClassPathFileSystem
 
create(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
create(Path, boolean) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
create(Path, Progressable) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
create(Path, short) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
create(Path, short, Progressable) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
create(Path, boolean, int) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
create(Path, boolean, int, Progressable) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
create(Path, boolean, int, short, long) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
create(Path, boolean, int, short, long, Progressable) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
create(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable, Options.ChecksumOpt) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
create(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
create(DrillFileSystem, String, String, boolean) - Static method in class org.apache.drill.exec.store.dfs.FileSelection
 
create(List<FileStatus>, List<String>, String, String, boolean) - Static method in class org.apache.drill.exec.store.dfs.FileSelection
Creates a selection with the given file statuses/files and selection root.
create(List<FileStatus>, List<String>, String) - Static method in class org.apache.drill.exec.store.dfs.FileSelection
 
create(WorkspaceSchemaFactory.TableInstance) - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
create(String, TypeProtos.MajorType) - Static method in class org.apache.drill.exec.store.ischema.InfoSchemaTable.Field
 
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem
 
create2PhasePlan(RelOptRuleCall, DrillAggregateRel) - Method in class org.apache.drill.exec.planner.physical.AggPruleBase
 
CREATE_PREPARE_STATEMENT_TIMEOUT_MILLIS - Static variable in class org.apache.drill.exec.ExecConstants
Timeout for create prepare statement request.
CREATE_PREPARE_STATEMENT_TIMEOUT_MILLIS_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
createAndLoginUser(Map<String, ?>) - Method in interface org.apache.drill.exec.rpc.security.AuthenticatorFactory
Create and get the login user based on the given properties.
createAndLoginUser(Map<String, ?>) - Method in class org.apache.drill.exec.rpc.security.kerberos.KerberosFactory
 
createAndLoginUser(Map<String, ?>) - Method in class org.apache.drill.exec.rpc.security.plain.PlainFactory
 
createAndSetupHashTable(TypedFieldId[], int) - Method in class org.apache.drill.exec.physical.impl.common.ChainedHashTable
 
createAuthenticator(DrillConfig, ScanResult) - Static method in class org.apache.drill.exec.rpc.user.security.UserAuthenticatorFactory
Create a UserAuthenticator implementation based on BOOT settings in given drillConfig.
createBroadcastPlan(RelOptRuleCall, DrillJoinRel, RexNode, JoinPruleBase.PhysicalJoinType, RelNode, RelNode, RelCollation, RelCollation) - Method in class org.apache.drill.exec.planner.physical.JoinPruleBase
 
createCalciteTypeWithNullability(RelDataTypeFactory, SqlTypeName, boolean) - Static method in class org.apache.drill.exec.planner.sql.TypeInferenceUtils
Given a SqlTypeName and nullability, create a RelDataType from the RelDataTypeFactory
createCall(String, List<T>) - Method in interface org.apache.drill.exec.planner.physical.HashPrelUtil.HashExpressionCreatorHelper
 
createCall(String, List<RexNode>) - Method in class org.apache.drill.exec.planner.physical.visitor.InsertLocalExchangeVisitor.RexNodeBasedHashExpressionCreatorHelper
 
createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
createComplexWriterRef(String) - Static method in class org.apache.drill.exec.expr.fn.ValueReference
 
createCondition(SqlNode, SqlOperator, SqlNode) - Static method in class org.apache.drill.exec.planner.sql.parser.DrillParserUtil
 
createConverter() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserWithCompoundIdConverter
 
createCursor() - Method in class org.apache.drill.exec.compile.FsmDescriptor
Create a cursor for performing and validating transitions according to this state machine.
createDefaultOptionDefinitions() - Static method in class org.apache.drill.exec.server.options.SystemOptionManager
Creates all the OptionDefinitions to be registered with the SystemOptionManager.
createDirectPlan(QueryContext, boolean, String) - Static method in class org.apache.drill.exec.planner.sql.DirectPlan
 
createDirectPlan(QueryContext, T) - Static method in class org.apache.drill.exec.planner.sql.DirectPlan
 
createDirectPlan(CoordinationProtos.DrillbitEndpoint, List<T>, Class<T>) - Static method in class org.apache.drill.exec.planner.sql.DirectPlan
 
createDistBothPlan(RelOptRuleCall, DrillJoinRel, JoinPruleBase.PhysicalJoinType, RelNode, RelNode, RelCollation, RelCollation, boolean) - Method in class org.apache.drill.exec.planner.physical.JoinPruleBase
 
createEventLoop(int, String) - Static method in class org.apache.drill.exec.client.DrillClient
 
createFieldReaderRef(String) - Static method in class org.apache.drill.exec.expr.fn.ValueReference
 
createFileAndApply(FileSystem, Path) - Method in class org.apache.drill.exec.store.StorageStrategy
Creates passed file on appropriate file system.
createFileSystem(String, Configuration) - Static method in class org.apache.drill.exec.util.ImpersonationUtil
Create DrillFileSystem for given proxyUserName and configuration.
createFromDirectories(List<String>, FileSelection, String) - Static method in class org.apache.drill.exec.store.dfs.FileSelection
 
createFullRootSchema(String, SchemaConfig.SchemaConfigInfoProvider) - Method in class org.apache.drill.exec.store.SchemaTreeProvider
Return full root schema with schema owner as the given user.
createFullRootSchema(SchemaConfig) - Method in class org.apache.drill.exec.store.SchemaTreeProvider
Create and return a Full SchemaTree with given schemaConfig.
CreateFunctionHandler - Class in org.apache.drill.exec.planner.sql.handlers
 
CreateFunctionHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.CreateFunctionHandler
 
createHashBasedPartitionExpression(List<T>, T, HashPrelUtil.HashExpressionCreatorHelper<T>) - Static method in class org.apache.drill.exec.planner.physical.HashPrelUtil
Create hash based partition expression based on the given distribution fields.
createHashExpression(List<T>, T, HashPrelUtil.HashExpressionCreatorHelper<T>, boolean) - Static method in class org.apache.drill.exec.planner.physical.HashPrelUtil
Create hash expression based on the given input fields.
createInnerEvalBlock() - Method in class org.apache.drill.exec.expr.ClassGenerator
Creates an inner braced and indented block for evaluation of the expression.
createInstance(CodeGenerator<?>) - Method in class org.apache.drill.exec.compile.CodeCompiler
Create a single instance of the generated class.
createInstances(CodeGenerator<?>, int) - Method in class org.apache.drill.exec.compile.CodeCompiler
Create multiple instances of the generated class.
createInterpreter() - Method in class org.apache.drill.exec.expr.fn.DrillSimpleFuncHolder
 
createKeysAndExprs() - Method in class org.apache.drill.exec.planner.physical.AggPrelBase
 
createLeftMappingSet() - Static method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
createLoginPage(String) - Static method in class org.apache.drill.exec.server.rest.ViewableWithPermissions
Create a login page.
createMainMappingSet() - Static method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
createMeta(FileSystem, String, ParquetFormatConfig) - Static method in class org.apache.drill.exec.store.parquet.Metadata
Create the parquet metadata file for the directory at the given path, and for any subdirectories
createNewFile(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
createNewPriorityQueue(MappingSet, MappingSet, MappingSet, OptionSet, FunctionLookupContext, CodeCompiler, List<Order.Ordering>, VectorAccessible, boolean, boolean, int, BufferAllocator, BatchSchema.SelectionVectorMode) - Static method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
createNewRowType(RelDataTypeFactory) - Method in class org.apache.drill.exec.planner.physical.PrelUtil.ProjectPushInfo
 
createNewSorter(FragmentContext, List<Order.Ordering>, VectorAccessible) - Static method in class org.apache.drill.exec.physical.impl.sort.SortBatch
 
createNewSorter(FragmentContext, List<Order.Ordering>, VectorAccessible, MappingSet, MappingSet, MappingSet) - Static method in class org.apache.drill.exec.physical.impl.sort.SortBatch
 
createNewSorter(FragmentContext, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch
 
createNewTable(String, List<String>, StorageStrategy) - Method in class org.apache.drill.exec.store.AbstractSchema
Creates table entry using table name, list of partition columns and storage strategy used to create table folder and files
createNewTable(String, List<String>) - Method in class org.apache.drill.exec.store.AbstractSchema
Creates table entry using table name and list of partition columns if any.
createNewTable(String, List<String>, StorageStrategy) - Method in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory.FileSystemSchema
 
createNewTable(String, List<String>, StorageStrategy) - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
createNewTable(String, List<String>, StorageStrategy) - Method in class org.apache.drill.exec.store.SubSchemaWrapper
 
createNewWrapperCurrent(int) - Method in class org.apache.drill.exec.record.selection.SelectionVector4
Caution: This method shares the underlying buffer between this vector and the newly created one.
createNewWrapperCurrent() - Method in class org.apache.drill.exec.record.selection.SelectionVector4
Caution: This method shares the underlying buffer between this vector and the newly created one.
createNonExistentColumns(OutputMutator, List<NullableIntVector>) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetSchema
Create "dummy" fields for columns which are selected in the SELECT clause, but not present in the Parquet schema.
createNonRecursive(Path, boolean, int, short, long, Progressable) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
Deprecated.
createNonRecursive(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
Deprecated.
createNonRecursive(Path, FsPermission, EnumSet<CreateFlag>, int, short, long, Progressable) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
Deprecated.
createOrUpdate(String, StoragePluginConfig, boolean) - Method in interface org.apache.drill.exec.store.StoragePluginRegistry
Create a plugin by name and configuration.
createOrUpdate(String, StoragePluginConfig, boolean) - Method in class org.apache.drill.exec.store.StoragePluginRegistryImpl
 
createOrUpdateInStorage(StoragePluginRegistry) - Method in class org.apache.drill.exec.server.rest.PluginConfigWrapper
 
createOrUpdatePlugin(String, String) - Method in class org.apache.drill.exec.server.rest.StorageResources
 
createOrUpdatePluginJSON(PluginConfigWrapper) - Method in class org.apache.drill.exec.server.rest.StorageResources
 
createPartitioner() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec
 
createPartitionSublists() - Method in class org.apache.drill.exec.planner.AbstractPartitionDescriptor
Create sublists of the partition locations, each sublist of size at most PartitionDescriptor.PARTITION_BATCH_SIZE
createPartitionSublists() - Method in class org.apache.drill.exec.planner.FileSystemPartitionDescriptor
 
createPartitionSublists() - Method in class org.apache.drill.exec.planner.ParquetPartitionDescriptor
 
createPathAndApply(FileSystem, Path) - Method in class org.apache.drill.exec.store.StorageStrategy
Creates passed path on appropriate file system.
createPreparedStatement(String) - Method in class org.apache.drill.exec.client.DrillClient
Create a prepared statement for given query.
createProxyUgi(String, String) - Static method in class org.apache.drill.exec.util.ImpersonationUtil
Create and return proxy user UserGroupInformation of operator owner if operator owner is valid.
createProxyUgi(String) - Static method in class org.apache.drill.exec.util.ImpersonationUtil
Create and return proxy user UserGroupInformation for give user name.
createQueryContextInfo(String, String) - Static method in class org.apache.drill.exec.util.Utilities
Create QueryContextInformation with given defaultSchemaName.
createRename(RelNode, List<String>) - Static method in class org.apache.drill.exec.planner.common.DrillRelOptUtil
Returns a relational expression which has the same fields as the underlying expression, but the fields have different names.
createRightMappingSet() - Static method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
createRootSchema(StoragePluginRegistry, SchemaConfig) - Static method in class org.apache.drill.exec.planner.sql.DynamicSchema
 
createRootSchema(OptionManager) - Method in class org.apache.drill.exec.store.SchemaTreeProvider
Return root schema for process user.
createRootSchema(String, SchemaConfig.SchemaConfigInfoProvider) - Method in class org.apache.drill.exec.store.SchemaTreeProvider
Return root schema with schema owner as the given user.
createRootSchema(SchemaConfig) - Method in class org.apache.drill.exec.store.SchemaTreeProvider
Create and return a SchemaTree with given schemaConfig.
createSaslClient(UserGroupInformation, Map<String, ?>) - Method in interface org.apache.drill.exec.rpc.security.AuthenticatorFactory
The caller is responsible for disposing the returned SaslClient.
createSaslClient(String[], String, String, String, Map<String, ?>, CallbackHandler) - Method in class org.apache.drill.exec.rpc.security.FastSaslClientFactory
 
createSaslClient(UserGroupInformation, Map<String, ?>) - Method in class org.apache.drill.exec.rpc.security.kerberos.KerberosFactory
 
createSaslClient(UserGroupInformation, Map<String, ?>) - Method in class org.apache.drill.exec.rpc.security.plain.PlainFactory
 
createSaslServer(UserGroupInformation, Map<String, ?>) - Method in interface org.apache.drill.exec.rpc.security.AuthenticatorFactory
The caller is responsible for disposing the returned SaslServer.
createSaslServer(String, String, String, Map<String, ?>, CallbackHandler) - Method in class org.apache.drill.exec.rpc.security.FastSaslServerFactory
 
createSaslServer(UserGroupInformation, Map<String, ?>) - Method in class org.apache.drill.exec.rpc.security.kerberos.KerberosFactory
 
createSaslServer(UserGroupInformation, Map<String, ?>) - Method in class org.apache.drill.exec.rpc.security.plain.PlainFactory
 
createSchema(List<String>, SchemaConfig, DrillFileSystem) - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory
 
createSenderReceiverMapping() - Method in class org.apache.drill.exec.physical.config.AbstractDeMuxExchange
 
createSenderReceiverMapping() - Method in class org.apache.drill.exec.physical.config.AbstractMuxExchange
 
createSnapshot(Path, String) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
createSSLEngine(BufferAllocator, String, int) - Method in class org.apache.drill.exec.ssl.SSLConfig
 
createSSLEngine(BufferAllocator, String, int) - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
createSSLEngine(BufferAllocator, String, int) - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
createSymlink(Path, Path, boolean) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
CreateTableEntry - Interface in org.apache.drill.exec.planner.logical
Interface that provides the info needed to create a new table.
CreateTableHandler - Class in org.apache.drill.exec.planner.sql.handlers
 
CreateTableHandler(SqlHandlerConfig, Pointer<String>) - Constructor for class org.apache.drill.exec.planner.sql.handlers.CreateTableHandler
 
createTableScan(List<PartitionLocation>, String, boolean, MetadataContext) - Method in class org.apache.drill.exec.planner.AbstractPartitionDescriptor
 
createTableScan(List<PartitionLocation>, String, boolean, MetadataContext) - Method in class org.apache.drill.exec.planner.FileSystemPartitionDescriptor
 
createTableScan(List<PartitionLocation>, boolean) - Method in class org.apache.drill.exec.planner.FileSystemPartitionDescriptor
 
createTableScan(List<PartitionLocation>, String, boolean, MetadataContext) - Method in class org.apache.drill.exec.planner.ParquetPartitionDescriptor
 
createTableScan(List<PartitionLocation>, boolean) - Method in class org.apache.drill.exec.planner.ParquetPartitionDescriptor
 
createTableScan(List<PartitionLocation>, boolean) - Method in interface org.apache.drill.exec.planner.PartitionDescriptor
Methods create a new TableScan rel node, given the lists of new partitions or new files to SCAN.
createTableScan(List<PartitionLocation>, String, boolean, MetadataContext) - Method in interface org.apache.drill.exec.planner.PartitionDescriptor
Create a new TableScan rel node, given the lists of new partitions or new files to scan and a path to a metadata cache file
createView(View) - Method in class org.apache.drill.exec.store.AbstractSchema
Create a new view given definition.
createView(View) - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
createVisitor(RelDataTypeFactory, DrillOperatorTable, RexBuilder) - Static method in class org.apache.drill.exec.planner.logical.PreProcessLogicalRel
 
createVisitor(QueryContext) - Static method in class org.apache.drill.exec.planner.sql.parser.UnsupportedOperatorsVisitor
 
CROSS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CryptoFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
CryptoFunctions.AESDecryptFunction - Class in org.apache.drill.exec.expr.fn.impl
AES_DECRYPT() decrypts the encrypted string crypt_str using the key string key_str and returns the original cleartext string.
CryptoFunctions.AESDecryptFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.AESDecryptFunction
 
CryptoFunctions.AESEncryptFunction - Class in org.apache.drill.exec.expr.fn.impl
aes_encrypt()/ aes_decrypt(): implement encryption and decryption of data using the official AES (Advanced Encryption Standard) algorithm, previously known as “Rijndael.” AES_ENCRYPT() encrypts the string str using the key string key_str and returns a binary string containing the encrypted output.
CryptoFunctions.AESEncryptFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.AESEncryptFunction
 
CryptoFunctions.MD2Function - Class in org.apache.drill.exec.expr.fn.impl
This class returns the md2 digest of a given input string.
CryptoFunctions.MD2Function() - Constructor for class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.MD2Function
 
CryptoFunctions.MD5Function - Class in org.apache.drill.exec.expr.fn.impl
This function returns the MD5 digest of a given input string.
CryptoFunctions.MD5Function() - Constructor for class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.MD5Function
 
CryptoFunctions.SHA1Function - Class in org.apache.drill.exec.expr.fn.impl
sha() / sha1(): Calculates an SHA-1 160-bit checksum for the string, as described in RFC 3174 (Secure Hash Algorithm).
CryptoFunctions.SHA1Function() - Constructor for class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.SHA1Function
 
CryptoFunctions.SHA256Function - Class in org.apache.drill.exec.expr.fn.impl
sha2() / sha256(): Calculates an SHA-2 256-bit checksum for the string.
CryptoFunctions.SHA256Function() - Constructor for class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.SHA256Function
 
CryptoFunctions.SHA384Function - Class in org.apache.drill.exec.expr.fn.impl
This function returns the SHA384 digest of a given input string.
CryptoFunctions.SHA384Function() - Constructor for class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.SHA384Function
 
CryptoFunctions.SHA512Function - Class in org.apache.drill.exec.expr.fn.impl
This function returns the SHA512 digest of a given input string.
CryptoFunctions.SHA512Function() - Constructor for class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.SHA512Function
 
CTAS_PARTITIONING_HASH_DISTRIBUTE - Static variable in class org.apache.drill.exec.ExecConstants
 
CTAS_PARTITIONING_HASH_DISTRIBUTE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
CUBE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
cume_dist - Variable in class org.apache.drill.exec.physical.impl.window.Partition
 
CUME_DIST - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
curChar - Variable in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplTokenManager
 
curPosInBuffer - Variable in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
The current read position in the buffer; the index of the next character to be read from the internalBuffer array.
curPosInStream - Variable in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
 
CURRENT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
current - Variable in class org.apache.drill.exec.store.sys.DrillbitIterator.DrillbitInstance
 
CURRENT_CATALOG - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CURRENT_DATE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CURRENT_DEFAULT_TRANSFORM_GROUP - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CURRENT_PATH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CURRENT_ROLE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CURRENT_SCHEMA - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CURRENT_TIME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CURRENT_TIMESTAMP - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CURRENT_TRANSFORM_GROUP_FOR_TYPE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CURRENT_USER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
currentContainer - Variable in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
currentField - Variable in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
 
currentToken - Variable in exception org.apache.drill.exec.planner.sql.parser.impl.ParseException
This is the last token that has been consumed successfully.
CURSOR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CURSOR_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
CursorExpression(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a CURSOR(query) expression.
CustomHandlerRegistry - Class in org.apache.drill.exec.rpc.control
 
CustomHandlerRegistry() - Constructor for class org.apache.drill.exec.rpc.control.CustomHandlerRegistry
 
CYCLE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 

D

DATA - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
data_port - Variable in class org.apache.drill.exec.store.sys.DrillbitIterator.DrillbitInstance
 
DATA_TYPE - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
dataArrived(QueryDataBatch, ConnectionThrottle) - Method in class org.apache.drill.exec.client.PrintingResultsListener
 
dataArrived(QueryDataBatch, ConnectionThrottle) - Method in class org.apache.drill.exec.rpc.user.AwaitableUserResultsListener
 
dataArrived(QueryDataBatch, ConnectionThrottle) - Method in interface org.apache.drill.exec.rpc.user.UserResultsListener
A QueryData message was received
DATABASE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DATABASES - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DataChangeVersion - Class in org.apache.drill.exec.store.sys.store
 
DataChangeVersion() - Constructor for class org.apache.drill.exec.store.sys.store.DataChangeVersion
 
DataClient - Class in org.apache.drill.exec.rpc.data
 
DataClient(CoordinationProtos.DrillbitEndpoint, DataConnectionConfig, ReconnectingConnection<DataClientConnection, BitData.BitClientHandshake>.CloseHandlerCreator) - Constructor for class org.apache.drill.exec.rpc.data.DataClient
 
DataClientConnection - Class in org.apache.drill.exec.rpc.data
 
DataClientConnection(SocketChannel, DataClient, EncryptionContext) - Constructor for class org.apache.drill.exec.rpc.data.DataClientConnection
 
DataConnectionCreator - Class in org.apache.drill.exec.rpc.data
Manages a connection for each endpoint.
DataConnectionCreator(BootStrapContext, BufferAllocator, WorkEventBus, WorkManager.WorkerBee) - Constructor for class org.apache.drill.exec.rpc.data.DataConnectionCreator
 
DataConnectionManager - Class in org.apache.drill.exec.rpc.data
 
DataConnectionManager(CoordinationProtos.DrillbitEndpoint, DataConnectionConfig) - Constructor for class org.apache.drill.exec.rpc.data.DataConnectionManager
 
DataDefaultInstanceHandler - Class in org.apache.drill.exec.rpc.data
 
DataDefaultInstanceHandler() - Constructor for class org.apache.drill.exec.rpc.data.DataDefaultInstanceHandler
 
DataProtobufLengthDecoder - Class in org.apache.drill.exec.rpc.data
 
DataProtobufLengthDecoder() - Constructor for class org.apache.drill.exec.rpc.data.DataProtobufLengthDecoder
 
DataProtobufLengthDecoder.Client - Class in org.apache.drill.exec.rpc.data
 
DataProtobufLengthDecoder.Client(BufferAllocator, OutOfMemoryHandler) - Constructor for class org.apache.drill.exec.rpc.data.DataProtobufLengthDecoder.Client
 
DataProtobufLengthDecoder.Server - Class in org.apache.drill.exec.rpc.data
 
DataProtobufLengthDecoder.Server(BufferAllocator, OutOfMemoryHandler) - Constructor for class org.apache.drill.exec.rpc.data.DataProtobufLengthDecoder.Server
 
DataRecord - Class in org.apache.drill.exec.schema
 
DataRecord() - Constructor for class org.apache.drill.exec.schema.DataRecord
 
DataRpcConfig - Class in org.apache.drill.exec.rpc.data
 
DataRpcConfig() - Constructor for class org.apache.drill.exec.rpc.data.DataRpcConfig
 
DataRpcMetrics - Class in org.apache.drill.exec.rpc.data
Holds metrics related to bit data rpc layer
DataServer - Class in org.apache.drill.exec.rpc.data
 
DataServer(DataConnectionConfig) - Constructor for class org.apache.drill.exec.rpc.data.DataServer
 
DataServerConnection - Class in org.apache.drill.exec.rpc.data
 
dataSize - Variable in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer.ColumnSize
 
DataTunnel - Class in org.apache.drill.exec.rpc.data
 
DataTunnel(DataConnectionManager) - Constructor for class org.apache.drill.exec.rpc.data.DataTunnel
 
DataType() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
DataValidationMode - Enum in org.apache.drill.exec.physical
 
DATE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DATE - Static variable in interface org.apache.drill.exec.vector.complex.fn.ExtendedTypeName
 
DATE_CORRUPTION_THRESHOLD - Static variable in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
The year 5000 (or 1106685 day from Unix epoch) is chosen as the threshold for auto-detecting date corruption.
DateAccessor - Class in org.apache.drill.exec.vector.accessor
 
DateAccessor(DateVector) - Constructor for class org.apache.drill.exec.vector.accessor.DateAccessor
 
DateBigIntFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
DateBigIntFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateBigIntFunctions
 
DateBigIntFunctions.BigIntDateAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateBigIntFunctions.BigIntDateAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateBigIntFunctions.BigIntDateAddFunction
 
DateBigIntFunctions.DateBigIntAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateBigIntFunctions.DateBigIntAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateBigIntFunctions.DateBigIntAddFunction
 
DateBigIntFunctions.DateBigIntSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateBigIntFunctions.DateBigIntSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateBigIntFunctions.DateBigIntSubtractFunction
 
DateEpochBEConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
DateEpochBEConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.DateEpochBEConvertFrom
 
DateEpochBEConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
DateEpochBEConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.DateEpochBEConvertTo
 
DateEpochConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
DateEpochConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.DateEpochConvertFrom
 
DateEpochConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
DateEpochConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.DateEpochConvertTo
 
DateGen - Class in org.apache.drill.exec.store.mock
Very simple date value generator that produces ISO dates uniformly distributed over the last year.
DateGen() - Constructor for class org.apache.drill.exec.store.mock.DateGen
 
DateIntervalDayFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntervalDayFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntervalDayFunctions
 
DateIntervalDayFunctions.DateIntervalDayAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntervalDayFunctions.DateIntervalDayAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntervalDayFunctions.DateIntervalDayAddFunction
 
DateIntervalDayFunctions.DateIntervalDaySubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntervalDayFunctions.DateIntervalDaySubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntervalDayFunctions.DateIntervalDaySubtractFunction
 
DateIntervalDayFunctions.IntervalDayDateAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntervalDayFunctions.IntervalDayDateAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntervalDayFunctions.IntervalDayDateAddFunction
 
DateIntervalFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntervalFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntervalFunctions
 
DateIntervalFunctions.DateIntervalAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntervalFunctions.DateIntervalAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntervalFunctions.DateIntervalAddFunction
 
DateIntervalFunctions.DateIntervalSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntervalFunctions.DateIntervalSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntervalFunctions.DateIntervalSubtractFunction
 
DateIntervalFunctions.IntervalDateAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntervalFunctions.IntervalDateAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntervalFunctions.IntervalDateAddFunction
 
DateIntervalYearFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntervalYearFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntervalYearFunctions
 
DateIntervalYearFunctions.DateIntervalYearAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntervalYearFunctions.DateIntervalYearAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntervalYearFunctions.DateIntervalYearAddFunction
 
DateIntervalYearFunctions.DateIntervalYearSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntervalYearFunctions.DateIntervalYearSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntervalYearFunctions.DateIntervalYearSubtractFunction
 
DateIntervalYearFunctions.IntervalYearDateAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntervalYearFunctions.IntervalYearDateAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntervalYearFunctions.IntervalYearDateAddFunction
 
DateIntFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntFunctions
 
DateIntFunctions.DateIntAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntFunctions.DateIntAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntFunctions.DateIntAddFunction
 
DateIntFunctions.DateIntSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntFunctions.DateIntSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntFunctions.DateIntSubtractFunction
 
DateIntFunctions.IntDateAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateIntFunctions.IntDateAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateIntFunctions.IntDateAddFunction
 
DateOutputFormat - Enum in org.apache.drill.exec.vector.complex.fn
Describes the default date output format to use for JSON.
DATETIME_INTERVAL_CODE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DATETIME_INTERVAL_PRECISION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DATETIME_PRECISION - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
DateTimeLiteral() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a date/time literal.
DateTypeFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions
 
DateTypeFunctions.AgeDate2Function - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.AgeDate2Function() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.AgeDate2Function
 
DateTypeFunctions.AgeDateFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.AgeDateFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.AgeDateFunction
 
DateTypeFunctions.AgeTimeStamp2Function - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.AgeTimeStamp2Function() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.AgeTimeStamp2Function
 
DateTypeFunctions.AgeTimeStampFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.AgeTimeStampFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.AgeTimeStampFunction
 
DateTypeFunctions.CastTimeStampToTime - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.CastTimeStampToTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.CastTimeStampToTime
 
DateTypeFunctions.CurrentDate - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.CurrentDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.CurrentDate
 
DateTypeFunctions.CurrentTime - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.CurrentTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.CurrentTime
 
DateTypeFunctions.DatePartFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.DatePartFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.DatePartFunction
 
DateTypeFunctions.DateTimeAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.DateTimeAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.DateTimeAddFunction
 
DateTypeFunctions.DateType - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.DateType() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.DateType
 
DateTypeFunctions.IntervalDayType - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.IntervalDayType() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IntervalDayType
 
DateTypeFunctions.IntervalType - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.IntervalType() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IntervalType
 
DateTypeFunctions.IntervalYearType - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.IntervalYearType() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IntervalYearType
 
DateTypeFunctions.IsDate - Class in org.apache.drill.exec.expr.fn.impl
Function to check if a varchar value can be cast to a date.
DateTypeFunctions.IsDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IsDate
 
DateTypeFunctions.IsDateRequiredInput - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.IsDateRequiredInput() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IsDateRequiredInput
 
DateTypeFunctions.LocalTimeStampNiladic - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.LocalTimeStampNiladic() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.LocalTimeStampNiladic
 
DateTypeFunctions.LocalTimeStampNonNiladic - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.LocalTimeStampNonNiladic() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.LocalTimeStampNonNiladic
 
DateTypeFunctions.TimeDateAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.TimeDateAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeDateAddFunction
 
DateTypeFunctions.TimeOfDay - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.TimeOfDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeOfDay
 
DateTypeFunctions.TimeStampType - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.TimeStampType() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeStampType
 
DateTypeFunctions.TimeType - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.TimeType() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeType
 
DateTypeFunctions.UnixTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.UnixTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.UnixTimeStamp
 
DateTypeFunctions.UnixTimeStampForDate - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.UnixTimeStampForDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.UnixTimeStampForDate
 
DateTypeFunctions.UnixTimeStampForDateWithPattern - Class in org.apache.drill.exec.expr.fn.impl
 
DateTypeFunctions.UnixTimeStampForDateWithPattern() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.UnixTimeStampForDateWithPattern
 
DAY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DEAD_BUFFER - Static variable in class org.apache.drill.exec.record.DeadBuf
 
DeadBuf - Class in org.apache.drill.exec.record
 
DEALLOCATE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
debug - Variable in class org.apache.drill.exec.compile.AbstractClassCompiler
 
debugStream - Variable in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplTokenManager
 
DebugStringBuilder - Class in org.apache.drill.exec.expr
Utility class to build a debug string for an object in a standard format.
DebugStringBuilder(Object) - Constructor for class org.apache.drill.exec.expr.DebugStringBuilder
 
DEC - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
decConnectionCount() - Method in class org.apache.drill.exec.rpc.control.ControlRpcMetrics
 
decConnectionCount() - Method in class org.apache.drill.exec.rpc.data.DataRpcMetrics
 
decConnectionCount() - Method in class org.apache.drill.exec.rpc.user.UserRpcMetrics
 
decConnectionCounter() - Method in class org.apache.drill.exec.rpc.control.ControlConnection
 
decConnectionCounter() - Method in class org.apache.drill.exec.rpc.data.DataClientConnection
 
decConnectionCounter() - Method in class org.apache.drill.exec.rpc.data.DataServerConnection
 
decConnectionCounter() - Method in class org.apache.drill.exec.rpc.user.UserClient.UserToBitConnection
 
decConnectionCounter() - Method in class org.apache.drill.exec.rpc.user.UserServer.BitToUserConnection
 
DECIMAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DECIMAL - Static variable in interface org.apache.drill.exec.vector.complex.fn.ExtendedTypeName
 
Decimal18Accessor - Class in org.apache.drill.exec.vector.accessor
 
Decimal18Accessor(Decimal18Vector) - Constructor for class org.apache.drill.exec.vector.accessor.Decimal18Accessor
 
Decimal18Functions - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions
 
Decimal18Functions.Decimal18AbsFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18AbsFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18AbsFunction
 
Decimal18Functions.Decimal18AddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18AddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18AddFunction
 
Decimal18Functions.Decimal18CeilFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18CeilFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18CeilFunction
 
Decimal18Functions.Decimal18DivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18DivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18DivideFunction
 
Decimal18Functions.Decimal18Equal - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18Equal() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18Equal
 
Decimal18Functions.Decimal18FloorFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18FloorFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18FloorFunction
 
Decimal18Functions.Decimal18GreaterThan - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18GreaterThan() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18GreaterThan
 
Decimal18Functions.Decimal18GreaterThanEq - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18GreaterThanEq() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18GreaterThanEq
 
Decimal18Functions.Decimal18LessThan - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18LessThan() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18LessThan
 
Decimal18Functions.Decimal18LessThanEq - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18LessThanEq() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18LessThanEq
 
Decimal18Functions.Decimal18ModFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18ModFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18ModFunction
 
Decimal18Functions.Decimal18MultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18MultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18MultiplyFunction
 
Decimal18Functions.Decimal18NotEqual - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18NotEqual() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18NotEqual
 
Decimal18Functions.Decimal18RoundFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18RoundFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18RoundFunction
 
Decimal18Functions.Decimal18RoundScaleFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18RoundScaleFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18RoundScaleFunction
 
Decimal18Functions.Decimal18SignFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18SignFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18SignFunction
 
Decimal18Functions.Decimal18SubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18SubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18SubtractFunction
 
Decimal18Functions.Decimal18TruncateScaleFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18TruncateScaleFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18TruncateScaleFunction
 
Decimal18Functions.Decimal18TruncFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.Decimal18TruncFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18TruncFunction
 
Decimal18Functions.GCompareDecimal18VsDecimal18NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.GCompareDecimal18VsDecimal18NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareDecimal18VsDecimal18NullHigh
 
Decimal18Functions.GCompareDecimal18VsDecimal18NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.GCompareDecimal18VsDecimal18NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareDecimal18VsDecimal18NullLow
 
Decimal18Functions.GCompareDecimal18VsNullableDecimal18NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.GCompareDecimal18VsNullableDecimal18NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareDecimal18VsNullableDecimal18NullHigh
 
Decimal18Functions.GCompareDecimal18VsNullableDecimal18NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.GCompareDecimal18VsNullableDecimal18NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareDecimal18VsNullableDecimal18NullLow
 
Decimal18Functions.GCompareNullableDecimal18VsDecimal18NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.GCompareNullableDecimal18VsDecimal18NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareNullableDecimal18VsDecimal18NullHigh
 
Decimal18Functions.GCompareNullableDecimal18VsDecimal18NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.GCompareNullableDecimal18VsDecimal18NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareNullableDecimal18VsDecimal18NullLow
 
Decimal18Functions.GCompareNullableDecimal18VsNullableDecimal18NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.GCompareNullableDecimal18VsNullableDecimal18NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareNullableDecimal18VsNullableDecimal18NullHigh
 
Decimal18Functions.GCompareNullableDecimal18VsNullableDecimal18NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal18Functions.GCompareNullableDecimal18VsNullableDecimal18NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareNullableDecimal18VsNullableDecimal18NullLow
 
Decimal28DenseAccessor - Class in org.apache.drill.exec.vector.accessor
 
Decimal28DenseAccessor(Decimal28DenseVector) - Constructor for class org.apache.drill.exec.vector.accessor.Decimal28DenseAccessor
 
Decimal28DenseFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28DenseFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions
 
Decimal28DenseFunctions.Decimal28DenseEqual - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28DenseFunctions.Decimal28DenseEqual() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseEqual
 
Decimal28DenseFunctions.Decimal28DenseGreaterThan - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28DenseFunctions.Decimal28DenseGreaterThan() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseGreaterThan
 
Decimal28DenseFunctions.Decimal28DenseGreaterThanEq - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28DenseFunctions.Decimal28DenseGreaterThanEq() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseGreaterThanEq
 
Decimal28DenseFunctions.Decimal28DenseLessThan - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28DenseFunctions.Decimal28DenseLessThan() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseLessThan
 
Decimal28DenseFunctions.Decimal28DenseLessThanEq - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28DenseFunctions.Decimal28DenseLessThanEq() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseLessThanEq
 
Decimal28DenseFunctions.Decimal28DenseNotEqual - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28DenseFunctions.Decimal28DenseNotEqual() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseNotEqual
 
Decimal28DenseFunctions.GCompareDecimal28DenseVsDecimal28DenseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28DenseFunctions.GCompareDecimal28DenseVsDecimal28DenseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareDecimal28DenseVsDecimal28DenseNullHigh
 
Decimal28DenseFunctions.GCompareDecimal28DenseVsDecimal28DenseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28DenseFunctions.GCompareDecimal28DenseVsDecimal28DenseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareDecimal28DenseVsDecimal28DenseNullLow
 
Decimal28DenseFunctions.GCompareDecimal28DenseVsNullableDecimal28DenseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28DenseFunctions.GCompareDecimal28DenseVsNullableDecimal28DenseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareDecimal28DenseVsNullableDecimal28DenseNullHigh
 
Decimal28DenseFunctions.GCompareDecimal28DenseVsNullableDecimal28DenseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28DenseFunctions.GCompareDecimal28DenseVsNullableDecimal28DenseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareDecimal28DenseVsNullableDecimal28DenseNullLow
 
Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsDecimal28DenseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsDecimal28DenseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsDecimal28DenseNullHigh
 
Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsDecimal28DenseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsDecimal28DenseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsDecimal28DenseNullLow
 
Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsNullableDecimal28DenseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsNullableDecimal28DenseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsNullableDecimal28DenseNullHigh
 
Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsNullableDecimal28DenseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsNullableDecimal28DenseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsNullableDecimal28DenseNullLow
 
Decimal28SparseAccessor - Class in org.apache.drill.exec.vector.accessor
 
Decimal28SparseAccessor(Decimal28SparseVector) - Constructor for class org.apache.drill.exec.vector.accessor.Decimal28SparseAccessor
 
Decimal28SparseFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions
 
Decimal28SparseFunctions.Decimal28SparseAbsFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseAbsFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseAbsFunction
 
Decimal28SparseFunctions.Decimal28SparseAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseAddFunction
 
Decimal28SparseFunctions.Decimal28SparseCeilFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseCeilFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseCeilFunction
 
Decimal28SparseFunctions.Decimal28SparseDivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseDivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseDivideFunction
 
Decimal28SparseFunctions.Decimal28SparseEqual - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseEqual() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseEqual
 
Decimal28SparseFunctions.Decimal28SparseFloorFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseFloorFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseFloorFunction
 
Decimal28SparseFunctions.Decimal28SparseGreaterThan - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseGreaterThan() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseGreaterThan
 
Decimal28SparseFunctions.Decimal28SparseGreaterThanEq - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseGreaterThanEq() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseGreaterThanEq
 
Decimal28SparseFunctions.Decimal28SparseLessThan - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseLessThan() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseLessThan
 
Decimal28SparseFunctions.Decimal28SparseLessThanEq - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseLessThanEq() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseLessThanEq
 
Decimal28SparseFunctions.Decimal28SparseModFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseModFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseModFunction
 
Decimal28SparseFunctions.Decimal28SparseMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseMultiplyFunction
 
Decimal28SparseFunctions.Decimal28SparseNotEqual - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseNotEqual() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseNotEqual
 
Decimal28SparseFunctions.Decimal28SparseRoundFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseRoundFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseRoundFunction
 
Decimal28SparseFunctions.Decimal28SparseRoundScaleFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseRoundScaleFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseRoundScaleFunction
 
Decimal28SparseFunctions.Decimal28SparseSignFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseSignFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseSignFunction
 
Decimal28SparseFunctions.Decimal28SparseSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseSubtractFunction
 
Decimal28SparseFunctions.Decimal28SparseTruncateFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseTruncateFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseTruncateFunction
 
Decimal28SparseFunctions.Decimal28SparseTruncateScaleFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.Decimal28SparseTruncateScaleFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseTruncateScaleFunction
 
Decimal28SparseFunctions.GCompareDecimal28SparseVsDecimal28SparseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.GCompareDecimal28SparseVsDecimal28SparseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareDecimal28SparseVsDecimal28SparseNullHigh
 
Decimal28SparseFunctions.GCompareDecimal28SparseVsDecimal28SparseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.GCompareDecimal28SparseVsDecimal28SparseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareDecimal28SparseVsDecimal28SparseNullLow
 
Decimal28SparseFunctions.GCompareDecimal28SparseVsNullableDecimal28SparseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.GCompareDecimal28SparseVsNullableDecimal28SparseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareDecimal28SparseVsNullableDecimal28SparseNullHigh
 
Decimal28SparseFunctions.GCompareDecimal28SparseVsNullableDecimal28SparseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.GCompareDecimal28SparseVsNullableDecimal28SparseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareDecimal28SparseVsNullableDecimal28SparseNullLow
 
Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsDecimal28SparseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsDecimal28SparseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsDecimal28SparseNullHigh
 
Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsDecimal28SparseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsDecimal28SparseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsDecimal28SparseNullLow
 
Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsNullableDecimal28SparseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsNullableDecimal28SparseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsNullableDecimal28SparseNullHigh
 
Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsNullableDecimal28SparseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsNullableDecimal28SparseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsNullableDecimal28SparseNullLow
 
decimal28Vector - Variable in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.Decimal28Column
 
decimal28Vector - Variable in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.Decimal38Column
 
Decimal38DenseAccessor - Class in org.apache.drill.exec.vector.accessor
 
Decimal38DenseAccessor(Decimal38DenseVector) - Constructor for class org.apache.drill.exec.vector.accessor.Decimal38DenseAccessor
 
Decimal38DenseFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38DenseFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions
 
Decimal38DenseFunctions.Decimal38DenseEqual - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38DenseFunctions.Decimal38DenseEqual() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseEqual
 
Decimal38DenseFunctions.Decimal38DenseGreaterThan - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38DenseFunctions.Decimal38DenseGreaterThan() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseGreaterThan
 
Decimal38DenseFunctions.Decimal38DenseGreaterThanEq - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38DenseFunctions.Decimal38DenseGreaterThanEq() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseGreaterThanEq
 
Decimal38DenseFunctions.Decimal38DenseLessThan - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38DenseFunctions.Decimal38DenseLessThan() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseLessThan
 
Decimal38DenseFunctions.Decimal38DenseLessThanEq - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38DenseFunctions.Decimal38DenseLessThanEq() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseLessThanEq
 
Decimal38DenseFunctions.Decimal38DenseNotEqual - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38DenseFunctions.Decimal38DenseNotEqual() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseNotEqual
 
Decimal38DenseFunctions.GCompareDecimal38DenseVsDecimal38DenseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38DenseFunctions.GCompareDecimal38DenseVsDecimal38DenseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareDecimal38DenseVsDecimal38DenseNullHigh
 
Decimal38DenseFunctions.GCompareDecimal38DenseVsDecimal38DenseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38DenseFunctions.GCompareDecimal38DenseVsDecimal38DenseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareDecimal38DenseVsDecimal38DenseNullLow
 
Decimal38DenseFunctions.GCompareDecimal38DenseVsNullableDecimal38DenseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38DenseFunctions.GCompareDecimal38DenseVsNullableDecimal38DenseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareDecimal38DenseVsNullableDecimal38DenseNullHigh
 
Decimal38DenseFunctions.GCompareDecimal38DenseVsNullableDecimal38DenseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38DenseFunctions.GCompareDecimal38DenseVsNullableDecimal38DenseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareDecimal38DenseVsNullableDecimal38DenseNullLow
 
Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsDecimal38DenseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsDecimal38DenseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsDecimal38DenseNullHigh
 
Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsDecimal38DenseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsDecimal38DenseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsDecimal38DenseNullLow
 
Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsNullableDecimal38DenseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsNullableDecimal38DenseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsNullableDecimal38DenseNullHigh
 
Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsNullableDecimal38DenseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsNullableDecimal38DenseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsNullableDecimal38DenseNullLow
 
Decimal38SparseAccessor - Class in org.apache.drill.exec.vector.accessor
 
Decimal38SparseAccessor(Decimal38SparseVector) - Constructor for class org.apache.drill.exec.vector.accessor.Decimal38SparseAccessor
 
Decimal38SparseFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions
 
Decimal38SparseFunctions.Decimal38SparseAbsFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseAbsFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseAbsFunction
 
Decimal38SparseFunctions.Decimal38SparseAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseAddFunction
 
Decimal38SparseFunctions.Decimal38SparseCeilFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseCeilFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseCeilFunction
 
Decimal38SparseFunctions.Decimal38SparseDivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseDivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseDivideFunction
 
Decimal38SparseFunctions.Decimal38SparseEqual - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseEqual() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseEqual
 
Decimal38SparseFunctions.Decimal38SparseFloorFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseFloorFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseFloorFunction
 
Decimal38SparseFunctions.Decimal38SparseGreaterThan - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseGreaterThan() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseGreaterThan
 
Decimal38SparseFunctions.Decimal38SparseGreaterThanEq - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseGreaterThanEq() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseGreaterThanEq
 
Decimal38SparseFunctions.Decimal38SparseLessThan - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseLessThan() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseLessThan
 
Decimal38SparseFunctions.Decimal38SparseLessThanEq - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseLessThanEq() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseLessThanEq
 
Decimal38SparseFunctions.Decimal38SparseModFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseModFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseModFunction
 
Decimal38SparseFunctions.Decimal38SparseMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseMultiplyFunction
 
Decimal38SparseFunctions.Decimal38SparseNotEqual - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseNotEqual() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseNotEqual
 
Decimal38SparseFunctions.Decimal38SparseRoundFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseRoundFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseRoundFunction
 
Decimal38SparseFunctions.Decimal38SparseRoundScaleFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseRoundScaleFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseRoundScaleFunction
 
Decimal38SparseFunctions.Decimal38SparseSignFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseSignFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseSignFunction
 
Decimal38SparseFunctions.Decimal38SparseSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseSubtractFunction
 
Decimal38SparseFunctions.Decimal38SparseTruncateFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseTruncateFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseTruncateFunction
 
Decimal38SparseFunctions.Decimal38SparseTruncateScaleFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.Decimal38SparseTruncateScaleFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseTruncateScaleFunction
 
Decimal38SparseFunctions.GCompareDecimal38SparseVsDecimal38SparseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.GCompareDecimal38SparseVsDecimal38SparseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareDecimal38SparseVsDecimal38SparseNullHigh
 
Decimal38SparseFunctions.GCompareDecimal38SparseVsDecimal38SparseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.GCompareDecimal38SparseVsDecimal38SparseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareDecimal38SparseVsDecimal38SparseNullLow
 
Decimal38SparseFunctions.GCompareDecimal38SparseVsNullableDecimal38SparseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.GCompareDecimal38SparseVsNullableDecimal38SparseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareDecimal38SparseVsNullableDecimal38SparseNullHigh
 
Decimal38SparseFunctions.GCompareDecimal38SparseVsNullableDecimal38SparseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.GCompareDecimal38SparseVsNullableDecimal38SparseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareDecimal38SparseVsNullableDecimal38SparseNullLow
 
Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsDecimal38SparseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsDecimal38SparseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsDecimal38SparseNullHigh
 
Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsDecimal38SparseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsDecimal38SparseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsDecimal38SparseNullLow
 
Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsNullableDecimal38SparseNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsNullableDecimal38SparseNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsNullableDecimal38SparseNullHigh
 
Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsNullableDecimal38SparseNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsNullableDecimal38SparseNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsNullableDecimal38SparseNullLow
 
Decimal9Accessor - Class in org.apache.drill.exec.vector.accessor
 
Decimal9Accessor(Decimal9Vector) - Constructor for class org.apache.drill.exec.vector.accessor.Decimal9Accessor
 
Decimal9Functions - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions
 
Decimal9Functions.Decimal9AbsFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9AbsFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9AbsFunction
 
Decimal9Functions.Decimal9AddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9AddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9AddFunction
 
Decimal9Functions.Decimal9CeilFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9CeilFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9CeilFunction
 
Decimal9Functions.Decimal9DivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9DivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9DivideFunction
 
Decimal9Functions.Decimal9Equal - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9Equal() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9Equal
 
Decimal9Functions.Decimal9FloorFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9FloorFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9FloorFunction
 
Decimal9Functions.Decimal9GreaterThan - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9GreaterThan() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9GreaterThan
 
Decimal9Functions.Decimal9GreaterThanEq - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9GreaterThanEq() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9GreaterThanEq
 
Decimal9Functions.Decimal9LessThan - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9LessThan() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9LessThan
 
Decimal9Functions.Decimal9LessThanEq - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9LessThanEq() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9LessThanEq
 
Decimal9Functions.Decimal9ModFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9ModFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9ModFunction
 
Decimal9Functions.Decimal9MultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9MultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9MultiplyFunction
 
Decimal9Functions.Decimal9NotEqual - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9NotEqual() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9NotEqual
 
Decimal9Functions.Decimal9RoundFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9RoundFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9RoundFunction
 
Decimal9Functions.Decimal9RoundScaleFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9RoundScaleFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9RoundScaleFunction
 
Decimal9Functions.Decimal9SignFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9SignFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9SignFunction
 
Decimal9Functions.Decimal9SubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9SubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9SubtractFunction
 
Decimal9Functions.Decimal9TruncateScaleFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9TruncateScaleFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9TruncateScaleFunction
 
Decimal9Functions.Decimal9TruncFunction - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.Decimal9TruncFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9TruncFunction
 
Decimal9Functions.GCompareDecimal9VsDecimal9NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.GCompareDecimal9VsDecimal9NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareDecimal9VsDecimal9NullHigh
 
Decimal9Functions.GCompareDecimal9VsDecimal9NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.GCompareDecimal9VsDecimal9NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareDecimal9VsDecimal9NullLow
 
Decimal9Functions.GCompareDecimal9VsNullableDecimal9NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.GCompareDecimal9VsNullableDecimal9NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareDecimal9VsNullableDecimal9NullHigh
 
Decimal9Functions.GCompareDecimal9VsNullableDecimal9NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.GCompareDecimal9VsNullableDecimal9NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareDecimal9VsNullableDecimal9NullLow
 
Decimal9Functions.GCompareNullableDecimal9VsDecimal9NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.GCompareNullableDecimal9VsDecimal9NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareNullableDecimal9VsDecimal9NullHigh
 
Decimal9Functions.GCompareNullableDecimal9VsDecimal9NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.GCompareNullableDecimal9VsDecimal9NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareNullableDecimal9VsDecimal9NullLow
 
Decimal9Functions.GCompareNullableDecimal9VsNullableDecimal9NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.GCompareNullableDecimal9VsNullableDecimal9NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareNullableDecimal9VsNullableDecimal9NullHigh
 
Decimal9Functions.GCompareNullableDecimal9VsNullableDecimal9NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
Decimal9Functions.GCompareNullableDecimal9VsNullableDecimal9NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareNullableDecimal9VsNullableDecimal9NullLow
 
DECIMAL_DISABLE_ERR_MSG - Static variable in interface org.apache.drill.exec.work.ExecErrorConstants
 
DECIMAL_NUMERIC_LITERAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DecimalAvgFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalAvgFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions
 
DecimalAvgFunctions.Decimal18Avg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalAvgFunctions.Decimal18Avg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal18Avg
 
DecimalAvgFunctions.Decimal28SparseAvg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalAvgFunctions.Decimal28SparseAvg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal28SparseAvg
 
DecimalAvgFunctions.Decimal38SparseAvg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalAvgFunctions.Decimal38SparseAvg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal38SparseAvg
 
DecimalAvgFunctions.Decimal9Avg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalAvgFunctions.Decimal9Avg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal9Avg
 
DecimalAvgFunctions.NullableDecimal18Avg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalAvgFunctions.NullableDecimal18Avg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal18Avg
 
DecimalAvgFunctions.NullableDecimal28SparseAvg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalAvgFunctions.NullableDecimal28SparseAvg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal28SparseAvg
 
DecimalAvgFunctions.NullableDecimal38SparseAvg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalAvgFunctions.NullableDecimal38SparseAvg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal38SparseAvg
 
DecimalAvgFunctions.NullableDecimal9Avg - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalAvgFunctions.NullableDecimal9Avg() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal9Avg
 
DecimalMaxFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMaxFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions
 
DecimalMaxFunctions.Decimal18Max - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMaxFunctions.Decimal18Max() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal18Max
 
DecimalMaxFunctions.Decimal28SparseMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMaxFunctions.Decimal28SparseMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal28SparseMax
 
DecimalMaxFunctions.Decimal38SparseMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMaxFunctions.Decimal38SparseMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal38SparseMax
 
DecimalMaxFunctions.Decimal9Max - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMaxFunctions.Decimal9Max() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal9Max
 
DecimalMaxFunctions.NullableDecimal18Max - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMaxFunctions.NullableDecimal18Max() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal18Max
 
DecimalMaxFunctions.NullableDecimal28SparseMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMaxFunctions.NullableDecimal28SparseMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal28SparseMax
 
DecimalMaxFunctions.NullableDecimal38SparseMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMaxFunctions.NullableDecimal38SparseMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal38SparseMax
 
DecimalMaxFunctions.NullableDecimal9Max - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMaxFunctions.NullableDecimal9Max() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal9Max
 
DecimalMinFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMinFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions
 
DecimalMinFunctions.Decimal18Min - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMinFunctions.Decimal18Min() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal18Min
 
DecimalMinFunctions.Decimal28SparseMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMinFunctions.Decimal28SparseMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal28SparseMin
 
DecimalMinFunctions.Decimal38SparseMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMinFunctions.Decimal38SparseMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal38SparseMin
 
DecimalMinFunctions.Decimal9Min - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMinFunctions.Decimal9Min() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal9Min
 
DecimalMinFunctions.NullableDecimal18Min - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMinFunctions.NullableDecimal18Min() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal18Min
 
DecimalMinFunctions.NullableDecimal28SparseMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMinFunctions.NullableDecimal28SparseMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal28SparseMin
 
DecimalMinFunctions.NullableDecimal38SparseMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMinFunctions.NullableDecimal38SparseMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal38SparseMin
 
DecimalMinFunctions.NullableDecimal9Min - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalMinFunctions.NullableDecimal9Min() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal9Min
 
DecimalReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
 
DecimalReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference
 
DecimalReturnTypeInference.DecimalAddReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
Return type calculation implementation for functions with return type set as FunctionTemplate.ReturnType.DECIMAL_ADD_SCALE.
DecimalReturnTypeInference.DecimalAddReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalAddReturnTypeInference
 
DecimalReturnTypeInference.DecimalAggReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
Return type calculation implementation for functions with return type set as FunctionTemplate.ReturnType.DECIMAL_AGGREGATE.
DecimalReturnTypeInference.DecimalAggReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalAggReturnTypeInference
 
DecimalReturnTypeInference.DecimalCastReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
Return type calculation implementation for functions with return type set as FunctionTemplate.ReturnType.DECIMAL_CAST.
DecimalReturnTypeInference.DecimalCastReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalCastReturnTypeInference
 
DecimalReturnTypeInference.DecimalDivScaleReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
Return type calculation implementation for functions with return type set as FunctionTemplate.ReturnType.DECIMAL_DIV_SCALE.
DecimalReturnTypeInference.DecimalDivScaleReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalDivScaleReturnTypeInference
 
DecimalReturnTypeInference.DecimalMaxScaleReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
Return type calculation implementation for functions with return type set as FunctionTemplate.ReturnType.DECIMAL_MAX_SCALE.
DecimalReturnTypeInference.DecimalMaxScaleReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalMaxScaleReturnTypeInference
 
DecimalReturnTypeInference.DecimalModScaleReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
Return type calculation implementation for functions with return type set as FunctionTemplate.ReturnType.DECIMAL_MOD_SCALE.
DecimalReturnTypeInference.DecimalModScaleReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalModScaleReturnTypeInference
 
DecimalReturnTypeInference.DecimalSetScaleReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
Return type calculation implementation for functions with return type set as FunctionTemplate.ReturnType.DECIMAL_SET_SCALE.
DecimalReturnTypeInference.DecimalSetScaleReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalSetScaleReturnTypeInference
 
DecimalReturnTypeInference.DecimalSumAggReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
Return type calculation implementation for functions with return type set as FunctionTemplate.ReturnType.DECIMAL_SUM_AGGREGATE.
DecimalReturnTypeInference.DecimalSumAggReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalSumAggReturnTypeInference
 
DecimalReturnTypeInference.DecimalSumScaleReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
Return type calculation implementation for functions with return type set as FunctionTemplate.ReturnType.DECIMAL_SUM_SCALE.
DecimalReturnTypeInference.DecimalSumScaleReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalSumScaleReturnTypeInference
 
DecimalReturnTypeInference.DecimalZeroScaleReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
Return type calculation implementation for functions with return type set as FunctionTemplate.ReturnType.DECIMAL_ZERO_SCALE.
DecimalReturnTypeInference.DecimalZeroScaleReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalZeroScaleReturnTypeInference
 
DecimalSumFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalSumFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions
 
DecimalSumFunctions.Decimal18Sum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalSumFunctions.Decimal18Sum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal18Sum
 
DecimalSumFunctions.Decimal28SparseSum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalSumFunctions.Decimal28SparseSum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal28SparseSum
 
DecimalSumFunctions.Decimal38SparseSum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalSumFunctions.Decimal38SparseSum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal38SparseSum
 
DecimalSumFunctions.Decimal9Sum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalSumFunctions.Decimal9Sum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal9Sum
 
DecimalSumFunctions.NullableDecimal18Sum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalSumFunctions.NullableDecimal18Sum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal18Sum
 
DecimalSumFunctions.NullableDecimal28SparseSum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalSumFunctions.NullableDecimal28SparseSum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal28SparseSum
 
DecimalSumFunctions.NullableDecimal38SparseSum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalSumFunctions.NullableDecimal38SparseSum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal38SparseSum
 
DecimalSumFunctions.NullableDecimal9Sum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
DecimalSumFunctions.NullableDecimal9Sum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal9Sum
 
declare(TypeProtos.MajorType) - Method in class org.apache.drill.exec.expr.ClassGenerator
 
declare(TypeProtos.MajorType, boolean) - Method in class org.apache.drill.exec.expr.ClassGenerator
 
DECLARE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
declareClassField(String, JType) - Method in class org.apache.drill.exec.expr.ClassGenerator
 
declareClassField(String, JType, JExpression) - Method in class org.apache.drill.exec.expr.ClassGenerator
 
declareVectorValueSetupAndMember(String, TypedFieldId) - Method in class org.apache.drill.exec.expr.ClassGenerator
 
declareVectorValueSetupAndMember(DirectExpression, TypedFieldId) - Method in class org.apache.drill.exec.expr.ClassGenerator
Creates class variable for the value vector using metadata from fieldId and initializes it using setup blocks.
declareWorkspaceVariables(ClassGenerator<?>) - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.drill.exec.rpc.control.ControlProtobufLengthDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.drill.exec.rpc.data.DataProtobufLengthDecoder.Client
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.drill.exec.rpc.data.DataProtobufLengthDecoder.Server
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.drill.exec.rpc.user.UserProtobufLengthDecoder
 
decodePacket(byte[], int, Packet) - Method in class org.apache.drill.exec.store.pcap.decoder.PacketDecoder
 
decodePcap(byte[], int, boolean, int) - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
decodeVIntSize(byte) - Static method in class org.apache.drill.exec.util.ByteBufUtil.HadoopWritables
Parse the first byte of a vint/vlong to determine the number of bytes
decrementAndGet() - Method in interface org.apache.drill.exec.cache.Counter
 
DEFAULT - Static variable in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
 
DEFAULT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DEFAULT - Static variable in enum org.apache.drill.exec.record.BatchSchema.SelectionVectorMode
 
DEFAULT - Static variable in class org.apache.drill.exec.server.options.OptionMetaData
 
DEFAULT - Static variable in class org.apache.drill.exec.store.dfs.WorkspaceConfig
Default workspace is a root directory which supports read, but not write.
DEFAULT - Static variable in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
DEFAULT - Static variable in class org.apache.drill.exec.store.StorageStrategy
For directories: drwxrwxr-x (owner and group have full access, others can read and execute).
DEFAULT_ADMIN_USER_GROUPS - Variable in class org.apache.drill.exec.server.options.TypeValidators.AdminUserGroupsValidator
 
DEFAULT_ADMIN_USERS - Variable in class org.apache.drill.exec.server.options.TypeValidators.AdminUsersValidator
 
DEFAULT_CLIENT_NAME - Static variable in class org.apache.drill.exec.client.DrillClient
 
DEFAULT_COLS_TO_READ - Static variable in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
DEFAULT_COLUMN_WIDTH - Static variable in class org.apache.drill.exec.util.VectorUtil
 
DEFAULT_CONSTANT_MAP - Static variable in class org.apache.drill.exec.expr.ClassGenerator
 
DEFAULT_CONTROLS - Static variable in class org.apache.drill.exec.testing.ExecutionControls
The default value for controls.
DEFAULT_IDENTIFIER_MAX_LENGTH - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
DEFAULT_INITIAL_CAPACITY - Static variable in interface org.apache.drill.exec.physical.impl.common.HashTable
The initial default capacity of the hash table (in terms of number of buckets).
DEFAULT_KW - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DEFAULT_LOAD_FACTOR - Static variable in interface org.apache.drill.exec.physical.impl.common.HashTable
The default load factor of a hash table.
DEFAULT_NAME - Static variable in class org.apache.drill.exec.store.easy.json.JSONFormatPlugin
 
DEFAULT_ROWS_PER_BATCH - Static variable in class org.apache.drill.exec.store.easy.json.JSONRecordReader
 
DEFAULT_SCALAR_MAP - Static variable in class org.apache.drill.exec.expr.ClassGenerator
 
DEFAULT_SCHEMA - Static variable in class org.apache.drill.exec.util.StoragePluginTestUtils
 
DEFAULT_SORT_ALLOCATION - Static variable in class org.apache.drill.exec.physical.config.ExternalSort
 
DEFAULT_SPILL_BATCH_SIZE - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
 
DEFAULT_SSL_HANDSHAKE_TIMEOUT_MS - Static variable in class org.apache.drill.exec.ssl.SSLConfig
 
DEFAULT_SSL_PROTOCOL - Static variable in class org.apache.drill.exec.ssl.SSLConfig
 
DEFAULT_SSL_PROVIDER - Static variable in class org.apache.drill.exec.ssl.SSLConfig
 
DEFAULT_TEMPORARY_WORKSPACE - Static variable in class org.apache.drill.exec.ExecConstants
Temporary tables can be created ONLY in default temporary workspace.
DEFAULT_TEXT_COLS_TO_READ - Static variable in class org.apache.drill.exec.store.AbstractRecordReader
 
DEFAULT_WS_NAME - Static variable in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory
 
DefaultFunctionResolver - Class in org.apache.drill.exec.resolver
 
DefaultFunctionResolver() - Constructor for class org.apache.drill.exec.resolver.DefaultFunctionResolver
 
DefaultInstanceHandler - Class in org.apache.drill.exec.rpc.control
 
DefaultInstanceHandler() - Constructor for class org.apache.drill.exec.rpc.control.DefaultInstanceHandler
 
defaultQueryMemoryPerNode(double) - Method in class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue
 
defaultQueryMemoryPerNode(double) - Method in class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue
 
defaultQueryMemoryPerNode(double) - Method in interface org.apache.drill.exec.work.foreman.rm.QueryQueue
Return the amount of memory per node when creating a EXPLAIN query plan.
defaultQueryMemoryPerNode(double) - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager
 
DefaultResourceManager - Class in org.apache.drill.exec.work.foreman.rm
Represents a default resource manager for clusters that do not provide query queues.
DefaultResourceManager() - Constructor for class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager
 
DefaultResourceManager.DefaultQueryResourceManager - Class in org.apache.drill.exec.work.foreman.rm
 
DefaultResourceManager.DefaultQueryResourceManager(DefaultResourceManager, Foreman) - Constructor for class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager.DefaultQueryResourceManager
 
DefaultResourceManager.DefaultResourceAllocator - Class in org.apache.drill.exec.work.foreman.rm
 
DefaultResourceManager.DefaultResourceAllocator(QueryContext) - Constructor for class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager.DefaultResourceAllocator
 
DefaultReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
Return type calculation implementation for functions with return type set as FunctionTemplate.ReturnType.DEFAULT.
DefaultReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DefaultReturnTypeInference
 
DEFAULTS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DefaultSqlHandler - Class in org.apache.drill.exec.planner.sql.handlers
 
DefaultSqlHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
 
DefaultSqlHandler(SqlHandlerConfig, Pointer<String>) - Constructor for class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
 
DefaultSqlHandler.ConvertedRelNode - Class in org.apache.drill.exec.planner.sql.handlers
 
DefaultSqlHandler.ConvertedRelNode(RelNode, RelDataType) - Constructor for class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler.ConvertedRelNode
 
DefaultSqlHandler.MetaDataProviderModifier - Class in org.apache.drill.exec.planner.sql.handlers
 
DefaultSqlHandler.MetaDataProviderModifier(RelMetadataProvider) - Constructor for class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler.MetaDataProviderModifier
 
DEFERRABLE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DEFERRED - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DEFINED - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
definePlugin(String, StoragePluginConfig, StoragePlugin) - Method in class org.apache.drill.exec.store.StoragePluginRegistryImpl
Add a plugin and configuration.
DEFINER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
definitionLevel - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnTypeMetadata_v3
 
DEGREE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
delete(K) - Method in interface org.apache.drill.exec.cache.DistributedMap
 
delete(String) - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
Deletes the given node residing at the given path
delete(String) - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet
 
DELETE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
delete(Path) - Method in class org.apache.drill.exec.store.ClassPathFileSystem
 
delete(Path, boolean) - Method in class org.apache.drill.exec.store.ClassPathFileSystem
 
delete(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
Deprecated.
delete(Path, boolean) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
delete(Path) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem
 
delete(Path, boolean) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem
 
delete(String) - Method in interface org.apache.drill.exec.store.sys.PersistentStore
Removes the value corresponding to the given key if exists, nothing happens otherwise.
delete(String) - Method in class org.apache.drill.exec.store.sys.store.InMemoryStore
 
delete(String) - Method in class org.apache.drill.exec.store.sys.store.LocalPersistentStore
 
delete(String) - Method in class org.apache.drill.exec.store.sys.store.ZookeeperPersistentStore
 
delete(String) - Method in class org.apache.drill.exec.testing.store.NoWriteLocalStore
 
deleteAllLocalOptions() - Method in class org.apache.drill.exec.server.options.FragmentOptionManager
 
deleteAllLocalOptions() - Method in class org.apache.drill.exec.server.options.InMemoryOptionManager
 
deleteAllLocalOptions() - Method in interface org.apache.drill.exec.server.options.OptionManager
Deletes all options.
deleteAllLocalOptions() - Method in class org.apache.drill.exec.server.options.SystemOptionManager
 
deleteFromStorage(StoragePluginRegistry) - Method in class org.apache.drill.exec.server.rest.PluginConfigWrapper
 
deleteLocalOption(String) - Method in class org.apache.drill.exec.server.options.FragmentOptionManager
 
deleteLocalOption(String) - Method in class org.apache.drill.exec.server.options.InMemoryOptionManager
 
deleteLocalOption(String) - Method in interface org.apache.drill.exec.server.options.OptionManager
Deletes the option.
deleteLocalOption(String) - Method in class org.apache.drill.exec.server.options.SystemOptionManager
 
deleteOnExit(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
deletePlugin(String) - Method in class org.apache.drill.exec.server.rest.StorageResources
 
deletePlugin(String) - Method in interface org.apache.drill.exec.store.StoragePluginRegistry
Delete a plugin by name
deletePlugin(String) - Method in class org.apache.drill.exec.store.StoragePluginRegistryImpl
 
deletePluginJSON(String) - Method in class org.apache.drill.exec.server.rest.StorageResources
 
deleteSnapshot(Path, String) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
DEMUX_EXCHANGE - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
dense_rank - Variable in class org.apache.drill.exec.physical.impl.window.Partition
 
DENSE_RANK - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DEPTH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DEREF - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DERIVED - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
deriveRowType() - Method in class org.apache.drill.exec.planner.logical.DrillDirectScanRel
 
deriveRowType() - Method in class org.apache.drill.exec.planner.logical.DrillScanRel
 
deriveRowType() - Method in class org.apache.drill.exec.planner.physical.ScanPrel
 
deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.drill.exec.planner.sql.DrillSqlAggOperatorWithoutInference
 
deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.drill.exec.planner.sql.DrillSqlOperatorWithoutInference
 
DESC - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
desc - Variable in class org.apache.drill.exec.testing.Injection
 
DESCRIBE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DescribeSchemaHandler - Class in org.apache.drill.exec.planner.sql.handlers
 
DescribeSchemaHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.DescribeSchemaHandler
 
DescribeSchemaHandler.DescribeSchemaResult - Class in org.apache.drill.exec.planner.sql.handlers
 
DescribeSchemaHandler.DescribeSchemaResult(String, String) - Constructor for class org.apache.drill.exec.planner.sql.handlers.DescribeSchemaHandler.DescribeSchemaResult
 
DescribeTableHandler - Class in org.apache.drill.exec.planner.sql.handlers
 
DescribeTableHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.DescribeTableHandler
 
description - Variable in enum org.apache.drill.exec.planner.PlannerPhase
 
DESCRIPTION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DESCRIPTOR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
deserialize(JsonParser, DeserializationContext) - Method in class org.apache.drill.exec.coord.DrillbitEndpointSerDe.De
 
deserialize(JsonParser, DeserializationContext) - Method in class org.apache.drill.exec.record.MajorTypeSerDe.De
 
deserialize(byte[]) - Method in interface org.apache.drill.exec.serialization.InstanceSerializer
 
deserialize(byte[]) - Method in class org.apache.drill.exec.serialization.JacksonSerializer
 
deserialize(byte[]) - Method in class org.apache.drill.exec.serialization.ProtoSerializer
 
deserialize(JsonParser, DeserializationContext) - Method in class org.apache.drill.exec.server.options.PersistedOptionValue.Deserializer
 
deserialize(JsonParser, DeserializationContext) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2.DeSerializer
 
deserialize(JsonParser, DeserializationContext) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3.DeSerializer
 
deserializeKey(String, DeserializationContext) - Method in class org.apache.drill.exec.testing.InjectionSite.InjectionSiteKeyDeserializer
 
deserializeReceived(byte[]) - Method in interface org.apache.drill.exec.rpc.control.Controller.CustomSerDe
 
deserializeReceived(byte[]) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.JacksonSerDe
 
deserializeReceived(byte[]) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.ProtoSerDe
 
desiredFields - Variable in class org.apache.drill.exec.planner.physical.PrelUtil.ProjectPushInfo
 
DESTINATION_OPTIONS_V6 - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
destinations - Variable in class org.apache.drill.exec.physical.base.AbstractSender
 
destroy(VALUE) - Method in interface org.apache.drill.exec.planner.sql.ExpandingConcurrentMap.MapValueFactory
 
destroy() - Method in class org.apache.drill.exec.server.rest.UserNameFilter
 
destroy(DrillTable) - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
detectCorruptDates(ParquetMetadata, List<SchemaPath>, boolean) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
Check for corrupted dates in a parquet file.
determineSize(long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
Determines the size of a single value in a variable column.
DETERMINISTIC - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DFS_DEFAULT_SCHEMA - Static variable in class org.apache.drill.exec.util.StoragePluginTestUtils
 
DFS_PLUGIN_NAME - Static variable in class org.apache.drill.exec.util.StoragePluginTestUtils
 
DFS_ROOT_SCHEMA - Static variable in class org.apache.drill.exec.util.StoragePluginTestUtils
 
DFS_TMP_SCHEMA - Static variable in class org.apache.drill.exec.util.StoragePluginTestUtils
 
DFSDirPartitionLocation - Class in org.apache.drill.exec.planner
Composite partition location corresponds to a directory in the file system.
DFSDirPartitionLocation(String[], Collection<PartitionLocation>) - Constructor for class org.apache.drill.exec.planner.DFSDirPartitionLocation
 
DFSFilePartitionLocation - Class in org.apache.drill.exec.planner
Class defines a single partition in a DFS table.
DFSFilePartitionLocation(int, String, String, boolean) - Constructor for class org.apache.drill.exec.planner.DFSFilePartitionLocation
 
DIAGNOSTICS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DiffSchema - Class in org.apache.drill.exec.schema
 
DiffSchema() - Constructor for class org.apache.drill.exec.schema.DiffSchema
 
digest64() - Method in class org.apache.drill.exec.store.pcap.decoder.Murmur128
 
DIGIT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
direct(String) - Static method in class org.apache.drill.exec.expr.DirectExpression
 
direct_current - Variable in class org.apache.drill.exec.store.sys.MemoryIterator.MemoryInfo
 
direct_max - Variable in class org.apache.drill.exec.store.sys.MemoryIterator.MemoryInfo
 
DirectBatchCreator - Class in org.apache.drill.exec.store.direct
 
DirectBatchCreator() - Constructor for class org.apache.drill.exec.store.direct.DirectBatchCreator
 
DirectBufInputStream - Class in org.apache.drill.exec.util.filereader
 
DirectBufInputStream(InputStream, BufferAllocator, String, long, long, boolean, boolean) - Constructor for class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
DirectExpression - Class in org.apache.drill.exec.expr
Encapsulates a Java expression, defined as anything that is valid in the following code:
(expr)
DirectGroupScan - Class in org.apache.drill.exec.store.direct
 
DirectGroupScan(RecordReader) - Constructor for class org.apache.drill.exec.store.direct.DirectGroupScan
 
DirectGroupScan(RecordReader, ScanStats) - Constructor for class org.apache.drill.exec.store.direct.DirectGroupScan
 
DirectoryExplorers - Class in org.apache.drill.exec.expr.fn.impl
 
DirectoryExplorers() - Constructor for class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers
 
DirectoryExplorers.IMaxDir - Class in org.apache.drill.exec.expr.fn.impl
 
DirectoryExplorers.IMaxDir() - Constructor for class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.IMaxDir
 
DirectoryExplorers.IMaxDirTwoArg - Class in org.apache.drill.exec.expr.fn.impl
 
DirectoryExplorers.IMaxDirTwoArg() - Constructor for class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.IMaxDirTwoArg
 
DirectoryExplorers.IMinDir - Class in org.apache.drill.exec.expr.fn.impl
 
DirectoryExplorers.IMinDir() - Constructor for class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.IMinDir
 
DirectoryExplorers.IMinDirTwoArg - Class in org.apache.drill.exec.expr.fn.impl
 
DirectoryExplorers.IMinDirTwoArg() - Constructor for class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.IMinDirTwoArg
 
DirectoryExplorers.MaxDir - Class in org.apache.drill.exec.expr.fn.impl
 
DirectoryExplorers.MaxDir() - Constructor for class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.MaxDir
 
DirectoryExplorers.MaxDirTwoArg - Class in org.apache.drill.exec.expr.fn.impl
 
DirectoryExplorers.MaxDirTwoArg() - Constructor for class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.MaxDirTwoArg
 
DirectoryExplorers.MinDir - Class in org.apache.drill.exec.expr.fn.impl
 
DirectoryExplorers.MinDir() - Constructor for class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.MinDir
 
DirectoryExplorers.MinDirTwoArg - Class in org.apache.drill.exec.expr.fn.impl
 
DirectoryExplorers.MinDirTwoArg() - Constructor for class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.MinDirTwoArg
 
DirectPlan - Class in org.apache.drill.exec.planner.sql
 
DirectPlan() - Constructor for class org.apache.drill.exec.planner.sql.DirectPlan
 
DirectScanPrule - Class in org.apache.drill.exec.planner.physical
 
DirectScanPrule() - Constructor for class org.apache.drill.exec.planner.physical.DirectScanPrule
 
DirectSorter - Class in org.apache.drill.exec.compile.bytecode
 
DirectSorter(int, String, MethodVisitor) - Constructor for class org.apache.drill.exec.compile.bytecode.DirectSorter
 
DirectSubScan - Class in org.apache.drill.exec.store.direct
 
DirectSubScan(RecordReader) - Constructor for class org.apache.drill.exec.store.direct.DirectSubScan
 
directVarInsn(int, int) - Method in class org.apache.drill.exec.compile.bytecode.DirectSorter
 
DirPrunedEnumerableTableScan - Class in org.apache.drill.exec.planner.logical
This class extends from EnumerableTableScan.
DirPrunedEnumerableTableScan(RelOptCluster, RelTraitSet, RelOptTable, Class, String) - Constructor for class org.apache.drill.exec.planner.logical.DirPrunedEnumerableTableScan
 
DISABLE_CACHE_CONFIG - Static variable in class org.apache.drill.exec.compile.CodeCompiler
Disables the code cache.
disable_tracing() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
disableCertificateVerification() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
disableCertificateVerification() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
disableCertificateVerification() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
disableFunctionReturn() - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
Clear the indication that this value is used as a function return value.
disableHostVerification() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
disableHostVerification() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
disableHostVerification() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
disableMarking() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
DISALLOW - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
disallowTemporaryTables() - Method in class org.apache.drill.exec.planner.sql.SqlConverter
Disallow temporary tables presence in sql statement (ex: in view definitions)
discardReadBytes() - Method in class org.apache.drill.exec.record.DeadBuf
 
discardSomeReadBytes() - Method in class org.apache.drill.exec.record.DeadBuf
 
DISCONNECT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DISPATCH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
dispatcher - Variable in class org.apache.drill.exec.coord.zk.ZkEphemeralStore
 
dispose(DrillUserPrincipal) - Method in class org.apache.drill.exec.server.rest.DrillRestServer.AnonDrillUserPrincipalProvider
 
dispose(WebUserConnection) - Method in class org.apache.drill.exec.server.rest.DrillRestServer.AnonWebUserConnectionProvider
 
dispose(WebUserConnection) - Method in class org.apache.drill.exec.server.rest.DrillRestServer.AuthWebUserConnectionProvider
 
dispose(DrillUserPrincipal) - Method in class org.apache.drill.exec.server.rest.DrillRestServer.DrillUserPrincipalProvider
 
disposeSaslClient() - Method in class org.apache.drill.exec.rpc.AbstractClientConnection
 
disposeSaslClient() - Method in class org.apache.drill.exec.rpc.control.ControlConnection
 
disposeSaslServer() - Method in class org.apache.drill.exec.rpc.AbstractServerConnection
 
DIST_INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.HashJoinPrule
 
DIST_INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.MergeJoinPrule
 
DIST_SEED - Static variable in class org.apache.drill.exec.planner.physical.HashPrelUtil
 
DISTINCT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DistributedCache - Interface in org.apache.drill.exec.cache
 
DistributedCache.CacheConfig<K,V> - Class in org.apache.drill.exec.cache
 
DistributedCache.CacheConfig(Class<K>, Class<V>, String, DistributedCache.SerializationMode) - Constructor for class org.apache.drill.exec.cache.DistributedCache.CacheConfig
 
DistributedCache.CacheConfigBuilder<K,V> - Class in org.apache.drill.exec.cache
 
DistributedCache.SerializationMode - Enum in org.apache.drill.exec.cache
 
DistributedMap<K,V> - Interface in org.apache.drill.exec.cache
 
DistributedMultiMap<K,V> - Interface in org.apache.drill.exec.cache
 
DistributedQueryQueue - Class in org.apache.drill.exec.work.foreman.rm
Distributed query queue which uses a Zookeeper distributed semaphore to control queuing across the cluster.
DistributedQueryQueue(DrillbitContext, DistributedQueryQueue.StatusAdapter) - Constructor for class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue
 
DistributedQueryQueue.StatusAdapter - Interface in org.apache.drill.exec.work.foreman.rm
 
DistributedQueryQueue.ZKQueueInfo - Class in org.apache.drill.exec.work.foreman.rm
Exposes a snapshot of internal state information for use in status reporting, such as in the UI.
DistributedQueryQueue.ZKQueueInfo(DistributedQueryQueue) - Constructor for class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue.ZKQueueInfo
 
DistributedSemaphore - Interface in org.apache.drill.exec.coord
 
DistributedSemaphore.DistributedLease - Interface in org.apache.drill.exec.coord
 
DistributedStorageEngine - Interface in org.apache.drill.exec.store
 
DistributionAffinity - Enum in org.apache.drill.exec.planner.fragment
Describes an operator's endpoint assignment requirements.
divideBy(RelOptCost) - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
DivideFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
DivideFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.DivideFunctions
 
DivideFunctions.BigIntBigIntDivide - Class in org.apache.drill.exec.expr.fn.impl
 
DivideFunctions.BigIntBigIntDivide() - Constructor for class org.apache.drill.exec.expr.fn.impl.DivideFunctions.BigIntBigIntDivide
 
DivideFunctions.Float4Float4Divide - Class in org.apache.drill.exec.expr.fn.impl
 
DivideFunctions.Float4Float4Divide() - Constructor for class org.apache.drill.exec.expr.fn.impl.DivideFunctions.Float4Float4Divide
 
DivideFunctions.Float8Float8Divide - Class in org.apache.drill.exec.expr.fn.impl
 
DivideFunctions.Float8Float8Divide() - Constructor for class org.apache.drill.exec.expr.fn.impl.DivideFunctions.Float8Float8Divide
 
DivideFunctions.IntIntDivide - Class in org.apache.drill.exec.expr.fn.impl
 
DivideFunctions.IntIntDivide() - Constructor for class org.apache.drill.exec.expr.fn.impl.DivideFunctions.IntIntDivide
 
DivideFunctions.SmallIntSmallIntDivide - Class in org.apache.drill.exec.expr.fn.impl
 
DivideFunctions.SmallIntSmallIntDivide() - Constructor for class org.apache.drill.exec.expr.fn.impl.DivideFunctions.SmallIntSmallIntDivide
 
DivideFunctions.TinyIntTinyIntDivide - Class in org.apache.drill.exec.expr.fn.impl
 
DivideFunctions.TinyIntTinyIntDivide() - Constructor for class org.apache.drill.exec.expr.fn.impl.DivideFunctions.TinyIntTinyIntDivide
 
DivideFunctions.UInt1UInt1Divide - Class in org.apache.drill.exec.expr.fn.impl
 
DivideFunctions.UInt1UInt1Divide() - Constructor for class org.apache.drill.exec.expr.fn.impl.DivideFunctions.UInt1UInt1Divide
 
DivideFunctions.UInt2UInt2Divide - Class in org.apache.drill.exec.expr.fn.impl
 
DivideFunctions.UInt2UInt2Divide() - Constructor for class org.apache.drill.exec.expr.fn.impl.DivideFunctions.UInt2UInt2Divide
 
DivideFunctions.UInt4UInt4Divide - Class in org.apache.drill.exec.expr.fn.impl
 
DivideFunctions.UInt4UInt4Divide() - Constructor for class org.apache.drill.exec.expr.fn.impl.DivideFunctions.UInt4UInt4Divide
 
DivideFunctions.UInt8UInt8Divide - Class in org.apache.drill.exec.expr.fn.impl
 
DivideFunctions.UInt8UInt8Divide() - Constructor for class org.apache.drill.exec.expr.fn.impl.DivideFunctions.UInt8UInt8Divide
 
doBatch(FileInputStream, int, boolean) - Method in class org.apache.drill.exec.client.DumpCat
Batch mode: $drill-dumpcat --file=local:///tmp/drilltrace/[queryid]_[tag]_[majorid]_[minor]_[operator] --batch=123 --include-headers=true Records: 1/1 Average Record Size: 8 bytes Total Data Size: 8 bytes Schema Information name: col1, minor_type: int4, data_mode: nullable name: col2, minor_type: int4, data_mode: non-nullable
doCompare(int, int) - Method in class org.apache.drill.exec.physical.impl.join.JoinTemplate
Compare the values of the left and right join key to determine whether the left is less than, greater than or equal to the right.
doCopy(int, int) - Method in interface org.apache.drill.exec.physical.impl.mergereceiver.MergingReceiverGeneratorBase
 
doCopy(int, int) - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingReceiverTemplate
 
doCopy(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierTemplate
 
doCopy(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.PriorityQueueCopierTemplate
 
doCopyLeft(int, int) - Method in class org.apache.drill.exec.physical.impl.join.JoinTemplate
Copy the data to the new record batch (if it fits).
doCopyRight(int, int) - Method in class org.apache.drill.exec.physical.impl.join.JoinTemplate
 
doEval(int, int) - Method in interface org.apache.drill.exec.physical.impl.filter.FilterSignature
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.filter.FilterTemplate2
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.filter.FilterTemplate4
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenTemplate
 
doEval(int, int, int) - Method in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinTemplate
 
doEval(int, int) - Method in interface org.apache.drill.exec.physical.impl.mergereceiver.MergingReceiverGeneratorBase
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingReceiverTemplate
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionProjectorTemplate
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.SampleCopierTemplate
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.SampleSortTemplate
 
doEval(int) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.project.ProjectorTemplate
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.sort.SortTemplate
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.svremover.CopierTemplate2
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.svremover.CopierTemplate4
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.union.UnionAllerTemplate
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MSortTemplate
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierTemplate
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.MSortTemplate
 
doEval(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.PriorityQueueCopierTemplate
 
doEval(char, char) - Method in class org.apache.drill.exec.physical.impl.xsort.SingleBatchSorterTemplate
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.drill.exec.server.rest.UserNameFilter
 
doJoin(JoinStatus) - Method in class org.apache.drill.exec.physical.impl.join.JoinTemplate
Copy rows from the input record batches until the output record batch is full
doJoin(JoinStatus) - Method in interface org.apache.drill.exec.physical.impl.join.JoinWorker
 
DOMAIN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
doMatch(RelOptRuleCall, ScanPrel, ProjectPrel, FilterPrel) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaPushFilterIntoRecordGenerator
 
Done() - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
doOnMatch(RelOptRuleCall, DrillLimitRel, DrillScanRel, DrillProjectRel) - Method in class org.apache.drill.exec.planner.logical.DrillPushLimitToScanRule
 
doOnMatch(RelOptRuleCall, Filter, Project, TableScan) - Method in class org.apache.drill.exec.planner.logical.partition.PruneScanRule
 
doOnMatch(RelOptRuleCall, FilterPrel, ProjectPrel, ScanPrel) - Method in class org.apache.drill.exec.store.parquet.ParquetPushDownFilter
 
doQuery(FileInputStream) - Method in class org.apache.drill.exec.client.DumpCat
Querymode: $drill-dumpcat --file=local:///tmp/drilltrace/[queryid]_[tag]_[majorid]_[minor]_[operator] Batches: 135 Records: 53,214/53,214 // the first one is the selected records.
doRpcCall(RpcOutcomeListener<GeneralRPCProtos.Ack>, ControlConnection) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.CancelQuery
 
doRpcCall(RpcOutcomeListener<GeneralRPCProtos.Ack>, ControlConnection) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.ReceiverFinished
 
doRpcCall(RpcOutcomeListener<UserBitShared.QueryProfile>, ControlConnection) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.RequestProfile
 
doRpcCall(RpcOutcomeListener<GeneralRPCProtos.Ack>, ControlConnection) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.SendFragment
 
doRpcCall(RpcOutcomeListener<GeneralRPCProtos.Ack>, ControlConnection) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.SendFragmentStatus
 
doRpcCall(RpcOutcomeListener<GeneralRPCProtos.Ack>, ControlConnection) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.SignalFragment
 
doSetup(RecordBatch) - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
 
doSetup(RecordBatch, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
doSetup(FragmentContext, RecordBatch, RecordBatch) - Method in interface org.apache.drill.exec.physical.impl.filter.FilterSignature
 
doSetup(FragmentContext, RecordBatch, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.filter.FilterTemplate2
 
doSetup(FragmentContext, RecordBatch, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.filter.FilterTemplate4
 
doSetup(FragmentContext, RecordBatch, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenTemplate
 
doSetup(FragmentContext, VectorContainer, RecordBatch, RecordBatch) - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinProbe
 
doSetup(FragmentContext, VectorContainer, RecordBatch, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinProbeTemplate
 
doSetup(FragmentContext, JoinStatus, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.join.JoinTemplate
 
doSetup(FragmentContext, VectorContainer, RecordBatch, RecordBatch) - Method in interface org.apache.drill.exec.physical.impl.join.NestedLoopJoin
 
doSetup(FragmentContext, VectorContainer, RecordBatch, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinTemplate
 
doSetup(FragmentContext, VectorAccessible, VectorAccessible) - Method in interface org.apache.drill.exec.physical.impl.mergereceiver.MergingReceiverGeneratorBase
 
doSetup(FragmentContext, VectorAccessible, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingReceiverTemplate
 
doSetup(FragmentContext, VectorAccessible, RecordBatch, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionProjectorTemplate
 
doSetup(FragmentContext, VectorAccessible, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.SampleCopierTemplate
 
doSetup(FragmentContext, VectorContainer, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.SampleSortTemplate
 
doSetup(FragmentContext, RecordBatch, PartitionerTemplate.OutgoingRecordBatch[]) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate
 
doSetup(RecordBatch, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
doSetup(FragmentContext, RecordBatch, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.project.ProjectorTemplate
 
doSetup(FragmentContext, VectorContainer, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.sort.SortTemplate
 
doSetup(FragmentContext, RecordBatch, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.svremover.CopierTemplate2
 
doSetup(FragmentContext, RecordBatch, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.svremover.CopierTemplate4
 
doSetup(VectorContainer, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
 
doSetup(FragmentContext, RecordBatch, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.union.UnionAllerTemplate
 
doSetup(FragmentContextInterface, VectorContainer, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MSortTemplate
 
doSetup(VectorAccessible, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierTemplate
 
doSetup(FragmentContext, VectorContainer, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.xsort.MSortTemplate
 
doSetup(FragmentContext, VectorAccessible, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.xsort.PriorityQueueCopierTemplate
 
doSetup(FragmentContextInterface, VectorAccessible, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.xsort.SingleBatchSorterTemplate
 
dot - Variable in class org.apache.drill.exec.compile.ClassTransformer.ClassNames
 
DOT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DOT_DRILL_GLOB - Static variable in enum org.apache.drill.exec.dotdrill.DotDrillType
 
DOT_PREFIX - Static variable in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
DotDrillFile - Class in org.apache.drill.exec.dotdrill
 
DotDrillType - Enum in org.apache.drill.exec.dotdrill
 
DotDrillUtil - Class in org.apache.drill.exec.dotdrill
 
DotDrillUtil() - Constructor for class org.apache.drill.exec.dotdrill.DotDrillUtil
 
DOUBLE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DOUBLE_PERIOD - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DOUBLE_QUOTE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DoubleBEConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
DoubleBEConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.DoubleBEConvertFrom
 
DoubleBEConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
DoubleBEConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.DoubleBEConvertTo
 
DoubleConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
DoubleConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.DoubleConvertFrom
 
DoubleConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
DoubleConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.DoubleConvertTo
 
DoubleGen - Class in org.apache.drill.exec.store.mock
Generates random field values uniformly distributed over the range +-1 million, with any number of digits past the decimal point.
DoubleGen() - Constructor for class org.apache.drill.exec.store.mock.DoubleGen
 
doWork() - Method in interface org.apache.drill.exec.physical.impl.aggregate.HashAggregator
 
doWork() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
Read and process (i.e., insert into the hash table and aggregate) records from the current batch.
doWork() - Method in interface org.apache.drill.exec.physical.impl.aggregate.StreamingAggregator
 
doWork() - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
 
doWork() - Method in class org.apache.drill.exec.physical.impl.filter.FilterRecordBatch
 
doWork() - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenRecordBatch
 
doWork() - Method in class org.apache.drill.exec.physical.impl.limit.LimitRecordBatch
 
doWork(VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
 
doWork() - Method in class org.apache.drill.exec.physical.impl.project.ProjectRecordBatch
 
doWork() - Method in class org.apache.drill.exec.physical.impl.svremover.RemovingRecordBatch
 
doWork() - Method in class org.apache.drill.exec.physical.impl.trace.TraceRecordBatch
Function is invoked for every record batch and it simply dumps the buffers associated with all the value vectors in this record batch to a log file.
doWork() - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
processes all rows of the first batch.
doWork() - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
processes all rows of the first batch.
doWork() - Method in interface org.apache.drill.exec.physical.impl.window.WindowFramer
process the inner batch and write the aggregated values in the container
doWork() - Method in class org.apache.drill.exec.record.AbstractSingleRecordBatch
 
DQID - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
drill() - Method in class org.apache.drill.exec.cache.DistributedCache.CacheConfigBuilder
 
DRILL_EXEC_SYS_STORE_PROVIDER_ZK_BLOBROOT - Static variable in class org.apache.drill.exec.store.sys.store.provider.ZookeeperPersistentStoreProvider
 
DRILL_FILTER_ON_JOIN - Static variable in class org.apache.drill.exec.planner.logical.DrillFilterJoinRules
Rule that pushes predicates from a Filter into the Join below them.
DRILL_INIT - Static variable in class org.apache.drill.exec.compile.sig.SignatureHolder
 
DRILL_INIT_METHOD - Static variable in class org.apache.drill.exec.compile.sig.SignatureHolder
 
DRILL_JOIN - Static variable in class org.apache.drill.exec.planner.logical.DrillFilterJoinRules
Rule that pushes predicates in a Join into the inputs to the join.
DRILL_LOGICAL - Static variable in interface org.apache.drill.exec.planner.logical.DrillRel
Calling convention for relational expressions that are "implemented" by generating Drill logical plans.
DRILL_LOGICAL_FILTER_FACTORY - Static variable in class org.apache.drill.exec.planner.logical.DrillRelFactories
 
DRILL_LOGICAL_INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillPushProjIntoScan
 
DRILL_LOGICAL_JOIN_FACTORY - Static variable in class org.apache.drill.exec.planner.logical.DrillRelFactories
 
DRILL_LOGICAL_PROJECT_FACTORY - Static variable in class org.apache.drill.exec.planner.logical.DrillRelFactories
 
DRILL_PHYSICAL - Static variable in interface org.apache.drill.exec.planner.physical.Prel
 
DRILL_PORT_HUNT - Static variable in class org.apache.drill.exec.ExecConstants
 
DRILL_REL_DATATYPE_SYSTEM - Static variable in class org.apache.drill.exec.planner.types.DrillRelDataTypeSystem
 
DRILL_SYS_FILE_SUFFIX - Static variable in class org.apache.drill.exec.ExecConstants
 
DRILL_SYSTEM_FILTER - Static variable in class org.apache.drill.exec.util.DrillFileSystemUtil
Path filter that skips all files and folders that start with dot or underscore.
DRILL_TMP_DIR - Static variable in class org.apache.drill.exec.ExecConstants
Local temporary directory is used as base for temporary storage of Dynamic UDF jars.
DRILL_VERSION_PROPERTY - Static variable in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
 
DRILL_WRITER_VERSION_STD_DATE_FORMAT - Static variable in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
Version 2 (and later) of the Drill Parquet writer uses the date format described in the Parquet spec.
DrillAggFunc - Interface in org.apache.drill.exec.expr
Aggregate function interface.
DrillAggregateRel - Class in org.apache.drill.exec.planner.logical
Aggregation implemented in Drill.
DrillAggregateRel(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.drill.exec.planner.logical.DrillAggregateRel
Creates a DrillAggregateRel.
DrillAggregateRelBase - Class in org.apache.drill.exec.planner.common
Base class for logical and physical Aggregations implemented in Drill
DrillAggregateRelBase(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.drill.exec.planner.common.DrillAggregateRelBase
 
DrillAggregateRule - Class in org.apache.drill.exec.planner.logical
Rule that converts an LogicalAggregate to a DrillAggregateRel, implemented by a Drill "segment" operation followed by a "collapseaggregate" operation.
DrillAvgVarianceConvertlet - Class in org.apache.drill.exec.planner.sql
 
DrillAvgVarianceConvertlet(SqlAvgAggFunction.Subtype) - Constructor for class org.apache.drill.exec.planner.sql.DrillAvgVarianceConvertlet
 
Drillbit - Class in org.apache.drill.exec.server
Starts, tracks and stops all the required services for a Drillbit daemon to work.
Drillbit(DrillConfig, RemoteServiceSet) - Constructor for class org.apache.drill.exec.server.Drillbit
 
Drillbit(DrillConfig, CaseInsensitiveMap<OptionDefinition>, RemoteServiceSet) - Constructor for class org.apache.drill.exec.server.Drillbit
 
Drillbit(DrillConfig, RemoteServiceSet, ScanResult) - Constructor for class org.apache.drill.exec.server.Drillbit
 
Drillbit(DrillConfig, CaseInsensitiveMap<OptionDefinition>, RemoteServiceSet, ScanResult) - Constructor for class org.apache.drill.exec.server.Drillbit
 
DRILLBIT_CONTROL_INJECTIONS - Static variable in class org.apache.drill.exec.ExecConstants
 
DRILLBIT_CONTROLS_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
DrillbitContext - Class in org.apache.drill.exec.server
 
DrillbitContext(CoordinationProtos.DrillbitEndpoint, BootStrapContext, ClusterCoordinator, Controller, DataConnectionCreator, WorkEventBus, PersistentStoreProvider) - Constructor for class org.apache.drill.exec.server.DrillbitContext
 
DrillbitContext(CoordinationProtos.DrillbitEndpoint, BootStrapContext, ClusterCoordinator, Controller, DataConnectionCreator, WorkEventBus, PersistentStoreProvider, PersistentStoreProvider) - Constructor for class org.apache.drill.exec.server.DrillbitContext
 
DrillbitEndpointSerDe - Class in org.apache.drill.exec.coord
 
DrillbitEndpointSerDe() - Constructor for class org.apache.drill.exec.coord.DrillbitEndpointSerDe
 
DrillbitEndpointSerDe.De - Class in org.apache.drill.exec.coord
 
DrillbitEndpointSerDe.De() - Constructor for class org.apache.drill.exec.coord.DrillbitEndpointSerDe.De
 
DrillbitEndpointSerDe.Se - Class in org.apache.drill.exec.coord
 
DrillbitEndpointSerDe.Se() - Constructor for class org.apache.drill.exec.coord.DrillbitEndpointSerDe.Se
 
DrillbitIterator - Class in org.apache.drill.exec.store.sys
 
DrillbitIterator(FragmentContext) - Constructor for class org.apache.drill.exec.store.sys.DrillbitIterator
 
DrillbitIterator.DrillbitInstance - Class in org.apache.drill.exec.store.sys
 
DrillbitIterator.DrillbitInstance() - Constructor for class org.apache.drill.exec.store.sys.DrillbitIterator.DrillbitInstance
 
drillbitRegistered(Set<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.coord.ClusterCoordinator
 
drillbitRegistered(Set<CoordinationProtos.DrillbitEndpoint>) - Method in interface org.apache.drill.exec.work.foreman.DrillbitStatusListener
The action to taken when a set of new drillbits are registered to the cluster.
DrillbitStartupException - Exception in org.apache.drill.exec.exception
 
DrillbitStartupException() - Constructor for exception org.apache.drill.exec.exception.DrillbitStartupException
 
DrillbitStartupException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.drill.exec.exception.DrillbitStartupException
 
DrillbitStartupException(String, Throwable) - Constructor for exception org.apache.drill.exec.exception.DrillbitStartupException
 
DrillbitStartupException(String) - Constructor for exception org.apache.drill.exec.exception.DrillbitStartupException
 
DrillbitStartupException(Throwable) - Constructor for exception org.apache.drill.exec.exception.DrillbitStartupException
 
DrillbitStateManager - Class in org.apache.drill.exec.server
 
DrillbitStateManager(DrillbitStateManager.DrillbitState) - Constructor for class org.apache.drill.exec.server.DrillbitStateManager
 
DrillbitStateManager.DrillbitState - Enum in org.apache.drill.exec.server
 
DrillbitStatusListener - Interface in org.apache.drill.exec.work.foreman
Interface to define the listener to take actions when the set of active drillbits is changed.
drillbitToQuiescentMode() - Method in class org.apache.drill.exec.server.rest.DrillRoot
 
drillbitUnregistered(Set<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.coord.ClusterCoordinator
Actions to take when there are a set of new de-active drillbits.
drillbitUnregistered(Set<CoordinationProtos.DrillbitEndpoint>) - Method in interface org.apache.drill.exec.work.foreman.DrillbitStatusListener
The action to taken when a set of drillbits are unregistered from the cluster.
DrillBufInputStream - Class in org.apache.drill.exec.vector.complex.fn
An InputStream that wraps a DrillBuf and implements the seekable interface.
DrillByteArray - Class in org.apache.drill.exec.expr.fn.impl
Thin wrapper around byte array.
DrillByteArray() - Constructor for class org.apache.drill.exec.expr.fn.impl.DrillByteArray
 
DrillByteArray(byte[], int) - Constructor for class org.apache.drill.exec.expr.fn.impl.DrillByteArray
 
DrillByteArray(byte[]) - Constructor for class org.apache.drill.exec.expr.fn.impl.DrillByteArray
 
DrillCalciteSqlAggFunctionWrapper - Class in org.apache.drill.exec.planner.sql
This class serves as a wrapper class for SqlAggFunction.
DrillCalciteSqlAggFunctionWrapper(SqlAggFunction, List<DrillFuncHolder>) - Constructor for class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
DrillCalciteSqlAggFunctionWrapper(SqlAggFunction, RelDataType) - Constructor for class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
DrillCalciteSqlFunctionWrapper - Class in org.apache.drill.exec.planner.sql
This class serves as a wrapper class for SqlFunction.
DrillCalciteSqlFunctionWrapper(SqlFunction, List<DrillFuncHolder>) - Constructor for class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
DrillCalciteSqlOperatorWrapper - Class in org.apache.drill.exec.planner.sql
This class serves as a wrapper class for SqlOperator.
DrillCalciteSqlOperatorWrapper(SqlOperator, String, List<DrillFuncHolder>) - Constructor for class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
DrillCalciteSqlWrapper - Interface in org.apache.drill.exec.planner.sql
This interface is meant for the users of the wrappers, DrillCalciteSqlOperatorWrapper, DrillCalciteSqlFunctionWrapper and DrillCalciteSqlAggFunctionWrapper, to access the wrapped Calcite SqlOperator without knowing exactly which wrapper it is.
DrillCalciteWrapperUtility - Class in org.apache.drill.exec.planner.sql.parser
DrillCheckClassAdapter - Class in org.apache.drill.exec.compile
There's a bug in ASM's CheckClassAdapter.
DrillCheckClassAdapter(ClassVisitor) - Constructor for class org.apache.drill.exec.compile.DrillCheckClassAdapter
See CheckClassAdapter.CheckClassAdapter(ClassVisitor).
DrillCheckClassAdapter(int, ClassVisitor) - Constructor for class org.apache.drill.exec.compile.DrillCheckClassAdapter
See CheckClassAdapter.CheckClassAdapter(ClassVisitor).
DrillCheckClassAdapter(int, ClassVisitor, boolean) - Constructor for class org.apache.drill.exec.compile.DrillCheckClassAdapter
See CheckClassAdapter.CheckClassAdapter(ClassVisitor, boolean).
DrillClient - Class in org.apache.drill.exec.client
Thin wrapper around a UserClient that handles connect/close and transforms String into ByteBuf.
DrillClient() - Constructor for class org.apache.drill.exec.client.DrillClient
 
DrillClient(boolean) - Constructor for class org.apache.drill.exec.client.DrillClient
 
DrillClient(String) - Constructor for class org.apache.drill.exec.client.DrillClient
 
DrillClient(DrillConfig) - Constructor for class org.apache.drill.exec.client.DrillClient
 
DrillClient(DrillConfig, boolean) - Constructor for class org.apache.drill.exec.client.DrillClient
 
DrillClient(DrillConfig, ClusterCoordinator) - Constructor for class org.apache.drill.exec.client.DrillClient
 
DrillClient(DrillConfig, ClusterCoordinator, boolean) - Constructor for class org.apache.drill.exec.client.DrillClient
 
DrillClient(DrillConfig, ClusterCoordinator, BufferAllocator) - Constructor for class org.apache.drill.exec.client.DrillClient
 
DrillClient(DrillConfig, ClusterCoordinator, BufferAllocator, boolean) - Constructor for class org.apache.drill.exec.client.DrillClient
 
DrillComplexWriterFuncHolder - Class in org.apache.drill.exec.expr.fn
 
DrillComplexWriterFuncHolder(FunctionAttributes, FunctionInitializer) - Constructor for class org.apache.drill.exec.expr.fn.DrillComplexWriterFuncHolder
 
DrillCompoundIdentifier - Class in org.apache.drill.exec.planner.sql.parser
 
DrillCompoundIdentifier(List<DrillCompoundIdentifier.IdentifierHolder>) - Constructor for class org.apache.drill.exec.planner.sql.parser.DrillCompoundIdentifier
 
DrillCompoundIdentifier.Builder - Class in org.apache.drill.exec.planner.sql.parser
 
DrillCompoundIdentifier.Builder() - Constructor for class org.apache.drill.exec.planner.sql.parser.DrillCompoundIdentifier.Builder
 
DrillConditions - Class in org.apache.drill.exec.planner.logical
 
DrillConditions() - Constructor for class org.apache.drill.exec.planner.logical.DrillConditions
 
DrillConfigIterator - Class in org.apache.drill.exec.server.options
 
DrillConfigIterator(DrillConfig) - Constructor for class org.apache.drill.exec.server.options.DrillConfigIterator
 
DrillConfigIterator.Iter - Class in org.apache.drill.exec.server.options
 
DrillConfigIterator.Iter(DrillConfig) - Constructor for class org.apache.drill.exec.server.options.DrillConfigIterator.Iter
 
DrillConstExecutor - Class in org.apache.drill.exec.planner.logical
 
DrillConstExecutor(FunctionImplementationRegistry, UdfUtilities, PlannerSettings) - Constructor for class org.apache.drill.exec.planner.logical.DrillConstExecutor
 
DrillConvertletTable - Class in org.apache.drill.exec.planner.sql
 
DrillCostBase - Class in org.apache.drill.exec.planner.cost
Implementation of the DrillRelOptCost, modeled similar to VolcanoCost
DrillCostBase(double, double, double, double) - Constructor for class org.apache.drill.exec.planner.cost.DrillCostBase
 
DrillCostBase(double, double, double, double, double) - Constructor for class org.apache.drill.exec.planner.cost.DrillCostBase
 
DrillCostBase.DrillCostFactory - Class in org.apache.drill.exec.planner.cost
 
DrillCostBase.DrillCostFactory() - Constructor for class org.apache.drill.exec.planner.cost.DrillCostBase.DrillCostFactory
 
DrillDefaultRelMetadataProvider - Class in org.apache.drill.exec.planner.cost
 
DrillDirectScanRel - Class in org.apache.drill.exec.planner.logical
Logical RelNode representing a DirectGroupScan.
DrillDirectScanRel(RelOptCluster, RelTraitSet, DirectGroupScan, RelDataType) - Constructor for class org.apache.drill.exec.planner.logical.DrillDirectScanRel
 
DrillDistributionTrait - Class in org.apache.drill.exec.planner.physical
 
DrillDistributionTrait(DrillDistributionTrait.DistributionType) - Constructor for class org.apache.drill.exec.planner.physical.DrillDistributionTrait
 
DrillDistributionTrait(DrillDistributionTrait.DistributionType, ImmutableList<DrillDistributionTrait.DistributionField>) - Constructor for class org.apache.drill.exec.planner.physical.DrillDistributionTrait
 
DrillDistributionTrait.DistributionField - Class in org.apache.drill.exec.planner.physical
 
DrillDistributionTrait.DistributionField(int) - Constructor for class org.apache.drill.exec.planner.physical.DrillDistributionTrait.DistributionField
 
DrillDistributionTrait.DistributionType - Enum in org.apache.drill.exec.planner.physical
 
DrillDistributionTraitDef - Class in org.apache.drill.exec.planner.physical
 
DrillExtractConvertlet - Class in org.apache.drill.exec.planner.sql
 
DrillFileSystem - Class in org.apache.drill.exec.store.dfs
DrillFileSystem is the wrapper around the actual FileSystem implementation.
DrillFileSystem(Configuration) - Constructor for class org.apache.drill.exec.store.dfs.DrillFileSystem
 
DrillFileSystem(Configuration, OperatorStatReceiver) - Constructor for class org.apache.drill.exec.store.dfs.DrillFileSystem
 
DrillFileSystem.DebugStackTrace - Class in org.apache.drill.exec.store.dfs
 
DrillFileSystem.DebugStackTrace(Path, StackTraceElement[]) - Constructor for class org.apache.drill.exec.store.dfs.DrillFileSystem.DebugStackTrace
 
DrillFileSystemUtil - Class in org.apache.drill.exec.util
In Drill file system all directories and files that start with dot or underscore is ignored.
DrillFileSystemUtil() - Constructor for class org.apache.drill.exec.util.DrillFileSystemUtil
 
DrillFilterAggregateTransposeRule - Class in org.apache.drill.exec.planner.logical
 
DrillFilterJoinRules - Class in org.apache.drill.exec.planner.logical
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
DrillFilterJoinRules() - Constructor for class org.apache.drill.exec.planner.logical.DrillFilterJoinRules
 
DrillFilterRel - Class in org.apache.drill.exec.planner.logical
 
DrillFilterRel(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.drill.exec.planner.logical.DrillFilterRel
 
DrillFilterRelBase - Class in org.apache.drill.exec.planner.common
Base class for logical and physical Filters implemented in Drill
DrillFilterRelBase(Convention, RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.drill.exec.planner.common.DrillFilterRelBase
 
DrillFilterRule - Class in org.apache.drill.exec.planner.logical
Rule that converts a org.apache.calcite.rel.FilterRel to a Drill "filter" operation.
DrillFixedRelDataTypeImpl - Class in org.apache.drill.exec.planner.types
Implements RowType for fixed field list with ANY type.
DrillFixedRelDataTypeImpl(RelDataTypeFactory, List<String>) - Constructor for class org.apache.drill.exec.planner.types.DrillFixedRelDataTypeImpl
 
drillFormattedFieldName(String) - Static method in class org.apache.drill.exec.store.httpd.HttpdParser
Drill cannot deal with fields with dots in them like request.referer.
DrillFSDataInputStream - Class in org.apache.drill.exec.store.dfs
Wrapper around FSDataInputStream to collect IO Stats.
DrillFSDataInputStream(FSDataInputStream, OperatorStatReceiver) - Constructor for class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
DrillFSDataInputStream(FSDataInputStream, OperatorStatReceiver, OpenFileTracker) - Constructor for class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
DrillFunc - Interface in org.apache.drill.exec.expr
 
DrillFuncHolder - Class in org.apache.drill.exec.expr.fn
 
DrillFuncHolder(FunctionAttributes, FunctionInitializer) - Constructor for class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
DrillFuncHolderExpr - Class in org.apache.drill.exec.expr
 
DrillFuncHolderExpr(String, DrillFuncHolder, List<LogicalExpression>, ExpressionPosition) - Constructor for class org.apache.drill.exec.expr.DrillFuncHolderExpr
 
DrillHash - Class in org.apache.drill.exec.expr.fn.impl
The base class of hash classes used in Drill.
DrillHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.DrillHash
 
DrillImplementor - Class in org.apache.drill.exec.planner.logical
Context for converting a tree of DrillRel nodes into a Drill logical plan.
DrillImplementor(DrillParseContext, PlanProperties.Generator.ResultMode) - Constructor for class org.apache.drill.exec.planner.logical.DrillImplementor
 
DrillInitMethodVisitor - Class in org.apache.drill.exec.compile
 
DrillInitMethodVisitor(String, MethodVisitor) - Constructor for class org.apache.drill.exec.compile.DrillInitMethodVisitor
 
DrillJoinRel - Class in org.apache.drill.exec.planner.logical
Logical Join implemented in Drill.
DrillJoinRel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType) - Constructor for class org.apache.drill.exec.planner.logical.DrillJoinRel
Creates a DrillJoinRel.
DrillJoinRel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, List<Integer>, List<Integer>) - Constructor for class org.apache.drill.exec.planner.logical.DrillJoinRel
 
DrillJoinRelBase - Class in org.apache.drill.exec.planner.common
Base class for logical and physical Joins implemented in Drill.
DrillJoinRelBase(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType) - Constructor for class org.apache.drill.exec.planner.common.DrillJoinRelBase
 
DrillJoinRule - Class in org.apache.drill.exec.planner.logical
Rule that converts a LogicalJoin to a DrillJoinRel, which is implemented by Drill "join" operation.
DrillLimitRel - Class in org.apache.drill.exec.planner.logical
 
DrillLimitRel(RelOptCluster, RelTraitSet, RelNode, RexNode, RexNode) - Constructor for class org.apache.drill.exec.planner.logical.DrillLimitRel
 
DrillLimitRelBase - Class in org.apache.drill.exec.planner.common
Base class for logical and physical Limits implemented in Drill
DrillLimitRelBase(RelOptCluster, RelTraitSet, RelNode, RexNode, RexNode) - Constructor for class org.apache.drill.exec.planner.common.DrillLimitRelBase
 
DrillLimitRelBase(RelOptCluster, RelTraitSet, RelNode, RexNode, RexNode, boolean) - Constructor for class org.apache.drill.exec.planner.common.DrillLimitRelBase
 
DrillLimitRule - Class in org.apache.drill.exec.planner.logical
This rule converts a Sort that has either a offset and fetch into a Drill Sort and LimitPOP Rel
DrillMergeFilterRule - Class in org.apache.drill.exec.planner.logical
MergeFilterRule implements the rule for combining two Filters
DrillMergeProjectRule - Class in org.apache.drill.exec.planner.logical
 
DrillOperatorTable - Class in org.apache.drill.exec.planner.sql
Implementation of SqlOperatorTable that contains standard operators and functions provided through SqlStdOperatorTable, and Drill User Defined Functions.
DrillOperatorTable(FunctionImplementationRegistry, OptionManager) - Constructor for class org.apache.drill.exec.planner.sql.DrillOperatorTable
 
DrillOptiq - Class in org.apache.drill.exec.planner.logical
Utilities for Drill's planner.
DrillOptiq() - Constructor for class org.apache.drill.exec.planner.logical.DrillOptiq
 
DrillParquetGroupConverter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter(OutputMutator, ComplexWriterImpl, MessageType, Collection<SchemaPath>, OptionManager, ParquetReaderUtility.DateCorruptionStatus) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter
 
DrillParquetGroupConverter(OutputMutator, BaseWriter.MapWriter, GroupType, Collection<SchemaPath>, OptionManager, ParquetReaderUtility.DateCorruptionStatus) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter
 
DrillParquetGroupConverter.CorruptionDetectingDateConverter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.CorruptionDetectingDateConverter(DateWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.CorruptionDetectingDateConverter
 
DrillParquetGroupConverter.DrillBigIntConverter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillBigIntConverter(BigIntWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillBigIntConverter
 
DrillParquetGroupConverter.DrillBinaryToDecimal28Converter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillBinaryToDecimal28Converter(Decimal28SparseWriter, int, int, DrillBuf) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillBinaryToDecimal28Converter
 
DrillParquetGroupConverter.DrillBinaryToDecimal38Converter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillBinaryToDecimal38Converter(Decimal38SparseWriter, int, int, DrillBuf) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillBinaryToDecimal38Converter
 
DrillParquetGroupConverter.DrillBoolConverter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillBoolConverter(BitWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillBoolConverter
 
DrillParquetGroupConverter.DrillCorruptedDateConverter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillCorruptedDateConverter(DateWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillCorruptedDateConverter
 
DrillParquetGroupConverter.DrillDateConverter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillDateConverter(DateWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillDateConverter
 
DrillParquetGroupConverter.DrillDecimal18Converter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillDecimal18Converter(Decimal18Writer, int, int) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillDecimal18Converter
 
DrillParquetGroupConverter.DrillDecimal9Converter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillDecimal9Converter(Decimal9Writer, int, int) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillDecimal9Converter
 
DrillParquetGroupConverter.DrillFixedBinaryToTimeStampConverter - Class in org.apache.drill.exec.store.parquet2
Parquet currently supports a fixed binary type INT96 for storing hive, impala timestamp with nanoseconds precision.
DrillParquetGroupConverter.DrillFixedBinaryToTimeStampConverter(TimeStampWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillFixedBinaryToTimeStampConverter
 
DrillParquetGroupConverter.DrillFixedBinaryToVarbinaryConverter - Class in org.apache.drill.exec.store.parquet2
Parquet currently supports a fixed binary type, which is not implemented in Drill.
DrillParquetGroupConverter.DrillFixedBinaryToVarbinaryConverter(VarBinaryWriter, int, DrillBuf) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillFixedBinaryToVarbinaryConverter
 
DrillParquetGroupConverter.DrillFixedLengthByteArrayToInterval - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillFixedLengthByteArrayToInterval(IntervalWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillFixedLengthByteArrayToInterval
 
DrillParquetGroupConverter.DrillFloat4Converter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillFloat4Converter(Float4Writer) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillFloat4Converter
 
DrillParquetGroupConverter.DrillFloat8Converter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillFloat8Converter(Float8Writer) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillFloat8Converter
 
DrillParquetGroupConverter.DrillIntConverter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillIntConverter(IntWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillIntConverter
 
DrillParquetGroupConverter.DrillTimeConverter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillTimeConverter(TimeWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillTimeConverter
 
DrillParquetGroupConverter.DrillTimeStampConverter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillTimeStampConverter(TimeStampWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillTimeStampConverter
 
DrillParquetGroupConverter.DrillVarBinaryConverter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillVarBinaryConverter(VarBinaryWriter, DrillBuf) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillVarBinaryConverter
 
DrillParquetGroupConverter.DrillVarCharConverter - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetGroupConverter.DrillVarCharConverter(VarCharWriter, DrillBuf) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillVarCharConverter
 
DrillParquetReader - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetReader(FragmentContext, ParquetMetadata, RowGroupReadEntry, List<SchemaPath>, DrillFileSystem, ParquetReaderUtility.DateCorruptionStatus) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetReader
 
DrillParquetReader.ProjectedColumnType - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetRecordMaterializer - Class in org.apache.drill.exec.store.parquet2
 
DrillParquetRecordMaterializer(OutputMutator, BaseWriter.ComplexWriter, MessageType, Collection<SchemaPath>, OptionManager, ParquetReaderUtility.DateCorruptionStatus) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetRecordMaterializer
 
DrillParseContext - Class in org.apache.drill.exec.planner.logical
 
DrillParseContext(PlannerSettings) - Constructor for class org.apache.drill.exec.planner.logical.DrillParseContext
 
DrillParserConfig - Class in org.apache.drill.exec.planner.sql
 
DrillParserConfig(PlannerSettings) - Constructor for class org.apache.drill.exec.planner.sql.DrillParserConfig
 
DrillParserImpl - Class in org.apache.drill.exec.planner.sql.parser.impl
SQL parser, generated from Parser.jj by JavaCC.
DrillParserImpl(InputStream) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
DrillParserImpl(InputStream, String) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
DrillParserImpl(Reader) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
DrillParserImpl(DrillParserImplTokenManager) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
DrillParserImplConstants - Interface in org.apache.drill.exec.planner.sql.parser.impl
 
DrillParserImplTokenManager - Class in org.apache.drill.exec.planner.sql.parser.impl
 
DrillParserImplTokenManager(SimpleCharStream) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplTokenManager
 
DrillParserImplTokenManager(SimpleCharStream, int) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplTokenManager
 
DrillParserUtil - Class in org.apache.drill.exec.planner.sql.parser
Helper methods or constants used in parsing a SQL query.
DrillParserUtil() - Constructor for class org.apache.drill.exec.planner.sql.parser.DrillParserUtil
 
DrillParserWithCompoundIdConverter - Class in org.apache.drill.exec.planner.sql.parser.impl
 
DrillParserWithCompoundIdConverter(Reader) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.DrillParserWithCompoundIdConverter
 
DrillProjectRel - Class in org.apache.drill.exec.planner.logical
Project implemented in Drill.
DrillProjectRel(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.drill.exec.planner.logical.DrillProjectRel
 
DrillProjectRelBase - Class in org.apache.drill.exec.planner.common
Base class for logical and physical Project implemented in Drill
DrillProjectRelBase(Convention, RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.drill.exec.planner.common.DrillProjectRelBase
 
DrillProjectRule - Class in org.apache.drill.exec.planner.logical
Rule that converts a LogicalProject to a Drill "project" operation.
DrillProjectSetOpTransposeRule - Class in org.apache.drill.exec.planner.logical
 
DrillProjectSetOpTransposeRule(PushProjector.ExprCondition) - Constructor for class org.apache.drill.exec.planner.logical.DrillProjectSetOpTransposeRule
 
DrillPushFilterPastProjectRule - Class in org.apache.drill.exec.planner.logical
 
DrillPushFilterPastProjectRule() - Constructor for class org.apache.drill.exec.planner.logical.DrillPushFilterPastProjectRule
 
DrillPushLimitToScanRule - Class in org.apache.drill.exec.planner.logical
 
DrillPushProjectPastFilterRule - Class in org.apache.drill.exec.planner.logical
 
DrillPushProjectPastFilterRule(PushProjector.ExprCondition) - Constructor for class org.apache.drill.exec.planner.logical.DrillPushProjectPastFilterRule
 
DrillPushProjectPastJoinRule - Class in org.apache.drill.exec.planner.logical
 
DrillPushProjectPastJoinRule(PushProjector.ExprCondition) - Constructor for class org.apache.drill.exec.planner.logical.DrillPushProjectPastJoinRule
 
DrillPushProjIntoScan - Class in org.apache.drill.exec.planner.logical
 
DrillReduceAggregatesRule - Class in org.apache.drill.exec.planner.logical
Rule to reduce aggregates to simpler forms.
DrillReduceAggregatesRule(RelOptRuleOperand) - Constructor for class org.apache.drill.exec.planner.logical.DrillReduceAggregatesRule
 
DrillReduceExpressionsRule - Class in org.apache.drill.exec.planner.logical
 
DrillReduceExpressionsRule() - Constructor for class org.apache.drill.exec.planner.logical.DrillReduceExpressionsRule
 
DrillRel - Interface in org.apache.drill.exec.planner.logical
Relational expression that is implemented in Drill.
DrillRelDataTypeSystem - Class in org.apache.drill.exec.planner.types
 
DrillRelDataTypeSystem() - Constructor for class org.apache.drill.exec.planner.types.DrillRelDataTypeSystem
 
DrillRelFactories - Class in org.apache.drill.exec.planner.logical
Contains factory implementation for creating various Drill Logical Rel nodes.
DrillRelFactories() - Constructor for class org.apache.drill.exec.planner.logical.DrillRelFactories
 
DrillRelMdDistinctRowCount - Class in org.apache.drill.exec.planner.cost
 
DrillRelMdDistinctRowCount() - Constructor for class org.apache.drill.exec.planner.cost.DrillRelMdDistinctRowCount
 
DrillRelMdRowCount - Class in org.apache.drill.exec.planner.cost
 
DrillRelMdRowCount() - Constructor for class org.apache.drill.exec.planner.cost.DrillRelMdRowCount
 
DrillRelNode - Interface in org.apache.drill.exec.planner.common
 
DrillRelOptCost - Interface in org.apache.drill.exec.planner.cost
 
DrillRelOptCostFactory - Interface in org.apache.drill.exec.planner.cost
 
DrillRelOptUtil - Class in org.apache.drill.exec.planner.common
Utility class that is a subset of the RelOptUtil class and is a placeholder for Drill specific static methods that are needed during either logical or physical planning.
DrillRelOptUtil() - Constructor for class org.apache.drill.exec.planner.common.DrillRelOptUtil
 
DrillRestLoginService - Class in org.apache.drill.exec.server.rest.auth
LoginService used when user authentication is enabled in Drillbit.
DrillRestLoginService(DrillbitContext) - Constructor for class org.apache.drill.exec.server.rest.auth.DrillRestLoginService
 
DrillRestServer - Class in org.apache.drill.exec.server.rest
 
DrillRestServer(WorkManager, ServletContext, Drillbit) - Constructor for class org.apache.drill.exec.server.rest.DrillRestServer
 
DrillRestServer.AnonDrillUserPrincipalProvider - Class in org.apache.drill.exec.server.rest
 
DrillRestServer.AnonDrillUserPrincipalProvider() - Constructor for class org.apache.drill.exec.server.rest.DrillRestServer.AnonDrillUserPrincipalProvider
 
DrillRestServer.AnonWebUserConnectionProvider - Class in org.apache.drill.exec.server.rest
 
DrillRestServer.AnonWebUserConnectionProvider() - Constructor for class org.apache.drill.exec.server.rest.DrillRestServer.AnonWebUserConnectionProvider
 
DrillRestServer.AuthWebUserConnectionProvider - Class in org.apache.drill.exec.server.rest
 
DrillRestServer.AuthWebUserConnectionProvider() - Constructor for class org.apache.drill.exec.server.rest.DrillRestServer.AuthWebUserConnectionProvider
 
DrillRestServer.DrillUserPrincipalProvider - Class in org.apache.drill.exec.server.rest
 
DrillRestServer.DrillUserPrincipalProvider() - Constructor for class org.apache.drill.exec.server.rest.DrillRestServer.DrillUserPrincipalProvider
 
DrillRestServer.UserAuthEnabled - Class in org.apache.drill.exec.server.rest
 
DrillRestServer.UserAuthEnabled(boolean) - Constructor for class org.apache.drill.exec.server.rest.DrillRestServer.UserAuthEnabled
 
DrillRoot - Class in org.apache.drill.exec.server.rest
 
DrillRoot() - Constructor for class org.apache.drill.exec.server.rest.DrillRoot
 
DrillRoot.ClusterInfo - Class in org.apache.drill.exec.server.rest
 
DrillRoot.ClusterInfo(Collection<DrillRoot.DrillbitInfo>, String, Collection<String>, boolean, boolean, boolean, DrillRoot.QueueInfo) - Constructor for class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
 
DrillRoot.ClusterInfo(Collection<DrillRoot.DrillbitInfo>, String, Collection<String>, boolean, boolean, boolean, DrillRoot.QueueInfo, String, String, String, String) - Constructor for class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
 
DrillRoot.DrillbitInfo - Class in org.apache.drill.exec.server.rest
 
DrillRoot.DrillbitInfo(CoordinationProtos.DrillbitEndpoint, boolean, boolean) - Constructor for class org.apache.drill.exec.server.rest.DrillRoot.DrillbitInfo
 
DrillRoot.QueueInfo - Class in org.apache.drill.exec.server.rest
Pretty-printing wrapper class around the ZK-based queue summary.
DrillRoot.QueueInfo(DistributedQueryQueue.ZKQueueInfo) - Constructor for class org.apache.drill.exec.server.rest.DrillRoot.QueueInfo
 
DrillScanPrel - Interface in org.apache.drill.exec.planner.physical
 
DrillScanRel - Class in org.apache.drill.exec.planner.logical
GroupScan of a Drill table.
DrillScanRel(RelOptCluster, RelTraitSet, RelOptTable) - Constructor for class org.apache.drill.exec.planner.logical.DrillScanRel
Creates a DrillScan.
DrillScanRel(RelOptCluster, RelTraitSet, RelOptTable, boolean) - Constructor for class org.apache.drill.exec.planner.logical.DrillScanRel
Creates a DrillScan.
DrillScanRel(RelOptCluster, RelTraitSet, RelOptTable, RelDataType, List<SchemaPath>) - Constructor for class org.apache.drill.exec.planner.logical.DrillScanRel
Creates a DrillScan.
DrillScanRel(RelOptCluster, RelTraitSet, RelOptTable, RelDataType, List<SchemaPath>, boolean) - Constructor for class org.apache.drill.exec.planner.logical.DrillScanRel
Creates a DrillScan.
DrillScanRel(RelOptCluster, RelTraitSet, RelOptTable, GroupScan, RelDataType, List<SchemaPath>) - Constructor for class org.apache.drill.exec.planner.logical.DrillScanRel
Creates a DrillScanRel for a particular GroupScan
DrillScanRel(RelOptCluster, RelTraitSet, RelOptTable, GroupScan, RelDataType, List<SchemaPath>, boolean) - Constructor for class org.apache.drill.exec.planner.logical.DrillScanRel
Creates a DrillScanRel for a particular GroupScan
DrillScanRelBase - Class in org.apache.drill.exec.planner.common
Base class for logical scan rel implemented in Drill.
DrillScanRelBase(Convention, RelOptCluster, RelTraitSet, RelOptTable) - Constructor for class org.apache.drill.exec.planner.common.DrillScanRelBase
 
DrillScanRelBase(Convention, RelOptCluster, RelTraitSet, RelOptTable, DrillTable) - Constructor for class org.apache.drill.exec.planner.common.DrillScanRelBase
 
DrillScanRule - Class in org.apache.drill.exec.planner.logical
 
DrillScreenRel - Class in org.apache.drill.exec.planner.logical
 
DrillScreenRel(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.drill.exec.planner.logical.DrillScreenRel
 
DrillScreenRelBase - Class in org.apache.drill.exec.planner.common
Base class for logical and physical Screen implemented in Drill
DrillScreenRelBase(Convention, RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.drill.exec.planner.common.DrillScreenRelBase
 
DrillSerializable - Interface in org.apache.drill.exec.cache
Classes that can be put in the Distributed Cache must implement this interface.
DrillServiceInstanceHelper - Class in org.apache.drill.exec.coord
 
DrillServiceInstanceHelper() - Constructor for class org.apache.drill.exec.coord.DrillServiceInstanceHelper
 
DrillSimpleFunc - Interface in org.apache.drill.exec.expr
 
DrillSimpleFuncHolder - Class in org.apache.drill.exec.expr.fn
 
DrillSimpleFuncHolder(FunctionAttributes, FunctionInitializer) - Constructor for class org.apache.drill.exec.expr.fn.DrillSimpleFuncHolder
 
DrillSortRel - Class in org.apache.drill.exec.planner.logical
Sort implemented in Drill.
DrillSortRel(RelOptCluster, RelTraitSet, RelNode, RelCollation) - Constructor for class org.apache.drill.exec.planner.logical.DrillSortRel
Creates a DrillSortRel.
DrillSortRel(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.drill.exec.planner.logical.DrillSortRel
Creates a DrillSortRel with offset and fetch.
DrillSortRule - Class in org.apache.drill.exec.planner.logical
Rule that converts an Sort to a DrillSortRel, implemented by a Drill "order" operation.
DrillSqlAggOperator - Class in org.apache.drill.exec.planner.sql
 
DrillSqlAggOperator(String, List<DrillFuncHolder>, int, int, SqlReturnTypeInference) - Constructor for class org.apache.drill.exec.planner.sql.DrillSqlAggOperator
 
DrillSqlAggOperator.DrillSqlAggOperatorBuilder - Class in org.apache.drill.exec.planner.sql
 
DrillSqlAggOperator.DrillSqlAggOperatorBuilder() - Constructor for class org.apache.drill.exec.planner.sql.DrillSqlAggOperator.DrillSqlAggOperatorBuilder
 
DrillSqlAggOperatorWithoutInference - Class in org.apache.drill.exec.planner.sql
 
DrillSqlAggOperatorWithoutInference(String, int) - Constructor for class org.apache.drill.exec.planner.sql.DrillSqlAggOperatorWithoutInference
 
DrillSqlCall - Class in org.apache.drill.exec.planner.sql.parser
SqlCall interface with addition of method to get the handler.
DrillSqlCall(SqlParserPos) - Constructor for class org.apache.drill.exec.planner.sql.parser.DrillSqlCall
 
DrillSqlOperator - Class in org.apache.drill.exec.planner.sql
 
DrillSqlOperator(String, int, boolean, boolean) - Constructor for class org.apache.drill.exec.planner.sql.DrillSqlOperator
Deprecated.
DrillSqlOperator(String, int, boolean, SqlReturnTypeInference, boolean) - Constructor for class org.apache.drill.exec.planner.sql.DrillSqlOperator
Deprecated.
DrillSqlOperator(String, int, boolean, RelDataType, boolean) - Constructor for class org.apache.drill.exec.planner.sql.DrillSqlOperator
Deprecated.
DrillSqlOperator(String, List<DrillFuncHolder>, int, int, boolean, SqlReturnTypeInference, boolean) - Constructor for class org.apache.drill.exec.planner.sql.DrillSqlOperator
 
DrillSqlOperator.DrillSqlOperatorBuilder - Class in org.apache.drill.exec.planner.sql
 
DrillSqlOperator.DrillSqlOperatorBuilder() - Constructor for class org.apache.drill.exec.planner.sql.DrillSqlOperator.DrillSqlOperatorBuilder
 
DrillSqlOperatorWithoutInference - Class in org.apache.drill.exec.planner.sql
 
DrillSqlOperatorWithoutInference(String, int, TypeProtos.MajorType, boolean, boolean) - Constructor for class org.apache.drill.exec.planner.sql.DrillSqlOperatorWithoutInference
 
DrillSqlWorker - Class in org.apache.drill.exec.planner.sql
 
DrillStoreRel - Class in org.apache.drill.exec.planner.logical
 
DrillStoreRel(RelOptCluster, RelTraitSet, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, boolean) - Constructor for class org.apache.drill.exec.planner.logical.DrillStoreRel
 
DrillStoreRelBase - Class in org.apache.drill.exec.planner.common
Base class for logical and physical Store implemented in Drill
DrillStoreRelBase(RelOptCluster, RelTraitSet, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, boolean) - Constructor for class org.apache.drill.exec.planner.common.DrillStoreRelBase
 
drillTable - Variable in class org.apache.drill.exec.planner.common.DrillScanRelBase
 
DrillTable - Class in org.apache.drill.exec.planner.logical
 
DrillTable(String, StoragePlugin, String, Object) - Constructor for class org.apache.drill.exec.planner.logical.DrillTable
Creates a DrillTable instance for a @{code TableType#Table} table.
DrillTable(String, StoragePlugin, Schema.TableType, String, Object) - Constructor for class org.apache.drill.exec.planner.logical.DrillTable
Creates a DrillTable instance.
DrillTable(String, StoragePlugin, Object) - Constructor for class org.apache.drill.exec.planner.logical.DrillTable
TODO: Same purpose as other constructor except the impersonation user is the user who is running the Drillbit process.
DrillTextRecordReader - Class in org.apache.drill.exec.store.text
 
DrillTextRecordReader(FileSplit, Configuration, FragmentContext, char, List<SchemaPath>) - Constructor for class org.apache.drill.exec.store.text.DrillTextRecordReader
 
DrillTextRecordWriter - Class in org.apache.drill.exec.store.text
 
DrillTextRecordWriter(BufferAllocator, StorageStrategy) - Constructor for class org.apache.drill.exec.store.text.DrillTextRecordWriter
 
DrillTextRecordWriter.ComplexStringFieldConverter - Class in org.apache.drill.exec.store.text
 
DrillTextRecordWriter.ComplexStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.text.DrillTextRecordWriter.ComplexStringFieldConverter
 
DrillTranslatableTable - Class in org.apache.drill.exec.planner.logical
TableMacros must return a TranslatableTable This class adapts the existing DrillTable to a TranslatableTable
DrillTranslatableTable(DrillTable) - Constructor for class org.apache.drill.exec.planner.logical.DrillTranslatableTable
 
DrillUnionAllRule - Class in org.apache.drill.exec.planner.logical
Rule that converts a LogicalUnion to a DrillUnionRelBase, implemented by a "union" operation.
DrillUnionRel - Class in org.apache.drill.exec.planner.logical
Union implemented in Drill.
DrillUnionRel(RelOptCluster, RelTraitSet, List<RelNode>, boolean, boolean) - Constructor for class org.apache.drill.exec.planner.logical.DrillUnionRel
Creates a DrillUnionRel.
DrillUnionRelBase - Class in org.apache.drill.exec.planner.common
Base class for logical and physical Union implemented in Drill
DrillUnionRelBase(RelOptCluster, RelTraitSet, List<RelNode>, boolean, boolean) - Constructor for class org.apache.drill.exec.planner.common.DrillUnionRelBase
 
DrillUserPrincipal - Class in org.apache.drill.exec.server.rest.auth
Captures Drill user credentials and privilege's of the session user.
DrillUserPrincipal(String, boolean) - Constructor for class org.apache.drill.exec.server.rest.auth.DrillUserPrincipal
 
DrillUserPrincipal.AnonDrillUserPrincipal - Class in org.apache.drill.exec.server.rest.auth
DrillUserPrincipal for anonymous (auth disabled) mode.
DrillUserPrincipal.AnonDrillUserPrincipal() - Constructor for class org.apache.drill.exec.server.rest.auth.DrillUserPrincipal.AnonDrillUserPrincipal
 
DrillValuesRel - Class in org.apache.drill.exec.planner.logical
Logical Values implementation in Drill.
DrillValuesRel(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>, RelTraitSet) - Constructor for class org.apache.drill.exec.planner.logical.DrillValuesRel
 
DrillValuesRel(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>, RelTraitSet, JSONOptions) - Constructor for class org.apache.drill.exec.planner.logical.DrillValuesRel
 
DrillValuesRelBase - Class in org.apache.drill.exec.planner.common
Base class for logical and physical Values implemented in Drill.
DrillValuesRelBase(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>, RelTraitSet) - Constructor for class org.apache.drill.exec.planner.common.DrillValuesRelBase
 
DrillValuesRelBase(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>, RelTraitSet, JSONOptions) - Constructor for class org.apache.drill.exec.planner.common.DrillValuesRelBase
This constructor helps to avoid unnecessary tuples parsing into json options during copying or logical to physical values conversion.
DrillValuesRule - Class in org.apache.drill.exec.planner.logical
Rule that converts a LogicalValues to a Drill "values" operation.
DrillVersionInfo - Class in org.apache.drill.common.util
Give access to Drill version as captured during the build Caution don't rely on major, minor and patch versions only to compare two Drill versions.
DrillVersionInfo() - Constructor for class org.apache.drill.common.util.DrillVersionInfo
 
DrillViewInfoProvider - Interface in org.apache.drill.exec.planner.logical
Interface used by Drill components such as InformationSchema generator to get view info.
DrillViewTable - Class in org.apache.drill.exec.planner.logical
 
DrillViewTable(View, String, ViewExpansionContext) - Constructor for class org.apache.drill.exec.planner.logical.DrillViewTable
 
DrillWindowRel - Class in org.apache.drill.exec.planner.logical
 
DrillWindowRel(RelOptCluster, RelTraitSet, RelNode, List<RexLiteral>, RelDataType, List<Window.Group>) - Constructor for class org.apache.drill.exec.planner.logical.DrillWindowRel
Creates a window relational expression.
DrillWindowRelBase - Class in org.apache.drill.exec.planner.common
 
DrillWindowRelBase(RelOptCluster, RelTraitSet, RelNode, List<RexLiteral>, RelDataType, List<Window.Group>) - Constructor for class org.apache.drill.exec.planner.common.DrillWindowRelBase
 
DrillWindowRule - Class in org.apache.drill.exec.planner.logical
 
DrillWriterRel - Class in org.apache.drill.exec.planner.logical
 
DrillWriterRel(RelOptCluster, RelTraitSet, RelNode, CreateTableEntry) - Constructor for class org.apache.drill.exec.planner.logical.DrillWriterRel
 
DrillWriterRelBase - Class in org.apache.drill.exec.planner.common
Base class for logical and physical Writer implemented in Drill.
DrillWriterRelBase(Convention, RelOptCluster, RelTraitSet, RelNode, CreateTableEntry) - Constructor for class org.apache.drill.exec.planner.common.DrillWriterRelBase
 
DROP - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DropFunctionHandler - Class in org.apache.drill.exec.planner.sql.handlers
 
DropFunctionHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.DropFunctionHandler
 
dropTable(String) - Method in class org.apache.drill.exec.store.AbstractSchema
 
dropTable(String) - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
We check if the table contains homogeneous file formats that Drill can read.
dropTableFromSchema(AbstractSchema, String) - Static method in class org.apache.drill.exec.planner.sql.handlers.SqlHandlerUtil
Drops table from schema.
DropTableHandler - Class in org.apache.drill.exec.planner.sql.handlers
 
DropTableHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.DropTableHandler
 
dropView(String) - Method in class org.apache.drill.exec.store.AbstractSchema
Drop the view with given name.
dropView(String) - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
dropViewFromSchema(AbstractSchema, String) - Static method in class org.apache.drill.exec.planner.sql.handlers.SqlHandlerUtil
Drops view from schema.
DUMMY_FILTER - Static variable in class org.apache.drill.exec.util.FileSystemUtil
Filter that will accept all files and directories.
DummyConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
This and DummyConvertTo class merely act as a placeholder so that Optiq allows 'convert_to()' and 'convert_from()' functions in SQL.
DummyConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.DummyConvertFrom
 
DummyConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
This and DummyConvertFrom class merely act as a placeholder so that Optiq allows 'convert_to()' and 'convert_from()' functions in SQL.
DummyConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.DummyConvertTo
 
DummyFlatten - Class in org.apache.drill.exec.expr.fn.impl.conv
This and DummyConvertTo class merely act as a placeholder so that Optiq allows the 'flatten()' function in SQL.
DummyFlatten() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.DummyFlatten
 
dump(StringBuilder, int) - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
Dump the value's members to a StringBuilder.
DumpCat - Class in org.apache.drill.exec.client
 
DumpCat() - Constructor for class org.apache.drill.exec.client.DumpCat
 
DumpCat.BatchNumValidator - Class in org.apache.drill.exec.client
Used to ensure the param "batch" is a non-negative number.
DumpCat.BatchNumValidator() - Constructor for class org.apache.drill.exec.client.DumpCat.BatchNumValidator
 
duplicate() - Method in class org.apache.drill.exec.record.DeadBuf
 
DYNAMIC - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DYNAMIC_FUNCTION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DYNAMIC_FUNCTION_CODE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
DYNAMIC_UDF_SUPPORT_ENABLED - Static variable in class org.apache.drill.exec.ExecConstants
 
DYNAMIC_UDF_SUPPORT_ENABLED_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
DynamicDrillTable - Class in org.apache.drill.exec.planner.logical
 
DynamicDrillTable(StoragePlugin, String, String, Object) - Constructor for class org.apache.drill.exec.planner.logical.DynamicDrillTable
 
DynamicDrillTable(StoragePlugin, String, Object) - Constructor for class org.apache.drill.exec.planner.logical.DynamicDrillTable
TODO: Same purpose as other constructor except the impersonation user is the user who is running the Drillbit process.
DynamicParam() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a dynamic parameter marker.
DynamicPojoRecordReader<T> - Class in org.apache.drill.exec.store.pojo
Dynamically reads values from the given list of records.
DynamicPojoRecordReader(LinkedHashMap<String, Class<?>>, List<List<T>>) - Constructor for class org.apache.drill.exec.store.pojo.DynamicPojoRecordReader
 
DynamicPojoRecordReader.Converter - Class in org.apache.drill.exec.store.pojo
An utility class that converts from JsonNode to DynamicPojoRecordReader during physical plan fragment deserialization.
DynamicPojoRecordReader.Converter(ObjectMapper) - Constructor for class org.apache.drill.exec.store.pojo.DynamicPojoRecordReader.Converter
 
DynamicResourceManager - Class in org.apache.drill.exec.work.foreman.rm
Wrapper around the default and/or distributed resource managers to allow dynamically enabling and disabling queueing.
DynamicResourceManager(DrillbitContext) - Constructor for class org.apache.drill.exec.work.foreman.rm.DynamicResourceManager
 
DynamicRootSchema - Class in org.apache.drill.exec.planner.sql
This class is to allow us loading schemas from storage plugins later when DynamicRootSchema.getSubSchema(String, boolean) is called.
DynamicSchema - Class in org.apache.drill.exec.planner.sql
Unlike SimpleCalciteSchema, DynamicSchema could have an empty or partial schemaMap, but it could maintain a map of name->SchemaFactory, and only register schema when the corresponsdent name is requested.
DynamicSchema(CalciteSchema, Schema, String) - Constructor for class org.apache.drill.exec.planner.sql.DynamicSchema
 

E

EACH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
EARLY_LIMIT0_OPT - Static variable in class org.apache.drill.exec.ExecConstants
 
EARLY_LIMIT0_OPT_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
earlyOutput() - Method in interface org.apache.drill.exec.physical.impl.aggregate.HashAggregator
 
earlyOutput() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
 
EasyFormatPlugin<T extends FormatPluginConfig> - Class in org.apache.drill.exec.store.dfs.easy
 
EasyFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig, T, boolean, boolean, boolean, boolean, List<String>, String) - Constructor for class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
EasyGroupScan - Class in org.apache.drill.exec.store.dfs.easy
 
EasyGroupScan(String, List<String>, StoragePluginConfig, FormatPluginConfig, StoragePluginRegistry, List<SchemaPath>, String) - Constructor for class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
EasyGroupScan(String, FileSelection, EasyFormatPlugin<?>, String) - Constructor for class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
EasyGroupScan(String, FileSelection, EasyFormatPlugin<?>, List<SchemaPath>, String) - Constructor for class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
EasyReaderBatchCreator - Class in org.apache.drill.exec.store.dfs.easy
 
EasyReaderBatchCreator() - Constructor for class org.apache.drill.exec.store.dfs.easy.EasyReaderBatchCreator
 
EasySubScan - Class in org.apache.drill.exec.store.dfs.easy
 
EasySubScan(String, List<CompleteFileWork.FileWorkImpl>, StoragePluginConfig, FormatPluginConfig, StoragePluginRegistry, List<SchemaPath>, String) - Constructor for class org.apache.drill.exec.store.dfs.easy.EasySubScan
 
EasySubScan(String, List<CompleteFileWork.FileWorkImpl>, EasyFormatPlugin<?>, List<SchemaPath>, String) - Constructor for class org.apache.drill.exec.store.dfs.easy.EasySubScan
 
EasyWriter - Class in org.apache.drill.exec.store.dfs.easy
 
EasyWriter(PhysicalOperator, String, List<String>, StorageStrategy, StoragePluginConfig, FormatPluginConfig, StoragePluginRegistry) - Constructor for class org.apache.drill.exec.store.dfs.easy.EasyWriter
 
EasyWriter(PhysicalOperator, String, List<String>, EasyFormatPlugin<?>) - Constructor for class org.apache.drill.exec.store.dfs.easy.EasyWriter
 
EasyWriterBatchCreator - Class in org.apache.drill.exec.store.dfs.easy
 
EasyWriterBatchCreator() - Constructor for class org.apache.drill.exec.store.dfs.easy.EasyWriterBatchCreator
 
ELEMENT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
elementCount - Variable in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer.ColumnSize
Total number of elements for a repeated type, or 1 if this is a non-repeated type.
elementCount - Variable in class org.apache.drill.exec.record.VectorInitializer.AllocationHint
 
ELSE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
EMBEDDED_QUEUE - Static variable in class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue
 
EmbeddedQueryQueue - Class in org.apache.drill.exec.work.foreman.rm
Query queue to be used in an embedded Drillbit.
EmbeddedQueryQueue(DrillbitContext) - Constructor for class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue
 
EmbeddedQueryQueue.EmbeddedQueueLease - Class in org.apache.drill.exec.work.foreman.rm
 
EmbeddedQueryQueue.EmbeddedQueueLease(UserBitShared.QueryId, long) - Constructor for class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue.EmbeddedQueueLease
 
emitLeft(int, int) - Method in interface org.apache.drill.exec.physical.impl.join.NestedLoopJoin
 
emitLeft(int, int) - Method in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinTemplate
 
emitRight(int, int, int) - Method in interface org.apache.drill.exec.physical.impl.join.NestedLoopJoin
 
emitRight(int, int, int) - Method in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinTemplate
 
ENABLE_BULK_LOAD_TABLE_LIST - Static variable in class org.apache.drill.exec.ExecConstants
 
ENABLE_BULK_LOAD_TABLE_LIST_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
ENABLE_DECIMAL_DATA_TYPE - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
ENABLE_DECIMAL_DATA_TYPE_KEY - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
ENABLE_ITERATOR_VALIDATION - Static variable in class org.apache.drill.exec.ExecConstants
Boot-time config option to enable validation.
ENABLE_ITERATOR_VALIDATION_OPTION - Static variable in class org.apache.drill.exec.ExecConstants
Enables batch iterator (operator) validation.
ENABLE_ITERATOR_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
ENABLE_MEMORY_ESTIMATION - Static variable in class org.apache.drill.exec.ExecConstants
 
ENABLE_MEMORY_ESTIMATION_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
ENABLE_NEW_TEXT_READER - Static variable in class org.apache.drill.exec.ExecConstants
 
ENABLE_NEW_TEXT_READER_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
ENABLE_QUERY_PROFILE_OPTION - Static variable in class org.apache.drill.exec.ExecConstants
Option to save query profiles.
ENABLE_QUERY_PROFILE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
ENABLE_QUEUE - Static variable in class org.apache.drill.exec.ExecConstants
 
ENABLE_SAVE_CODE_FOR_DEBUG_TOPN - Static variable in class org.apache.drill.exec.compile.CodeCompiler
Enables saving generated code for debugging
enable_tracing() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
ENABLE_UNION_TYPE - Static variable in class org.apache.drill.exec.ExecConstants
 
ENABLE_VECTOR_VALIDATION - Static variable in class org.apache.drill.exec.ExecConstants
Boot-time config option to enable vector validation.
ENABLE_VECTOR_VALIDATION_OPTION - Static variable in class org.apache.drill.exec.ExecConstants
When iterator validation is enabled, additionally validates the vectors in each batch passed to each iterator.
ENABLE_VECTOR_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
ENABLE_VERBOSE_ERRORS - Static variable in class org.apache.drill.exec.ExecConstants
 
ENABLE_VERBOSE_ERRORS_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
ENABLE_WINDOW_FUNCTIONS - Static variable in class org.apache.drill.exec.ExecConstants
 
ENABLE_WINDOW_FUNCTIONS_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
enableBatchValidation(boolean) - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
enabled() - Method in class org.apache.drill.exec.server.rest.PluginConfigWrapper
 
enabled() - Method in class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue
 
ENABLED - Static variable in class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue
 
enabled() - Method in class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue
 
enabled() - Method in interface org.apache.drill.exec.work.foreman.rm.QueryQueue
Determine if the queue is enabled.
enableHints - Variable in class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
enableMarking() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
enablePlugin(String, Boolean) - Method in class org.apache.drill.exec.server.rest.StorageResources
 
ENCAPSULATING_SECURITY_V6 - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
encryptionContext - Variable in class org.apache.drill.exec.rpc.AbstractConnectionConfig
 
END - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
end() - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter
 
END_EXEC - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
endBitMasks - Static variable in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
endColumn - Variable in class org.apache.drill.exec.planner.sql.parser.impl.Token
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
endEmptyField() - Method in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
 
endField() - Method in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
 
endField() - Method in class org.apache.drill.exec.store.EventBasedRecordWriter.FieldConverter
 
endFields() - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor.VisualizationState
 
endLine - Variable in class org.apache.drill.exec.planner.sql.parser.impl.Token
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
endNode() - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor.VisualizationState
 
endpoint - Variable in class org.apache.drill.exec.coord.zk.ZKRegistrationHandle
 
endpoint - Variable in class org.apache.drill.exec.work.EndpointListener
 
EndpointAffinity - Class in org.apache.drill.exec.physical
EndpointAffinity captures affinity value for a given single Drillbit endpoint.
EndpointAffinity(CoordinationProtos.DrillbitEndpoint) - Constructor for class org.apache.drill.exec.physical.EndpointAffinity
Create EndpointAffinity instance for given Drillbit endpoint.
EndpointAffinity(CoordinationProtos.DrillbitEndpoint, double) - Constructor for class org.apache.drill.exec.physical.EndpointAffinity
Create EndpointAffinity instance for given Drillbit endpoint and affinity initialized to given affinity value.
EndpointAffinity(CoordinationProtos.DrillbitEndpoint, double, boolean, int) - Constructor for class org.apache.drill.exec.physical.EndpointAffinity
Creates EndpointAffinity instance for given DrillbitEndpoint, affinity and mandatory assignment requirement flag.
EndpointByteMap - Interface in org.apache.drill.exec.store.schedule
Presents an interface that describes the number of bytes for a particular work unit associated with a particular DrillbitEndpoint.
EndpointByteMapImpl - Class in org.apache.drill.exec.store.schedule
 
EndpointByteMapImpl() - Constructor for class org.apache.drill.exec.store.schedule.EndpointByteMapImpl
 
EndpointListener<RET,V> - Class in org.apache.drill.exec.work
 
EndpointListener(CoordinationProtos.DrillbitEndpoint, V) - Constructor for class org.apache.drill.exec.work.EndpointListener
 
endRecord() - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter
 
endRecord() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
 
endRecord() - Method in interface org.apache.drill.exec.store.RecordWriter
Called after adding all fields in a particular record are added using add{TypeHolder}(fieldId, TypeHolder) methods.
endRecord() - Method in class org.apache.drill.exec.store.text.DrillTextRecordWriter
 
enforceTotalByteSize - Variable in class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
enforceTotalSize - Variable in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
enforceWidth() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
Deprecated.
enforceWidth() - Method in interface org.apache.drill.exec.physical.base.GroupScan
Deprecated.
Use GroupScan.getMinParallelizationWidth() to determine whether this GroupScan spans more than one fragment.
enoughMemory(Prel, OptionManager, int) - Static method in class org.apache.drill.exec.planner.physical.visitor.MemoryEstimationVisitor
 
enqueue(RawFragmentBatch) - Method in class org.apache.drill.exec.work.batch.BaseRawBatchBuffer
 
enqueue(RawFragmentBatch) - Method in interface org.apache.drill.exec.work.batch.RawBatchBuffer
Add the next new raw fragment batch to the buffer.
enqueue(UserBitShared.QueryId, double) - Method in class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue
This limits the number of "small" and "large" queries that a Drill cluster will run simultaneously, if queuing is enabled.
enqueue(UserBitShared.QueryId, double) - Method in class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue
 
enqueue(UserBitShared.QueryId, double) - Method in interface org.apache.drill.exec.work.foreman.rm.QueryQueue
Queue a query.
enqueueInner(RawFragmentBatch) - Method in class org.apache.drill.exec.work.batch.BaseRawBatchBuffer
implementation specific method to enqueue batch
enqueueInner(RawFragmentBatch) - Method in class org.apache.drill.exec.work.batch.SpoolingRawBatchBuffer
 
enqueueInner(RawFragmentBatch) - Method in class org.apache.drill.exec.work.batch.UnlimitedRawBatchBuffer
 
enqueueResponse(AckSender) - Method in class org.apache.drill.exec.work.batch.ResponseSenderQueue
 
ensureAtLeastOneField(BaseWriter.ComplexWriter) - Method in class org.apache.drill.exec.store.bson.BsonRecordReader
 
ensureAtLeastOneField(BaseWriter.ComplexWriter) - Method in interface org.apache.drill.exec.store.easy.json.JsonProcessor
 
ensureAtLeastOneField(BaseWriter.ComplexWriter) - Method in class org.apache.drill.exec.store.easy.json.reader.CountingJsonReader
 
ensureAtLeastOneField(BaseWriter.ComplexWriter) - Method in class org.apache.drill.exec.vector.complex.fn.JsonReader
 
ensureAtLeastOneField(BaseWriter.ComplexWriter, Collection<SchemaPath>, boolean, List<BaseWriter.ListWriter>) - Static method in class org.apache.drill.exec.vector.complex.fn.JsonReaderUtils
 
ensureWritable(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
ensureWritable(int, boolean) - Method in class org.apache.drill.exec.record.DeadBuf
 
enterChild() - Method in class org.apache.drill.exec.compile.sig.MappingSet
 
enterConstant() - Method in class org.apache.drill.exec.compile.sig.MappingSet
 
entries() - Method in class org.apache.drill.exec.coord.local.MapBackedStore
 
entries() - Method in interface org.apache.drill.exec.coord.store.TransientStore
Returns an iterator of (key, value) tuples.
entries() - Method in class org.apache.drill.exec.coord.zk.ZkEphemeralStore
 
entries() - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
Returns an iterator of (key, value) pairs residing under root path.
entrySet() - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
entryWidth - Variable in class org.apache.drill.exec.record.VectorInitializer.AllocationHint
 
EnumerableDrillRule - Class in org.apache.drill.exec.planner.logical
Rule that converts any Drill relational expression to enumerable format by adding a DrillScreenRelBase.
EOF - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
eol - Variable in exception org.apache.drill.exec.planner.sql.parser.impl.ParseException
The end of line string for this machine.
EQ - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
 
EQ - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
EQUAL_IS_DISTINCT_FROM - Static variable in class org.apache.drill.exec.planner.logical.DrillFilterJoinRules
Predicate that always returns true for any filter in OUTER join, and only true for EQUAL or IS_DISTINCT_FROM over RexInputRef in INNER join.
equals(Object) - Method in class org.apache.drill.exec.cache.DistributedCache.CacheConfig
 
equals(Object) - Method in class org.apache.drill.exec.compile.ClassTransformer.ClassNames
 
equals(Object) - Method in class org.apache.drill.exec.compile.ClassTransformer.ClassSet
 
equals(Object) - Method in class org.apache.drill.exec.coord.store.TransientStoreConfig
 
equals(Object) - Method in class org.apache.drill.exec.coord.store.TransientStoreEvent
 
equals(Object) - Method in class org.apache.drill.exec.expr.CodeGenerator
 
equals(Object) - Method in class org.apache.drill.exec.expr.DirectExpression
 
equals(Object) - Method in class org.apache.drill.exec.physical.EndpointAffinity
 
equals(RelOptCost) - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
equals(Object) - Method in class org.apache.drill.exec.planner.fragment.Fragment
 
equals(Object) - Method in class org.apache.drill.exec.planner.logical.DrillTable
 
equals(Object) - Method in class org.apache.drill.exec.planner.logical.DrillTranslatableTable
 
equals(Object) - Method in class org.apache.drill.exec.planner.logical.StoragePlugins
 
equals(Object) - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTrait.DistributionField
 
equals(Object) - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
 
equals(Object) - Method in class org.apache.drill.exec.planner.physical.explain.PrelSequencer.OpId
 
equals(Object) - Method in class org.apache.drill.exec.planner.physical.PrelUtil.DesiredField
 
EQUALS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
equals(Object) - Method in class org.apache.drill.exec.planner.types.RelDataTypeDrillImpl
 
equals(Object) - Method in class org.apache.drill.exec.planner.types.RelDataTypeHolder
 
equals(Object) - Method in class org.apache.drill.exec.record.BatchSchema
 
equals(Object) - Method in class org.apache.drill.exec.record.DeadBuf
 
equals(Object) - Method in class org.apache.drill.exec.record.TypedFieldId
 
equals(Object) - Method in class org.apache.drill.exec.rpc.control.ControlConnection
 
equals(Object) - Method in class org.apache.drill.exec.rpc.data.DataClientConnection
 
equals(Object) - Method in class org.apache.drill.exec.serialization.JacksonSerializer
 
equals(Object) - Method in class org.apache.drill.exec.serialization.ProtoSerializer
 
equals(Object) - Method in class org.apache.drill.exec.server.options.OptionMetaData
 
equals(Object) - Method in class org.apache.drill.exec.server.options.OptionValue
 
equals(Object) - Method in class org.apache.drill.exec.server.options.PersistedOptionValue
 
equals(Object) - Method in class org.apache.drill.exec.store.avro.AvroFormatConfig
 
equals(Object) - Method in class org.apache.drill.exec.store.dfs.FileSystemConfig
 
equals(Object) - Method in class org.apache.drill.exec.store.dfs.NamedFormatPluginConfig
 
equals(Object) - Method in class org.apache.drill.exec.store.dfs.WorkspaceConfig
 
equals(Object) - Method in class org.apache.drill.exec.store.easy.json.JSONFormatPlugin.JSONFormatConfig
 
equals(Object) - Method in class org.apache.drill.exec.store.easy.sequencefile.SequenceFileFormatConfig
 
equals(Object) - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
equals(Object) - Method in class org.apache.drill.exec.store.httpd.HttpdLogFormatPlugin.HttpdLogFormatConfig
 
equals(Object) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaConfig
 
equals(Object) - Method in class org.apache.drill.exec.store.mock.MockStorageEngineConfig
 
equals(Object) - Method in class org.apache.drill.exec.store.NamedStoragePluginConfig
 
equals(Object) - Method in class org.apache.drill.exec.store.parquet.MetadataVersion
 
equals(Object) - Method in class org.apache.drill.exec.store.parquet.ParquetFormatConfig
 
equals(Object) - Method in class org.apache.drill.exec.store.pcap.dto.ColumnDto
 
equals(Object) - Method in class org.apache.drill.exec.store.pcap.PcapFormatConfig
 
equals(Object) - Method in class org.apache.drill.exec.store.sys.PersistentStoreConfig
 
equals(Object) - Method in class org.apache.drill.exec.store.sys.SystemTablePluginConfig
 
equals(Object) - Method in class org.apache.drill.exec.testing.InjectionSite
 
equalsIgnoreType(Object) - Method in class org.apache.drill.exec.server.options.OptionValue
 
error - Variable in class org.apache.drill.exec.rpc.AbstractDisposableUserClientConnection
 
errorClassNameToException(String) - Static method in exception org.apache.drill.exec.work.foreman.SqlUnsupportedException
 
errorMessage - Variable in class org.apache.drill.exec.server.rest.GenericExceptionMapper.GenericErrorMessage
 
errors() - Method in class org.apache.drill.exec.physical.impl.validate.BatchValidator
Obtain the list of errors.
ESCAPE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
escape - Variable in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
estElementCountPerArray - Variable in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer.ColumnSize
The estimated, average number of elements per parent value.
estimateMemory(Prel) - Static method in class org.apache.drill.exec.planner.physical.visitor.MemoryEstimationVisitor
 
estimateRowCount(RelMetadataQuery) - Method in class org.apache.drill.exec.planner.common.DrillFilterRelBase
 
estimateRowCount(RelMetadataQuery) - Method in class org.apache.drill.exec.planner.common.DrillJoinRelBase
 
estimateRowCount(RelMetadataQuery) - Method in class org.apache.drill.exec.planner.common.DrillLimitRelBase
 
estimateRowCount(RelMetadataQuery) - Method in class org.apache.drill.exec.planner.logical.DrillDirectScanRel
 
estimateRowCount(RelMetadataQuery) - Method in class org.apache.drill.exec.planner.logical.DrillScanRel
 
estimateRowCount(RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.NestedLoopJoinPrel
 
estimateRowCount(RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.ScanPrel
 
estSize - Variable in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer.ColumnSize
Actual average column width as determined from actual memory use.
ETHER_DST_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
ETHER_HEADER_LENGTH - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
ETHER_SRC_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
ETHER_TYPE_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
eval() - Method in interface org.apache.drill.exec.expr.DrillSimpleFunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.ExceptionFunction.ThrowException
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.BigIntBigIntAdd
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.Float4Float4Add
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.Float8Float8Add
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.IntIntAdd
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.SmallIntSmallIntAdd
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.TinyIntTinyIntAdd
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.UInt1UInt1Add
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.UInt2UInt2Add
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.UInt4UInt4Add
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.UInt8UInt8Add
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Alternator.Alternate2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Alternator.Alternate3
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.BitFunctions.BitAnd
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.BitFunctions.BitOr
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.BitFunctions.IntXor
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ByteSubstring
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.CastBigIntDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.CastBigIntTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.CastIntTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.CastVarCharVar16Char
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.CharSubstring
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ContextFunctions.CurrentSchema
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ContextFunctions.SessionId
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ContextFunctions.User
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BigIntBEConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BigIntBEConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BigIntConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BigIntConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BigIntVLongConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BigIntVLongConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BooleanByteConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BooleanByteConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.ConvertFromImpalaTimestamp.ImpalaTimestampConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DateEpochBEConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DateEpochBEConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DateEpochConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DateEpochConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DoubleBEConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DoubleBEConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DoubleConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DoubleConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DummyConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DummyConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DummyFlatten
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.FloatBEConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.FloatBEConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.FloatConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.FloatConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.IntBEConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.IntBEConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.IntConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.IntConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.IntVIntConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.IntVIntConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertFrom.ConvertFromJson
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertFrom.ConvertFromJsonVarchar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertTo.ConvertToExtendedJson
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertTo.ConvertToJson
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.SmallIntBEConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.SmallIntBEConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.SmallIntConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.SmallIntConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeEpochBEConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeEpochBEConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeEpochConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeEpochConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeStampEpochBEConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeStampEpochBEConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeStampEpochConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeStampEpochConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TinyIntConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TinyIntConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UInt4BEConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UInt4BEConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UInt4ConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UInt4ConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UInt8ConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UInt8ConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UTF16ConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UTF16ConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UTF8ConvertFrom
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UTF8ConvertTo
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.AESDecryptFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.AESEncryptFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.MD2Function
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.MD5Function
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.SHA1Function
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.SHA256Function
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.SHA384Function
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.SHA512Function
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateBigIntFunctions.BigIntDateAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateBigIntFunctions.DateBigIntAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateBigIntFunctions.DateBigIntSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalDayFunctions.DateIntervalDayAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalDayFunctions.DateIntervalDaySubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalDayFunctions.IntervalDayDateAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalFunctions.DateIntervalAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalFunctions.DateIntervalSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalFunctions.IntervalDateAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalYearFunctions.DateIntervalYearAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalYearFunctions.DateIntervalYearSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalYearFunctions.IntervalYearDateAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntFunctions.DateIntAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntFunctions.DateIntSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntFunctions.IntDateAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.AgeDate2Function
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.AgeDateFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.AgeTimeStamp2Function
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.AgeTimeStampFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.CastTimeStampToTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.CurrentDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.CurrentTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.DatePartFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.DateTimeAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.DateType
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IntervalDayType
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IntervalType
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IntervalYearType
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IsDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IsDateRequiredInput
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.LocalTimeStampNiladic
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.LocalTimeStampNonNiladic
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeDateAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeOfDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeStampType
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeType
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.UnixTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.UnixTimeStampForDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.UnixTimeStampForDateWithPattern
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18AbsFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18AddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18CeilFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18DivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18Equal
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18FloorFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18GreaterThan
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18GreaterThanEq
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18LessThan
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18LessThanEq
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18ModFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18MultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18NotEqual
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18RoundFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18RoundScaleFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18SignFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18SubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18TruncateScaleFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18TruncFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareDecimal18VsDecimal18NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareDecimal18VsDecimal18NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareDecimal18VsNullableDecimal18NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareDecimal18VsNullableDecimal18NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareNullableDecimal18VsDecimal18NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareNullableDecimal18VsDecimal18NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareNullableDecimal18VsNullableDecimal18NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareNullableDecimal18VsNullableDecimal18NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseEqual
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseGreaterThan
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseGreaterThanEq
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseLessThan
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseLessThanEq
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseNotEqual
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareDecimal28DenseVsDecimal28DenseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareDecimal28DenseVsDecimal28DenseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareDecimal28DenseVsNullableDecimal28DenseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareDecimal28DenseVsNullableDecimal28DenseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsDecimal28DenseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsDecimal28DenseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsNullableDecimal28DenseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsNullableDecimal28DenseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseAbsFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseCeilFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseDivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseEqual
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseFloorFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseGreaterThan
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseGreaterThanEq
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseLessThan
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseLessThanEq
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseModFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseNotEqual
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseRoundFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseRoundScaleFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseSignFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseTruncateFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseTruncateScaleFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareDecimal28SparseVsDecimal28SparseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareDecimal28SparseVsDecimal28SparseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareDecimal28SparseVsNullableDecimal28SparseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareDecimal28SparseVsNullableDecimal28SparseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsDecimal28SparseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsDecimal28SparseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsNullableDecimal28SparseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsNullableDecimal28SparseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseEqual
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseGreaterThan
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseGreaterThanEq
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseLessThan
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseLessThanEq
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseNotEqual
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareDecimal38DenseVsDecimal38DenseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareDecimal38DenseVsDecimal38DenseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareDecimal38DenseVsNullableDecimal38DenseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareDecimal38DenseVsNullableDecimal38DenseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsDecimal38DenseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsDecimal38DenseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsNullableDecimal38DenseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsNullableDecimal38DenseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseAbsFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseCeilFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseDivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseEqual
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseFloorFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseGreaterThan
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseGreaterThanEq
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseLessThan
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseLessThanEq
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseModFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseNotEqual
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseRoundFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseRoundScaleFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseSignFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseTruncateFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseTruncateScaleFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareDecimal38SparseVsDecimal38SparseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareDecimal38SparseVsDecimal38SparseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareDecimal38SparseVsNullableDecimal38SparseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareDecimal38SparseVsNullableDecimal38SparseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsDecimal38SparseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsDecimal38SparseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsNullableDecimal38SparseNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsNullableDecimal38SparseNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9AbsFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9AddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9CeilFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9DivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9Equal
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9FloorFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9GreaterThan
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9GreaterThanEq
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9LessThan
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9LessThanEq
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9ModFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9MultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9NotEqual
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9RoundFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9RoundScaleFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9SignFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9SubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9TruncateScaleFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9TruncFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareDecimal9VsDecimal9NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareDecimal9VsDecimal9NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareDecimal9VsNullableDecimal9NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareDecimal9VsNullableDecimal9NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareNullableDecimal9VsDecimal9NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareNullableDecimal9VsDecimal9NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareNullableDecimal9VsNullableDecimal9NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareNullableDecimal9VsNullableDecimal9NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.IMaxDir
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.IMaxDirTwoArg
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.IMinDir
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.IMinDirTwoArg
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.MaxDir
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.MaxDirTwoArg
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.MinDir
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.MinDirTwoArg
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.BigIntBigIntDivide
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.Float4Float4Divide
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.Float8Float8Divide
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.IntIntDivide
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.SmallIntSmallIntDivide
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.TinyIntTinyIntDivide
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.UInt1UInt1Divide
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.UInt2UInt2Divide
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.UInt4UInt4Divide
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.UInt8UInt8Divide
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GBigIntToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GBigIntToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntDecimal28Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntDecimal38Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBitTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDateToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDateToVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18BigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Decimal28Dense
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Decimal28Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Decimal38Dense
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Decimal38Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Decimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Float4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Float8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Int
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18VarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28DenseDecimal28Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28DenseDecimal38Dense
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28DenseDecimal38Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28DenseFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28DenseFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseDecimal28Dense
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseDecimal38Dense
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseDecimal38Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38DenseDecimal38Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38DenseFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38DenseFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseDecimal28Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseDecimal38Dense
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9BigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Decimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Decimal28Dense
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Decimal28Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Decimal38Dense
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Decimal38Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Float4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Float8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Int
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9VarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableDecimal28Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableDecimal38Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableDecimal28Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableDecimal38Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableDecimal28Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableDecimal38Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableDecimal28Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableDecimal38Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4BigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Decimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Decimal28Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Decimal38Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Decimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Float8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Int
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4VarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4VarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8BigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Decimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Decimal28Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Decimal38Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Decimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Float4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Int
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8VarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8VarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighDecimal28Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighDecimal38Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntDecimal28Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntDecimal38Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalDayToInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalDayToVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalToIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalToIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalToVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalYearToInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalYearToVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastTimeStampToDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastTimeStampToVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastTimeToVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastTinyIntBit
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryToDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryToTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharDecimal28Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharDecimal38Sparse
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.EqualsBigIntVsBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareBigIntVsBigIntNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareBigIntVsBigIntNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareBigIntVsNullableBigIntNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareBigIntVsNullableBigIntNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareNullableBigIntVsBigIntNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareNullableBigIntVsBigIntNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareNullableBigIntVsNullableBigIntNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareNullableBigIntVsNullableBigIntNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GreaterThanBigIntVsBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GreaterThanEqBigIntVsBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.LessThanBigIntVsBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.LessThanEqBigIntVsBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.NotEqualsBigIntVsBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.EqualsBitVsBit
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareBitVsBitNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareBitVsBitNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareBitVsNullableBitNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareBitVsNullableBitNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareNullableBitVsBitNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareNullableBitVsBitNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareNullableBitVsNullableBitNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareNullableBitVsNullableBitNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GreaterThanBitVsBit
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GreaterThanEqBitVsBit
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.LessThanBitVsBit
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.LessThanEqBitVsBit
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.NotEqualsBitVsBit
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.EqualsDateVsDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareDateVsDateNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareDateVsDateNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareDateVsNullableDateNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareDateVsNullableDateNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareNullableDateVsDateNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareNullableDateVsDateNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareNullableDateVsNullableDateNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareNullableDateVsNullableDateNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GreaterThanDateVsDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GreaterThanEqDateVsDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.LessThanDateVsDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.LessThanEqDateVsDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.NotEqualsDateVsDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.EqualsFloat4VsFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareFloat4VsFloat4NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareFloat4VsFloat4NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareFloat4VsNullableFloat4NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareFloat4VsNullableFloat4NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareNullableFloat4VsFloat4NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareNullableFloat4VsFloat4NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareNullableFloat4VsNullableFloat4NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareNullableFloat4VsNullableFloat4NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GreaterThanEqFloat4VsFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GreaterThanFloat4VsFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.LessThanEqFloat4VsFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.LessThanFloat4VsFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.NotEqualsFloat4VsFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.EqualsFloat8VsFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareFloat8VsFloat8NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareFloat8VsFloat8NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareFloat8VsNullableFloat8NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareFloat8VsNullableFloat8NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareNullableFloat8VsFloat8NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareNullableFloat8VsFloat8NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareNullableFloat8VsNullableFloat8NullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareNullableFloat8VsNullableFloat8NullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GreaterThanEqFloat8VsFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GreaterThanFloat8VsFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.LessThanEqFloat8VsFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.LessThanFloat8VsFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.NotEqualsFloat8VsFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.EqualsIntervalDayVsIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsIntervalDayNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsIntervalDayNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsNullableIntervalDayNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsNullableIntervalDayNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsIntervalDayNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsIntervalDayNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsNullableIntervalDayNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsNullableIntervalDayNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GreaterThanEqIntervalDayVsIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GreaterThanIntervalDayVsIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.LessThanEqIntervalDayVsIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.LessThanIntervalDayVsIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.NotEqualsIntervalDayVsIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.EqualsIntervalVsInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareIntervalVsIntervalNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareIntervalVsIntervalNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareIntervalVsNullableIntervalNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareIntervalVsNullableIntervalNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareNullableIntervalVsIntervalNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareNullableIntervalVsIntervalNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareNullableIntervalVsNullableIntervalNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareNullableIntervalVsNullableIntervalNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GreaterThanEqIntervalVsInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GreaterThanIntervalVsInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.LessThanEqIntervalVsInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.LessThanIntervalVsInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.NotEqualsIntervalVsInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.EqualsIntervalYearVsIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsIntervalYearNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsIntervalYearNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsNullableIntervalYearNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsNullableIntervalYearNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsIntervalYearNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsIntervalYearNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsNullableIntervalYearNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsNullableIntervalYearNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GreaterThanEqIntervalYearVsIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GreaterThanIntervalYearVsIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.LessThanEqIntervalYearVsIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.LessThanIntervalYearVsIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.NotEqualsIntervalYearVsIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.EqualsIntVsInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareIntVsIntNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareIntVsIntNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareIntVsNullableIntNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareIntVsNullableIntNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareNullableIntVsIntNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareNullableIntVsIntNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareNullableIntVsNullableIntNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareNullableIntVsNullableIntNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GreaterThanEqIntVsInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GreaterThanIntVsInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.LessThanEqIntVsInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.LessThanIntVsInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.NotEqualsIntVsInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.EqualsTimeStampVsTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsNullableTimeStampNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsNullableTimeStampNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsTimeStampNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsTimeStampNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareTimeStampVsNullableTimeStampNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareTimeStampVsNullableTimeStampNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareTimeStampVsTimeStampNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareTimeStampVsTimeStampNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GreaterThanEqTimeStampVsTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GreaterThanTimeStampVsTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.LessThanEqTimeStampVsTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.LessThanTimeStampVsTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.NotEqualsTimeStampVsTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.EqualsTimeVsTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareNullableTimeVsNullableTimeNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareNullableTimeVsNullableTimeNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareNullableTimeVsTimeNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareNullableTimeVsTimeNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareTimeVsNullableTimeNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareTimeVsNullableTimeNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareTimeVsTimeNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareTimeVsTimeNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GreaterThanEqTimeVsTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GreaterThanTimeVsTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.LessThanEqTimeVsTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.LessThanTimeVsTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.NotEqualsTimeVsTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.EqualsVarBinaryVsVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsNullableVarBinaryNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsNullableVarBinaryNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsVarBinaryNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsVarBinaryNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsNullableVarBinaryNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsNullableVarBinaryNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsVarBinaryNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsVarBinaryNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GreaterThanEqVarBinaryVsVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GreaterThanVarBinaryVsVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.LessThanEqVarBinaryVsVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.LessThanVarBinaryVsVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.NotEqualsVarBinaryVsVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.EqualsVarBinaryVsVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsNullableVarCharNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsNullableVarCharNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsVarCharNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsVarCharNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareVarBinaryVsNullableVarCharNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareVarBinaryVsNullableVarCharNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareVarBinaryVsVarCharNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareVarBinaryVsVarCharNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GreaterThanEqVarBinaryVsVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GreaterThanVarBinaryVsVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.LessThanEqVarBinaryVsVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.LessThanVarBinaryVsVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.NotEqualsVarBinaryVsVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.EqualsVarCharVsVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareNullableVarCharVsNullableVarBinaryNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareNullableVarCharVsNullableVarBinaryNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareNullableVarCharVsVarBinaryNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareNullableVarCharVsVarBinaryNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareVarCharVsNullableVarBinaryNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareVarCharVsNullableVarBinaryNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareVarCharVsVarBinaryNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareVarCharVsVarBinaryNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GreaterThanEqVarCharVsVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GreaterThanVarCharVsVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.LessThanEqVarCharVsVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.LessThanVarCharVsVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.NotEqualsVarCharVsVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.EqualsVarCharVsVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareNullableVarCharVsNullableVarCharNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareNullableVarCharVsNullableVarCharNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareNullableVarCharVsVarCharNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareNullableVarCharVsVarCharNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareVarCharVsNullableVarCharNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareVarCharVsNullableVarCharNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareVarCharVsVarCharNullHigh
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareVarCharVsVarCharNullLow
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GreaterThanEqVarCharVsVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GreaterThanVarCharVsVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.LessThanEqVarCharVsVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.LessThanVarCharVsVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.NotEqualsVarCharVsVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableBigIntHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableBitHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDateHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal18Holder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal28DenseHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal28SparseHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal38DenseHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal38SparseHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal9Holder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableFloat4Holder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableFloat8Holder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableIntervalDayHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableIntervalHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableIntervalYearHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableIntHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableSmallIntHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableTimeHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableTimeStampHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableTinyIntHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableUInt1Holder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableUInt2Holder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableUInt4Holder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableUInt8Holder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableVar16CharHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableVarBinaryHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableVarCharHolder
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateArithmetic.GDateDifference
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateCenturyDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateDayDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateDecadeDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateDummyDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateHourDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateMillenniumDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateMinuteDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateMonthDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateQuarterDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateSecondDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateWeekDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateYearDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalCenturyDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayCenturyDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayDayDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayDecadeDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayDummyDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayHourDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayMillenniumDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayMinuteDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayMonthDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayQuarterDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDaySecondDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayYearDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDecadeDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDummyDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalHourDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalMillenniumDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalMinuteDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalMonthDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalQuarterDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalSecondDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearCenturyDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearDayDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearDecadeDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearDummyDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearHourDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearMillenniumDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearMinuteDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearMonthDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearQuarterDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearSecondDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearYearDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeCenturyDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeDayDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeDecadeDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeDummyDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeHourDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeMillenniumDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeMinuteDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeMonthDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeQuarterDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeSecondDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampCenturyDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampDayDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampDecadeDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampDummyDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampHourDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampMillenniumDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampMinuteDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampMonthDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampQuarterDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampSecondDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampWeekDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampYearDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeYearDateTrunc
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDateToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal18ToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal18ToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal28DenseToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal28DenseToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal28SparseToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal28SparseToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal38DenseToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal38DenseToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal38SparseToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal38SparseToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal9ToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal9ToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.DayFromDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.DayFromInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.DayFromIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.DayFromIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.DayFromTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MonthFromDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MonthFromInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MonthFromIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MonthFromIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MonthFromTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.YearFromDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.YearFromInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.YearFromIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.YearFromIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.YearFromTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GFloat4ToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GFloat4ToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GFloat8ToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GFloat8ToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GIntToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GIntToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueBigIntNullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueBit
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueBitNullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDateNullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDecimal18
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDecimal18Nullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDecimal9
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDecimal9Nullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueFloat4Nullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueFloat8Nullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueIntNullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueSmallIntNullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTimeNullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTimeStampNullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTinyIntNullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt1Nullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt2Nullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt4Nullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt8Nullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVar16Char
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVar16CharNullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVarBinaryNullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVarCharNullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpBigIntHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpBigIntHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpBitHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpBitHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDateHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDateHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal18Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal18Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal28DenseHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal28DenseHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal28SparseHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal28SparseHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal38DenseHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal38DenseHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal38SparseHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal38SparseHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal9Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal9Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpFloat4Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpFloat4Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpFloat8Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpFloat8Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalDayHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalDayHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalYearHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalYearHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableBigIntHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableBigIntHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableBitHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableBitHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDateHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDateHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal18Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal18Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal28DenseHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal28DenseHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal28SparseHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal28SparseHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal38DenseHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal38DenseHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal38SparseHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal38SparseHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal9Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal9Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableFloat4Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableFloat4Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableFloat8Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableFloat8Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalDayHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalDayHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalYearHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalYearHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableSmallIntHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableSmallIntHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTimeHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTimeHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTimeStampHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTimeStampHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTinyIntHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTinyIntHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt1Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt1Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt2Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt2Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt4Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt4Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt8Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt8Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVar16CharHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVar16CharHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVarBinaryHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVarBinaryHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVarCharHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVarCharHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedBigIntHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedBigIntHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedBitHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedBitHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDateHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDateHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal18Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal18Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal28DenseHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal28DenseHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal28SparseHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal28SparseHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal38DenseHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal38DenseHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal38SparseHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal38SparseHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal9Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal9Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedFloat4Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedFloat4Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedFloat8Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedFloat8Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalDayHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalDayHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalYearHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalYearHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedSmallIntHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedSmallIntHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTimeHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTimeHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTimeStampHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTimeStampHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTinyIntHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTinyIntHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt1Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt1Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt2Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt2Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt4Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt4Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt8Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt8Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVar16CharHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVar16CharHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVarBinaryHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVarBinaryHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVarCharHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVarCharHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpSmallIntHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpSmallIntHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpTimeHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpTimeHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpTimeStampHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpTimeStampHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpTinyIntHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpTinyIntHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt1Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt1Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt2Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt2Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt4Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt4Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt8Holder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt8Holder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpVar16CharHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpVar16CharHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpVarBinaryHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpVarBinaryHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpVarCharHolder.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpVarCharHolder.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GSmallIntToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GSmallIntToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GTimeArithmetic.GTimeDifference
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GTimeStampArithmetic.GTimeStampDifference
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GTimeStampToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GTimeToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GTinyIntToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GTinyIntToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GToDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GToTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt1ToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt1ToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt2ToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt2ToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt4ToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt4ToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt8ToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt8ToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionBit
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionVar16Char
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsBit
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsInterval
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsIntervalDay
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsIntervalYear
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsVar16Char
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsVarBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.BigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.Decimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.Decimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.Decimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.Decimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.DoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.FloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.IntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableBigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableDecimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableDecimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableDecimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableDecimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableDoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableFloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.BigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.BitHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.DateHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Decimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Decimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Decimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Decimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.DoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.FloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.IntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableBigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableBitHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDateHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDecimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDecimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDecimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDecimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableFloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableTimeHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableTimeStampHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableVar16CharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableVarBinaryHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableVarCharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.TimeHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.TimeStampHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Var16CharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.VarBinaryHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.VarCharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.BigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.BitHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.DateHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Decimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Decimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Decimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Decimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.DoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.FloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.IntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableBigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableBitHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDateHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDecimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDecimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDecimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDecimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableFloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableTimeHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableTimeStampHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableVar16CharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableVarBinaryHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableVarCharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.TimeHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.TimeStampHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Var16CharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.VarBinaryHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.VarCharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.BigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.Decimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.Decimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.Decimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.Decimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.DoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.FloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.IntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableBigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableDecimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableDecimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableDecimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableDecimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableDoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableFloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.BigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.Decimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.Decimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.Decimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.Decimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.DoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.FloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.IntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableBigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableDecimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableDecimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableDecimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableDecimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableDoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableFloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.BigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.BitHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.DateHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Decimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Decimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Decimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Decimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.DoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.FloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.IntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableBigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableBitHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDateHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDecimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDecimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDecimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDecimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableFloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableTimeHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableTimeStampHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableVar16CharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableVarBinaryHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableVarCharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.TimeHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.TimeStampHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Var16CharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.VarBinaryHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.VarCharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.BigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.BitHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.DateHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Decimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Decimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Decimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Decimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.DoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.FloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.IntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableBigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableBitHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDateHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDecimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDecimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDecimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDecimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableFloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableTimeHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableTimeStampHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableVar16CharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableVarBinaryHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableVarCharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.TimeHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.TimeStampHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Var16CharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.VarBinaryHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.VarCharHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.BigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.Decimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.Decimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.Decimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.Decimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.DoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.FloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.IntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableBigIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableDecimal18Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableDecimal28Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableDecimal38Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableDecimal9Hash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableDoubleHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableFloatHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableIntHash
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalBigIntFunctions.BigIntIntervalMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalBigIntFunctions.IntervalBigIntDivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalBigIntFunctions.IntervalBigIntMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayBigIntFunctions.BigIntIntervalDayMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayBigIntFunctions.IntervalDayBigIntDivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayBigIntFunctions.IntervalDayBigIntMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat4Functions.Float4IntervalDayMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat4Functions.IntervalDayFloat4DivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat4Functions.IntervalDayFloat4MultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat8Functions.Float8IntervalDayMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat8Functions.IntervalDayFloat8DivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat8Functions.IntervalDayFloat8MultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFunctions.IntervalDayAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFunctions.IntervalDayNegateFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFunctions.IntervalDaySubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayIntFunctions.IntervalDayIntDivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayIntFunctions.IntervalDayIntMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayIntFunctions.IntIntervalDayMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFloat4Functions.Float4IntervalMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFloat4Functions.IntervalFloat4DivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFloat4Functions.IntervalFloat4MultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFloat8Functions.Float8IntervalMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFloat8Functions.IntervalFloat8DivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFloat8Functions.IntervalFloat8MultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFunctions.IntervalAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFunctions.IntervalNegateFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFunctions.IntervalSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalIntFunctions.IntervalIntDivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalIntFunctions.IntervalIntMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalIntFunctions.IntIntervalMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearBigIntFunctions.BigIntIntervalYearMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearBigIntFunctions.IntervalYearBigIntDivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearBigIntFunctions.IntervalYearBigIntMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat4Functions.Float4IntervalYearMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat4Functions.IntervalYearFloat4DivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat4Functions.IntervalYearFloat4MultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat8Functions.Float8IntervalYearMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat8Functions.IntervalYearFloat8DivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat8Functions.IntervalYearFloat8MultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFunctions.IntervalYearAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFunctions.IntervalYearNegateFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFunctions.IntervalYearSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearIntFunctions.IntervalYearIntDivideFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearIntFunctions.IntervalYearIntMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearIntFunctions.IntIntervalYearMultiplyFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsFalse.Optional
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsFalse.Required
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNotFalse.Optional
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNotFalse.Required
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNotTrue.Optional
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNotTrue.Required
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.BigIntIsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.IntIsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableBigIntIsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableIntIsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableSmallIntIsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableTinyIntIsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableUInt1IsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableUInt2IsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableUInt4IsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableUInt8IsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableVarCharIsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.SmallIntIsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.TinyIntIsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.UInt1IsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.UInt2IsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.UInt4IsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.UInt8IsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.VarCharIsNumeric
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsTrue.Optional
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.IsTrue.Required
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Mappify.ConvertMapToKeyValuePairs
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.MathFunctions.Pi
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.MathFunctions.Power
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.MathFunctions.Random
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.MathFunctions.ToNumber
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.BigIntBigIntMultiply
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.Float4Float4Multiply
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.Float8Float8Multiply
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.IntIntMultiply
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.SmallIntSmallIntMultiply
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.TinyIntTinyIntMultiply
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.UInt1UInt1Multiply
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.UInt2UInt2Multiply
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.UInt4UInt4Multiply
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.UInt8UInt8Multiply
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.AddressCountFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.BroadcastAddressFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.HighAddressFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.InetAtonFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.InetNtoaFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.InNetworkFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.IsPrivateIP
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.IsValidIPFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.IsValidIPV4Function
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.IsValidIPv6Function
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.LowAddressFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.NetmaskFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.urldecodeFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.urlencodeFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.Not.Required
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ParseQueryFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.ParseUrlFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleCastFunctions.CastBooleanVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleCastFunctions.CastVarCharBoolean
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsBit
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthBit
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthVarChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SqlToDate
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SqlToTime
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SqlToTimeStamp
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.AsciiEndode
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.AsciiString
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.AsciiToChar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.BinaryString
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.BitLength
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Btrim
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.BtrimOneArg
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ByteLength
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.CharLength
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Concat
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatBothNullInput
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatLeftNullInput
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatOperator
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatRightNullInput
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ILike
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ILikeWithEscape
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.InitCap
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Left
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Like
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.LikeWithEscape
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.LowerCase
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Lpad
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.LpadTwoArg
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Ltrim
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.LtrimOneArg
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.OctetLength
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Position
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.RegexpMatches
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.RegexpReplace
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.RepeatString
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Replace
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ReverseString
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Right
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Rpad
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.RpadTwoArg
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Rtrim
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.RtrimOneArg
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Similar
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.SimilarWithEscape
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Split
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.SplitPart
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.StringBinary
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Strpos
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Substring
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.SubstringOffset
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.SubstringRegex
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.SubstringRegexNullable
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.UpperCase
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.BigIntBigIntSubtract
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.Float4Float4Subtract
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.Float8Float8Subtract
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.IntIntSubtract
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.SmallIntSmallIntSubtract
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.TinyIntTinyIntSubtract
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.UInt1UInt1Subtract
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.UInt2UInt2Subtract
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.UInt4UInt4Subtract
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.UInt8UInt8Subtract
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeBigIntFunctions.BigIntTimeAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeBigIntFunctions.TimeBigIntAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeBigIntFunctions.TimeBigIntSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalDayFunctions.IntervalDayTimeAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalDayFunctions.TimeIntervalDayAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalDayFunctions.TimeIntervalDaySubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalFunctions.IntervalTimeAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalFunctions.TimeIntervalAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalFunctions.TimeIntervalSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalYearFunctions.IntervalYearTimeAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalYearFunctions.TimeIntervalYearAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalYearFunctions.TimeIntervalYearSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntFunctions.IntTimeAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntFunctions.TimeIntAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntFunctions.TimeIntSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampBigIntFunctions.BigIntTimeStampAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampBigIntFunctions.TimeStampBigIntAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampBigIntFunctions.TimeStampBigIntSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalDayFunctions.IntervalDayTimeStampAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalDayFunctions.TimeStampIntervalDayAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalDayFunctions.TimeStampIntervalDaySubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalFunctions.IntervalTimeStampAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalFunctions.TimeStampIntervalAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalFunctions.TimeStampIntervalSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalYearFunctions.IntervalYearTimeStampAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalYearFunctions.TimeStampIntervalYearAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalYearFunctions.TimeStampIntervalYearSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntFunctions.IntTimeStampAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntFunctions.TimeStampIntAddFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntFunctions.TimeStampIntSubtractFunction
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhBigInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhFloat4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhFloat8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanSmallInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanTinyInt
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanUInt1
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanUInt2
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanUInt4
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanUInt8
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CastUnionList
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CastUnionMap
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CastUnionToUnion
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CompareType
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.GetType
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.IsNotNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.IsNull
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.UnionIsList
 
eval() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.UnionIsMap
 
evalFilter(LogicalExpression, ParquetMetadata, int, OptionManager, FragmentContext) - Static method in class org.apache.drill.exec.store.parquet.ParquetRGFilterEvaluator
 
evalFilter(LogicalExpression, ParquetMetadata, int, OptionManager, FragmentContext, Map<String, String>) - Static method in class org.apache.drill.exec.store.parquet.ParquetRGFilterEvaluator
 
EvalSetupException - Exception in org.apache.drill.exec.physical.impl.filter
 
EvalSetupException() - Constructor for exception org.apache.drill.exec.physical.impl.filter.EvalSetupException
 
evaluate(RecordBatch, ValueVector, LogicalExpression) - Static method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator
 
evaluate(int, UdfUtilities, VectorAccessible, ValueVector, LogicalExpression) - Static method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator
 
evaluate(Map<String, String>) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilter
Evaluate the filter for given pairs.
evaluateConstantExpr(UdfUtilities, LogicalExpression) - Static method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator
 
evaluateFunction(DrillSimpleFunc, ValueHolder[], String) - Static method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator
 
evaluatePeer(int) - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
called once for each peer row of the current frame.
EvaluationPredicate - Class in org.apache.drill.exec.physical.impl.filter
 
EvaluationVisitor - Class in org.apache.drill.exec.expr
Visitor that generates code for eval
EvaluationVisitor() - Constructor for class org.apache.drill.exec.expr.EvaluationVisitor
 
EventBasedRecordWriter - Class in org.apache.drill.exec.store
Reads records from the RecordValueAccessor and writes into RecordWriter.
EventBasedRecordWriter(VectorAccessible, RecordWriter) - Constructor for class org.apache.drill.exec.store.EventBasedRecordWriter
 
EventBasedRecordWriter.FieldConverter - Class in org.apache.drill.exec.store
 
EventBasedRecordWriter.FieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.EventBasedRecordWriter.FieldConverter
 
EventDispatcher<V> - Class in org.apache.drill.exec.coord.zk
An abstraction used for dispatching store events.
EventDispatcher(ZkEphemeralStore<V>) - Constructor for class org.apache.drill.exec.coord.zk.EventDispatcher
 
EVERY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ExactFunctionResolver - Class in org.apache.drill.exec.resolver
 
ExactFunctionResolver() - Constructor for class org.apache.drill.exec.resolver.ExactFunctionResolver
 
EXCEPT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
EXCEPTION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
exception - Variable in class org.apache.drill.exec.rpc.AbstractDisposableUserClientConnection
 
EXCEPTION_FUNCTION_NAME - Static variable in class org.apache.drill.exec.expr.fn.ExceptionFunction
 
ExceptionFunction - Class in org.apache.drill.exec.expr.fn
 
ExceptionFunction() - Constructor for class org.apache.drill.exec.expr.fn.ExceptionFunction
 
ExceptionFunction.ThrowException - Class in org.apache.drill.exec.expr.fn
 
ExceptionFunction.ThrowException() - Constructor for class org.apache.drill.exec.expr.fn.ExceptionFunction.ThrowException
 
ExceptionInjection - Class in org.apache.drill.exec.testing
Injection for a single exception.
ExcessiveExchangeIdentifier - Class in org.apache.drill.exec.planner.physical.visitor
 
ExcessiveExchangeIdentifier(long) - Constructor for class org.apache.drill.exec.planner.physical.visitor.ExcessiveExchangeIdentifier
 
Exchange - Interface in org.apache.drill.exec.physical.base
 
EXCHANGE - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
Exchange.ParallelizationDependency - Enum in org.apache.drill.exec.physical.base
Exchanges are fragment boundaries in physical operator tree.
ExchangePrel - Class in org.apache.drill.exec.planner.physical
 
ExchangePrel(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.drill.exec.planner.physical.ExchangePrel
 
ExchangeRemoverMaterializer - Class in org.apache.drill.exec.planner.fragment.contrib
Materializer visitor to remove exchange(s) NOTE: this Visitor does NOT set OperatorId, as after Exchange removal all operators need renumbering Use OperatorIdVisitor on top to set correct OperatorId
EXCLUDE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
EXCLUDING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
EXEC - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ExecConstants - Class in org.apache.drill.exec
 
ExecErrorConstants - Interface in org.apache.drill.exec.work
 
execute(Partitioner) - Method in interface org.apache.drill.exec.physical.impl.partitionsender.PartitionerDecorator.GeneralExecuteIface
 
EXECUTE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
executeBuildPhase() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
 
executeMethodLogic(PartitionerDecorator.GeneralExecuteIface) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerDecorator
Helper to execute the different methods wrapped into same logic
executePreparedStatement(UserProtos.PreparedStatementHandle, UserResultsListener) - Method in class org.apache.drill.exec.client.DrillClient
Execute the given prepared statement.
executePreparedStatement(UserProtos.PreparedStatementHandle) - Method in class org.apache.drill.exec.client.DrillClient
Execute the given prepared statement and return the results.
executeProbePhase() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinProbeTemplate
 
executeProjectRightPhase() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinProbeTemplate
 
ExecutionControls - Class in org.apache.drill.exec.testing
Tracks the simulated controls that will be injected for testing purposes.
ExecutionControls(OptionManager, CoordinationProtos.DrillbitEndpoint) - Constructor for class org.apache.drill.exec.testing.ExecutionControls
 
ExecutionControls.ControlsOptionValidator - Class in org.apache.drill.exec.testing
The JSON specified for the ExecConstants.DRILLBIT_CONTROL_INJECTIONS option is validated using this class.
ExecutionControls.ControlsOptionValidator(String, int) - Constructor for class org.apache.drill.exec.testing.ExecutionControls.ControlsOptionValidator
Constructor for controls option validator.
ExecutionControls.InjectionMixIn - Class in org.apache.drill.exec.testing
 
ExecutionControls.InjectionMixIn() - Constructor for class org.apache.drill.exec.testing.ExecutionControls.InjectionMixIn
 
ExecutionControlsInjector - Class in org.apache.drill.exec.testing
Injects exceptions and pauses at execution time for testing.
ExecutionControlsInjector(Class<?>) - Constructor for class org.apache.drill.exec.testing.ExecutionControlsInjector
Constructor.
EXISTS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
exists() - Method in class org.apache.drill.exec.server.rest.PluginConfigWrapper
 
exists(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
exit() - Method in class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager.DefaultQueryResourceManager
 
exit() - Method in interface org.apache.drill.exec.work.foreman.rm.QueryResourceManager
Mark the query as completing, giving up its slot in the cluster.
exit() - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedQueryResourceManager
 
exitChild() - Method in class org.apache.drill.exec.compile.sig.MappingSet
 
exitConstant() - Method in class org.apache.drill.exec.compile.sig.MappingSet
 
EXP - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ExpandableHyperContainer - Class in org.apache.drill.exec.record
 
ExpandableHyperContainer() - Constructor for class org.apache.drill.exec.record.ExpandableHyperContainer
 
ExpandableHyperContainer(VectorAccessible) - Constructor for class org.apache.drill.exec.record.ExpandableHyperContainer
 
ExpandBuff(boolean) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
ExpandingConcurrentMap<KEY,VALUE> - Class in org.apache.drill.exec.planner.sql
A special type of concurrent map which attempts to create an object before returning that it does not exist.
ExpandingConcurrentMap(ExpandingConcurrentMap.MapValueFactory<KEY, VALUE>) - Constructor for class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
Create a new ExpandingConcurrentMap.
ExpandingConcurrentMap.MapValueFactory<KEY,VALUE> - Interface in org.apache.drill.exec.planner.sql
 
expandView(RelDataType, String, List<String>) - Method in class org.apache.drill.exec.planner.torel.ConversionContext
 
expandView(RelDataType, String, SchemaPlus, List<String>) - Method in class org.apache.drill.exec.planner.torel.ConversionContext
 
expectedTokenSequences - Variable in exception org.apache.drill.exec.planner.sql.parser.impl.ParseException
Each entry in this array is an array of integers.
EXPLAIN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ExplainDepth() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses WITH TYPE | WITH IMPLEMENTATION | WITHOUT IMPLEMENTATION modifier for EXPLAIN PLAN.
ExplainDetailLevel() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses INCLUDING ALL ATTRIBUTES modifier for EXPLAIN PLAN.
ExplainHandler - Class in org.apache.drill.exec.planner.sql.handlers
 
ExplainHandler(SqlHandlerConfig, Pointer<String>) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ExplainHandler
 
ExplainHandler.LogicalExplain - Class in org.apache.drill.exec.planner.sql.handlers
 
ExplainHandler.LogicalExplain(RelNode, SqlExplainLevel, QueryContext) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ExplainHandler.LogicalExplain
 
ExplainHandler.PhysicalExplain - Class in org.apache.drill.exec.planner.sql.handlers
 
ExplainHandler.PhysicalExplain(RelNode, PhysicalPlan, SqlExplainLevel, QueryContext) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ExplainHandler.PhysicalExplain
 
explainTerms(RelWriter) - Method in class org.apache.drill.exec.planner.common.DrillLimitRelBase
 
explainTerms(RelWriter) - Method in class org.apache.drill.exec.planner.logical.DirPrunedEnumerableTableScan
 
explainTerms(RelWriter) - Method in class org.apache.drill.exec.planner.logical.DrillDirectScanRel
 
explainTerms(RelWriter) - Method in class org.apache.drill.exec.planner.logical.DrillScanRel
 
explainTerms(RelWriter) - Method in class org.apache.drill.exec.planner.physical.FlattenPrel
 
explainTerms(RelWriter) - Method in class org.apache.drill.exec.planner.physical.HashToRandomExchangePrel
 
explainTerms(RelWriter) - Method in class org.apache.drill.exec.planner.physical.ScanPrel
 
explainTerms(RelWriter) - Method in class org.apache.drill.exec.planner.physical.SingleMergeExchangePrel
 
explainTerms(RelWriter) - Method in class org.apache.drill.exec.planner.physical.TopNPrel
 
ExplicitTable(SqlParserPos) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses an explicit TABLE t reference.
EXPONENT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
expr - Variable in class org.apache.drill.exec.physical.config.AbstractDeMuxExchange
 
Expression(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a row expression or a parenthesized expression of any kind.
Expression2(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a binary row expression, or a parenthesized expression of any kind.
Expression3(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a unary row expression, or a parenthesized expression of any kind.
ExpressionCommaList(SqlParserPos, SqlAbstractParserImpl.ExprContext) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a list of expressions separated by commas.
ExpressionTreeMaterializer - Class in org.apache.drill.exec.expr
 
ExprHelper - Class in org.apache.drill.exec.planner.logical
 
ExprHelper() - Constructor for class org.apache.drill.exec.planner.logical.ExprHelper
 
EXTEND - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ExtendedBuiltinFunctionCall() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
ExtendedJsonOutput - Class in org.apache.drill.exec.vector.complex.fn
Writes JSON Output that will wrap Binary, Date, Time, Timestamp, Integer, Decimal and Interval types with wrapping maps for better type resolution upon deserialization.
ExtendedJsonOutput(JsonGenerator) - Constructor for class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
ExtendedMathFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.CbrtBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.CbrtBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtBigInt
 
ExtendedMathFunctions.CbrtDecimal18 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.CbrtDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtDecimal18
 
ExtendedMathFunctions.CbrtDecimal9 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.CbrtDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtDecimal9
 
ExtendedMathFunctions.CbrtFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.CbrtFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtFloat4
 
ExtendedMathFunctions.CbrtFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.CbrtFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtFloat8
 
ExtendedMathFunctions.CbrtInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.CbrtInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtInt
 
ExtendedMathFunctions.CbrtSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.CbrtSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtSmallInt
 
ExtendedMathFunctions.CbrtTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.CbrtTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtTinyInt
 
ExtendedMathFunctions.CbrtUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.CbrtUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtUInt1
 
ExtendedMathFunctions.CbrtUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.CbrtUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtUInt2
 
ExtendedMathFunctions.CbrtUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.CbrtUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtUInt4
 
ExtendedMathFunctions.CbrtUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.CbrtUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtUInt8
 
ExtendedMathFunctions.DegreesBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.DegreesBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesBigInt
 
ExtendedMathFunctions.DegreesDecimal18 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.DegreesDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesDecimal18
 
ExtendedMathFunctions.DegreesDecimal9 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.DegreesDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesDecimal9
 
ExtendedMathFunctions.DegreesFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.DegreesFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesFloat4
 
ExtendedMathFunctions.DegreesFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.DegreesFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesFloat8
 
ExtendedMathFunctions.DegreesInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.DegreesInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesInt
 
ExtendedMathFunctions.DegreesSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.DegreesSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesSmallInt
 
ExtendedMathFunctions.DegreesTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.DegreesTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesTinyInt
 
ExtendedMathFunctions.DegreesUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.DegreesUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesUInt1
 
ExtendedMathFunctions.DegreesUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.DegreesUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesUInt2
 
ExtendedMathFunctions.DegreesUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.DegreesUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesUInt4
 
ExtendedMathFunctions.DegreesUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.DegreesUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesUInt8
 
ExtendedMathFunctions.ExpBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.ExpBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpBigInt
 
ExtendedMathFunctions.ExpDecimal18 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.ExpDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpDecimal18
 
ExtendedMathFunctions.ExpDecimal9 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.ExpDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpDecimal9
 
ExtendedMathFunctions.ExpFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.ExpFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpFloat4
 
ExtendedMathFunctions.ExpFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.ExpFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpFloat8
 
ExtendedMathFunctions.ExpInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.ExpInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpInt
 
ExtendedMathFunctions.ExpSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.ExpSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpSmallInt
 
ExtendedMathFunctions.ExpTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.ExpTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpTinyInt
 
ExtendedMathFunctions.ExpUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.ExpUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpUInt1
 
ExtendedMathFunctions.ExpUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.ExpUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpUInt2
 
ExtendedMathFunctions.ExpUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.ExpUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpUInt4
 
ExtendedMathFunctions.ExpUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.ExpUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpUInt8
 
ExtendedMathFunctions.LogBaseBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogBaseBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseBigInt
 
ExtendedMathFunctions.LogBaseDecimal18 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogBaseDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseDecimal18
 
ExtendedMathFunctions.LogBaseDecimal9 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogBaseDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseDecimal9
 
ExtendedMathFunctions.LogBaseFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogBaseFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseFloat4
 
ExtendedMathFunctions.LogBaseFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogBaseFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseFloat8
 
ExtendedMathFunctions.LogBaseInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogBaseInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseInt
 
ExtendedMathFunctions.LogBaseSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogBaseSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseSmallInt
 
ExtendedMathFunctions.LogBaseTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogBaseTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseTinyInt
 
ExtendedMathFunctions.LogBaseUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogBaseUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseUInt1
 
ExtendedMathFunctions.LogBaseUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogBaseUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseUInt2
 
ExtendedMathFunctions.LogBaseUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogBaseUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseUInt4
 
ExtendedMathFunctions.LogBaseUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogBaseUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseUInt8
 
ExtendedMathFunctions.LogBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBigInt
 
ExtendedMathFunctions.LogDecimal18 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogDecimal18
 
ExtendedMathFunctions.LogDecimal9 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogDecimal9
 
ExtendedMathFunctions.LogFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogFloat4
 
ExtendedMathFunctions.LogFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogFloat8
 
ExtendedMathFunctions.LogInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogInt
 
ExtendedMathFunctions.LogSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogSmallInt
 
ExtendedMathFunctions.LogTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogTinyInt
 
ExtendedMathFunctions.LogUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogUInt1
 
ExtendedMathFunctions.LogUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogUInt2
 
ExtendedMathFunctions.LogUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogUInt4
 
ExtendedMathFunctions.LogUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.LogUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogUInt8
 
ExtendedMathFunctions.RadiansBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.RadiansBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansBigInt
 
ExtendedMathFunctions.RadiansDecimal18 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.RadiansDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansDecimal18
 
ExtendedMathFunctions.RadiansDecimal9 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.RadiansDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansDecimal9
 
ExtendedMathFunctions.RadiansFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.RadiansFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansFloat4
 
ExtendedMathFunctions.RadiansFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.RadiansFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansFloat8
 
ExtendedMathFunctions.RadiansInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.RadiansInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansInt
 
ExtendedMathFunctions.RadiansSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.RadiansSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansSmallInt
 
ExtendedMathFunctions.RadiansTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.RadiansTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansTinyInt
 
ExtendedMathFunctions.RadiansUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.RadiansUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansUInt1
 
ExtendedMathFunctions.RadiansUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.RadiansUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansUInt2
 
ExtendedMathFunctions.RadiansUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.RadiansUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansUInt4
 
ExtendedMathFunctions.RadiansUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
ExtendedMathFunctions.RadiansUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansUInt8
 
ExtendedMockRecordReader - Class in org.apache.drill.exec.store.mock
Extended form of the mock record reader that uses generator class instances to create the mock values.
ExtendedMockRecordReader(FragmentContext, MockTableDef.MockScanEntry) - Constructor for class org.apache.drill.exec.store.mock.ExtendedMockRecordReader
 
ExtendedOptionIterator - Class in org.apache.drill.exec.store.sys
 
ExtendedOptionIterator(FragmentContext, boolean) - Constructor for class org.apache.drill.exec.store.sys.ExtendedOptionIterator
 
ExtendedOptionIterator.ExtendedOptionValueWrapper - Class in org.apache.drill.exec.store.sys
Wrapper class for Extended Option Value
ExtendedOptionIterator.ExtendedOptionValueWrapper(String, String, OptionValue.AccessibleScopes, String, OptionValue.OptionScope) - Constructor for class org.apache.drill.exec.store.sys.ExtendedOptionIterator.ExtendedOptionValueWrapper
 
ExtendedOptionIterator.Status - Enum in org.apache.drill.exec.store.sys
 
ExtendedTableRef() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Allows parser to be extended with new types of table references.
ExtendedType - Enum in org.apache.drill.exec.vector.complex.fn
 
ExtendedTypeName - Interface in org.apache.drill.exec.vector.complex.fn
 
ExtendList() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
extensions - Variable in class org.apache.drill.exec.store.easy.json.JSONFormatPlugin.JSONFormatConfig
 
extensions - Variable in class org.apache.drill.exec.store.easy.sequencefile.SequenceFileFormatConfig
 
extensions - Variable in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
EXTERNAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
EXTERNAL_SORT_BATCH_LIMIT - Static variable in class org.apache.drill.exec.ExecConstants
 
EXTERNAL_SORT_DISABLE_MANAGED - Static variable in class org.apache.drill.exec.ExecConstants
 
EXTERNAL_SORT_DISABLE_MANAGED_OPTION - Static variable in class org.apache.drill.exec.ExecConstants
 
EXTERNAL_SORT_MAX_MEMORY - Static variable in class org.apache.drill.exec.ExecConstants
 
EXTERNAL_SORT_MERGE_BATCH_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
EXTERNAL_SORT_MERGE_LIMIT - Static variable in class org.apache.drill.exec.ExecConstants
 
EXTERNAL_SORT_MSORT_MAX_BATCHSIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
EXTERNAL_SORT_SPILL_BATCH_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
EXTERNAL_SORT_SPILL_DIRS - Static variable in class org.apache.drill.exec.ExecConstants
 
EXTERNAL_SORT_SPILL_FILE_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
EXTERNAL_SORT_SPILL_FILESYSTEM - Static variable in class org.apache.drill.exec.ExecConstants
 
EXTERNAL_SORT_SPILL_GROUP_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
EXTERNAL_SORT_SPILL_THRESHOLD - Static variable in class org.apache.drill.exec.ExecConstants
 
EXTERNAL_SORT_TARGET_SPILL_BATCH_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
ExternalSort - Class in org.apache.drill.exec.physical.config
 
ExternalSort(PhysicalOperator, List<Order.Ordering>, boolean) - Constructor for class org.apache.drill.exec.physical.config.ExternalSort
 
ExternalSortBatch - Class in org.apache.drill.exec.physical.impl.xsort
 
ExternalSortBatch(ExternalSort, FragmentContext, RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch
 
ExternalSortBatch - Class in org.apache.drill.exec.physical.impl.xsort.managed
External sort batch: a sort batch which can spill to disk in order to operate within a defined memory footprint.
ExternalSortBatch(ExternalSort, FragmentContext, RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
 
ExternalSortBatch.Metric - Enum in org.apache.drill.exec.physical.impl.xsort
 
ExternalSortBatch.Metric - Enum in org.apache.drill.exec.physical.impl.xsort.managed
 
ExternalSortBatchCreator - Class in org.apache.drill.exec.physical.impl.xsort
 
ExternalSortBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatchCreator
 
EXTRACT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
extractColumnPrefix(String) - Static method in class org.apache.drill.exec.planner.StarColumnHelper
 
extractHeader - Variable in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
extractSqlOperatorFromWrapper(SqlOperator) - Static method in class org.apache.drill.exec.planner.sql.parser.DrillCalciteWrapperUtility
This static method will extract the SqlOperator inside the given SqlOperator if the given SqlOperator is wrapped in DrillCalciteSqlWrapper and will just return the given SqlOperator if it is not wrapped.
extractSqlOperatorFromWrapper(SqlFunction) - Static method in class org.apache.drill.exec.planner.sql.parser.DrillCalciteWrapperUtility
This static method will extract the SqlFunction inside the given SqlFunction if the given SqlFunction is wrapped in DrillCalciteSqlFunctionWrapper and will just return the given SqlFunction if it is not wrapped.
extractSqlOperatorFromWrapper(SqlAggFunction) - Static method in class org.apache.drill.exec.planner.sql.parser.DrillCalciteWrapperUtility
This static method will extract the SqlAggFunction inside the given SqlAggFunction if the given SqlFunction is wrapped in DrillCalciteSqlAggFunctionWrapper and will just return the given SqlAggFunction if it is not wrapped.
extractStarColumnPrefix(String) - Static method in class org.apache.drill.exec.planner.StarColumnHelper
 

F

f(String) - Method in class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
 
FACTORY - Static variable in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
SqlParserImplFactory implementation for creating parser.
FACTORY - Static variable in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserWithCompoundIdConverter
SqlParserImplFactory implementation for creating parser.
fadviseIfAvailable(FSDataInputStream, long, long) - Static method in class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
fail(Throwable) - Method in interface org.apache.drill.exec.ops.FragmentContext.ExecutorState
Inform the executor if a exception occurs and fragment should be failed.
fail(Throwable) - Method in class org.apache.drill.exec.ops.FragmentContext
 
FAIL - Static variable in class org.apache.drill.exec.rpc.control.ControlRpcConfig
 
FAIL - Static variable in class org.apache.drill.exec.rpc.data.DataRpcConfig
 
failed(RpcException) - Method in class org.apache.drill.exec.ops.StatusHandler
 
failed(RpcException) - Method in class org.apache.drill.exec.rpc.security.AuthenticationOutcomeListener
 
FailingRequestHandler<S extends ServerConnection<S>> - Class in org.apache.drill.exec.rpc
This handler fails any request on the connection.
FailingRequestHandler() - Constructor for class org.apache.drill.exec.rpc.FailingRequestHandler
 
fallback - Variable in class org.apache.drill.exec.server.options.FallbackOptionManager
 
FallbackOptionManager - Class in org.apache.drill.exec.server.options
An OptionManager which allows for falling back onto another OptionManager when retrieving options.
FallbackOptionManager(OptionManager) - Constructor for class org.apache.drill.exec.server.options.FallbackOptionManager
 
FALSE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
FastSaslClientFactory - Class in org.apache.drill.exec.rpc.security
FastSaslServerFactory - Class in org.apache.drill.exec.rpc.security
fetch - Variable in class org.apache.drill.exec.planner.common.DrillLimitRelBase
 
FETCH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
field - Variable in class org.apache.drill.exec.planner.physical.PrelUtil.DesiredField
 
field(String, boolean) - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor.VisualizationState
 
Field - Class in org.apache.drill.exec.schema
 
Field(RecordSchema, TypeProtos.MajorType, String) - Constructor for class org.apache.drill.exec.schema.Field
 
field - Variable in class org.apache.drill.exec.store.ischema.InfoSchemaFilter.FieldExprNode
 
fieldDelimiter - Variable in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
FieldGen - Interface in org.apache.drill.exec.store.mock
Interface which all mock column data generators must implement.
fieldId - Variable in class org.apache.drill.exec.store.EventBasedRecordWriter.FieldConverter
 
FieldIdUtil - Class in org.apache.drill.exec.vector.complex
 
FieldIdUtil() - Constructor for class org.apache.drill.exec.vector.complex.FieldIdUtil
 
fieldKey - Static variable in class org.apache.drill.exec.expr.fn.impl.MappifyUtility
 
fieldName - Variable in class org.apache.drill.exec.store.EventBasedRecordWriter.FieldConverter
 
FieldSelection - Class in org.apache.drill.exec.vector.complex.fn
This class manages the projection pushdown for a complex path.
fieldValue - Static variable in class org.apache.drill.exec.expr.fn.impl.MappifyUtility
 
fieldVectorMap() - Method in class org.apache.drill.exec.physical.impl.ScanBatch.Mutator
 
fileClosed(DrillFSDataInputStream) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
fileClosed(DrillFSDataInputStream) - Method in interface org.apache.drill.exec.store.dfs.OpenFileTracker
Remove the given DrillFSDataInputStream from opened file list.
FileGroupScan - Interface in org.apache.drill.exec.physical.base
 
fileOpened(Path, DrillFSDataInputStream) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
fileOpened(Path, DrillFSDataInputStream) - Method in interface org.apache.drill.exec.store.dfs.OpenFileTracker
Add new file location and DrillFSDataInputStream to list.
FILES - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
files - Variable in class org.apache.drill.exec.store.dfs.FileSelection
 
FileSelection - Class in org.apache.drill.exec.store.dfs
Jackson serializable description of a file selection.
FileSelection(List<FileStatus>, List<String>, String) - Constructor for class org.apache.drill.exec.store.dfs.FileSelection
Creates a selection out of given file statuses/files and selection root.
FileSelection(List<FileStatus>, List<String>, String, String, boolean) - Constructor for class org.apache.drill.exec.store.dfs.FileSelection
 
FileSelection(List<FileStatus>, List<String>, String, String, boolean, FileSelection.StatusType) - Constructor for class org.apache.drill.exec.store.dfs.FileSelection
 
FileSelection(FileSelection) - Constructor for class org.apache.drill.exec.store.dfs.FileSelection
Copy constructor for convenience.
FILESYSTEM_PARTITION_COLUMN_LABEL - Static variable in class org.apache.drill.exec.ExecConstants
The column label (for directory levels) in results when querying files in a directory E.g.
FILESYSTEM_PARTITION_COLUMN_LABEL_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
FileSystemConfig - Class in org.apache.drill.exec.store.dfs
 
FileSystemConfig() - Constructor for class org.apache.drill.exec.store.dfs.FileSystemConfig
 
FileSystemCreateTableEntry - Class in org.apache.drill.exec.planner.logical
Implements CreateTableEntry interface to create new tables in FileSystem storage.
FileSystemCreateTableEntry(FileSystemConfig, FormatPluginConfig, String, List<String>, StorageStrategy, StoragePluginRegistry) - Constructor for class org.apache.drill.exec.planner.logical.FileSystemCreateTableEntry
 
FileSystemCreateTableEntry(FileSystemConfig, FormatPlugin, String, List<String>, StorageStrategy) - Constructor for class org.apache.drill.exec.planner.logical.FileSystemCreateTableEntry
 
FileSystemPartitionDescriptor - Class in org.apache.drill.exec.planner
 
FileSystemPartitionDescriptor(PlannerSettings, TableScan) - Constructor for class org.apache.drill.exec.planner.FileSystemPartitionDescriptor
 
FileSystemPlugin - Class in org.apache.drill.exec.store.dfs
A Storage engine associated with a Hadoop FileSystem Implementation.
FileSystemPlugin(FileSystemConfig, DrillbitContext, String) - Constructor for class org.apache.drill.exec.store.dfs.FileSystemPlugin
 
FileSystemSchemaFactory - Class in org.apache.drill.exec.store.dfs
This is the top level schema that responds to root level path requests.
FileSystemSchemaFactory(String, List<WorkspaceSchemaFactory>) - Constructor for class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory
 
FileSystemSchemaFactory(FileSystemPlugin, String, List<WorkspaceSchemaFactory>) - Constructor for class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory
 
FileSystemSchemaFactory.FileSystemSchema - Class in org.apache.drill.exec.store.dfs
 
FileSystemSchemaFactory.FileSystemSchema(String, SchemaConfig) - Constructor for class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory.FileSystemSchema
 
FileSystemUtil - Class in org.apache.drill.exec.util
Helper class that provides methods to list directories or file or both statuses.
FileSystemUtil() - Constructor for class org.apache.drill.exec.util.FileSystemUtil
 
FileWork - Interface in org.apache.drill.exec.store.dfs.easy
 
FillBuff() - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
fillNullVectors(int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
When the SELECT clause references columns that do not exist in the Parquet file, we don't issue an error; instead we simply make up a column and fill it with nulls.
Filter - Class in org.apache.drill.exec.physical.config
 
Filter(PhysicalOperator, LogicalExpression, float) - Constructor for class org.apache.drill.exec.physical.config.Filter
 
FILTER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
filter - Variable in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
 
FILTER_INSTANCE_DRILL - Static variable in class org.apache.drill.exec.planner.logical.DrillReduceExpressionsRule
 
FILTER_MAX_SELECTIVITY_ESTIMATE_FACTOR - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
FILTER_MIN_SELECTIVITY_ESTIMATE_FACTOR - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
filterBatch(int) - Method in interface org.apache.drill.exec.physical.impl.filter.Filterer
 
filterBatch(int) - Method in class org.apache.drill.exec.physical.impl.filter.FilterTemplate2
 
filterBatch(int) - Method in class org.apache.drill.exec.physical.impl.filter.FilterTemplate4
 
FilterBatchCreator - Class in org.apache.drill.exec.physical.impl.filter
 
FilterBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.filter.FilterBatchCreator
 
Filterer - Interface in org.apache.drill.exec.physical.impl.filter
 
filterNulls - Variable in class org.apache.drill.exec.planner.common.DrillJoinRelBase
The join key positions for which null values will not match.
FilterPrel - Class in org.apache.drill.exec.planner.physical
 
FilterPrel(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.drill.exec.planner.physical.FilterPrel
 
FilterPrule - Class in org.apache.drill.exec.planner.physical
 
FilterRecordBatch - Class in org.apache.drill.exec.physical.impl.filter
 
FilterRecordBatch(Filter, RecordBatch, FragmentContext) - Constructor for class org.apache.drill.exec.physical.impl.filter.FilterRecordBatch
 
FilterSignature - Interface in org.apache.drill.exec.physical.impl.filter
 
FilterTemplate2 - Class in org.apache.drill.exec.physical.impl.filter
 
FilterTemplate2() - Constructor for class org.apache.drill.exec.physical.impl.filter.FilterTemplate2
 
FilterTemplate4 - Class in org.apache.drill.exec.physical.impl.filter
 
FilterTemplate4() - Constructor for class org.apache.drill.exec.physical.impl.filter.FilterTemplate4
 
FINAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
FinalColumnReorderer - Class in org.apache.drill.exec.planner.physical.visitor
 
FinalColumnReorderer() - Constructor for class org.apache.drill.exec.planner.physical.visitor.FinalColumnReorderer
 
finalizeConnection(BitControl.BitControlHandshake, ControlConnection) - Method in class org.apache.drill.exec.rpc.control.ControlClient
 
finalizeRel() - Method in interface org.apache.drill.exec.planner.sql.handlers.PrelFinalizable
 
finalizeSaslSession() - Method in class org.apache.drill.exec.rpc.AbstractServerConnection
 
finalizeSaslSession() - Method in class org.apache.drill.exec.rpc.user.UserServer.BitToUserConnection
 
finalMerge(List<? extends BatchGroup>, VectorContainer, int, VectorInitializer) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SpilledRuns
 
finalType(TypeProtos.MajorType) - Method in class org.apache.drill.exec.record.TypedFieldId.Builder
 
find(Text, byte, int) - Method in class org.apache.drill.exec.store.text.DrillTextRecordReader
Returns the index within the text of the first occurrence of delimiter, starting the search at the specified index.
findAvailablePlugins(ScanResult) - Static method in class org.apache.drill.exec.store.StoragePluginRegistryImpl
Get a list of all available storage plugin class constructors.
findClass(String) - Method in class org.apache.drill.exec.compile.CachedClassLoader
 
findClass(String) - Method in class org.apache.drill.exec.compile.QueryClassLoader
 
findDrillFunction(FunctionResolver, FunctionCall) - Method in class org.apache.drill.exec.expr.fn.FunctionImplementationRegistry
First attempts to find the Drill function implementation that matches the name, arg types and return type.
findDrillFunction(FunctionResolver, FunctionCall) - Method in interface org.apache.drill.exec.expr.fn.FunctionLookupContext
Method returns the materialized drill function corresponding to the functioncall that is passed in
findExactMatchingDrillFunction(String, List<TypeProtos.MajorType>, TypeProtos.MajorType) - Method in class org.apache.drill.exec.expr.fn.FunctionImplementationRegistry
Finds the Drill function implementation that matches the name, arg types and return type.
findItemOrFlatten(RexNode, List<RexNode>) - Static method in class org.apache.drill.exec.planner.common.DrillRelOptUtil
Travesal RexNode to find the item/flattern operator.
FindLimit0Visitor - Class in org.apache.drill.exec.planner.sql.handlers
Visitor that will identify whether the root portion of the RelNode tree contains a limit 0 pattern.
FindLimit0Visitor.RelDataTypeReader - Class in org.apache.drill.exec.planner.sql.handlers
Reader for column names and types.
FindLimit0Visitor.RelDataTypeReader(List<String>, List<TypeProtos.MajorType>) - Constructor for class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor.RelDataTypeReader
 
findNonDrillFunction(FunctionCall) - Method in class org.apache.drill.exec.expr.fn.FunctionImplementationRegistry
Find function implementation for given functionCall in non-Drill function registries such as Hive UDF registry.
findNonDrillFunction(FunctionCall) - Method in interface org.apache.drill.exec.expr.fn.FunctionLookupContext
Find function implementation for given functionCall in non-Drill function registries such as Hive UDF registry.
FindPartitionConditions - Class in org.apache.drill.exec.planner.logical.partition
 
FindPartitionConditions(BitSet) - Constructor for class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
 
FindPartitionConditions(BitSet, RexBuilder) - Constructor for class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
 
FindPartitionConditions.OpState - Class in org.apache.drill.exec.planner.logical.partition
During top-down traversal of the expression tree, keep track of the current operators that are directory filters.
FindPartitionConditions.OpState(SqlOperator) - Constructor for class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions.OpState
 
findSchema(SchemaPlus, List<String>) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
Search and return schema with given schemaPath.
findSchema(SchemaPlus, String) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
Same utility as SchemaUtilites.findSchema(SchemaPlus, List) except the search schema path given here is complete path instead of list.
finishBatch() - Method in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
 
finished() - Method in class org.apache.drill.exec.record.RecordIterator
 
finishRecord() - Method in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
 
finishRecord() - Method in class org.apache.drill.exec.store.httpd.HttpdLogRecord
Call this method after a record has been parsed.
finishUnregistration(String) - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
 
fireListeners(TransientStoreEvent) - Method in class org.apache.drill.exec.coord.store.BaseTransientStore
 
fireListeners(TransientStoreEvent) - Method in class org.apache.drill.exec.coord.zk.ZkEphemeralStore
This method override ensures package level method visibility.
FIRST - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
FIRST_VALUE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
fixedWidthArray(String, float) - Method in class org.apache.drill.exec.record.VectorInitializer
 
FixedWidthRepeatedReader - Class in org.apache.drill.exec.store.parquet.columnreaders
 
fixTraits(RelOptRuleCall, RelTraitSet) - Static method in class org.apache.drill.exec.planner.physical.PrelUtil
 
fixTraits(RelOptPlanner, RelTraitSet) - Static method in class org.apache.drill.exec.planner.physical.PrelUtil
 
FlattenBatchCreator - Class in org.apache.drill.exec.physical.impl.flatten
 
FlattenBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.flatten.FlattenBatchCreator
 
Flattener - Interface in org.apache.drill.exec.physical.impl.flatten
 
Flattener.Monitor - Interface in org.apache.drill.exec.physical.impl.flatten
 
FlattenPOP - Class in org.apache.drill.exec.physical.config
 
FlattenPOP(PhysicalOperator, SchemaPath) - Constructor for class org.apache.drill.exec.physical.config.FlattenPOP
 
FlattenPrel - Class in org.apache.drill.exec.planner.physical
 
FlattenPrel(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.drill.exec.planner.physical.FlattenPrel
 
FlattenRecordBatch - Class in org.apache.drill.exec.physical.impl.flatten
 
FlattenRecordBatch(FlattenPOP, RecordBatch, FragmentContext) - Constructor for class org.apache.drill.exec.physical.impl.flatten.FlattenRecordBatch
 
flattenRecords(int, int, Flattener.Monitor) - Method in interface org.apache.drill.exec.physical.impl.flatten.Flattener
 
flattenRecords(int, int, Flattener.Monitor) - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenTemplate
 
FlattenTemplate - Class in org.apache.drill.exec.physical.impl.flatten
 
FlattenTemplate() - Constructor for class org.apache.drill.exec.physical.impl.flatten.FlattenTemplate
 
flipIfRight() - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
 
flipIfRight() - Method in class org.apache.drill.exec.physical.config.MergeJoinPOP
 
FLOAT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Float4Accessor - Class in org.apache.drill.exec.vector.accessor
 
Float4Accessor(Float4Vector) - Constructor for class org.apache.drill.exec.vector.accessor.Float4Accessor
 
Float8Accessor - Class in org.apache.drill.exec.vector.accessor
 
Float8Accessor(Float8Vector) - Constructor for class org.apache.drill.exec.vector.accessor.Float8Accessor
 
FLOAT_TYPE - Static variable in class org.apache.drill.exec.schema.json.jackson.JacksonHelper
 
float_val - Variable in class org.apache.drill.exec.server.options.OptionValue
 
float_val - Variable in class org.apache.drill.exec.store.sys.OptionIterator.OptionValueWrapper
 
FloatBEConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
FloatBEConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.FloatBEConvertFrom
 
FloatBEConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
FloatBEConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.FloatBEConvertTo
 
FloatConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
FloatConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.FloatConvertFrom
 
FloatConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
FloatConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.FloatConvertTo
 
FLOOR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
FloorCeilOptions(SqlParserPos, boolean) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
flush() - Method in class org.apache.drill.exec.compile.LogWriter
 
flush(boolean) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
flush() - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingOutputStream
 
flush() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
flush() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
flushCache() - Method in class org.apache.drill.exec.compile.CodeCompiler
Flush the compiled classes from the cache.
flushOutgoingBatches(boolean, boolean) - Method in interface org.apache.drill.exec.physical.impl.partitionsender.Partitioner
 
flushOutgoingBatches(boolean, boolean) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerDecorator
flushOutgoingBatches - decorator to call real Partitioner(s) flushOutgoingBatches
flushOutgoingBatches(boolean, boolean) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate
Flush each outgoing record batch, and optionally reset the state of each outgoing record batch (on schema change).
flushResponses() - Method in class org.apache.drill.exec.work.batch.ResponseSenderQueue
 
flushResponses(int) - Method in class org.apache.drill.exec.work.batch.ResponseSenderQueue
Flush only up to a count responses
flushToFileWriter(ParquetFileWriter) - Method in class org.apache.parquet.hadoop.ParquetColumnChunkPageWriteStore
Writes the column chunks in the corresponding row group
fmix64(long) - Static method in class org.apache.drill.exec.expr.fn.impl.MurmurHash3
 
FOLLOWING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
footer() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetSchema
 
FooterGatherer - Class in org.apache.drill.exec.store.parquet
 
FooterGatherer() - Constructor for class org.apache.drill.exec.store.parquet.FooterGatherer
 
FOR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
FORCE_2PHASE_AGGR - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
FORCE_2PHASE_AGGR_KEY - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
forceSingleMode() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
forceSpill() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl
 
forEachByte(ByteBufProcessor) - Method in class org.apache.drill.exec.record.DeadBuf
 
forEachByte(int, int, ByteBufProcessor) - Method in class org.apache.drill.exec.record.DeadBuf
 
forEachByteDesc(ByteBufProcessor) - Method in class org.apache.drill.exec.record.DeadBuf
 
forEachByteDesc(int, int, ByteBufProcessor) - Method in class org.apache.drill.exec.record.DeadBuf
 
FOREIGN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Foreman - Class in org.apache.drill.exec.work.foreman
Foreman manages all the fragments (local and remote) for a single query where this is the driving/root node.
Foreman(WorkManager.WorkerBee, DrillbitContext, UserClientConnection, UserBitShared.QueryId, UserProtos.RunQuery) - Constructor for class org.apache.drill.exec.work.foreman.Foreman
Constructor.
Foreman.PhysicalFromLogicalExplain - Class in org.apache.drill.exec.work.foreman
 
Foreman.PhysicalFromLogicalExplain(String) - Constructor for class org.apache.drill.exec.work.foreman.Foreman.PhysicalFromLogicalExplain
 
Foreman.ProfileOption - Enum in org.apache.drill.exec.work.foreman
 
foremanDrillbit - Variable in class org.apache.drill.exec.work.fragment.FragmentStatusReporter
 
ForemanException - Exception in org.apache.drill.exec.work.foreman
 
ForemanException() - Constructor for exception org.apache.drill.exec.work.foreman.ForemanException
 
ForemanException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.drill.exec.work.foreman.ForemanException
 
ForemanException(String, Throwable) - Constructor for exception org.apache.drill.exec.work.foreman.ForemanException
 
ForemanException(String) - Constructor for exception org.apache.drill.exec.work.foreman.ForemanException
 
ForemanException(Throwable) - Constructor for exception org.apache.drill.exec.work.foreman.ForemanException
 
ForemanSetupException - Exception in org.apache.drill.exec.work.foreman
 
ForemanSetupException() - Constructor for exception org.apache.drill.exec.work.foreman.ForemanSetupException
 
ForemanSetupException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.drill.exec.work.foreman.ForemanSetupException
 
ForemanSetupException(String, Throwable) - Constructor for exception org.apache.drill.exec.work.foreman.ForemanSetupException
 
ForemanSetupException(String) - Constructor for exception org.apache.drill.exec.work.foreman.ForemanSetupException
 
ForemanSetupException(Throwable) - Constructor for exception org.apache.drill.exec.work.foreman.ForemanSetupException
 
FORMAL_COMMENT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
format - Static variable in class org.apache.drill.exec.server.rest.profile.ProfileResources.ProfileInfo
 
formatConfig - Variable in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
FormatCreator - Class in org.apache.drill.exec.store.dfs
Responsible for instantiating format plugins
formatFieldSchema(MaterializedField) - Static method in class org.apache.drill.exec.util.VectorUtil
 
FormatMatcher - Class in org.apache.drill.exec.store.dfs
 
FormatMatcher() - Constructor for class org.apache.drill.exec.store.dfs.FormatMatcher
 
FormatPlugin - Interface in org.apache.drill.exec.store.dfs
Similar to a storage engine but built specifically to work within a FileSystem context.
formats - Variable in class org.apache.drill.exec.store.dfs.FileSystemConfig
 
FormatSelection - Class in org.apache.drill.exec.store.dfs
 
FormatSelection() - Constructor for class org.apache.drill.exec.store.dfs.FormatSelection
 
FormatSelection(FormatPluginConfig, List<String>) - Constructor for class org.apache.drill.exec.store.dfs.FormatSelection
 
FormatSelection(FormatPluginConfig, FileSelection) - Constructor for class org.apache.drill.exec.store.dfs.FormatSelection
 
formatter() - Method in class org.apache.drill.exec.expr.DebugStringBuilder
 
FORTRAN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
forward(long) - Method in class org.apache.drill.exec.record.RecordIterator
 
FOUND - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Fragment - Class in org.apache.drill.exec.planner.fragment
 
Fragment() - Constructor for class org.apache.drill.exec.planner.fragment.Fragment
 
fragment() - Method in class org.apache.drill.exec.work.QueryWorkUnit.MinorFragmentDefn
 
Fragment.ExchangeFragmentPair - Class in org.apache.drill.exec.planner.fragment
 
Fragment.ExchangeFragmentPair(Exchange, Fragment) - Constructor for class org.apache.drill.exec.planner.fragment.Fragment.ExchangeFragmentPair
 
FRAGMENT_COLUMNS - Static variable in class org.apache.drill.exec.server.rest.profile.FragmentWrapper
 
FRAGMENT_COLUMNS_TOOLTIP - Static variable in class org.apache.drill.exec.server.rest.profile.FragmentWrapper
 
FRAGMENT_V6 - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
FragmentContext - Class in org.apache.drill.exec.ops
Contextual objects required for execution of a particular fragment.
FragmentContext(DrillbitContext, BitControl.PlanFragment, FunctionImplementationRegistry) - Constructor for class org.apache.drill.exec.ops.FragmentContext
Create a FragmentContext instance for non-root fragment.
FragmentContext(DrillbitContext, BitControl.PlanFragment, QueryContext, UserClientConnection, FunctionImplementationRegistry) - Constructor for class org.apache.drill.exec.ops.FragmentContext
Create a FragmentContext instance for root fragment.
FragmentContext(DrillbitContext, BitControl.PlanFragment, UserClientConnection, FunctionImplementationRegistry) - Constructor for class org.apache.drill.exec.ops.FragmentContext
TODO: Remove this constructor when removing the SimpleRootExec (DRILL-2097).
fragmentContext - Variable in class org.apache.drill.exec.physical.impl.BaseRootExec
 
fragmentContext - Variable in class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
FragmentContext.ExecutorState - Interface in org.apache.drill.exec.ops
 
FragmentContextInterface - Interface in org.apache.drill.exec.ops
Fragment context interface: separates implementation from definition.
FragmentData - Class in org.apache.drill.exec.work.foreman
 
FragmentData(ExecProtos.FragmentHandle, CoordinationProtos.DrillbitEndpoint, boolean) - Constructor for class org.apache.drill.exec.work.foreman.FragmentData
 
fragmentExecutor - Variable in class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
FragmentExecutor - Class in org.apache.drill.exec.work.fragment
Responsible for running a single fragment on a single Drillbit.
FragmentExecutor(FragmentContext, BitControl.PlanFragment, FragmentStatusReporter) - Constructor for class org.apache.drill.exec.work.fragment.FragmentExecutor
Create a FragmentExecutor where we need to parse and materialize the root operator.
FragmentExecutor(FragmentContext, BitControl.PlanFragment, FragmentStatusReporter, FragmentRoot) - Constructor for class org.apache.drill.exec.work.fragment.FragmentExecutor
Create a FragmentExecutor where we already have a root operator in memory.
fragmentHandle - Variable in class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
FragmentLeaf - Interface in org.apache.drill.exec.physical.base
A Physical Operator that can be the leaf node of one particular execution fragment.
FragmentManager - Interface in org.apache.drill.exec.work.fragment
The Fragment Manager is responsible managing incoming data and executing a fragment.
fragmentMap - Variable in class org.apache.drill.exec.work.batch.AbstractDataCollector
 
FragmentOptionManager - Class in org.apache.drill.exec.server.options
OptionManager that holds options within FragmentContext.
FragmentOptionManager(OptionManager, OptionList) - Constructor for class org.apache.drill.exec.server.options.FragmentOptionManager
 
FragmentParallelizer - Interface in org.apache.drill.exec.planner.fragment
Generic interface to provide different parallelization strategies for MajorFragments.
FragmentRoot - Interface in org.apache.drill.exec.physical.base
Describes the root operation within a particular Fragment.
FragmentSetupException - Exception in org.apache.drill.exec.exception
 
FragmentSetupException() - Constructor for exception org.apache.drill.exec.exception.FragmentSetupException
 
FragmentSetupException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.drill.exec.exception.FragmentSetupException
 
FragmentSetupException(String, Throwable) - Constructor for exception org.apache.drill.exec.exception.FragmentSetupException
 
FragmentSetupException(String) - Constructor for exception org.apache.drill.exec.exception.FragmentSetupException
 
FragmentSetupException(Throwable) - Constructor for exception org.apache.drill.exec.exception.FragmentSetupException
 
FragmentStats - Class in org.apache.drill.exec.ops
Holds statistics of a particular (minor) fragment.
FragmentStats(BufferAllocator, CoordinationProtos.DrillbitEndpoint) - Constructor for class org.apache.drill.exec.ops.FragmentStats
 
FragmentStatusListener - Interface in org.apache.drill.exec.work.foreman
 
FragmentStatusReporter - Class in org.apache.drill.exec.work.fragment
The status reporter is responsible for receiving changes in fragment state and propagating the status back to the Foreman either through a control tunnel or locally.
FragmentStatusReporter(FragmentContext) - Constructor for class org.apache.drill.exec.work.fragment.FragmentStatusReporter
 
FragmentVisitor<T,V> - Interface in org.apache.drill.exec.planner.fragment
 
FragmentWrapper - Class in org.apache.drill.exec.server.rest.profile
Wrapper class for a major fragment profile.
FragmentWrapper(UserBitShared.MajorFragmentProfile, long) - Constructor for class org.apache.drill.exec.server.rest.profile.FragmentWrapper
 
FragmentWritableBatch - Class in org.apache.drill.exec.record
 
FragmentWritableBatch(boolean, UserBitShared.QueryId, int, int, int, int, WritableBatch) - Constructor for class org.apache.drill.exec.record.FragmentWritableBatch
 
FragmentWritableBatch(boolean, UserBitShared.QueryId, int, int, int, int[], WritableBatch) - Constructor for class org.apache.drill.exec.record.FragmentWritableBatch
 
FRAME_TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.window.WindowFramer
 
FrameSupportTemplate - Class in org.apache.drill.exec.physical.impl.window
WindowFramer implementation that supports the FRAME clause.
FrameSupportTemplate() - Constructor for class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
 
FREE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
freeMemory(long) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
FROM - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
FromClause() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses the FROM clause a SELECT.
fromString(String) - Static method in enum org.apache.drill.exec.compile.ClassTransformer.ScalarReplacementOption
Convert a string to an enum value.
FsmCursor - Class in org.apache.drill.exec.compile
Maintains state while traversing a finite state machine described by an FsmDescriptor.
FsmDescriptor - Class in org.apache.drill.exec.compile
Describes a finite state machine in terms of a mapping of tokens to characters, a regular expression describing the valid transitions using the characters, and an end state.
FsmDescriptor(Map<String, Character>, String, String) - Constructor for class org.apache.drill.exec.compile.FsmDescriptor
Create a finite state machine descriptor.
FULL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
FUNC_CPU_COST - Static variable in class org.apache.drill.exec.planner.cost.DrillCostBase
 
FUNCTION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
function - Variable in class org.apache.drill.exec.store.ischema.InfoSchemaFilter.FunctionExprNode
 
FunctionAttributes - Class in org.apache.drill.exec.expr.fn
Attributes of a function Those are used in code generation and optimization.
FunctionAttributes(FunctionTemplate, ValueReference[], ValueReference, WorkspaceReference[]) - Constructor for class org.apache.drill.exec.expr.fn.FunctionAttributes
 
FunctionConverter - Class in org.apache.drill.exec.expr.fn
Converts FunctionCalls to Java Expressions.
FunctionConverter() - Constructor for class org.apache.drill.exec.expr.fn.FunctionConverter
 
FunctionGenerationHelper - Class in org.apache.drill.exec.expr.fn
 
FunctionGenerationHelper() - Constructor for class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
 
FunctionHolder - Class in org.apache.drill.exec.expr.fn.registry
Holder class that contains: function name function signature which is string representation of function name and its input parameters DrillFuncHolder associated with the function
FunctionHolder(String, String, DrillFuncHolder) - Constructor for class org.apache.drill.exec.expr.fn.registry.FunctionHolder
 
FunctionImplementationRegistry - Class in org.apache.drill.exec.expr.fn
This class offers the registry for functions.
FunctionImplementationRegistry(DrillConfig) - Constructor for class org.apache.drill.exec.expr.fn.FunctionImplementationRegistry
 
FunctionImplementationRegistry(DrillConfig, ScanResult) - Constructor for class org.apache.drill.exec.expr.fn.FunctionImplementationRegistry
 
FunctionImplementationRegistry(DrillConfig, ScanResult, OptionManager) - Constructor for class org.apache.drill.exec.expr.fn.FunctionImplementationRegistry
 
FunctionImplementationRegistry(DrillConfig, ScanResult, OptionSet) - Constructor for class org.apache.drill.exec.expr.fn.FunctionImplementationRegistry
 
functionImplementationRegistry - Variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
FunctionInitializer - Class in org.apache.drill.exec.expr.fn
To avoid the cost of initializing all functions up front, this class contains all information required to initializing a function when it is used.
FunctionInitializer(String, ClassLoader) - Constructor for class org.apache.drill.exec.expr.fn.FunctionInitializer
 
FunctionLookupContext - Interface in org.apache.drill.exec.expr.fn
 
FunctionName() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses the name of a function (either a compound identifier or a reserved word which can be used as a function name).
FunctionParameterList(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses function parameter lists including DISTINCT keyword recognition, DEFAULT, and named argument assignment.
FunctionRegistryHolder - Class in org.apache.drill.exec.expr.fn.registry
Function registry holder stores function implementations by jar name, function name.
FunctionRegistryHolder() - Constructor for class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
 
FunctionResolver - Interface in org.apache.drill.exec.resolver
An implementing class of FunctionResolver provide their own algorithm to choose a DrillFuncHolder from a given list of candidates, with respect to a given FunctionCall
FunctionResolverFactory - Class in org.apache.drill.exec.resolver
 
FunctionResolverFactory() - Constructor for class org.apache.drill.exec.resolver.FunctionResolverFactory
 
functionsSize() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
Returns quantity of functions stored in FunctionRegistryHolder.functions.
FunctionTemplate - Annotation Type in org.apache.drill.exec.expr.annotations
 
FunctionTemplate.FunctionCostCategory - Enum in org.apache.drill.exec.expr.annotations
 
FunctionTemplate.FunctionScope - Enum in org.apache.drill.exec.expr.annotations
Function scope is used to indicate function output rows relation: simple / scalar (1 -> 1) or aggregate (n -> 1).
FunctionTemplate.NullHandling - Enum in org.apache.drill.exec.expr.annotations
 
FunctionTemplate.ReturnType - Enum in org.apache.drill.exec.expr.annotations
Return type enum is used to indicate which return type calculation logic should be used for functions.
FunctionUtils - Class in org.apache.drill.exec.expr.fn
 
FunctionUtils() - Constructor for class org.apache.drill.exec.expr.fn.FunctionUtils
 
FunctionValidationException - Exception in org.apache.drill.exec.exception
 
FunctionValidationException(String) - Constructor for exception org.apache.drill.exec.exception.FunctionValidationException
 
FUSION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 

G

G - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
GBigIntToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GBigIntToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GBigIntToChar
 
GBigIntToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GBigIntToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GBigIntToTimeStamp
 
GCompareBigIntVsBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBigIntVsBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt
 
GCompareBigIntVsBigInt.EqualsBigIntVsBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBigIntVsBigInt.EqualsBigIntVsBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.EqualsBigIntVsBigInt
 
GCompareBigIntVsBigInt.GCompareBigIntVsBigIntNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBigIntVsBigInt.GCompareBigIntVsBigIntNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareBigIntVsBigIntNullHigh
 
GCompareBigIntVsBigInt.GCompareBigIntVsBigIntNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBigIntVsBigInt.GCompareBigIntVsBigIntNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareBigIntVsBigIntNullLow
 
GCompareBigIntVsBigInt.GCompareBigIntVsNullableBigIntNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBigIntVsBigInt.GCompareBigIntVsNullableBigIntNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareBigIntVsNullableBigIntNullHigh
 
GCompareBigIntVsBigInt.GCompareBigIntVsNullableBigIntNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBigIntVsBigInt.GCompareBigIntVsNullableBigIntNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareBigIntVsNullableBigIntNullLow
 
GCompareBigIntVsBigInt.GCompareNullableBigIntVsBigIntNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBigIntVsBigInt.GCompareNullableBigIntVsBigIntNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareNullableBigIntVsBigIntNullHigh
 
GCompareBigIntVsBigInt.GCompareNullableBigIntVsBigIntNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBigIntVsBigInt.GCompareNullableBigIntVsBigIntNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareNullableBigIntVsBigIntNullLow
 
GCompareBigIntVsBigInt.GCompareNullableBigIntVsNullableBigIntNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBigIntVsBigInt.GCompareNullableBigIntVsNullableBigIntNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareNullableBigIntVsNullableBigIntNullHigh
 
GCompareBigIntVsBigInt.GCompareNullableBigIntVsNullableBigIntNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBigIntVsBigInt.GCompareNullableBigIntVsNullableBigIntNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareNullableBigIntVsNullableBigIntNullLow
 
GCompareBigIntVsBigInt.GreaterThanBigIntVsBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBigIntVsBigInt.GreaterThanBigIntVsBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GreaterThanBigIntVsBigInt
 
GCompareBigIntVsBigInt.GreaterThanEqBigIntVsBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBigIntVsBigInt.GreaterThanEqBigIntVsBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GreaterThanEqBigIntVsBigInt
 
GCompareBigIntVsBigInt.LessThanBigIntVsBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBigIntVsBigInt.LessThanBigIntVsBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.LessThanBigIntVsBigInt
 
GCompareBigIntVsBigInt.LessThanEqBigIntVsBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBigIntVsBigInt.LessThanEqBigIntVsBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.LessThanEqBigIntVsBigInt
 
GCompareBigIntVsBigInt.NotEqualsBigIntVsBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBigIntVsBigInt.NotEqualsBigIntVsBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.NotEqualsBigIntVsBigInt
 
GCompareBitVsBit - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBitVsBit() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit
 
GCompareBitVsBit.EqualsBitVsBit - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBitVsBit.EqualsBitVsBit() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.EqualsBitVsBit
 
GCompareBitVsBit.GCompareBitVsBitNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBitVsBit.GCompareBitVsBitNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareBitVsBitNullHigh
 
GCompareBitVsBit.GCompareBitVsBitNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBitVsBit.GCompareBitVsBitNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareBitVsBitNullLow
 
GCompareBitVsBit.GCompareBitVsNullableBitNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBitVsBit.GCompareBitVsNullableBitNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareBitVsNullableBitNullHigh
 
GCompareBitVsBit.GCompareBitVsNullableBitNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBitVsBit.GCompareBitVsNullableBitNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareBitVsNullableBitNullLow
 
GCompareBitVsBit.GCompareNullableBitVsBitNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBitVsBit.GCompareNullableBitVsBitNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareNullableBitVsBitNullHigh
 
GCompareBitVsBit.GCompareNullableBitVsBitNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBitVsBit.GCompareNullableBitVsBitNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareNullableBitVsBitNullLow
 
GCompareBitVsBit.GCompareNullableBitVsNullableBitNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBitVsBit.GCompareNullableBitVsNullableBitNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareNullableBitVsNullableBitNullHigh
 
GCompareBitVsBit.GCompareNullableBitVsNullableBitNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBitVsBit.GCompareNullableBitVsNullableBitNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareNullableBitVsNullableBitNullLow
 
GCompareBitVsBit.GreaterThanBitVsBit - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBitVsBit.GreaterThanBitVsBit() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GreaterThanBitVsBit
 
GCompareBitVsBit.GreaterThanEqBitVsBit - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBitVsBit.GreaterThanEqBitVsBit() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GreaterThanEqBitVsBit
 
GCompareBitVsBit.LessThanBitVsBit - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBitVsBit.LessThanBitVsBit() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.LessThanBitVsBit
 
GCompareBitVsBit.LessThanEqBitVsBit - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBitVsBit.LessThanEqBitVsBit() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.LessThanEqBitVsBit
 
GCompareBitVsBit.NotEqualsBitVsBit - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareBitVsBit.NotEqualsBitVsBit() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.NotEqualsBitVsBit
 
GCompareDateVsDate - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareDateVsDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate
 
GCompareDateVsDate.EqualsDateVsDate - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareDateVsDate.EqualsDateVsDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.EqualsDateVsDate
 
GCompareDateVsDate.GCompareDateVsDateNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareDateVsDate.GCompareDateVsDateNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareDateVsDateNullHigh
 
GCompareDateVsDate.GCompareDateVsDateNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareDateVsDate.GCompareDateVsDateNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareDateVsDateNullLow
 
GCompareDateVsDate.GCompareDateVsNullableDateNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareDateVsDate.GCompareDateVsNullableDateNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareDateVsNullableDateNullHigh
 
GCompareDateVsDate.GCompareDateVsNullableDateNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareDateVsDate.GCompareDateVsNullableDateNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareDateVsNullableDateNullLow
 
GCompareDateVsDate.GCompareNullableDateVsDateNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareDateVsDate.GCompareNullableDateVsDateNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareNullableDateVsDateNullHigh
 
GCompareDateVsDate.GCompareNullableDateVsDateNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareDateVsDate.GCompareNullableDateVsDateNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareNullableDateVsDateNullLow
 
GCompareDateVsDate.GCompareNullableDateVsNullableDateNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareDateVsDate.GCompareNullableDateVsNullableDateNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareNullableDateVsNullableDateNullHigh
 
GCompareDateVsDate.GCompareNullableDateVsNullableDateNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareDateVsDate.GCompareNullableDateVsNullableDateNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareNullableDateVsNullableDateNullLow
 
GCompareDateVsDate.GreaterThanDateVsDate - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareDateVsDate.GreaterThanDateVsDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GreaterThanDateVsDate
 
GCompareDateVsDate.GreaterThanEqDateVsDate - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareDateVsDate.GreaterThanEqDateVsDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GreaterThanEqDateVsDate
 
GCompareDateVsDate.LessThanDateVsDate - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareDateVsDate.LessThanDateVsDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.LessThanDateVsDate
 
GCompareDateVsDate.LessThanEqDateVsDate - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareDateVsDate.LessThanEqDateVsDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.LessThanEqDateVsDate
 
GCompareDateVsDate.NotEqualsDateVsDate - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareDateVsDate.NotEqualsDateVsDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.NotEqualsDateVsDate
 
GCompareFloat4VsFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat4VsFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4
 
GCompareFloat4VsFloat4.EqualsFloat4VsFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat4VsFloat4.EqualsFloat4VsFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.EqualsFloat4VsFloat4
 
GCompareFloat4VsFloat4.GCompareFloat4VsFloat4NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat4VsFloat4.GCompareFloat4VsFloat4NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareFloat4VsFloat4NullHigh
 
GCompareFloat4VsFloat4.GCompareFloat4VsFloat4NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat4VsFloat4.GCompareFloat4VsFloat4NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareFloat4VsFloat4NullLow
 
GCompareFloat4VsFloat4.GCompareFloat4VsNullableFloat4NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat4VsFloat4.GCompareFloat4VsNullableFloat4NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareFloat4VsNullableFloat4NullHigh
 
GCompareFloat4VsFloat4.GCompareFloat4VsNullableFloat4NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat4VsFloat4.GCompareFloat4VsNullableFloat4NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareFloat4VsNullableFloat4NullLow
 
GCompareFloat4VsFloat4.GCompareNullableFloat4VsFloat4NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat4VsFloat4.GCompareNullableFloat4VsFloat4NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareNullableFloat4VsFloat4NullHigh
 
GCompareFloat4VsFloat4.GCompareNullableFloat4VsFloat4NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat4VsFloat4.GCompareNullableFloat4VsFloat4NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareNullableFloat4VsFloat4NullLow
 
GCompareFloat4VsFloat4.GCompareNullableFloat4VsNullableFloat4NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat4VsFloat4.GCompareNullableFloat4VsNullableFloat4NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareNullableFloat4VsNullableFloat4NullHigh
 
GCompareFloat4VsFloat4.GCompareNullableFloat4VsNullableFloat4NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat4VsFloat4.GCompareNullableFloat4VsNullableFloat4NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareNullableFloat4VsNullableFloat4NullLow
 
GCompareFloat4VsFloat4.GreaterThanEqFloat4VsFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat4VsFloat4.GreaterThanEqFloat4VsFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GreaterThanEqFloat4VsFloat4
 
GCompareFloat4VsFloat4.GreaterThanFloat4VsFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat4VsFloat4.GreaterThanFloat4VsFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GreaterThanFloat4VsFloat4
 
GCompareFloat4VsFloat4.LessThanEqFloat4VsFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat4VsFloat4.LessThanEqFloat4VsFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.LessThanEqFloat4VsFloat4
 
GCompareFloat4VsFloat4.LessThanFloat4VsFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat4VsFloat4.LessThanFloat4VsFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.LessThanFloat4VsFloat4
 
GCompareFloat4VsFloat4.NotEqualsFloat4VsFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat4VsFloat4.NotEqualsFloat4VsFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.NotEqualsFloat4VsFloat4
 
GCompareFloat8VsFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat8VsFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8
 
GCompareFloat8VsFloat8.EqualsFloat8VsFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat8VsFloat8.EqualsFloat8VsFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.EqualsFloat8VsFloat8
 
GCompareFloat8VsFloat8.GCompareFloat8VsFloat8NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat8VsFloat8.GCompareFloat8VsFloat8NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareFloat8VsFloat8NullHigh
 
GCompareFloat8VsFloat8.GCompareFloat8VsFloat8NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat8VsFloat8.GCompareFloat8VsFloat8NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareFloat8VsFloat8NullLow
 
GCompareFloat8VsFloat8.GCompareFloat8VsNullableFloat8NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat8VsFloat8.GCompareFloat8VsNullableFloat8NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareFloat8VsNullableFloat8NullHigh
 
GCompareFloat8VsFloat8.GCompareFloat8VsNullableFloat8NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat8VsFloat8.GCompareFloat8VsNullableFloat8NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareFloat8VsNullableFloat8NullLow
 
GCompareFloat8VsFloat8.GCompareNullableFloat8VsFloat8NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat8VsFloat8.GCompareNullableFloat8VsFloat8NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareNullableFloat8VsFloat8NullHigh
 
GCompareFloat8VsFloat8.GCompareNullableFloat8VsFloat8NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat8VsFloat8.GCompareNullableFloat8VsFloat8NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareNullableFloat8VsFloat8NullLow
 
GCompareFloat8VsFloat8.GCompareNullableFloat8VsNullableFloat8NullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat8VsFloat8.GCompareNullableFloat8VsNullableFloat8NullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareNullableFloat8VsNullableFloat8NullHigh
 
GCompareFloat8VsFloat8.GCompareNullableFloat8VsNullableFloat8NullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat8VsFloat8.GCompareNullableFloat8VsNullableFloat8NullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareNullableFloat8VsNullableFloat8NullLow
 
GCompareFloat8VsFloat8.GreaterThanEqFloat8VsFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat8VsFloat8.GreaterThanEqFloat8VsFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GreaterThanEqFloat8VsFloat8
 
GCompareFloat8VsFloat8.GreaterThanFloat8VsFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat8VsFloat8.GreaterThanFloat8VsFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GreaterThanFloat8VsFloat8
 
GCompareFloat8VsFloat8.LessThanEqFloat8VsFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat8VsFloat8.LessThanEqFloat8VsFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.LessThanEqFloat8VsFloat8
 
GCompareFloat8VsFloat8.LessThanFloat8VsFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat8VsFloat8.LessThanFloat8VsFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.LessThanFloat8VsFloat8
 
GCompareFloat8VsFloat8.NotEqualsFloat8VsFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareFloat8VsFloat8.NotEqualsFloat8VsFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.NotEqualsFloat8VsFloat8
 
GCompareIntervalDayVsIntervalDay - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalDayVsIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay
 
GCompareIntervalDayVsIntervalDay.EqualsIntervalDayVsIntervalDay - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalDayVsIntervalDay.EqualsIntervalDayVsIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.EqualsIntervalDayVsIntervalDay
 
GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsIntervalDayNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsIntervalDayNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsIntervalDayNullHigh
 
GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsIntervalDayNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsIntervalDayNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsIntervalDayNullLow
 
GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsNullableIntervalDayNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsNullableIntervalDayNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsNullableIntervalDayNullHigh
 
GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsNullableIntervalDayNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsNullableIntervalDayNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsNullableIntervalDayNullLow
 
GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsIntervalDayNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsIntervalDayNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsIntervalDayNullHigh
 
GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsIntervalDayNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsIntervalDayNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsIntervalDayNullLow
 
GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsNullableIntervalDayNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsNullableIntervalDayNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsNullableIntervalDayNullHigh
 
GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsNullableIntervalDayNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsNullableIntervalDayNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsNullableIntervalDayNullLow
 
GCompareIntervalDayVsIntervalDay.GreaterThanEqIntervalDayVsIntervalDay - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalDayVsIntervalDay.GreaterThanEqIntervalDayVsIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GreaterThanEqIntervalDayVsIntervalDay
 
GCompareIntervalDayVsIntervalDay.GreaterThanIntervalDayVsIntervalDay - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalDayVsIntervalDay.GreaterThanIntervalDayVsIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GreaterThanIntervalDayVsIntervalDay
 
GCompareIntervalDayVsIntervalDay.LessThanEqIntervalDayVsIntervalDay - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalDayVsIntervalDay.LessThanEqIntervalDayVsIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.LessThanEqIntervalDayVsIntervalDay
 
GCompareIntervalDayVsIntervalDay.LessThanIntervalDayVsIntervalDay - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalDayVsIntervalDay.LessThanIntervalDayVsIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.LessThanIntervalDayVsIntervalDay
 
GCompareIntervalDayVsIntervalDay.NotEqualsIntervalDayVsIntervalDay - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalDayVsIntervalDay.NotEqualsIntervalDayVsIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.NotEqualsIntervalDayVsIntervalDay
 
GCompareIntervalVsInterval - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalVsInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval
 
GCompareIntervalVsInterval.EqualsIntervalVsInterval - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalVsInterval.EqualsIntervalVsInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.EqualsIntervalVsInterval
 
GCompareIntervalVsInterval.GCompareIntervalVsIntervalNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalVsInterval.GCompareIntervalVsIntervalNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareIntervalVsIntervalNullHigh
 
GCompareIntervalVsInterval.GCompareIntervalVsIntervalNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalVsInterval.GCompareIntervalVsIntervalNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareIntervalVsIntervalNullLow
 
GCompareIntervalVsInterval.GCompareIntervalVsNullableIntervalNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalVsInterval.GCompareIntervalVsNullableIntervalNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareIntervalVsNullableIntervalNullHigh
 
GCompareIntervalVsInterval.GCompareIntervalVsNullableIntervalNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalVsInterval.GCompareIntervalVsNullableIntervalNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareIntervalVsNullableIntervalNullLow
 
GCompareIntervalVsInterval.GCompareNullableIntervalVsIntervalNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalVsInterval.GCompareNullableIntervalVsIntervalNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareNullableIntervalVsIntervalNullHigh
 
GCompareIntervalVsInterval.GCompareNullableIntervalVsIntervalNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalVsInterval.GCompareNullableIntervalVsIntervalNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareNullableIntervalVsIntervalNullLow
 
GCompareIntervalVsInterval.GCompareNullableIntervalVsNullableIntervalNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalVsInterval.GCompareNullableIntervalVsNullableIntervalNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareNullableIntervalVsNullableIntervalNullHigh
 
GCompareIntervalVsInterval.GCompareNullableIntervalVsNullableIntervalNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalVsInterval.GCompareNullableIntervalVsNullableIntervalNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareNullableIntervalVsNullableIntervalNullLow
 
GCompareIntervalVsInterval.GreaterThanEqIntervalVsInterval - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalVsInterval.GreaterThanEqIntervalVsInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GreaterThanEqIntervalVsInterval
 
GCompareIntervalVsInterval.GreaterThanIntervalVsInterval - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalVsInterval.GreaterThanIntervalVsInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GreaterThanIntervalVsInterval
 
GCompareIntervalVsInterval.LessThanEqIntervalVsInterval - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalVsInterval.LessThanEqIntervalVsInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.LessThanEqIntervalVsInterval
 
GCompareIntervalVsInterval.LessThanIntervalVsInterval - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalVsInterval.LessThanIntervalVsInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.LessThanIntervalVsInterval
 
GCompareIntervalVsInterval.NotEqualsIntervalVsInterval - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalVsInterval.NotEqualsIntervalVsInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.NotEqualsIntervalVsInterval
 
GCompareIntervalYearVsIntervalYear - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalYearVsIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear
 
GCompareIntervalYearVsIntervalYear.EqualsIntervalYearVsIntervalYear - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalYearVsIntervalYear.EqualsIntervalYearVsIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.EqualsIntervalYearVsIntervalYear
 
GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsIntervalYearNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsIntervalYearNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsIntervalYearNullHigh
 
GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsIntervalYearNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsIntervalYearNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsIntervalYearNullLow
 
GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsNullableIntervalYearNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsNullableIntervalYearNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsNullableIntervalYearNullHigh
 
GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsNullableIntervalYearNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsNullableIntervalYearNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsNullableIntervalYearNullLow
 
GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsIntervalYearNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsIntervalYearNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsIntervalYearNullHigh
 
GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsIntervalYearNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsIntervalYearNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsIntervalYearNullLow
 
GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsNullableIntervalYearNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsNullableIntervalYearNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsNullableIntervalYearNullHigh
 
GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsNullableIntervalYearNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsNullableIntervalYearNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsNullableIntervalYearNullLow
 
GCompareIntervalYearVsIntervalYear.GreaterThanEqIntervalYearVsIntervalYear - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalYearVsIntervalYear.GreaterThanEqIntervalYearVsIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GreaterThanEqIntervalYearVsIntervalYear
 
GCompareIntervalYearVsIntervalYear.GreaterThanIntervalYearVsIntervalYear - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalYearVsIntervalYear.GreaterThanIntervalYearVsIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GreaterThanIntervalYearVsIntervalYear
 
GCompareIntervalYearVsIntervalYear.LessThanEqIntervalYearVsIntervalYear - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalYearVsIntervalYear.LessThanEqIntervalYearVsIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.LessThanEqIntervalYearVsIntervalYear
 
GCompareIntervalYearVsIntervalYear.LessThanIntervalYearVsIntervalYear - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalYearVsIntervalYear.LessThanIntervalYearVsIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.LessThanIntervalYearVsIntervalYear
 
GCompareIntervalYearVsIntervalYear.NotEqualsIntervalYearVsIntervalYear - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntervalYearVsIntervalYear.NotEqualsIntervalYearVsIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.NotEqualsIntervalYearVsIntervalYear
 
GCompareIntVsInt - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntVsInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt
 
GCompareIntVsInt.EqualsIntVsInt - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntVsInt.EqualsIntVsInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.EqualsIntVsInt
 
GCompareIntVsInt.GCompareIntVsIntNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntVsInt.GCompareIntVsIntNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareIntVsIntNullHigh
 
GCompareIntVsInt.GCompareIntVsIntNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntVsInt.GCompareIntVsIntNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareIntVsIntNullLow
 
GCompareIntVsInt.GCompareIntVsNullableIntNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntVsInt.GCompareIntVsNullableIntNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareIntVsNullableIntNullHigh
 
GCompareIntVsInt.GCompareIntVsNullableIntNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntVsInt.GCompareIntVsNullableIntNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareIntVsNullableIntNullLow
 
GCompareIntVsInt.GCompareNullableIntVsIntNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntVsInt.GCompareNullableIntVsIntNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareNullableIntVsIntNullHigh
 
GCompareIntVsInt.GCompareNullableIntVsIntNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntVsInt.GCompareNullableIntVsIntNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareNullableIntVsIntNullLow
 
GCompareIntVsInt.GCompareNullableIntVsNullableIntNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntVsInt.GCompareNullableIntVsNullableIntNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareNullableIntVsNullableIntNullHigh
 
GCompareIntVsInt.GCompareNullableIntVsNullableIntNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntVsInt.GCompareNullableIntVsNullableIntNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareNullableIntVsNullableIntNullLow
 
GCompareIntVsInt.GreaterThanEqIntVsInt - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntVsInt.GreaterThanEqIntVsInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GreaterThanEqIntVsInt
 
GCompareIntVsInt.GreaterThanIntVsInt - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntVsInt.GreaterThanIntVsInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GreaterThanIntVsInt
 
GCompareIntVsInt.LessThanEqIntVsInt - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntVsInt.LessThanEqIntVsInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.LessThanEqIntVsInt
 
GCompareIntVsInt.LessThanIntVsInt - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntVsInt.LessThanIntVsInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.LessThanIntVsInt
 
GCompareIntVsInt.NotEqualsIntVsInt - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareIntVsInt.NotEqualsIntVsInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.NotEqualsIntVsInt
 
GCompareTimeStampVsTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeStampVsTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp
 
GCompareTimeStampVsTimeStamp.EqualsTimeStampVsTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeStampVsTimeStamp.EqualsTimeStampVsTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.EqualsTimeStampVsTimeStamp
 
GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsNullableTimeStampNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsNullableTimeStampNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsNullableTimeStampNullHigh
 
GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsNullableTimeStampNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsNullableTimeStampNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsNullableTimeStampNullLow
 
GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsTimeStampNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsTimeStampNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsTimeStampNullHigh
 
GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsTimeStampNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsTimeStampNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsTimeStampNullLow
 
GCompareTimeStampVsTimeStamp.GCompareTimeStampVsNullableTimeStampNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeStampVsTimeStamp.GCompareTimeStampVsNullableTimeStampNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareTimeStampVsNullableTimeStampNullHigh
 
GCompareTimeStampVsTimeStamp.GCompareTimeStampVsNullableTimeStampNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeStampVsTimeStamp.GCompareTimeStampVsNullableTimeStampNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareTimeStampVsNullableTimeStampNullLow
 
GCompareTimeStampVsTimeStamp.GCompareTimeStampVsTimeStampNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeStampVsTimeStamp.GCompareTimeStampVsTimeStampNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareTimeStampVsTimeStampNullHigh
 
GCompareTimeStampVsTimeStamp.GCompareTimeStampVsTimeStampNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeStampVsTimeStamp.GCompareTimeStampVsTimeStampNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareTimeStampVsTimeStampNullLow
 
GCompareTimeStampVsTimeStamp.GreaterThanEqTimeStampVsTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeStampVsTimeStamp.GreaterThanEqTimeStampVsTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GreaterThanEqTimeStampVsTimeStamp
 
GCompareTimeStampVsTimeStamp.GreaterThanTimeStampVsTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeStampVsTimeStamp.GreaterThanTimeStampVsTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GreaterThanTimeStampVsTimeStamp
 
GCompareTimeStampVsTimeStamp.LessThanEqTimeStampVsTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeStampVsTimeStamp.LessThanEqTimeStampVsTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.LessThanEqTimeStampVsTimeStamp
 
GCompareTimeStampVsTimeStamp.LessThanTimeStampVsTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeStampVsTimeStamp.LessThanTimeStampVsTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.LessThanTimeStampVsTimeStamp
 
GCompareTimeStampVsTimeStamp.NotEqualsTimeStampVsTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeStampVsTimeStamp.NotEqualsTimeStampVsTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.NotEqualsTimeStampVsTimeStamp
 
GCompareTimeVsTime - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeVsTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime
 
GCompareTimeVsTime.EqualsTimeVsTime - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeVsTime.EqualsTimeVsTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.EqualsTimeVsTime
 
GCompareTimeVsTime.GCompareNullableTimeVsNullableTimeNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeVsTime.GCompareNullableTimeVsNullableTimeNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareNullableTimeVsNullableTimeNullHigh
 
GCompareTimeVsTime.GCompareNullableTimeVsNullableTimeNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeVsTime.GCompareNullableTimeVsNullableTimeNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareNullableTimeVsNullableTimeNullLow
 
GCompareTimeVsTime.GCompareNullableTimeVsTimeNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeVsTime.GCompareNullableTimeVsTimeNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareNullableTimeVsTimeNullHigh
 
GCompareTimeVsTime.GCompareNullableTimeVsTimeNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeVsTime.GCompareNullableTimeVsTimeNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareNullableTimeVsTimeNullLow
 
GCompareTimeVsTime.GCompareTimeVsNullableTimeNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeVsTime.GCompareTimeVsNullableTimeNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareTimeVsNullableTimeNullHigh
 
GCompareTimeVsTime.GCompareTimeVsNullableTimeNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeVsTime.GCompareTimeVsNullableTimeNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareTimeVsNullableTimeNullLow
 
GCompareTimeVsTime.GCompareTimeVsTimeNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeVsTime.GCompareTimeVsTimeNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareTimeVsTimeNullHigh
 
GCompareTimeVsTime.GCompareTimeVsTimeNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeVsTime.GCompareTimeVsTimeNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareTimeVsTimeNullLow
 
GCompareTimeVsTime.GreaterThanEqTimeVsTime - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeVsTime.GreaterThanEqTimeVsTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GreaterThanEqTimeVsTime
 
GCompareTimeVsTime.GreaterThanTimeVsTime - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeVsTime.GreaterThanTimeVsTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GreaterThanTimeVsTime
 
GCompareTimeVsTime.LessThanEqTimeVsTime - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeVsTime.LessThanEqTimeVsTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.LessThanEqTimeVsTime
 
GCompareTimeVsTime.LessThanTimeVsTime - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeVsTime.LessThanTimeVsTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.LessThanTimeVsTime
 
GCompareTimeVsTime.NotEqualsTimeVsTime - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareTimeVsTime.NotEqualsTimeVsTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.NotEqualsTimeVsTime
 
GCompareVarBinaryVsVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary
 
GCompareVarBinaryVsVarBinary.EqualsVarBinaryVsVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarBinary.EqualsVarBinaryVsVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.EqualsVarBinaryVsVarBinary
 
GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsNullableVarBinaryNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsNullableVarBinaryNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsNullableVarBinaryNullHigh
 
GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsNullableVarBinaryNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsNullableVarBinaryNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsNullableVarBinaryNullLow
 
GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsVarBinaryNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsVarBinaryNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsVarBinaryNullHigh
 
GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsVarBinaryNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsVarBinaryNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsVarBinaryNullLow
 
GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsNullableVarBinaryNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsNullableVarBinaryNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsNullableVarBinaryNullHigh
 
GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsNullableVarBinaryNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsNullableVarBinaryNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsNullableVarBinaryNullLow
 
GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsVarBinaryNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsVarBinaryNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsVarBinaryNullHigh
 
GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsVarBinaryNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsVarBinaryNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsVarBinaryNullLow
 
GCompareVarBinaryVsVarBinary.GreaterThanEqVarBinaryVsVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarBinary.GreaterThanEqVarBinaryVsVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GreaterThanEqVarBinaryVsVarBinary
 
GCompareVarBinaryVsVarBinary.GreaterThanVarBinaryVsVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarBinary.GreaterThanVarBinaryVsVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GreaterThanVarBinaryVsVarBinary
 
GCompareVarBinaryVsVarBinary.LessThanEqVarBinaryVsVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarBinary.LessThanEqVarBinaryVsVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.LessThanEqVarBinaryVsVarBinary
 
GCompareVarBinaryVsVarBinary.LessThanVarBinaryVsVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarBinary.LessThanVarBinaryVsVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.LessThanVarBinaryVsVarBinary
 
GCompareVarBinaryVsVarBinary.NotEqualsVarBinaryVsVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarBinary.NotEqualsVarBinaryVsVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.NotEqualsVarBinaryVsVarBinary
 
GCompareVarBinaryVsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar
 
GCompareVarBinaryVsVarChar.EqualsVarBinaryVsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarChar.EqualsVarBinaryVsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.EqualsVarBinaryVsVarChar
 
GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsNullableVarCharNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsNullableVarCharNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsNullableVarCharNullHigh
 
GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsNullableVarCharNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsNullableVarCharNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsNullableVarCharNullLow
 
GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsVarCharNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsVarCharNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsVarCharNullHigh
 
GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsVarCharNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsVarCharNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsVarCharNullLow
 
GCompareVarBinaryVsVarChar.GCompareVarBinaryVsNullableVarCharNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarChar.GCompareVarBinaryVsNullableVarCharNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareVarBinaryVsNullableVarCharNullHigh
 
GCompareVarBinaryVsVarChar.GCompareVarBinaryVsNullableVarCharNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarChar.GCompareVarBinaryVsNullableVarCharNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareVarBinaryVsNullableVarCharNullLow
 
GCompareVarBinaryVsVarChar.GCompareVarBinaryVsVarCharNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarChar.GCompareVarBinaryVsVarCharNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareVarBinaryVsVarCharNullHigh
 
GCompareVarBinaryVsVarChar.GCompareVarBinaryVsVarCharNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarChar.GCompareVarBinaryVsVarCharNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareVarBinaryVsVarCharNullLow
 
GCompareVarBinaryVsVarChar.GreaterThanEqVarBinaryVsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarChar.GreaterThanEqVarBinaryVsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GreaterThanEqVarBinaryVsVarChar
 
GCompareVarBinaryVsVarChar.GreaterThanVarBinaryVsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarChar.GreaterThanVarBinaryVsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GreaterThanVarBinaryVsVarChar
 
GCompareVarBinaryVsVarChar.LessThanEqVarBinaryVsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarChar.LessThanEqVarBinaryVsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.LessThanEqVarBinaryVsVarChar
 
GCompareVarBinaryVsVarChar.LessThanVarBinaryVsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarChar.LessThanVarBinaryVsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.LessThanVarBinaryVsVarChar
 
GCompareVarBinaryVsVarChar.NotEqualsVarBinaryVsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarBinaryVsVarChar.NotEqualsVarBinaryVsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.NotEqualsVarBinaryVsVarChar
 
GCompareVarCharVsVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary
 
GCompareVarCharVsVarBinary.EqualsVarCharVsVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarBinary.EqualsVarCharVsVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.EqualsVarCharVsVarBinary
 
GCompareVarCharVsVarBinary.GCompareNullableVarCharVsNullableVarBinaryNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarBinary.GCompareNullableVarCharVsNullableVarBinaryNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareNullableVarCharVsNullableVarBinaryNullHigh
 
GCompareVarCharVsVarBinary.GCompareNullableVarCharVsNullableVarBinaryNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarBinary.GCompareNullableVarCharVsNullableVarBinaryNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareNullableVarCharVsNullableVarBinaryNullLow
 
GCompareVarCharVsVarBinary.GCompareNullableVarCharVsVarBinaryNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarBinary.GCompareNullableVarCharVsVarBinaryNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareNullableVarCharVsVarBinaryNullHigh
 
GCompareVarCharVsVarBinary.GCompareNullableVarCharVsVarBinaryNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarBinary.GCompareNullableVarCharVsVarBinaryNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareNullableVarCharVsVarBinaryNullLow
 
GCompareVarCharVsVarBinary.GCompareVarCharVsNullableVarBinaryNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarBinary.GCompareVarCharVsNullableVarBinaryNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareVarCharVsNullableVarBinaryNullHigh
 
GCompareVarCharVsVarBinary.GCompareVarCharVsNullableVarBinaryNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarBinary.GCompareVarCharVsNullableVarBinaryNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareVarCharVsNullableVarBinaryNullLow
 
GCompareVarCharVsVarBinary.GCompareVarCharVsVarBinaryNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarBinary.GCompareVarCharVsVarBinaryNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareVarCharVsVarBinaryNullHigh
 
GCompareVarCharVsVarBinary.GCompareVarCharVsVarBinaryNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarBinary.GCompareVarCharVsVarBinaryNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareVarCharVsVarBinaryNullLow
 
GCompareVarCharVsVarBinary.GreaterThanEqVarCharVsVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarBinary.GreaterThanEqVarCharVsVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GreaterThanEqVarCharVsVarBinary
 
GCompareVarCharVsVarBinary.GreaterThanVarCharVsVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarBinary.GreaterThanVarCharVsVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GreaterThanVarCharVsVarBinary
 
GCompareVarCharVsVarBinary.LessThanEqVarCharVsVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarBinary.LessThanEqVarCharVsVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.LessThanEqVarCharVsVarBinary
 
GCompareVarCharVsVarBinary.LessThanVarCharVsVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarBinary.LessThanVarCharVsVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.LessThanVarCharVsVarBinary
 
GCompareVarCharVsVarBinary.NotEqualsVarCharVsVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarBinary.NotEqualsVarCharVsVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.NotEqualsVarCharVsVarBinary
 
GCompareVarCharVsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar
 
GCompareVarCharVsVarChar.EqualsVarCharVsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarChar.EqualsVarCharVsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.EqualsVarCharVsVarChar
 
GCompareVarCharVsVarChar.GCompareNullableVarCharVsNullableVarCharNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarChar.GCompareNullableVarCharVsNullableVarCharNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareNullableVarCharVsNullableVarCharNullHigh
 
GCompareVarCharVsVarChar.GCompareNullableVarCharVsNullableVarCharNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarChar.GCompareNullableVarCharVsNullableVarCharNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareNullableVarCharVsNullableVarCharNullLow
 
GCompareVarCharVsVarChar.GCompareNullableVarCharVsVarCharNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarChar.GCompareNullableVarCharVsVarCharNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareNullableVarCharVsVarCharNullHigh
 
GCompareVarCharVsVarChar.GCompareNullableVarCharVsVarCharNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarChar.GCompareNullableVarCharVsVarCharNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareNullableVarCharVsVarCharNullLow
 
GCompareVarCharVsVarChar.GCompareVarCharVsNullableVarCharNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarChar.GCompareVarCharVsNullableVarCharNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareVarCharVsNullableVarCharNullHigh
 
GCompareVarCharVsVarChar.GCompareVarCharVsNullableVarCharNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarChar.GCompareVarCharVsNullableVarCharNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareVarCharVsNullableVarCharNullLow
 
GCompareVarCharVsVarChar.GCompareVarCharVsVarCharNullHigh - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarChar.GCompareVarCharVsVarCharNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareVarCharVsVarCharNullHigh
 
GCompareVarCharVsVarChar.GCompareVarCharVsVarCharNullLow - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarChar.GCompareVarCharVsVarCharNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareVarCharVsVarCharNullLow
 
GCompareVarCharVsVarChar.GreaterThanEqVarCharVsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarChar.GreaterThanEqVarCharVsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GreaterThanEqVarCharVsVarChar
 
GCompareVarCharVsVarChar.GreaterThanVarCharVsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarChar.GreaterThanVarCharVsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GreaterThanVarCharVsVarChar
 
GCompareVarCharVsVarChar.LessThanEqVarCharVsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarChar.LessThanEqVarCharVsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.LessThanEqVarCharVsVarChar
 
GCompareVarCharVsVarChar.LessThanVarCharVsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarChar.LessThanVarCharVsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.LessThanVarCharVsVarChar
 
GCompareVarCharVsVarChar.NotEqualsVarCharVsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GCompareVarCharVsVarChar.NotEqualsVarCharVsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.NotEqualsVarCharVsVarChar
 
GConvertToNullableBigIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableBigIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableBigIntHolder
 
GConvertToNullableBitHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableBitHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableBitHolder
 
GConvertToNullableDateHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableDateHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDateHolder
 
GConvertToNullableDecimal18Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableDecimal18Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal18Holder
 
GConvertToNullableDecimal28DenseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableDecimal28DenseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal28DenseHolder
 
GConvertToNullableDecimal28SparseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableDecimal28SparseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal28SparseHolder
 
GConvertToNullableDecimal38DenseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableDecimal38DenseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal38DenseHolder
 
GConvertToNullableDecimal38SparseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableDecimal38SparseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal38SparseHolder
 
GConvertToNullableDecimal9Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableDecimal9Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal9Holder
 
GConvertToNullableFloat4Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableFloat4Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableFloat4Holder
 
GConvertToNullableFloat8Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableFloat8Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableFloat8Holder
 
GConvertToNullableIntervalDayHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableIntervalDayHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableIntervalDayHolder
 
GConvertToNullableIntervalHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableIntervalHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableIntervalHolder
 
GConvertToNullableIntervalYearHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableIntervalYearHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableIntervalYearHolder
 
GConvertToNullableIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableIntHolder
 
GConvertToNullableSmallIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableSmallIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableSmallIntHolder
 
GConvertToNullableTimeHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableTimeHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableTimeHolder
 
GConvertToNullableTimeStampHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableTimeStampHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableTimeStampHolder
 
GConvertToNullableTinyIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableTinyIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableTinyIntHolder
 
GConvertToNullableUInt1Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableUInt1Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableUInt1Holder
 
GConvertToNullableUInt2Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableUInt2Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableUInt2Holder
 
GConvertToNullableUInt4Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableUInt4Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableUInt4Holder
 
GConvertToNullableUInt8Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableUInt8Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableUInt8Holder
 
GConvertToNullableVar16CharHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableVar16CharHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableVar16CharHolder
 
GConvertToNullableVarBinaryHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableVarBinaryHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableVarBinaryHolder
 
GConvertToNullableVarCharHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GConvertToNullableVarCharHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GConvertToNullableVarCharHolder
 
GDateArithmetic - Class in org.apache.drill.exec.expr.fn.impl
 
GDateArithmetic() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateArithmetic
 
GDateArithmetic.GDateDifference - Class in org.apache.drill.exec.expr.fn.impl
 
GDateArithmetic.GDateDifference() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateArithmetic.GDateDifference
 
GDateTimeTruncateFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions
 
GDateTimeTruncateFunctions.GDateCenturyDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GDateCenturyDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateCenturyDateTrunc
 
GDateTimeTruncateFunctions.GDateDayDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GDateDayDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateDayDateTrunc
 
GDateTimeTruncateFunctions.GDateDecadeDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GDateDecadeDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateDecadeDateTrunc
 
GDateTimeTruncateFunctions.GDateDummyDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
This class merely act as a placeholder so that Calcite allows 'trunc('truncationUnit', col)' function in SQL.
GDateTimeTruncateFunctions.GDateDummyDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateDummyDateTrunc
 
GDateTimeTruncateFunctions.GDateHourDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GDateHourDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateHourDateTrunc
 
GDateTimeTruncateFunctions.GDateMillenniumDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GDateMillenniumDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateMillenniumDateTrunc
 
GDateTimeTruncateFunctions.GDateMinuteDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GDateMinuteDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateMinuteDateTrunc
 
GDateTimeTruncateFunctions.GDateMonthDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GDateMonthDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateMonthDateTrunc
 
GDateTimeTruncateFunctions.GDateQuarterDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GDateQuarterDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateQuarterDateTrunc
 
GDateTimeTruncateFunctions.GDateSecondDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GDateSecondDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateSecondDateTrunc
 
GDateTimeTruncateFunctions.GDateWeekDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GDateWeekDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateWeekDateTrunc
 
GDateTimeTruncateFunctions.GDateYearDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GDateYearDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateYearDateTrunc
 
GDateTimeTruncateFunctions.GIntervalCenturyDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalCenturyDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalCenturyDateTrunc
 
GDateTimeTruncateFunctions.GIntervalDayCenturyDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalDayCenturyDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayCenturyDateTrunc
 
GDateTimeTruncateFunctions.GIntervalDayDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalDayDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayDateTrunc
 
GDateTimeTruncateFunctions.GIntervalDayDayDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalDayDayDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayDayDateTrunc
 
GDateTimeTruncateFunctions.GIntervalDayDecadeDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalDayDecadeDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayDecadeDateTrunc
 
GDateTimeTruncateFunctions.GIntervalDayDummyDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
This class merely act as a placeholder so that Calcite allows 'trunc('truncationUnit', col)' function in SQL.
GDateTimeTruncateFunctions.GIntervalDayDummyDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayDummyDateTrunc
 
GDateTimeTruncateFunctions.GIntervalDayHourDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalDayHourDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayHourDateTrunc
 
GDateTimeTruncateFunctions.GIntervalDayMillenniumDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalDayMillenniumDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayMillenniumDateTrunc
 
GDateTimeTruncateFunctions.GIntervalDayMinuteDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalDayMinuteDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayMinuteDateTrunc
 
GDateTimeTruncateFunctions.GIntervalDayMonthDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalDayMonthDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayMonthDateTrunc
 
GDateTimeTruncateFunctions.GIntervalDayQuarterDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalDayQuarterDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayQuarterDateTrunc
 
GDateTimeTruncateFunctions.GIntervalDaySecondDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalDaySecondDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDaySecondDateTrunc
 
GDateTimeTruncateFunctions.GIntervalDayYearDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalDayYearDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayYearDateTrunc
 
GDateTimeTruncateFunctions.GIntervalDecadeDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalDecadeDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDecadeDateTrunc
 
GDateTimeTruncateFunctions.GIntervalDummyDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
This class merely act as a placeholder so that Calcite allows 'trunc('truncationUnit', col)' function in SQL.
GDateTimeTruncateFunctions.GIntervalDummyDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDummyDateTrunc
 
GDateTimeTruncateFunctions.GIntervalHourDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalHourDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalHourDateTrunc
 
GDateTimeTruncateFunctions.GIntervalMillenniumDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalMillenniumDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalMillenniumDateTrunc
 
GDateTimeTruncateFunctions.GIntervalMinuteDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalMinuteDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalMinuteDateTrunc
 
GDateTimeTruncateFunctions.GIntervalMonthDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalMonthDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalMonthDateTrunc
 
GDateTimeTruncateFunctions.GIntervalQuarterDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalQuarterDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalQuarterDateTrunc
 
GDateTimeTruncateFunctions.GIntervalSecondDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalSecondDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalSecondDateTrunc
 
GDateTimeTruncateFunctions.GIntervalYearCenturyDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalYearCenturyDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearCenturyDateTrunc
 
GDateTimeTruncateFunctions.GIntervalYearDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalYearDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearDateTrunc
 
GDateTimeTruncateFunctions.GIntervalYearDayDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalYearDayDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearDayDateTrunc
 
GDateTimeTruncateFunctions.GIntervalYearDecadeDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalYearDecadeDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearDecadeDateTrunc
 
GDateTimeTruncateFunctions.GIntervalYearDummyDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
This class merely act as a placeholder so that Calcite allows 'trunc('truncationUnit', col)' function in SQL.
GDateTimeTruncateFunctions.GIntervalYearDummyDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearDummyDateTrunc
 
GDateTimeTruncateFunctions.GIntervalYearHourDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalYearHourDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearHourDateTrunc
 
GDateTimeTruncateFunctions.GIntervalYearMillenniumDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalYearMillenniumDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearMillenniumDateTrunc
 
GDateTimeTruncateFunctions.GIntervalYearMinuteDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalYearMinuteDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearMinuteDateTrunc
 
GDateTimeTruncateFunctions.GIntervalYearMonthDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalYearMonthDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearMonthDateTrunc
 
GDateTimeTruncateFunctions.GIntervalYearQuarterDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalYearQuarterDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearQuarterDateTrunc
 
GDateTimeTruncateFunctions.GIntervalYearSecondDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalYearSecondDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearSecondDateTrunc
 
GDateTimeTruncateFunctions.GIntervalYearYearDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GIntervalYearYearDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearYearDateTrunc
 
GDateTimeTruncateFunctions.GTimeCenturyDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeCenturyDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeCenturyDateTrunc
 
GDateTimeTruncateFunctions.GTimeDayDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeDayDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeDayDateTrunc
 
GDateTimeTruncateFunctions.GTimeDecadeDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeDecadeDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeDecadeDateTrunc
 
GDateTimeTruncateFunctions.GTimeDummyDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
This class merely act as a placeholder so that Calcite allows 'trunc('truncationUnit', col)' function in SQL.
GDateTimeTruncateFunctions.GTimeDummyDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeDummyDateTrunc
 
GDateTimeTruncateFunctions.GTimeHourDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeHourDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeHourDateTrunc
 
GDateTimeTruncateFunctions.GTimeMillenniumDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeMillenniumDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeMillenniumDateTrunc
 
GDateTimeTruncateFunctions.GTimeMinuteDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeMinuteDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeMinuteDateTrunc
 
GDateTimeTruncateFunctions.GTimeMonthDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeMonthDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeMonthDateTrunc
 
GDateTimeTruncateFunctions.GTimeQuarterDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeQuarterDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeQuarterDateTrunc
 
GDateTimeTruncateFunctions.GTimeSecondDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeSecondDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeSecondDateTrunc
 
GDateTimeTruncateFunctions.GTimeStampCenturyDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeStampCenturyDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampCenturyDateTrunc
 
GDateTimeTruncateFunctions.GTimeStampDayDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeStampDayDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampDayDateTrunc
 
GDateTimeTruncateFunctions.GTimeStampDecadeDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeStampDecadeDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampDecadeDateTrunc
 
GDateTimeTruncateFunctions.GTimeStampDummyDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
This class merely act as a placeholder so that Calcite allows 'trunc('truncationUnit', col)' function in SQL.
GDateTimeTruncateFunctions.GTimeStampDummyDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampDummyDateTrunc
 
GDateTimeTruncateFunctions.GTimeStampHourDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeStampHourDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampHourDateTrunc
 
GDateTimeTruncateFunctions.GTimeStampMillenniumDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeStampMillenniumDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampMillenniumDateTrunc
 
GDateTimeTruncateFunctions.GTimeStampMinuteDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeStampMinuteDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampMinuteDateTrunc
 
GDateTimeTruncateFunctions.GTimeStampMonthDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeStampMonthDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampMonthDateTrunc
 
GDateTimeTruncateFunctions.GTimeStampQuarterDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeStampQuarterDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampQuarterDateTrunc
 
GDateTimeTruncateFunctions.GTimeStampSecondDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeStampSecondDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampSecondDateTrunc
 
GDateTimeTruncateFunctions.GTimeStampWeekDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeStampWeekDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampWeekDateTrunc
 
GDateTimeTruncateFunctions.GTimeStampYearDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeStampYearDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampYearDateTrunc
 
GDateTimeTruncateFunctions.GTimeYearDateTrunc - Class in org.apache.drill.exec.expr.fn.impl
 
GDateTimeTruncateFunctions.GTimeYearDateTrunc() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeYearDateTrunc
 
GDateToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GDateToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDateToChar
 
GDecimal18ToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GDecimal18ToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDecimal18ToChar
 
GDecimal18ToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GDecimal18ToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDecimal18ToTimeStamp
 
GDecimal28DenseToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GDecimal28DenseToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDecimal28DenseToChar
 
GDecimal28DenseToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GDecimal28DenseToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDecimal28DenseToTimeStamp
 
GDecimal28SparseToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GDecimal28SparseToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDecimal28SparseToChar
 
GDecimal28SparseToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GDecimal28SparseToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDecimal28SparseToTimeStamp
 
GDecimal38DenseToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GDecimal38DenseToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDecimal38DenseToChar
 
GDecimal38DenseToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GDecimal38DenseToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDecimal38DenseToTimeStamp
 
GDecimal38SparseToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GDecimal38SparseToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDecimal38SparseToChar
 
GDecimal38SparseToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GDecimal38SparseToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDecimal38SparseToTimeStamp
 
GDecimal9ToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GDecimal9ToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDecimal9ToChar
 
GDecimal9ToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GDecimal9ToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GDecimal9ToTimeStamp
 
GE - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
 
GE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
gen - Variable in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
gen - Variable in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
GENERAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
generate() - Method in class org.apache.drill.exec.expr.CodeGenerator
 
generate(JFormatter) - Method in class org.apache.drill.exec.expr.DirectExpression
 
generate() - Method in interface org.apache.drill.exec.physical.impl.TopN.PriorityQueue
This method must be called before fetching the final priority queue hyper batch and final Sv4 vector.
generate() - Method in class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
 
generateAndCompile(CodeGenerator<?>) - Method in class org.apache.drill.exec.compile.CodeCompiler.CodeGenCompiler
Generate code for the code generator, then compile it.
generateAndGet() - Method in class org.apache.drill.exec.expr.CodeGenerator
 
generateBody(ClassGenerator<?>, ClassGenerator.BlockType, String, ClassGenerator.HoldingContainer[], JVar[], boolean) - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
generateComparisons(ClassGenerator<?>, VectorAccessible, Logger) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BaseSortWrapper
 
generateCopies(ClassGenerator<?>, VectorAccessible, boolean) - Static method in class org.apache.drill.exec.vector.CopyUtil
 
generated - Variable in class org.apache.drill.exec.compile.ClassTransformer.ClassSet
 
GENERATED - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
generateEvalBody(ClassGenerator<?>, ClassGenerator.HoldingContainer[], String, JVar[], FieldReference) - Method in class org.apache.drill.exec.expr.fn.DrillComplexWriterFuncHolder
 
generateEvalBody(ClassGenerator<?>, ClassGenerator.HoldingContainer[], String, JVar[], FieldReference) - Method in class org.apache.drill.exec.expr.fn.DrillSimpleFuncHolder
 
generateFileWork(List<FileStatus>, boolean) - Method in class org.apache.drill.exec.store.schedule.BlockMapBuilder
 
generateParseException() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
generateSV2Filterer() - Method in class org.apache.drill.exec.physical.impl.filter.FilterRecordBatch
 
generateSV4Filterer() - Method in class org.apache.drill.exec.physical.impl.filter.FilterRecordBatch
 
generateTypeString(StringBuilder, boolean) - Method in class org.apache.drill.exec.planner.types.DrillFixedRelDataTypeImpl
 
generateTypeString(StringBuilder, boolean) - Method in class org.apache.drill.exec.planner.types.RelDataTypeDrillImpl
 
generateWorkUnit(OptionList, CoordinationProtos.DrillbitEndpoint, UserBitShared.QueryId, Fragment, PlanningSet, UserSession, BitControl.QueryContextInformation) - Method in class org.apache.drill.exec.planner.fragment.SimpleParallelizer
 
generator - Variable in class org.apache.drill.exec.store.mock.ColumnDef
 
generator - Variable in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
The scan can request to use a specific data generator class.
GeneratorMapping - Class in org.apache.drill.exec.compile.sig
The code generator works with four conceptual methods which can have any actual names.
GeneratorMapping(String, String, String, String) - Constructor for class org.apache.drill.exec.compile.sig.GeneratorMapping
 
GeneratorMapping(GeneratorMapping) - Constructor for class org.apache.drill.exec.compile.sig.GeneratorMapping
 
GenericAccessor - Class in org.apache.drill.exec.vector.accessor
 
GenericAccessor(ValueVector) - Constructor for class org.apache.drill.exec.vector.accessor.GenericAccessor
 
GenericExceptionMapper - Class in org.apache.drill.exec.server.rest
 
GenericExceptionMapper() - Constructor for class org.apache.drill.exec.server.rest.GenericExceptionMapper
 
GenericExceptionMapper.GenericErrorMessage - Class in org.apache.drill.exec.server.rest
 
GenericExceptionMapper.GenericErrorMessage(String) - Constructor for class org.apache.drill.exec.server.rest.GenericExceptionMapper.GenericErrorMessage
 
get() - Method in class org.apache.drill.exec.cache.CachedVectorContainer
 
get() - Method in interface org.apache.drill.exec.cache.Counter
 
get(K) - Method in interface org.apache.drill.exec.cache.DistributedMap
 
get(K) - Method in interface org.apache.drill.exec.cache.DistributedMultiMap
 
get() - Method in class org.apache.drill.exec.cache.VectorAccessibleSerializable
 
get(int) - Method in class org.apache.drill.exec.compile.sig.SignatureHolder
 
get(String) - Method in class org.apache.drill.exec.compile.sig.SignatureHolder
 
get(String) - Method in class org.apache.drill.exec.coord.local.MapBackedStore
 
get(String) - Method in interface org.apache.drill.exec.coord.store.TransientStore
Returns a value corresponding to the given look-up key if exists, null otherwise.
get(String) - Method in class org.apache.drill.exec.coord.zk.ZkEphemeralStore
 
get(String) - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
Returns a value corresponding to the given path if path exists in the cache, null otherwise.
get(String, boolean) - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
Returns the value corresponding to the given key, null otherwise.
get(String, DataChangeVersion) - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
Returns the value corresponding to the given key, null otherwise.
get(String, boolean, DataChangeVersion) - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
Returns the value corresponding to the given key, null otherwise.
get(String) - Static method in enum org.apache.drill.exec.expr.BooleanType
Finds boolean by passed literal.
get(TemplateClassDefinition<T>) - Static method in class org.apache.drill.exec.expr.CodeGenerator
 
get(TemplateClassDefinition<T>, OptionSet) - Static method in class org.apache.drill.exec.expr.CodeGenerator
 
get(MappingSet, TemplateClassDefinition<T>, OptionSet) - Static method in class org.apache.drill.exec.expr.CodeGenerator
 
get() - Method in class org.apache.drill.exec.planner.fragment.ParallelizationInfo.ParallelizationInfoCollector
Get a ParallelizationInfo instance based on the current state of collected info.
get(Fragment) - Method in class org.apache.drill.exec.planner.fragment.PlanningSet
 
get(SqlCall) - Method in class org.apache.drill.exec.planner.sql.DrillConvertletTable
 
get(Object) - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
GET - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
get(TypeProtos.MajorType) - Static method in class org.apache.drill.exec.record.MajorTypeSerDe.MajorTypeHolder
 
get(int) - Method in class org.apache.drill.exec.record.selection.SelectionVector4
 
get(RecordBatch) - Static method in class org.apache.drill.exec.record.WritableBatch
 
get() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.CustomFuture
 
get(long, TimeUnit) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.CustomFuture
 
get() - Method in class org.apache.drill.exec.server.rest.DrillRestServer.UserAuthEnabled
 
get(CoordinationProtos.DrillbitEndpoint) - Method in interface org.apache.drill.exec.store.schedule.EndpointByteMap
 
get(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.store.schedule.EndpointByteMapImpl
 
get(String, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.BasePersistentStore
By default get with version will behave the same way as without version.
get(String) - Method in interface org.apache.drill.exec.store.sys.PersistentStore
Returns the value for the given key if exists, null otherwise.
get(String, DataChangeVersion) - Method in interface org.apache.drill.exec.store.sys.PersistentStore
Returns the value for the given key if exists, null otherwise.
get(String) - Method in class org.apache.drill.exec.store.sys.store.InMemoryStore
 
get(String, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.store.InMemoryStore
 
get(String) - Method in class org.apache.drill.exec.store.sys.store.LocalPersistentStore
 
get(String, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.store.LocalPersistentStore
 
get(String) - Method in class org.apache.drill.exec.store.sys.store.ZookeeperPersistentStore
 
get(String, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.store.ZookeeperPersistentStore
 
get(String, boolean, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.store.ZookeeperPersistentStore
 
get(String) - Method in class org.apache.drill.exec.testing.store.NoWriteLocalStore
 
get(String, DataChangeVersion) - Method in class org.apache.drill.exec.testing.store.NoWriteLocalStore
 
get(int) - Method in class org.apache.drill.exec.util.ArrayWrappedIntIntMap
Returns the value pointed by the given index.
getAccessibleScopes() - Method in class org.apache.drill.exec.server.options.OptionMetaData
 
getAccessibleScopes() - Method in class org.apache.drill.exec.server.rest.StatusResources.OptionWrapper
 
getAclStatus(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getActiveEndpoints() - Method in class org.apache.drill.exec.ops.QueryContext
 
getAddress() - Method in class org.apache.drill.exec.server.rest.DrillRoot.DrillbitInfo
 
getAdminUserGroups(OptionManager) - Method in class org.apache.drill.exec.server.options.TypeValidators.AdminUserGroupsValidator
 
getAdminUserGroups() - Method in class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
 
getAdminUsers(OptionManager) - Method in class org.apache.drill.exec.server.options.TypeValidators.AdminUsersValidator
 
getAdminUsers() - Method in class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
 
getAffinity() - Method in class org.apache.drill.exec.physical.EndpointAffinity
Get the affinity value.
getAffinityFactor() - Method in interface org.apache.drill.exec.planner.fragment.ParallelizationParameters
 
getAffinityFactor() - Method in class org.apache.drill.exec.planner.fragment.SimpleParallelizer
 
getAffinityMap(List<T>) - Static method in class org.apache.drill.exec.store.schedule.AffinityCreator
 
getAggExprs() - Method in class org.apache.drill.exec.planner.physical.AggPrelBase
 
getAggPhase() - Method in class org.apache.drill.exec.physical.config.HashAggregate
 
getAggregateFieldName(FunctionCall) - Static method in class org.apache.drill.exec.planner.logical.ExprHelper
 
getAggregations() - Method in class org.apache.drill.exec.physical.config.WindowPOP
 
getAggrExprs() - Method in class org.apache.drill.exec.physical.config.HashAggregate
 
getAll() - Method in class org.apache.drill.exec.store.sys.BasePersistentStore
 
getAll() - Method in interface org.apache.drill.exec.store.sys.PersistentStore
Returns an iterator of entries.
getAllFactoryNames() - Method in interface org.apache.drill.exec.rpc.security.AuthenticatorProvider
 
getAllFactoryNames() - Method in class org.apache.drill.exec.rpc.security.AuthenticatorProviderImpl
 
getAllFactoryNames() - Method in class org.apache.drill.exec.rpc.security.ClientAuthenticatorProvider
 
getAllFunctionsWithHolders(AtomicLong) - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
Returns list of functions with list of function holders for each functions.
getAllFunctionsWithHolders() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
Returns list of functions with list of function holders for each functions without version number.
getAllFunctionsWithSignatures() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
Returns list of functions with list of function signatures for each functions.
getAllJarNames() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
Retrieves list of all jars name present in FunctionRegistryHolder.jars This is read operation, so several users can get this data.
getAllJarNames() - Method in class org.apache.drill.exec.expr.fn.registry.LocalFunctionRegistry
Returns list of jar names registered in function registry.
getAllocator() - Method in class org.apache.drill.exec.client.DrillClient
 
getAllocator() - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
getAllocator() - Method in class org.apache.drill.exec.ops.FragmentContext
Deprecated.
getAllocator() - Method in interface org.apache.drill.exec.ops.OperatorContext
Return the memory allocator for this operator.
getAllocator() - Method in interface org.apache.drill.exec.ops.OptimizerRulesContext
Method returns the allocator
getAllocator() - Method in class org.apache.drill.exec.ops.QueryContext
 
getAllocator() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierWrapper
 
getAllocator() - Method in class org.apache.drill.exec.record.VectorContainer
 
getAllocator() - Method in class org.apache.drill.exec.rpc.AbstractConnectionConfig
 
getAllocator() - Method in class org.apache.drill.exec.rpc.AbstractServerConnection
 
getAllocator() - Method in interface org.apache.drill.exec.rpc.ConnectionConfig
 
getAllocator() - Method in class org.apache.drill.exec.rpc.data.DataClientConnection
 
getAllocator() - Method in class org.apache.drill.exec.rpc.user.UserClient.UserToBitConnection
 
getAllocator() - Method in class org.apache.drill.exec.server.BootStrapContext
 
getAllocator() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getAllocator() - Method in class org.apache.drill.exec.server.rest.WebSessionResources
 
getAllowedSignatures(String) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
getAllowedSignatures(String) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
getAllowedSignatures(String) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
getAsCompoundIdentifier() - Method in class org.apache.drill.exec.planner.sql.parser.DrillCompoundIdentifier
 
getAsFiles() - Method in class org.apache.drill.exec.store.dfs.FormatSelection
 
getAsFileWork() - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork
 
getAssignedEndpoint(int) - Method in class org.apache.drill.exec.planner.fragment.Wrapper
 
getAssignedEndpoints() - Method in class org.apache.drill.exec.planner.fragment.Wrapper
 
getAssignedSchema() - Method in class org.apache.drill.exec.schema.Field
 
getAsSingleInt() - Method in class org.apache.drill.exec.planner.physical.explain.PrelSequencer.OpId
 
getAsSqlNode() - Method in class org.apache.drill.exec.planner.sql.parser.DrillCompoundIdentifier
 
getAuthenticator() - Method in class org.apache.drill.exec.rpc.security.plain.PlainFactory
 
getAuthenticatorFactory(String) - Method in interface org.apache.drill.exec.rpc.security.AuthenticatorProvider
 
getAuthenticatorFactory(String) - Method in class org.apache.drill.exec.rpc.security.AuthenticatorProviderImpl
 
getAuthenticatorFactory(String) - Method in class org.apache.drill.exec.rpc.security.ClientAuthenticatorProvider
 
getAuthFactory(List<String>) - Method in class org.apache.drill.exec.rpc.BitConnectionConfig
 
getAuthMechanismToUse() - Method in class org.apache.drill.exec.rpc.BitConnectionConfig
 
getAuthProvider() - Method in class org.apache.drill.exec.rpc.AbstractConnectionConfig
 
getAuthProvider() - Method in interface org.apache.drill.exec.rpc.ConnectionConfig
 
getAuthProvider() - Method in class org.apache.drill.exec.server.BootStrapContext
 
getAuthProvider() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getAvailableBits() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getAvailableEndpoints() - Method in class org.apache.drill.exec.coord.ClusterCoordinator
Get a collection of available Drillbit endpoints, Thread-safe.
getAvailableEndpoints() - Method in class org.apache.drill.exec.coord.local.LocalClusterCoordinator
 
getAvailableEndpoints() - Method in class org.apache.drill.exec.coord.zk.ZKClusterCoordinator
 
getBaseName() - Method in class org.apache.drill.exec.dotdrill.DotDrillFile
Return base file name without the parent directory and extensions.
getBaseTableLocation() - Method in class org.apache.drill.exec.planner.FileSystemPartitionDescriptor
 
getBaseTableLocation() - Method in class org.apache.drill.exec.planner.ParquetPartitionDescriptor
 
getBaseTableLocation() - Method in interface org.apache.drill.exec.planner.PartitionDescriptor
 
getBatch(FragmentContext, HashAggregate, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggBatchCreator
 
getBatch(FragmentContext, StreamingAggregate, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggBatchCreator
 
getBatch(FragmentContext, T, List<RecordBatch>) - Method in interface org.apache.drill.exec.physical.impl.BatchCreator
 
getBatch(FragmentContext, Filter, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.filter.FilterBatchCreator
 
getBatch(FragmentContext, FlattenPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenBatchCreator
 
getBatch(FragmentContext, HashJoinPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatchCreator
 
getBatch(FragmentContext, MergeJoinPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.join.MergeJoinCreator
 
getBatch(FragmentContext, NestedLoopJoinPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatchCreator
 
getBatch(FragmentContext, Limit, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.limit.LimitBatchCreator
 
getBatch(FragmentContext, MergingReceiverPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.MergingReceiverCreator
 
getBatch(FragmentContext, ProducerConsumer, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.producer.ProducerConsumerBatchCreator
 
getBatch(FragmentContext, ComplexToJson, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.project.ComplexToJsonBatchCreator
 
getBatch(FragmentContext, Project, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.project.ProjectBatchCreator
 
getBatch(FragmentContext, Sort, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.sort.SortBatchCreator
 
getBatch(FragmentContext, SelectionVectorRemover, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.svremover.SVRemoverCreator
 
getBatch(FragmentContext, TopN, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.TopN.TopNSortBatchCreator
 
getBatch(FragmentContext, Trace, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.trace.TraceBatchCreator
 
getBatch(FragmentContext, UnionAll, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.union.UnionAllBatchCreator
 
getBatch(FragmentContext, UnorderedReceiver, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverCreator
 
getBatch(FragmentContext, IteratorValidator, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorCreator
 
getBatch(FragmentContext, Values, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.values.ValuesBatchCreator
 
getBatch(FragmentContext, WindowPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.window.WindowFrameBatchCreator
 
getBatch(FragmentContext, ExternalSort, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatchCreator
 
getBatch(FragmentContext, EasySubScan, List<RecordBatch>) - Method in class org.apache.drill.exec.store.dfs.easy.EasyReaderBatchCreator
 
getBatch(FragmentContext, EasyWriter, List<RecordBatch>) - Method in class org.apache.drill.exec.store.dfs.easy.EasyWriterBatchCreator
 
getBatch(FragmentContext, DirectSubScan, List<RecordBatch>) - Method in class org.apache.drill.exec.store.direct.DirectBatchCreator
 
getBatch(FragmentContext, InfoSchemaSubScan, List<RecordBatch>) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaBatchCreator
 
getBatch(FragmentContext, MockSubScanPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.store.mock.MockScanBatchCreator
 
getBatch(FragmentContext, ParquetRowGroupScan, List<RecordBatch>) - Method in class org.apache.drill.exec.store.parquet.ParquetScanBatchCreator
 
getBatch(FragmentContext, ParquetWriter, List<RecordBatch>) - Method in class org.apache.drill.exec.store.parquet.ParquetWriterBatchCreator
 
getBatch(FragmentContext, SystemTableScan, List<RecordBatch>) - Method in class org.apache.drill.exec.store.sys.SystemTableBatchCreator
 
getBatchCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MergeSortWrapper
 
getBatchCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierWrapper.BatchMerger
 
getBatchCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.EmptyResults
 
getBatchCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SingleBatchResults
 
getBatchCount() - Method in interface org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SortResults
 
getBatchIndex() - Method in class org.apache.drill.exec.expr.BatchReference
 
getBatchIndex(int) - Static method in class org.apache.drill.exec.record.selection.SelectionVector4
 
getBatchName() - Method in class org.apache.drill.exec.expr.BatchReference
 
getBatchNoHV(int, Iterable<ValueVector>, boolean) - Static method in class org.apache.drill.exec.record.WritableBatch
 
getBatchNoHVWrap(int, Iterable<VectorWrapper<?>>, boolean) - Static method in class org.apache.drill.exec.record.WritableBatch
 
getBatchRef() - Method in class org.apache.drill.exec.expr.ValueVectorReadExpression
 
getBatchSize() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.SpilledRun
 
getBatchSize() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockScanEntry
 
getBatchSize() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
getBee() - Method in class org.apache.drill.exec.work.WorkManager
 
getBeginColumn() - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
getBeginLine() - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
getBestMatch(List<DrillFuncHolder>, FunctionCall) - Method in class org.apache.drill.exec.resolver.DefaultFunctionResolver
 
getBestMatch(List<DrillFuncHolder>, FunctionCall) - Method in class org.apache.drill.exec.resolver.ExactFunctionResolver
 
getBestMatch(List<DrillFuncHolder>, FunctionCall) - Method in interface org.apache.drill.exec.resolver.FunctionResolver
Creates a placeholder SqlFunction for an invocation of a function with a possibly qualified name.
getBestMatch(List<String>, String) - Static method in class org.apache.drill.exec.util.ApproximateStringMatcher
 
getBigDecimal(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getBigDecimal(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getBigDecimal(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal18Accessor
 
getBigDecimal(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal28DenseAccessor
 
getBigDecimal(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal28SparseAccessor
 
getBigDecimal(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal38DenseAccessor
 
getBigDecimal(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal38SparseAccessor
 
getBigDecimal(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal9Accessor
 
getBigDecimal(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal18Accessor
 
getBigDecimal(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal28DenseAccessor
 
getBigDecimal(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal28SparseAccessor
 
getBigDecimal(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal38DenseAccessor
 
getBigDecimal(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal38SparseAccessor
 
getBigDecimal(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal9Accessor
 
getBigDecimal(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getBigDecimal(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
getBitClientLoopGroup() - Method in class org.apache.drill.exec.server.BootStrapContext
 
getBitLoopGroup() - Method in class org.apache.drill.exec.server.BootStrapContext
 
getBitLoopGroup() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getBits() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getBitWidthAllFixedFields() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
getBitWidthAllFixedFields() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetSchema
 
getBlock(String) - Method in class org.apache.drill.exec.expr.ClassGenerator
 
getBlock(ClassGenerator.BlockType) - Method in class org.apache.drill.exec.expr.ClassGenerator
 
getBlock() - Method in class org.apache.drill.exec.expr.SizedJBlock
 
getBlockSize(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
Deprecated.
getBodies() - Method in interface org.apache.drill.exec.rpc.control.Controller.CustomResponse
The optional unstructured portion of the message.
getBody() - Method in class org.apache.drill.exec.record.RawFragmentBatch
 
getBoolean(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getBoolean(String) - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
getBoolean(String) - Method in interface org.apache.drill.exec.server.options.OptionSet
Return the value of a Boolean option.
getBoolean(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getBoolean(int) - Method in class org.apache.drill.exec.vector.accessor.BitAccessor
 
getBoolean(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getBoolean(int) - Method in class org.apache.drill.exec.vector.accessor.NullableBitAccessor
 
getBoolean(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getBoolean(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
getBoolVal() - Method in class org.apache.drill.exec.server.options.PersistedOptionValue
This is present for forward compatibility.
getBootstrapContext() - Method in class org.apache.drill.exec.rpc.AbstractConnectionConfig
 
getBootstrapContext() - Method in interface org.apache.drill.exec.rpc.ConnectionConfig
 
getBroadcastFactor() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getBroadcastThreshold() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getBuffer() - Method in class org.apache.drill.exec.record.selection.SelectionVector2
 
getBuffer(boolean) - Method in class org.apache.drill.exec.record.selection.SelectionVector2
 
getBuffer() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.CustomFuture
 
getBuffer(int) - Method in class org.apache.drill.exec.work.batch.AbstractDataCollector
 
getBuffer(int) - Method in class org.apache.drill.exec.work.batch.MergingCollector
 
getBuffer(int) - Method in class org.apache.drill.exec.work.batch.PartitionedCollector
 
getBufferedBatchLimit() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
 
getBufferManager() - Method in class org.apache.drill.exec.ops.BaseFragmentContext
 
getBufferManager() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getBufferMemoryLimit() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
getBuffers() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getBuffers() - Method in class org.apache.drill.exec.physical.impl.materialize.QueryWritableBatch
 
getBuffers() - Method in class org.apache.drill.exec.record.FragmentWritableBatch
 
getBuffers() - Method in class org.apache.drill.exec.record.WritableBatch
 
getBuffers() - Method in class org.apache.drill.exec.work.batch.AbstractDataCollector
 
getBuffers(int) - Method in class org.apache.drill.exec.work.batch.IncomingBuffers
 
getBufferSizeFor(int) - Method in interface org.apache.drill.exec.physical.impl.flatten.Flattener.Monitor
Get the required buffer size for the specified number of records.
getBuildNumber() - Static method in class org.apache.drill.common.util.DrillVersionInfo
Get the Drill build number from pom
getByte(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getByte(byte[], int) - Static method in class org.apache.drill.exec.store.pcap.PcapFormatUtils
 
getByte(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getByte(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getByte(int) - Method in class org.apache.drill.exec.vector.accessor.NullableTinyIntAccessor
 
getByte(int) - Method in class org.apache.drill.exec.vector.accessor.NullableUInt1Accessor
 
getByte(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getByte(int) - Method in class org.apache.drill.exec.vector.accessor.TinyIntAccessor
 
getByte(int) - Method in class org.apache.drill.exec.vector.accessor.UInt1Accessor
 
getByte(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
getByteCode(ClassTransformer.ClassNames, String) - Method in class org.apache.drill.exec.compile.AbstractClassCompiler
 
getByteCount() - Method in class org.apache.drill.exec.physical.impl.materialize.QueryWritableBatch
 
getByteCount() - Method in class org.apache.drill.exec.record.FragmentWritableBatch
 
getByteCount() - Method in class org.apache.drill.exec.record.RawFragmentBatch
 
getByteMap() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan.RowGroupInfo
 
getByteMap() - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork
 
getByteMap() - Method in interface org.apache.drill.exec.store.schedule.CompleteWork
 
getBytes() - Method in class org.apache.drill.exec.expr.fn.impl.DrillByteArray
 
getBytes(int, ByteBuf) - Method in class org.apache.drill.exec.record.DeadBuf
 
getBytes(int, ByteBuf, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getBytes(int, ByteBuf, int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getBytes(int, byte[]) - Method in class org.apache.drill.exec.record.DeadBuf
 
getBytes(int, byte[], int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getBytes(int, ByteBuffer) - Method in class org.apache.drill.exec.record.DeadBuf
 
getBytes(int, OutputStream, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getBytes(int, GatheringByteChannel, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getBytes() - Method in class org.apache.drill.exec.store.dfs.MagicString
 
getBytes(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getBytes(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getBytes(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVar16CharAccessor
 
getBytes(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVarBinaryAccessor
 
getBytes(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVarCharAccessor
 
getBytes(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getBytes(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
getBytes(int) - Method in class org.apache.drill.exec.vector.accessor.Var16CharAccessor
 
getBytes(int) - Method in class org.apache.drill.exec.vector.accessor.VarBinaryAccessor
 
getBytes(int) - Method in class org.apache.drill.exec.vector.accessor.VarCharAccessor
 
getCache() - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
 
getCacheFileRoot() - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
getCalciteTypeFromDrillType(TypeProtos.MinorType) - Static method in class org.apache.drill.exec.planner.sql.TypeInferenceUtils
Given a Drill's TypeProtos.MinorType, return a Calcite's corresponding SqlTypeName
getCallBack() - Method in interface org.apache.drill.exec.physical.impl.OutputMutator
 
getCallBack() - Method in class org.apache.drill.exec.physical.impl.ScanBatch.Mutator
 
getCanonicalServiceName() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getCapacity() - Method in class org.apache.drill.exec.store.sys.PersistentStoreConfig
 
getCardinality() - Method in class org.apache.drill.exec.physical.config.HashAggregate
 
getCatalogs(UserProtos.LikeFilter) - Method in class org.apache.drill.exec.client.DrillClient
Get the list of catalogs in INFORMATION_SCHEMA.CATALOGS table satisfying the given filters.
getChannelClosureFuture() - Method in class org.apache.drill.exec.rpc.user.UserServer.BitToUserConnection
 
getChannelClosureFuture() - Method in interface org.apache.drill.exec.rpc.UserClientConnection
Returns the ChannelFuture which will be notified when this channel is closed.
getChannelClosureFuture() - Method in class org.apache.drill.exec.server.rest.WebUserConnection
 
getChar(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getChar(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getChar(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getChar(int) - Method in class org.apache.drill.exec.vector.accessor.NullableUInt2Accessor
 
getChar(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getChar(int) - Method in class org.apache.drill.exec.vector.accessor.UInt2Accessor
 
getChar(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
getChild(String, String) - Method in class org.apache.drill.exec.compile.ClassTransformer.ClassSet
 
getChild(String) - Method in class org.apache.drill.exec.compile.ClassTransformer.ClassSet
 
getChild() - Method in class org.apache.drill.exec.expr.ValueVectorWriteExpression
 
getChild() - Method in class org.apache.drill.exec.physical.base.AbstractSingle
 
getChild() - Method in interface org.apache.drill.exec.physical.base.Exchange
Return the feeding child of this operator node.
getChild() - Method in interface org.apache.drill.exec.physical.base.Store
Get the child of this store operator as this will be needed for parallelization materialization purposes.
getChild() - Method in class org.apache.drill.exec.physical.impl.filter.ReturnValueExpression
 
getChild(String) - Method in class org.apache.drill.exec.vector.complex.fn.FieldSelection
 
getChildCount(PhysicalOperator) - Static method in class org.apache.drill.exec.ops.OperatorUtilities
 
getChildFileSystems() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getChildHolders() - Method in class org.apache.drill.exec.compile.sig.SignatureHolder
 
getChildren() - Method in class org.apache.drill.exec.physical.base.AbstractMultiple
 
getChildren() - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions.OpState
 
getChildWrapper(int[]) - Method in class org.apache.drill.exec.record.HyperVectorWrapper
 
getChildWrapper(int[]) - Method in class org.apache.drill.exec.record.SimpleVectorWrapper
 
getChildWrapper(int[]) - Method in interface org.apache.drill.exec.record.VectorWrapper
 
getClassByteCode(ClassTransformer.ClassNames, String) - Method in class org.apache.drill.exec.compile.AbstractClassCompiler
 
getClassByteCode(ClassTransformer.ClassNames, String) - Method in class org.apache.drill.exec.compile.QueryClassLoader
 
getClassLoader() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
getClassLoader() - Method in class org.apache.drill.exec.expr.fn.FunctionInitializer
 
getClassLoader() - Method in class org.apache.drill.exec.expr.fn.registry.JarScan
 
getClassName() - Method in class org.apache.drill.exec.expr.CodeGenerator
 
getClassName() - Method in class org.apache.drill.exec.expr.fn.FunctionInitializer
 
getClasspathScan() - Method in class org.apache.drill.exec.server.BootStrapContext
 
getClasspathScan() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getCleanupBlock() - Method in class org.apache.drill.exec.expr.ClassGenerator
 
getClient() - Method in class org.apache.drill.exec.coord.zk.ZkEphemeralStore
 
getCloseFuture() - Method in class org.apache.drill.exec.server.rest.WebSessionResources
 
getCloseHandler(SocketChannel, ControlConnection) - Method in class org.apache.drill.exec.rpc.control.ControlClient
 
getCloseHandler(SocketChannel, ControlConnection) - Method in class org.apache.drill.exec.rpc.control.ControlServer
 
getCloseHandler(SocketChannel, DataClientConnection) - Method in class org.apache.drill.exec.rpc.data.DataClient
 
getCloseHandler(SocketChannel, DataServerConnection) - Method in class org.apache.drill.exec.rpc.data.DataServer
 
getCluster() - Method in class org.apache.drill.exec.planner.torel.ConversionContext
 
getClusterCoordinator() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getClusterInfo() - Method in class org.apache.drill.exec.server.rest.DrillRoot
 
getClusterInfoJSON() - Method in class org.apache.drill.exec.server.rest.DrillRoot
 
getCode() - Method in class org.apache.drill.exec.expr.SingleClassStringWriter
 
getCodecFactory() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
getCodeGenerator() - Method in class org.apache.drill.exec.expr.ClassGenerator
 
getCollation() - Method in class org.apache.drill.exec.planner.physical.HashToMergeExchangePrel
 
getCollectors(PhysicalOperator) - Static method in class org.apache.drill.exec.planner.fragment.SimpleParallelizer.CountRequiredFragments
 
getColNameToSchemaElementMapping(ParquetMetadata) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
 
getColumn() - Method in class org.apache.drill.exec.physical.config.FlattenPOP
 
getColumn() - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
Deprecated. 
getColumn() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDescribeTable
 
getColumn(int) - Method in class org.apache.drill.exec.record.BatchSchema
 
getColumnByIndex(int) - Method in class org.apache.drill.exec.store.pcap.schema.Schema
 
getColumnMetadata() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetSchema
 
getColumnName() - Method in class org.apache.drill.exec.store.pcap.dto.ColumnDto
 
getColumnQualifier() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDescribeTable
 
getColumnReaders() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
 
getColumns(UserProtos.LikeFilter, UserProtos.LikeFilter, UserProtos.LikeFilter, UserProtos.LikeFilter) - Method in class org.apache.drill.exec.client.DrillClient
Get the list of columns in INFORMATION_SCHEMA.COLUMNS table satisfying the given filters.
getColumns() - Method in class org.apache.drill.exec.planner.logical.DrillScanRel
 
getColumns(RelDataType, List<RexNode>) - Static method in class org.apache.drill.exec.planner.physical.PrelUtil
 
getColumns() - Method in class org.apache.drill.exec.server.rest.QueryResources.TabularResult
 
getColumns() - Method in class org.apache.drill.exec.store.AbstractRecordReader
 
getColumns() - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
getColumns() - Method in class org.apache.drill.exec.store.dfs.easy.EasySubScan
 
getColumns() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata
 
getColumns() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v1
 
getColumns() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v2
 
getColumns() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v3
 
getColumns() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
getColumns() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan.RowGroupInfo
 
getColumns() - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
 
getColumns() - Method in class org.apache.drill.exec.store.pcap.schema.Schema
Return list with all columns names and its types
getColumnType() - Method in class org.apache.drill.exec.store.pcap.dto.ColumnDto
 
getColumnTypeInfo(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
getColumnTypeInfo(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
getColumnValueCount(SchemaPath) - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
By default, throw exception, since group scan does not have exact column value count.
getColumnValueCount(SchemaPath) - Method in interface org.apache.drill.exec.physical.base.GroupScan
Return the number of non-null value in the specified column.
getColumnValueCount(SchemaPath) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
Return column value count for the specified column.
getComment() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
getComment() - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
getComparators() - Method in class org.apache.drill.exec.physical.impl.common.HashTableConfig
 
getCompiler() - Method in class org.apache.drill.exec.ops.BaseFragmentContext
 
getCompiler() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getCompiler() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getCompletedProfileStore() - Method in class org.apache.drill.exec.server.QueryProfileStoreContext
 
getCompletionFactor() - Method in class org.apache.drill.exec.physical.config.OrderedPartitionSender
 
getComplexExprs() - Method in class org.apache.drill.exec.planner.physical.visitor.RexVisitorComplexExprSplitter
 
getCompositePartitionPath() - Method in class org.apache.drill.exec.planner.DFSDirPartitionLocation
 
getCompositePartitionPath() - Method in interface org.apache.drill.exec.planner.PartitionLocation
Returns the path string of directory names only for composite partition
getCompositePartitionPath() - Method in class org.apache.drill.exec.planner.SimplePartitionLocation
 
getCondition() - Method in class org.apache.drill.exec.physical.config.NestedLoopJoinPOP
 
getConditions() - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
 
getConditions() - Method in class org.apache.drill.exec.physical.config.MergeJoinPOP
 
getConf() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getConfig() - Method in class org.apache.drill.exec.client.DrillClient
 
getConfig() - Method in class org.apache.drill.exec.coord.store.BaseTransientStore
 
getConfig() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getConfig() - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
Returns the Drill configuration for this run.
getConfig() - Method in class org.apache.drill.exec.ops.QueryContext
 
getConfig() - Method in class org.apache.drill.exec.server.BootStrapContext
 
getConfig() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getConfig() - Method in class org.apache.drill.exec.server.rest.PluginConfigWrapper
 
getConfig() - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
getConfig() - Method in class org.apache.drill.exec.store.dfs.FileSystemPlugin
 
getConfig() - Method in interface org.apache.drill.exec.store.dfs.FormatPlugin
 
getConfig() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaStoragePlugin
 
getConfig() - Method in class org.apache.drill.exec.store.mock.ColumnDef
 
getConfig() - Method in class org.apache.drill.exec.store.mock.MockStorageEngine
 
getConfig() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
getConfig() - Method in interface org.apache.drill.exec.store.StoragePlugin
Method returns a Jackson serializable object that extends a StoragePluginConfig
getConfig() - Method in class org.apache.drill.exec.store.sys.PersistentStoreRegistry
 
getConfig() - Method in class org.apache.drill.exec.store.sys.SystemTablePlugin
 
getConfigLocation() - Method in class org.apache.drill.exec.server.StartupOptions
 
getConfigProperty() - Method in class org.apache.drill.exec.server.options.OptionValidator
 
getConfigProperty() - Method in class org.apache.drill.exec.server.options.TypeValidators.TypeValidator
 
getConnectionManager(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.rpc.control.ConnectionManagerRegistry
 
getConstantExpressionSet(LogicalExpression) - Static method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
Get a list of expressions that mark boundaries into a constant space.
getConstantValueHolder(String, TypeProtos.MinorType, Function<DrillBuf, ValueHolder>) - Method in class org.apache.drill.exec.ops.FragmentContext
 
getConstantValueHolder(String, TypeProtos.MinorType, Function<DrillBuf, ValueHolder>) - Method in class org.apache.drill.exec.ops.QueryContext
 
getConstantValueHolder(String, TypeProtos.MinorType, Function<DrillBuf, ValueHolder>) - Method in interface org.apache.drill.exec.ops.UdfUtilities
Works with value holders cache which holds constant value and its wrapper by type.
getContainer() - Method in class org.apache.drill.exec.expr.HoldingContainerExpression
 
getContainer() - Method in class org.apache.drill.exec.physical.impl.sort.RecordBatchData
 
getContainer() - Method in class org.apache.drill.exec.physical.impl.window.WindowDataBatch
 
getContainer() - Method in class org.apache.drill.exec.physical.impl.xsort.BatchGroup
 
getContainer() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
getContainer() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MergeSortWrapper
 
getContainer() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierWrapper.BatchMerger
 
getContainer() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.EmptyResults
 
getContainer() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SingleBatchResults
 
getContainer() - Method in interface org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SortResults
Container into which results are delivered.
getContainer() - Method in class org.apache.drill.exec.record.RecordBatchLoader
 
getContent() - Method in class org.apache.drill.exec.physical.config.Values
 
getContent() - Method in class org.apache.drill.exec.planner.common.DrillValuesRelBase
 
getContent() - Method in class org.apache.drill.exec.server.rest.profile.FragmentWrapper
 
getContent() - Method in class org.apache.drill.exec.server.rest.profile.OperatorWrapper
 
getContentSummary(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getContext() - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
 
getContext() - Method in class org.apache.drill.exec.physical.impl.filter.FilterRecordBatch
 
getContext() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
getContext() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
 
getContext() - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
 
getContext() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
getContext() - Method in class org.apache.drill.exec.physical.impl.window.WindowDataBatch
 
getContext() - Method in class org.apache.drill.exec.planner.logical.DrillImplementor
 
getContext() - Method in class org.apache.drill.exec.planner.physical.PhysicalPlanCreator
 
getContext() - Method in class org.apache.drill.exec.planner.sql.handlers.SqlHandlerConfig
 
getContext() - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
getContext() - Method in interface org.apache.drill.exec.record.RecordBatch
Gets the FragmentContext of the current query fragment.
getContext() - Method in class org.apache.drill.exec.record.SimpleRecordBatch
 
getContext() - Method in class org.apache.drill.exec.server.Drillbit
 
getContext() - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
getContext() - Method in interface org.apache.drill.exec.store.dfs.FormatPlugin
 
getContext() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
getContext() - Method in class org.apache.drill.exec.store.sys.SystemTablePlugin
 
getContext() - Method in class org.apache.drill.exec.work.fragment.FragmentExecutor
 
getContext() - Method in class org.apache.drill.exec.work.WorkManager
 
getContext() - Method in class org.apache.drill.exec.work.WorkManager.WorkerBee
 
getContextInformation() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getContextInformation() - Method in class org.apache.drill.exec.ops.QueryContext
 
getContextInformation() - Method in interface org.apache.drill.exec.ops.UdfUtilities
Get the context information such as: - query start time - root fragment timezone - query userName - system userName - default schema name in current session at the time of query.
getController() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getController() - Method in class org.apache.drill.exec.service.ServiceEngine
 
getControlMessageHandler() - Method in class org.apache.drill.exec.work.WorkManager
 
getControlPort() - Method in class org.apache.drill.exec.server.rest.DrillRoot.DrillbitInfo
 
getControlTunnel(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.ops.FragmentContext
 
getConvertedNode() - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler.ConvertedRelNode
 
getConverter() - Method in class org.apache.drill.exec.planner.sql.handlers.SqlHandlerConfig
 
getConverter(RecordWriter, int, String, FieldReader) - Static method in class org.apache.drill.exec.store.EventBasedRecordWriter
 
getConverter(int) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter
 
getCoordinator() - Method in class org.apache.drill.exec.server.RemoteServiceSet
 
getCoordinator() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources
 
getCoordinator() - Method in class org.apache.drill.exec.store.sys.PersistentStoreRegistry
 
getCopier(VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierWrapper
 
getCost() - Method in class org.apache.drill.exec.physical.base.AbstractBase
 
getCost() - Method in interface org.apache.drill.exec.physical.base.PhysicalOperator
 
getCost(List<TypeProtos.MajorType>, DrillFuncHolder) - Static method in class org.apache.drill.exec.resolver.TypeCastRules
 
getCostCategory() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
getCostCategory() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
 
getCostFactory() - Method in class org.apache.drill.exec.planner.sql.SqlConverter
 
getCount() - Method in class org.apache.drill.exec.expr.SizedJBlock
 
getCount() - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingInputStream
 
getCount() - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingOutputStream
 
getCount() - Method in class org.apache.drill.exec.record.selection.SelectionVector2
 
getCount() - Method in class org.apache.drill.exec.record.selection.SelectionVector4
 
getCounter(String) - Method in interface org.apache.drill.exec.cache.DistributedCache
 
getCpu() - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
getCpuCost() - Method in class org.apache.drill.exec.physical.base.ScanStats
 
getCreateTableEntry() - Method in class org.apache.drill.exec.planner.common.DrillWriterRelBase
 
getcreateViewType() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateView
 
getCredentials() - Method in class org.apache.drill.exec.rpc.user.UserSession
 
getCumulativeCost() - Method in class org.apache.drill.exec.expr.DrillFuncHolderExpr
 
getCumulativeCost() - Method in class org.apache.drill.exec.expr.HoldingContainerExpression
 
getCumulativeCost() - Method in class org.apache.drill.exec.expr.ValueVectorReadExpression
 
getCumulativeCost() - Method in class org.apache.drill.exec.expr.ValueVectorWriteExpression
 
getCumulativeCost() - Method in class org.apache.drill.exec.physical.impl.filter.ReturnValueExpression
 
getCurator() - Method in class org.apache.drill.exec.coord.zk.ZKClusterCoordinator
 
getCurrentDefaultSchema() - Method in class org.apache.drill.exec.ops.ContextInformation
 
getCurrentEndpoint() - Method in class org.apache.drill.exec.ops.QueryContext
 
getCurrentHandler() - Method in class org.apache.drill.exec.rpc.AbstractServerConnection
 
getCurrentMapping() - Method in class org.apache.drill.exec.compile.sig.MappingSet
 
getCurrentPosition() - Method in class org.apache.drill.exec.record.RecordIterator
 
getCurrentRecord() - Method in class org.apache.drill.exec.store.parquet2.DrillParquetRecordMaterializer
 
getCurrentVersion() - Method in class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
 
getCustomTunnel(int, Class<SEND>, Parser<RECEIVE>) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel
 
getCustomTunnel(int, Controller.CustomSerDe<SEND>, Controller.CustomSerDe<RECEIVE>) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel
 
getData() - Method in class org.apache.drill.exec.cache.CachedVectorContainer
 
getData() - Method in class org.apache.drill.exec.rpc.user.QueryDataBatch
 
getData(int) - Method in class org.apache.drill.exec.schema.DataRecord
 
getData() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
getDataAddr() - Method in class org.apache.drill.exec.record.selection.SelectionVector2
 
getDataConnectionCreator() - Method in class org.apache.drill.exec.service.ServiceEngine
 
getDataConnectionsPool() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getDataPort() - Method in class org.apache.drill.exec.server.rest.DrillRoot.DrillbitInfo
 
getDataSize() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.InputBatch
 
getDataTunnel(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.ops.FragmentContext
 
getDate(DrillBuf, int, int) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionHelpers
 
getDate(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getDate(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getDate(int) - Method in class org.apache.drill.exec.vector.accessor.DateAccessor
 
getDate(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDateAccessor
 
getDate(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getDateCorruptionStatus() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
Flag indicating if the old non-standard data format appears in this file, see DRILL-4203.
getDateTimeValueFromBinary(Binary, boolean) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility.NanoTimeUtils
 
getDb() - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowFiles
 
getDb() - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowTables
 
getDecimalMetadataForField(MaterializedField) - Static method in class org.apache.drill.exec.store.parquet.ParquetTypeHelper
 
getDecoder(BufferAllocator) - Method in class org.apache.drill.exec.rpc.control.ControlClient
 
getDecoder(BufferAllocator, OutOfMemoryHandler) - Method in class org.apache.drill.exec.rpc.control.ControlServer
 
getDecoder(BufferAllocator) - Method in class org.apache.drill.exec.rpc.data.DataClient
 
getDecoder(BufferAllocator, OutOfMemoryHandler) - Method in class org.apache.drill.exec.rpc.data.DataServer
 
getDecoder(BufferAllocator) - Method in class org.apache.drill.exec.rpc.user.UserClient
 
getDecoder(BufferAllocator, OutOfMemoryHandler) - Method in class org.apache.drill.exec.rpc.user.UserServer
 
getDef() - Method in class org.apache.drill.exec.record.WritableBatch
 
getDefault() - Static method in enum org.apache.drill.exec.expr.annotations.FunctionTemplate.FunctionCostCategory
 
getDefault() - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTraitDef
 
getDefault(String) - Method in class org.apache.drill.exec.server.options.FragmentOptionManager
 
getDefault(String) - Method in interface org.apache.drill.exec.server.options.OptionSet
Gets the default value for the specified option.
getDefault(String) - Method in class org.apache.drill.exec.server.options.QueryOptionManager
 
getDefault(String) - Method in class org.apache.drill.exec.server.options.SessionOptionManager
 
getDefault(String) - Method in class org.apache.drill.exec.server.options.SystemOptionManager
 
getDefaultAffinityMap(List<CoordinationProtos.DrillbitEndpoint>) - Static method in class org.apache.drill.exec.physical.base.AbstractExchange
Get a default endpoint affinity map where affinity of a Drillbit is proportional to the number of its occurrances in given endpoint list.
getDefaultBlockSize() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
Deprecated.
getDefaultBlockSize(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getDefaultColumnsToRead() - Method in class org.apache.drill.exec.store.AbstractRecordReader
 
getDefaultColumnsToRead() - Method in class org.apache.drill.exec.store.easy.json.JSONRecordReader
 
getDefaultColumnsToRead() - Method in class org.apache.drill.exec.store.easy.text.compliant.CompliantTextRecordReader
Returns list of default columns to read to replace empty list of columns.
getDefaultColumnsToRead() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
getDefaultColumnsToRead() - Method in class org.apache.drill.exec.store.text.DrillTextRecordReader
 
getDefaultInputFormat() - Method in class org.apache.drill.exec.store.dfs.WorkspaceConfig
 
getDefaultLocation() - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
getDefaultMapping() - Static method in class org.apache.drill.exec.expr.ClassGenerator
 
getDefaultReplication() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
Deprecated.
getDefaultReplication(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getDefaultSchema() - Method in class org.apache.drill.exec.planner.sql.SqlConverter
 
getDefaultSchema(SchemaPlus) - Method in class org.apache.drill.exec.rpc.user.UserSession
Get default schema from current default schema path and given schema tree.
getDefaultSchema() - Method in class org.apache.drill.exec.store.AbstractSchema
The schema can be a top level schema which doesn't have its own tables, but refers to one of the default sub schemas for table look up.
getDefaultSchema() - Method in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory.FileSystemSchema
 
getDefaultSchema() - Method in class org.apache.drill.exec.store.SubSchemaWrapper
 
getDefaultSchemaPath() - Method in class org.apache.drill.exec.rpc.user.UserSession
 
getDefinition() - Method in class org.apache.drill.exec.expr.CodeGenerator
 
getDefinitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v1
 
getDefinitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
getDefinitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
getDefinitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataBase
 
getDefinitions() - Method in class org.apache.drill.exec.server.BootStrapContext
 
getDelegationToken(String) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getDelimiter() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Returns the field delimiter character.
getDesc() - Method in class org.apache.drill.exec.testing.Injection
 
getDescrip() - Method in class org.apache.drill.exec.store.mock.MockTableDef
Description of this data source.
getDestination() - Method in class org.apache.drill.exec.physical.config.SingleSender
 
getDestinations() - Method in class org.apache.drill.exec.physical.base.AbstractSender
 
getDestinations() - Method in interface org.apache.drill.exec.physical.base.Sender
Get the list of destination endpoints that this Sender will be communicating with.
getDestinations() - Method in class org.apache.drill.exec.physical.config.SingleSender
 
getDfsName() - Method in interface org.apache.drill.exec.store.DistributedStorageEngine
 
getDigest() - Method in interface org.apache.drill.exec.physical.base.GroupScan
Returns a signature of the GroupScan which should usually be composed of all its attributes which could describe it uniquely.
getDigest() - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
getDigest() - Method in class org.apache.drill.exec.store.direct.DirectGroupScan
 
getDigest() - Method in class org.apache.drill.exec.store.direct.MetadataDirectGroupScan
Returns string representation of group scan data.
getDigest() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaGroupScan
 
getDigest() - Method in class org.apache.drill.exec.store.mock.MockGroupScanPOP
 
getDigest() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
getDigest() - Method in class org.apache.drill.exec.store.sys.SystemTableScan
 
getDir() - Method in class org.apache.drill.exec.work.batch.SpoolingRawBatchBuffer
 
getDirectories() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v1
 
getDirectories() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
getDirectories() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
getDirectories() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataBase
 
getDirectories() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataDirs
 
getDirectScanRelIfFullySchemaed(RelNode) - Static method in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor
If all field types of the given node are recognized types and honored by execution, then this method returns the tree: DrillDirectScanRel(field types).
getDirFilterOnProject(OptimizerRulesContext) - Static method in class org.apache.drill.exec.planner.logical.partition.PruneScanRule
 
getDirFilterOnScan(OptimizerRulesContext) - Static method in class org.apache.drill.exec.planner.logical.partition.PruneScanRule
 
getDirs() - Method in class org.apache.drill.exec.planner.DFSFilePartitionLocation
 
getDirStatus() - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
getDiskCost() - Method in class org.apache.drill.exec.physical.base.ScanStats
 
getDisplayName() - Method in class org.apache.drill.exec.server.rest.profile.FragmentWrapper
 
getDisplayName() - Method in class org.apache.drill.exec.server.rest.profile.OperatorWrapper
 
getDistFields() - Method in class org.apache.drill.exec.planner.physical.HashToMergeExchangePrel
 
getDistinctRowCount(RelNode, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in class org.apache.drill.exec.planner.cost.DrillRelMdDistinctRowCount
 
getDistributionAffinity() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
getDistributionAffinity() - Method in class org.apache.drill.exec.physical.base.AbstractStore
 
getDistributionAffinity() - Method in interface org.apache.drill.exec.physical.base.HasAffinity
Get distribution affinity which describes the parallelization strategy of the operator.
getDistributionAffinity() - Method in class org.apache.drill.exec.physical.config.Screen
 
getDistributionAffinity() - Method in class org.apache.drill.exec.planner.fragment.Stats
 
getDistributionAffinity() - Method in interface org.apache.drill.exec.planner.physical.HasDistributionAffinity
 
getDistributionAffinity() - Method in class org.apache.drill.exec.planner.physical.ScanPrel
 
getDistributionAffinity() - Method in class org.apache.drill.exec.planner.physical.ScreenPrel
 
getDistributionAffinity() - Method in class org.apache.drill.exec.store.sys.SystemTableScan
 
getDistributionField(DrillAggregateRel, boolean) - Method in class org.apache.drill.exec.planner.physical.AggPruleBase
 
getDistributionField(List<Integer>) - Method in class org.apache.drill.exec.planner.physical.JoinPruleBase
 
getDotDrills(DrillFileSystem, Path, DotDrillType...) - Static method in class org.apache.drill.exec.dotdrill.DotDrillUtil
 
getDotDrills(DrillFileSystem, Path, String, DotDrillType...) - Static method in class org.apache.drill.exec.dotdrill.DotDrillUtil
 
getDouble(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getDouble(String) - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
getDouble(String) - Method in interface org.apache.drill.exec.server.options.OptionSet
Return the value of a double option.
getDouble(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getDouble(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getDouble(int) - Method in class org.apache.drill.exec.vector.accessor.Float8Accessor
 
getDouble(int) - Method in class org.apache.drill.exec.vector.accessor.NullableFloat8Accessor
 
getDouble(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getDouble(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
getDoubles() - Method in class org.apache.drill.exec.store.httpd.HttpdLogRecord
 
getDrillbitContext() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getDrillbitContext() - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
Drillbit context.
getDrillbits() - Method in class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
 
getDrillbitStatus() - Method in class org.apache.drill.exec.server.rest.DrillRoot
 
getDrillbitStatusListener() - Method in class org.apache.drill.exec.work.foreman.QueryManager
 
getDrillOperatorTable() - Method in class org.apache.drill.exec.ops.QueryContext
 
getDrillSqlReturnTypeInference(String, List<DrillFuncHolder>) - Static method in class org.apache.drill.exec.planner.sql.TypeInferenceUtils
Give the name and DrillFuncHolder list, return the inference mechanism.
getDrillTable() - Method in class org.apache.drill.exec.planner.common.DrillScanRelBase
 
getDrillTable() - Method in class org.apache.drill.exec.planner.logical.DrillTranslatableTable
 
getDrillTypeFromCalciteType(RelDataType) - Static method in class org.apache.drill.exec.planner.sql.TypeInferenceUtils
Given a Calcite's RelDataType, return a Drill's corresponding TypeProtos.MinorType
getDrillTypeFromCalciteType(SqlTypeName) - Static method in class org.apache.drill.exec.planner.sql.TypeInferenceUtils
Given a Calcite's SqlTypeName, return a Drill's corresponding TypeProtos.MinorType
getDrillVersion() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v1
 
getDrillVersion() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
getDrillVersion() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
getDrillVersion() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataBase
 
getDrillVersion() - Static method in class org.apache.drill.exec.util.Utilities
Read the manifest file and get the Drill version number
getDst_ip() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
getDst_port() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
getDuration() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.ProfileInfo
 
getEmptyBatchWithSchema(boolean, UserBitShared.QueryId, int, int, int, int, BatchSchema) - Static method in class org.apache.drill.exec.record.FragmentWritableBatch
 
getEmptyLast(UserBitShared.QueryId, int, int, int, int) - Static method in class org.apache.drill.exec.record.FragmentWritableBatch
 
getEmptyLast(UserBitShared.QueryId, int, int, int, int[]) - Static method in class org.apache.drill.exec.record.FragmentWritableBatch
 
getEmptyLastWithSchema(UserBitShared.QueryId, int, int, int, int, BatchSchema) - Static method in class org.apache.drill.exec.record.FragmentWritableBatch
 
getEmptyValue() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Returns the String representation of an empty value (defaults to null)
getEncoding() - Method in class org.apache.drill.exec.planner.physical.BroadcastExchangePrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.ComplexToJsonPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.FilterPrel
FilterPrel adds an SV2 (TWO_BYTE mode SelectionVector).
getEncoding() - Method in class org.apache.drill.exec.planner.physical.FlattenPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.HashAggPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.HashJoinPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.HashToMergeExchangePrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.HashToRandomExchangePrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.LimitPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.MergeJoinPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.NestedLoopJoinPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.OrderedPartitionExchangePrel
 
getEncoding() - Method in interface org.apache.drill.exec.planner.physical.Prel
A Prel's own SelectionVector mode - i.e whether it generates an SV2, SV4 or None
getEncoding() - Method in class org.apache.drill.exec.planner.physical.ProducerConsumerPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.ProjectPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.ScanPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.ScreenPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.SelectionVectorRemoverPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.SingleMergeExchangePrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.SortPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.StreamAggPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.TopNPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.UnionAllPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.UnionDistinctPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.UnionExchangePrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.UnorderedDeMuxExchangePrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.UnorderedMuxExchangePrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.ValuesPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.WindowPrel
 
getEncoding() - Method in class org.apache.drill.exec.planner.physical.WriterPrel
 
getEncryptedConnectionCount() - Method in class org.apache.drill.exec.rpc.control.ControlRpcMetrics
 
getEncryptedConnectionCount() - Method in class org.apache.drill.exec.rpc.data.DataRpcMetrics
 
getEncryptedConnectionCount() - Method in class org.apache.drill.exec.rpc.user.UserRpcMetrics
 
getEncryptionCtxt() - Method in class org.apache.drill.exec.rpc.AbstractConnectionConfig
 
getEncryptionCtxt() - Method in interface org.apache.drill.exec.rpc.ConnectionConfig
 
getEnd() - Method in class org.apache.drill.exec.physical.config.WindowPOP
 
getEndColumn() - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
getEnding() - Method in enum org.apache.drill.exec.dotdrill.DotDrillType
Return extension string of file type represented by this object.
getEndLine() - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
getEndPoint() - Method in interface org.apache.drill.exec.coord.ClusterCoordinator.RegistrationHandle
Get the drillbit endpoint associated with the registration handle
getEndPoint() - Method in class org.apache.drill.exec.coord.zk.ZKRegistrationHandle
 
getEndpoint() - Method in class org.apache.drill.exec.physical.config.RangeSender.EndpointPartition
 
getEndpoint() - Method in class org.apache.drill.exec.physical.config.Screen
 
getEndpoint() - Method in class org.apache.drill.exec.physical.EndpointAffinity
Return the Drillbit endpoint in this instance.
getEndpoint() - Method in class org.apache.drill.exec.physical.MinorFragmentEndpoint
Get the Drillbit endpoint where the fragment is assigned for execution.
getEndpoint() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getEndpoint() - Method in class org.apache.drill.exec.work.EndpointListener
 
getEndpoint() - Method in class org.apache.drill.exec.work.foreman.FragmentData
 
getEndpointAffinityMap() - Method in class org.apache.drill.exec.planner.fragment.ParallelizationInfo
 
getEndpointByteMap(Set<String>, FileWork) - Method in class org.apache.drill.exec.store.schedule.BlockMapBuilder
For a given FileWork, calculate how many bytes are available on each on drillbit endpoint
getEndTime() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.ProfileInfo
 
getEndUnit() - Method in class org.apache.drill.exec.dotdrill.View.FieldType
Gets the time range end unit of the type qualifier of the interval data type descriptor of this field (iff interval type).
getEngineConfig() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
getEngineConfig() - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
 
getEntirePartitionLocation() - Method in class org.apache.drill.exec.planner.DFSDirPartitionLocation
 
getEntirePartitionLocation() - Method in class org.apache.drill.exec.planner.DFSFilePartitionLocation
Return the full location of this partition
getEntirePartitionLocation() - Method in class org.apache.drill.exec.planner.ParquetPartitionLocation
Get the location of this partition
getEntirePartitionLocation() - Method in interface org.apache.drill.exec.planner.PartitionLocation
Returns the string representation of this partition.
getEntries() - Method in class org.apache.drill.exec.store.mock.MockTableDef
The set of entries that define the groups within the file.
getEntries() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
getError() - Method in class org.apache.drill.exec.rpc.AbstractDisposableUserClientConnection
 
getErrors() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.QProfiles
 
getEscape() - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
getEstBatchSize() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierWrapper.BatchMerger
Gets the estimated batch size, in bytes.
getEthernetDestination() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
getEthernetSource() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
getEvalBlock() - Method in class org.apache.drill.exec.expr.ClassGenerator
 
getEvalBlockLabel(String) - Method in class org.apache.drill.exec.expr.ClassGenerator
 
getExactResolver(FunctionCall) - Static method in class org.apache.drill.exec.resolver.FunctionResolverFactory
 
getExccess() - Method in class org.apache.drill.exec.server.StartupOptions
 
getExceptionWithContext(UserException.Builder, String, String, Object...) - Method in class org.apache.drill.exec.store.bson.BsonRecordReader
 
getExceptionWithContext(Throwable, String, String, Object...) - Method in class org.apache.drill.exec.store.bson.BsonRecordReader
 
getExceptionWithContext(UserException.Builder, String, String, Object...) - Method in interface org.apache.drill.exec.store.easy.json.JsonProcessor
 
getExceptionWithContext(Throwable, String, String, Object...) - Method in interface org.apache.drill.exec.store.easy.json.JsonProcessor
 
getExceptionWithContext(UserException.Builder, String, String, Object...) - Method in class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
 
getExceptionWithContext(Throwable, String, String, Object...) - Method in class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
 
getExchange() - Method in class org.apache.drill.exec.planner.fragment.Fragment.ExchangeFragmentPair
 
getExec(FragmentContext, FragmentRoot) - Static method in class org.apache.drill.exec.physical.impl.ImplCreator
Create and return fragment RootExec for given FragmentRoot.
getExec(FragmentContext, FragmentRoot) - Static method in class org.apache.drill.exec.physical.impl.TraceInjector
 
getExecutionControls() - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
getExecutionControls() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getExecutionControls() - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
Return the set of execution controls used to inject faults into running code for testing.
getExecutionControls() - Method in interface org.apache.drill.exec.ops.OperatorContext
 
getExecutionControls() - Method in class org.apache.drill.exec.ops.QueryContext
 
getExecutionDuration() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
 
getExecutor() - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
getExecutor() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getExecutor() - Method in interface org.apache.drill.exec.ops.OperatorContext
 
getExecutor() - Method in class org.apache.drill.exec.server.BootStrapContext
 
getExecutor() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getExecutor() - Method in class org.apache.drill.exec.work.WorkManager
 
getExecutorThreadName(ExecProtos.FragmentHandle) - Static method in class org.apache.drill.exec.proto.helper.QueryIdHelper
 
getExpr(String, List<LogicalExpression>, ExpressionPosition) - Method in class org.apache.drill.exec.expr.fn.AbstractFuncHolder
 
getExpr(String, List<LogicalExpression>, ExpressionPosition) - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
getExpr() - Method in class org.apache.drill.exec.physical.config.Filter
 
getExpr() - Method in class org.apache.drill.exec.physical.config.HashPartitionSender
 
getExpression() - Method in class org.apache.drill.exec.physical.config.AbstractDeMuxExchange
 
getExpression() - Method in class org.apache.drill.exec.physical.config.HashToRandomExchange
 
getExpression(SchemaPlus, String) - Method in class org.apache.drill.exec.store.AbstractSchema
 
getExprRoot() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilter
 
getExprs() - Method in class org.apache.drill.exec.physical.config.Project
 
getExprs() - Method in class org.apache.drill.exec.physical.config.StreamingAggregate
 
getExtensions() - Method in class org.apache.drill.exec.store.easy.json.JSONFormatPlugin.JSONFormatConfig
 
getExtensions() - Method in class org.apache.drill.exec.store.easy.sequencefile.SequenceFileFormatConfig
 
getExtensions() - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
getExternalInterface() - Method in class org.apache.drill.exec.compile.TemplateClassDefinition
 
getFailureCause() - Method in interface org.apache.drill.exec.ops.FragmentContext.ExecutorState
Deprecated.
getFailureCause() - Method in class org.apache.drill.exec.ops.FragmentContext
Deprecated.
getFamily() - Method in class org.apache.drill.exec.planner.types.RelDataTypeDrillImpl
 
getFetch() - Method in class org.apache.drill.exec.planner.common.DrillLimitRelBase
 
getField(String, boolean, boolean) - Method in class org.apache.drill.exec.planner.types.DrillFixedRelDataTypeImpl
 
getField(String, boolean, boolean) - Method in class org.apache.drill.exec.planner.types.RelDataTypeDrillImpl
 
getField(RelDataTypeFactory, String) - Method in class org.apache.drill.exec.planner.types.RelDataTypeHolder
 
getField() - Method in class org.apache.drill.exec.record.HyperVectorWrapper
 
getField() - Method in class org.apache.drill.exec.record.SimpleVectorWrapper
 
getField() - Method in interface org.apache.drill.exec.record.VectorWrapper
 
getField(int) - Method in class org.apache.drill.exec.schema.BackedRecord
 
getField(String, int) - Method in class org.apache.drill.exec.schema.ListSchema
 
getField(String, int) - Method in class org.apache.drill.exec.schema.ObjectSchema
 
getField(int) - Method in interface org.apache.drill.exec.schema.Record
 
getField(String, int) - Method in interface org.apache.drill.exec.schema.RecordSchema
 
getField() - Method in class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
 
getFieldById(int, ComplexHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableTinyIntHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, TinyIntHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedTinyIntHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableUInt1Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, UInt1Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedUInt1Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableUInt2Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, UInt2Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedUInt2Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableSmallIntHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, SmallIntHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedSmallIntHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableIntHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, IntHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedIntHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableUInt4Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, UInt4Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedUInt4Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableFloat4Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, Float4Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedFloat4Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableTimeHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, TimeHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedTimeHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableIntervalYearHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, IntervalYearHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedIntervalYearHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableDecimal9Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, Decimal9Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedDecimal9Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableBigIntHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, BigIntHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedBigIntHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableUInt8Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, UInt8Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedUInt8Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableFloat8Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, Float8Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedFloat8Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableDateHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, DateHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedDateHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableTimeStampHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, TimeStampHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedTimeStampHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableDecimal18Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, Decimal18Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedDecimal18Holder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableIntervalDayHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, IntervalDayHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedIntervalDayHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableIntervalHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, IntervalHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedIntervalHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableDecimal28DenseHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, Decimal28DenseHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedDecimal28DenseHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableDecimal38DenseHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, Decimal38DenseHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedDecimal38DenseHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableDecimal38SparseHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, Decimal38SparseHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedDecimal38SparseHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableDecimal28SparseHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, Decimal28SparseHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedDecimal28SparseHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableVarBinaryHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, VarBinaryHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedVarBinaryHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableVarCharHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, VarCharHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedVarCharHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableVar16CharHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, Var16CharHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedVar16CharHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, NullableBitHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, BitHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldById(int, RepeatedBitHolder) - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
getFieldCount() - Method in class org.apache.drill.exec.planner.types.DrillFixedRelDataTypeImpl
 
getFieldCount() - Method in class org.apache.drill.exec.planner.types.RelDataTypeDrillImpl
 
getFieldCount() - Method in class org.apache.drill.exec.planner.types.RelDataTypeHolder
 
getFieldCount() - Method in class org.apache.drill.exec.record.BatchSchema
 
getFieldDelimiter() - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
getFieldDelimiterAsString() - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
getFieldId() - Method in class org.apache.drill.exec.expr.ValueVectorReadExpression
 
getFieldId() - Method in class org.apache.drill.exec.expr.ValueVectorWriteExpression
 
getFieldId() - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTrait.DistributionField
 
getFieldId(ValueVector, int, SchemaPath, boolean) - Static method in class org.apache.drill.exec.vector.complex.FieldIdUtil
 
getFieldIdIfMatches(int, SchemaPath) - Method in class org.apache.drill.exec.record.HyperVectorWrapper
 
getFieldIdIfMatches(int, SchemaPath) - Method in class org.apache.drill.exec.record.SimpleVectorWrapper
 
getFieldIdIfMatches(int, SchemaPath) - Method in interface org.apache.drill.exec.record.VectorWrapper
Traverse the object graph and determine whether the provided SchemaPath matches data within the Wrapper.
getFieldIdIfMatches(ValueVector, TypedFieldId.Builder, boolean, PathSegment) - Static method in class org.apache.drill.exec.vector.complex.FieldIdUtil
 
getFieldIdIfMatchesUnion(UnionVector, TypedFieldId.Builder, boolean, PathSegment) - Static method in class org.apache.drill.exec.vector.complex.FieldIdUtil
 
getFieldIds() - Method in class org.apache.drill.exec.record.TypedFieldId
 
getFieldList() - Method in class org.apache.drill.exec.planner.types.DrillFixedRelDataTypeImpl
 
getFieldList() - Method in class org.apache.drill.exec.planner.types.RelDataTypeDrillImpl
 
getFieldList(RelDataTypeFactory) - Method in class org.apache.drill.exec.planner.types.RelDataTypeHolder
 
getFieldLists(LogicalPlan) - Static method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer
 
getFieldMajorType(Schema.Field, TypeProtos.DataMode) - Static method in class org.apache.drill.exec.store.avro.AvroTypeHelper
Maintains a mapping between Avro types and Drill types.
getFieldMajorType(Schema.Type, TypeProtos.DataMode) - Static method in class org.apache.drill.exec.store.avro.AvroTypeHelper
Maintains a mapping between Avro types and Drill types.
getFieldName(LogicalExpression) - Static method in class org.apache.drill.exec.planner.logical.ExprHelper
 
getFieldName() - Method in class org.apache.drill.exec.schema.Field
 
getFieldName() - Method in class org.apache.drill.exec.schema.NamedField
 
getFieldName() - Method in class org.apache.drill.exec.schema.OrderedField
 
getFieldNames() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateTable
 
getFieldNames() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateView
 
getFieldNames() - Method in class org.apache.drill.exec.planner.types.DrillFixedRelDataTypeImpl
 
getFieldNames() - Method in class org.apache.drill.exec.planner.types.RelDataTypeDrillImpl
 
getFieldNames() - Method in class org.apache.drill.exec.planner.types.RelDataTypeHolder
 
getFieldNames() - Method in class org.apache.drill.exec.store.pojo.PojoDataType
 
getFieldNames() - Method in class org.apache.drill.exec.store.RecordDataType
 
getFields() - Method in class org.apache.drill.exec.dotdrill.View
 
getFields() - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
 
getFields() - Method in class org.apache.drill.exec.planner.physical.HashToRandomExchangePrel
 
getFields() - Method in class org.apache.drill.exec.schema.ListSchema
 
getFields() - Method in class org.apache.drill.exec.schema.ObjectSchema
 
getFields() - Method in interface org.apache.drill.exec.schema.RecordSchema
 
getFieldSelection(List<SchemaPath>) - Static method in class org.apache.drill.exec.vector.complex.fn.FieldSelection
Generates a field selection based on a list of fields.
getFieldSqlTypeNames() - Method in class org.apache.drill.exec.store.pojo.PojoDataType
 
getFieldSqlTypeNames() - Method in class org.apache.drill.exec.store.RecordDataType
 
getFieldType() - Method in class org.apache.drill.exec.schema.Field
 
getFieldType(JsonToken, boolean) - Static method in class org.apache.drill.exec.schema.json.jackson.JacksonHelper
 
getFieldValue(T, int) - Method in class org.apache.drill.exec.store.pojo.AbstractPojoRecordReader
Retrieves field value to be written based for given row and field position.
getFieldValue(List<T>, int) - Method in class org.apache.drill.exec.store.pojo.DynamicPojoRecordReader
 
getFieldValue(T, int) - Method in class org.apache.drill.exec.store.pojo.PojoRecordReader
 
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getFileBlockLocations(Path, long, long) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getFileChecksum(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getFileChecksum(Path, long) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getFileCount() - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet
 
getFileDescriptor() - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
getFileLinkStatus(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getFileLocationsAndStatus() - Method in class org.apache.drill.exec.planner.FileSystemPartitionDescriptor
 
getFileNameForQueryFragment(FragmentContext, String, String) - Static method in class org.apache.drill.exec.util.Utilities
 
getFilePermission() - Method in class org.apache.drill.exec.store.StorageStrategy
 
getFiles() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
getFiles() - Method in interface org.apache.drill.exec.physical.base.GroupScan
Returns a collection of file names associated with this GroupScan.
getFiles() - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
getFiles() - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
getFiles() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v1
 
getFiles() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
getFiles() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
getFiles() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataBase
 
getFiles() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
getFileSelection() - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
getFileSet() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
getFileStatus(Path) - Method in class org.apache.drill.exec.store.ClassPathFileSystem
 
getFileStatus(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getFileStatus(Path) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem
 
getFileStatuses() - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
getFileSystem() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
getFileSystem(DrillConfig, Path) - Static method in class org.apache.drill.exec.store.sys.store.LocalPersistentStore
 
getFilter() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaGroupScan
 
getFilter() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaSubScan
 
getFilter() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
getFilter() - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
 
getFilterExpression(DrillParseContext) - Method in class org.apache.drill.exec.planner.common.DrillFilterRelBase
 
getFilterMaxSelectivityEstimateFactor() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getFilterMinSelectivityEstimateFactor() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getFilterOnProject(OptimizerRulesContext) - Static method in class org.apache.drill.exec.store.parquet.ParquetPushDownFilter
 
getFilterOnProjectParquet(OptimizerRulesContext) - Static method in class org.apache.drill.exec.planner.logical.partition.ParquetPruneScanRule
 
getFilterOnScan(OptimizerRulesContext) - Static method in class org.apache.drill.exec.store.parquet.ParquetPushDownFilter
 
getFilterOnScanParquet(OptimizerRulesContext) - Static method in class org.apache.drill.exec.planner.logical.partition.ParquetPruneScanRule
 
getFinalCondition() - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
 
getFinalSv4() - Method in interface org.apache.drill.exec.physical.impl.TopN.PriorityQueue
Retrieves the selection vector used to select the elements in the priority queue from the hyper batch provided by the PriorityQueue.getHyperBatch() method.
getFinalSv4() - Method in class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
 
getFinalType() - Method in class org.apache.drill.exec.record.TypedFieldId
 
getFinish() - Method in class org.apache.drill.exec.physical.config.PartitionRange
 
getFinish() - Method in class org.apache.drill.exec.work.foreman.LoggedQuery
 
getFinishedQueries() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.QProfiles
 
getFirst() - Method in class org.apache.drill.exec.physical.config.Limit
 
getFirstColumnReader() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
Several readers use the first column reader to get information about the whole record or group (such as row count.)
getFirstPath(DrillFileSystem) - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
getFlattenExpression(DrillParseContext) - Method in class org.apache.drill.exec.planner.physical.FlattenPrel
 
getFlattenField() - Method in interface org.apache.drill.exec.physical.impl.flatten.Flattener
 
getFlattenField() - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenTemplate
 
getFloat(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getFloat(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getFloat(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getFloat(int) - Method in class org.apache.drill.exec.vector.accessor.Float4Accessor
 
getFloat(int) - Method in class org.apache.drill.exec.vector.accessor.NullableFloat4Accessor
 
getFloat(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getFloat(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
getFloatVal() - Method in class org.apache.drill.exec.server.options.PersistedOptionValue
This is present for forward compatibility.
getFolderPermission() - Method in class org.apache.drill.exec.store.StorageStrategy
 
getFooters(Configuration, List<FileStatus>, int) - Static method in class org.apache.drill.exec.store.parquet.FooterGatherer
 
getForeman() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.ProfileInfo
 
getForemanEndpoint() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getForemanForQueryId(UserBitShared.QueryId) - Method in class org.apache.drill.exec.work.WorkManager.WorkerBee
 
getFormat() - Method in class org.apache.drill.exec.store.dfs.FormatSelection
 
getFormatConfig() - Method in class org.apache.drill.exec.planner.logical.FileSystemCreateTableEntry
 
getFormatConfig() - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
getFormatConfig() - Method in class org.apache.drill.exec.store.dfs.easy.EasySubScan
 
getFormatConfig() - Method in class org.apache.drill.exec.store.dfs.easy.EasyWriter
 
getFormatConfig() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
getFormatConfig() - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
 
getFormatConfig() - Method in class org.apache.drill.exec.store.parquet.ParquetWriter
 
getFormatPlugin() - Method in class org.apache.drill.exec.store.dfs.BasicFormatMatcher
 
getFormatPlugin() - Method in class org.apache.drill.exec.store.dfs.easy.EasySubScan
 
getFormatPlugin() - Method in class org.apache.drill.exec.store.dfs.easy.EasyWriter
 
getFormatPlugin(String) - Method in class org.apache.drill.exec.store.dfs.FileSystemPlugin
 
getFormatPlugin(FormatPluginConfig) - Method in class org.apache.drill.exec.store.dfs.FileSystemPlugin
If format plugin configuration is for named format plugin, will return format plugin from pre-loaded list by name.
getFormatPlugin() - Method in class org.apache.drill.exec.store.dfs.FormatMatcher
 
getFormatPlugin() - Method in class org.apache.drill.exec.store.parquet.ParquetWriter
 
getFormatPlugin(StoragePluginConfig, FormatPluginConfig) - Method in interface org.apache.drill.exec.store.StoragePluginRegistry
Get the Format plugin for the FileSystemPlugin associated with the provided storage config and format config.
getFormatPlugin(StoragePluginConfig, FormatPluginConfig) - Method in class org.apache.drill.exec.store.StoragePluginRegistryImpl
 
getFractionalSecondPrecision() - Method in class org.apache.drill.exec.dotdrill.View.FieldType
Gets the fractional second precision of the type qualifier of the interval data type descriptor of this field (iff interval type).
getFragIdString() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getFragmentContext() - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
getFragmentContext() - Method in interface org.apache.drill.exec.ops.OperatorContext
 
getFragmentContext() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
getFragmentContext() - Method in class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
getFragmentContext() - Method in interface org.apache.drill.exec.work.fragment.FragmentManager
 
getFragmentCount() - Method in class org.apache.drill.exec.work.batch.BaseRawBatchBuffer
Return the fragment count from construction time.
getFragmentDependencies() - Method in class org.apache.drill.exec.planner.fragment.Wrapper
Get the list of fragements this particular fragment depends for determining its
getFragmentId() - Method in class org.apache.drill.exec.planner.physical.explain.PrelSequencer.OpId
 
getFragmentId(ExecProtos.FragmentHandle) - Static method in class org.apache.drill.exec.proto.helper.QueryIdHelper
 
getFragmentManager(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.rpc.control.WorkEventBus
 
getFragmentManagerIfExists(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.rpc.control.WorkEventBus
 
getFragmentParallelizer() - Method in enum org.apache.drill.exec.planner.fragment.DistributionAffinity
 
getFragmentProfiles() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
 
getFragmentRunner(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.work.WorkManager.WorkerBee
 
getFragments(OptionList, CoordinationProtos.DrillbitEndpoint, UserBitShared.QueryId, Collection<CoordinationProtos.DrillbitEndpoint>, Fragment, UserSession, BitControl.QueryContextInformation) - Method in class org.apache.drill.exec.planner.fragment.SimpleParallelizer
Generate a set of assigned fragments based on the provided fragment tree.
getFragments() - Method in class org.apache.drill.exec.work.QueryWorkUnit
 
getFragmentsHelper(Collection<CoordinationProtos.DrillbitEndpoint>, Fragment) - Method in class org.apache.drill.exec.planner.fragment.SimpleParallelizer
Helper method to reuse the code for QueryWorkUnit(s) generation
getFragmentsOverview() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
 
getFragmentStatesAsString() - Method in class org.apache.drill.exec.work.foreman.QueryManager
 
getFragmentStatusListener() - Method in class org.apache.drill.exec.work.foreman.QueryManager
 
getFs() - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
 
getFS() - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
getFsConf() - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
getFsConf() - Method in class org.apache.drill.exec.store.dfs.FileSystemPlugin
 
getFsConf() - Method in interface org.apache.drill.exec.store.dfs.FormatPlugin
 
getFsConf() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
getFsPartitionColumnLabel() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getFullFieldName() - Method in class org.apache.drill.exec.schema.Field
 
getFullLog(String) - Method in class org.apache.drill.exec.server.rest.LogsResources
 
getFullRootSchema() - Method in class org.apache.drill.exec.ops.FragmentContext
This method is only used to construt InfoSchemaReader, it is for the reader to get full schema, so here we are going to return a fully initialized schema tree.
getFullRootSchema(SchemaConfig) - Method in class org.apache.drill.exec.ops.QueryContext
Create and return a fully initialized SchemaTree with given schemaConfig.
getFullSchemaName() - Method in class org.apache.drill.exec.store.AbstractSchema
 
getFunction(FunctionCall) - Method in interface org.apache.drill.exec.expr.fn.PluggableFunctionRegistry
If exists return the function implementation holder matching the given functionCall expression, otherwise null.
getFunctionImplementationRegistry() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getFunctionNames() - Method in class org.apache.drill.exec.store.AbstractSchema
 
getFunctionNames() - Method in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory.FileSystemSchema
 
getFunctionNames() - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
getFunctionNames() - Method in class org.apache.drill.exec.store.SubSchemaWrapper
 
getFunctionNamesByJar(String) - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
Retrieves all function names associated with the jar from FunctionRegistryHolder.jars.
getFunctionRegistry() - Method in class org.apache.drill.exec.ops.BaseFragmentContext
 
getFunctionRegistry() - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
Returns the UDF registry.
getFunctionRegistry() - Method in interface org.apache.drill.exec.ops.OptimizerRulesContext
Method returns the function registry
getFunctionRegistry() - Method in class org.apache.drill.exec.ops.QueryContext
 
getFunctionRegistryVersion() - Method in class org.apache.drill.exec.planner.sql.DrillOperatorTable
 
getFunctions() - Method in class org.apache.drill.exec.planner.sql.DrillSqlAggOperator
 
getFunctions() - Method in class org.apache.drill.exec.planner.sql.DrillSqlOperator
 
getFunctions(String) - Method in class org.apache.drill.exec.store.AbstractSchema
 
getFunctions(String) - Method in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory.FileSystemSchema
 
getFunctions(String) - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
getFunctions(String) - Method in class org.apache.drill.exec.store.SubSchemaWrapper
 
getGenerated4Copier(RecordBatch, FragmentContext, BufferAllocator, VectorContainer, RecordBatch, SchemaChangeCallBack) - Static method in class org.apache.drill.exec.physical.impl.svremover.RemovingRecordBatch
 
getGeneratedCode() - Method in class org.apache.drill.exec.expr.CodeGenerator
 
getGenerator() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
getGracePeriod() - Method in class org.apache.drill.exec.server.rest.DrillRoot
 
getGroupByExprs() - Method in class org.apache.drill.exec.physical.config.HashAggregate
 
getGroupRecordCount() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetSchema
Return the Parquet file row count.
getGroupScan() - Method in class org.apache.drill.exec.planner.logical.DrillDirectScanRel
 
getGroupScan() - Method in class org.apache.drill.exec.planner.logical.DrillScanRel
 
getGroupScan() - Method in class org.apache.drill.exec.planner.logical.DrillTable
 
getGroupScan() - Method in interface org.apache.drill.exec.planner.physical.DrillScanPrel
 
getGroupScan() - Method in class org.apache.drill.exec.planner.physical.ScanPrel
 
getGroupScan(String, FileSelection, List<SchemaPath>) - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
getGroupScan(String, FileSelection, List<SchemaPath>) - Method in interface org.apache.drill.exec.store.dfs.FormatPlugin
 
getGroupScan(String, FileSelection, List<SchemaPath>) - Method in class org.apache.drill.exec.store.easy.sequencefile.SequenceFileFormatPlugin
 
getGroupScan(String, FileSelection, List<SchemaPath>) - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin
 
getGroupScan(String, FileSelection, List<SchemaPath>) - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
getGroupScanProperty() - Method in class org.apache.drill.exec.physical.base.ScanStats
Return if GroupScan knows the exact row count in the result of getSize() call.
getHadoopPath() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
getHandle() - Method in class org.apache.drill.exec.ops.FragmentContext
The FragmentHandle for this Fragment
getHandle() - Method in class org.apache.drill.exec.work.foreman.FragmentData
 
getHandle() - Method in class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
getHandle() - Method in interface org.apache.drill.exec.work.fragment.FragmentManager
 
getHandlerRegistry() - Method in class org.apache.drill.exec.work.batch.ControlMessageHandler
 
getHandshakeHandler(ControlConnection) - Method in class org.apache.drill.exec.rpc.control.ControlServer
 
getHandshakeHandler(DataServerConnection) - Method in class org.apache.drill.exec.rpc.data.DataServer
 
getHandshakeHandler(UserServer.BitToUserConnection) - Method in class org.apache.drill.exec.rpc.user.UserServer
 
getHandshakeTimeout() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
getHandshakeTimeout() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
getHandshakeTimeout() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
getHashBuild(int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
getHashCode(int) - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
 
getHashCode(int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
getHashExpression(List<LogicalExpression>, boolean) - Static method in class org.apache.drill.exec.planner.physical.HashPrelUtil
Return a hash expression : hash32(field1, hash32(field2, hash32(field3, 0)));
getHashExpression(List<DrillDistributionTrait.DistributionField>, RelDataType) - Static method in class org.apache.drill.exec.planner.physical.HashPrelUtil
Create a distribution hash expression.
getHashJoinSwapMarginFactor() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getHashProbe(int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
getHeader() - Method in class org.apache.drill.exec.physical.impl.materialize.QueryWritableBatch
 
getHeader() - Method in class org.apache.drill.exec.record.FragmentWritableBatch
 
getHeader() - Method in class org.apache.drill.exec.record.RawFragmentBatch
 
getHeader() - Method in class org.apache.drill.exec.rpc.data.IncomingDataBatch
 
getHeader() - Method in class org.apache.drill.exec.rpc.user.QueryDataBatch
 
getHeaders() - Method in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
 
getHeldRecordBatches() - Method in class org.apache.drill.exec.physical.impl.sort.SortRecordBatchBuilder
 
getHolder(Class<?>) - Static method in class org.apache.drill.exec.compile.sig.SignatureHolder
 
getHolder() - Method in class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
 
getHolder() - Method in class org.apache.drill.exec.expr.DrillFuncHolderExpr
 
getHolder(AnnotatedClassDescriptor, ClassLoader) - Method in class org.apache.drill.exec.expr.fn.FunctionConverter
 
getHolder() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionHolder
 
getHoldersByFunctionName(String, AtomicLong) - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
Returns all function holders associated with function name.
getHoldersByFunctionName(String) - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
Returns all function holders associated with function name without version number.
getHolderType(TypeProtos.MajorType) - Method in class org.apache.drill.exec.expr.ClassGenerator
 
getHolderType(JCodeModel, TypeProtos.MinorType, TypeProtos.DataMode) - Static method in class org.apache.drill.exec.expr.TypeHelper
 
getHomeDirectory() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getHostAffinity() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata
 
getHostAffinity() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v1
 
getHostAffinity() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v2
 
getHostAffinity() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v3
 
getHostName() - Method in class org.apache.drill.exec.server.BootStrapContext
 
getHyperBatch() - Method in interface org.apache.drill.exec.physical.impl.TopN.PriorityQueue
Retrieves the final priority queue HyperBatch containing the results.
getHyperBatch() - Method in class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
 
getId() - Method in class org.apache.drill.exec.ops.OperatorStats
 
getId() - Method in class org.apache.drill.exec.physical.MinorFragmentEndpoint
Get the minor fragment id.
getId() - Method in class org.apache.drill.exec.server.rest.profile.FragmentWrapper
 
getId() - Method in class org.apache.drill.exec.server.rest.profile.OperatorWrapper
 
getIden() - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
Return the ValueHolder identity for this value.
getIdentifierCasing(Casing, boolean) - Static method in class org.apache.drill.exec.work.metadata.ServerMetaProvider.ServerMetaWorker
 
getIdentifierMaxLength() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getIdentity() - Method in class org.apache.drill.exec.ops.FragmentContext
Get this node's identity.
getIdentityService() - Method in class org.apache.drill.exec.server.rest.auth.DrillRestLoginService
 
getIdIfValid(String) - Method in class org.apache.drill.exec.planner.FileSystemPartitionDescriptor
 
getIdIfValid(String) - Method in class org.apache.drill.exec.planner.ParquetPartitionDescriptor
 
getIdIfValid(String) - Method in interface org.apache.drill.exec.planner.PartitionDescriptor
Check to see if the name is a partition name.
getIdMap(Prel) - Static method in class org.apache.drill.exec.planner.physical.explain.PrelSequencer
 
getIgnoreAuthErrors() - Method in class org.apache.drill.exec.store.SchemaConfig
 
GetImage() - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
getImplementationClass(CodeGenerator<?>) - Method in class org.apache.drill.exec.compile.ClassBuilder
Given a code generator which has already generated plain Java code, compile the code, create a class loader, and return the resulting Java class.
getImplementationClass(CodeGenerator<?>) - Method in class org.apache.drill.exec.compile.ClassTransformer
 
getImplementationClass(QueryClassLoader, TemplateClassDefinition<?>, String, String) - Method in class org.apache.drill.exec.compile.ClassTransformer
 
getImplementationClass(ClassGenerator<T>) - Method in class org.apache.drill.exec.ops.BaseFragmentContext
 
getImplementationClass(CodeGenerator<T>) - Method in class org.apache.drill.exec.ops.BaseFragmentContext
 
getImplementationClass(ClassGenerator<T>, int) - Method in class org.apache.drill.exec.ops.BaseFragmentContext
 
getImplementationClass(CodeGenerator<T>, int) - Method in class org.apache.drill.exec.ops.BaseFragmentContext
 
getImplementationClass(ClassGenerator<T>) - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
Generates code for a class given a ClassGenerator, and returns a single instance of the generated class.
getImplementationClass(CodeGenerator<T>) - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
Generates code for a class given a CodeGenerator, and returns a single instance of the generated class.
getImplementationClass(ClassGenerator<T>, int) - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
Generates code for a class given a ClassGenerator, and returns the specified number of instances of the generated class.
getImplementationClass(CodeGenerator<T>, int) - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
Generates code for a class given a CodeGenerator, and returns the specified number of instances of the generated class.
getImports() - Method in class org.apache.drill.exec.expr.fn.FunctionInitializer
 
getImports(Java.CompilationUnit) - Static method in class org.apache.drill.exec.expr.fn.ImportGrabber
Creates list of imports that are present in compilation unit.
getIncoming() - Method in class org.apache.drill.exec.compile.sig.MappingSet
 
getIncoming() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
getIncomingCount() - Method in class org.apache.drill.exec.ops.OpProfileDef
 
getIndex() - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
Get the original local variable slot assigned to this value/holder.
getIndex(int) - Method in class org.apache.drill.exec.record.selection.SelectionVector2
 
getIndexOrderedEndpoints(List<CoordinationProtos.DrillbitEndpoint>) - Static method in class org.apache.drill.exec.physical.base.PhysicalOperatorUtil
Helper method to create a list of MinorFragmentEndpoint instances from a given endpoint assignment list.
getInfo() - Method in class org.apache.drill.exec.planner.fragment.Materializer.IndexedFragmentNode
 
getInfo() - Method in class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue
 
getInitialAllocation() - Method in class org.apache.drill.exec.physical.base.AbstractBase
 
getInitialAllocation() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
getInitialAllocation() - Method in interface org.apache.drill.exec.physical.base.PhysicalOperator
 
getInitialAllocation() - Method in class org.apache.drill.exec.planner.fragment.Wrapper
 
getInitialAllocation() - Method in class org.apache.drill.exec.store.sys.SystemTableScan
 
getInitialCapacity() - Method in class org.apache.drill.exec.physical.impl.common.HashTableConfig
 
getInitialCommand(RpcCommand<M, ControlConnection>) - Method in class org.apache.drill.exec.rpc.control.ControlClient
 
getInitialCommand(RpcCommand<M, DataClientConnection>) - Method in class org.apache.drill.exec.rpc.data.DataClient
 
getInitialPlanningMemorySize() - Static method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getInjector() - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
getInjector() - Method in interface org.apache.drill.exec.ops.OperatorContext
Returns the fault injection mechanism used to introduce faults at runtime for testing.
getInjector(Class<?>) - Static method in class org.apache.drill.exec.testing.ControlsInjectorFactory
Returns an ExecutionControlsInjector if assertions are not enabled, or NoOpControlsInjector otherwise.
getInnerGenerator(String) - Method in class org.apache.drill.exec.expr.ClassGenerator
 
getInnerRecordCount() - Method in class org.apache.drill.exec.record.RecordIterator
 
getInputBatchCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
 
getInputBatchSize() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
getInputBytes() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
 
getInputParameters() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
Generates string representation of function input parameters: PARAMETER_TYPE_1-PARAMETER_MODE_1,PARAMETER_TYPE_2-PARAMETER_MODE_2 Example: VARCHAR-REQUIRED,VARCHAR-OPTIONAL Returns empty string if function has no input parameters.
getInputRewriter() - Method in class org.apache.drill.exec.planner.physical.PrelUtil.ProjectPushInfo
 
getInputRowCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
 
getInputStream() - Method in class org.apache.drill.exec.store.parquet.ColumnDataReader
 
getInputStream() - Method in class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
getInstance(CodeGenerator<T>, Logger) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BaseWrapper
 
getInstance(boolean, RelFactories.ProjectFactory, FunctionImplementationRegistry) - Static method in class org.apache.drill.exec.planner.logical.DrillMergeProjectRule
 
getInstance() - Static method in class org.apache.drill.exec.rpc.control.ControlRpcMetrics
 
getInstance() - Static method in class org.apache.drill.exec.rpc.data.DataRpcMetrics
 
getInstance() - Static method in class org.apache.drill.exec.rpc.security.ClientAuthenticatorProvider
 
getInstance() - Static method in class org.apache.drill.exec.rpc.security.FastSaslClientFactory
 
getInstance() - Static method in class org.apache.drill.exec.rpc.security.FastSaslServerFactory
 
getInstance() - Static method in class org.apache.drill.exec.rpc.user.UserRpcMetrics
 
getInSubqueryThreshold() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getInt(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getInt(byte[], int) - Static method in class org.apache.drill.exec.store.pcap.PcapFormatUtils
 
getInt(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getInt(int) - Method in class org.apache.drill.exec.vector.accessor.BitAccessor
 
getInt(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getInt(int) - Method in class org.apache.drill.exec.vector.accessor.IntAccessor
 
getInt(int) - Method in class org.apache.drill.exec.vector.accessor.NullableBitAccessor
 
getInt(int) - Method in class org.apache.drill.exec.vector.accessor.NullableIntAccessor
 
getInt(int) - Method in class org.apache.drill.exec.vector.accessor.NullableUInt4Accessor
 
getInt(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getInt(int) - Method in class org.apache.drill.exec.vector.accessor.UInt4Accessor
 
getInt(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
getIntermediateClass() - Method in class org.apache.drill.exec.record.TypedFieldId
Return the class for the value vector (type, mode).
getIntermediateType() - Method in class org.apache.drill.exec.record.TypedFieldId
 
getInternalOptionList() - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
getInternalOptionList() - Method in interface org.apache.drill.exec.server.options.OptionManager
Returns all the internal options contained in this option manager.
getInterpreter() - Method in class org.apache.drill.exec.expr.DrillFuncHolderExpr
 
getIntervalQualifier() - Method in class org.apache.drill.exec.dotdrill.View.FieldType
Gets the interval type qualifier of the interval data type descriptor of this field (iff interval type).
getIntFileOrder(boolean, byte[], int) - Static method in class org.apache.drill.exec.store.pcap.PcapFormatUtils
 
getIntFromLEBytes(byte[], int) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
 
getIntLittleEndian(long) - Static method in class org.apache.drill.exec.expr.fn.impl.DrillHash
 
getIo() - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
getIsNullable() - Method in class org.apache.drill.exec.dotdrill.View.FieldType
Gets the nullability of the data type desription of this field.
getIsSet() - Method in class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
 
getIterator(FragmentContext) - Method in enum org.apache.drill.exec.store.sys.SystemTable
 
getJar() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateFunction
 
getJar() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropFunction
 
getJarName() - Method in class org.apache.drill.exec.expr.fn.registry.JarScan
 
getJarNameByFunctionSignature(String, String) - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
Looks which jar in FunctionRegistryHolder.jars contains passed function signature.
getJavaPatternString() - Method in class org.apache.drill.exec.expr.fn.impl.RegexpUtil.SqlPatternInfo
 
getJdbcTableType() - Method in class org.apache.drill.exec.planner.logical.DrillTable
 
getJdbcTableType() - Method in class org.apache.drill.exec.planner.logical.DrillTranslatableTable
 
getJdbcTableType() - Method in class org.apache.drill.exec.planner.logical.DrillViewTable
 
getJoinCategory(RelNode, RelNode, RexNode, List<Integer>, List<Integer>, List<Boolean>) - Static method in class org.apache.drill.exec.physical.impl.join.JoinUtils
 
getJoinInput(int, RelNode) - Method in class org.apache.drill.exec.planner.physical.JoinPrel
Check to make sure that the fields of the inputs are the same as the output field names.
getJoinType() - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
 
getJoinType() - Method in class org.apache.drill.exec.physical.config.MergeJoinPOP
 
getJoinType() - Method in class org.apache.drill.exec.physical.config.NestedLoopJoinPOP
 
getJoinType() - Method in class org.apache.drill.exec.physical.impl.join.MergeJoinBatch
 
getKey() - Method in class org.apache.drill.exec.coord.store.TransientStoreEvent
 
getKeyClass() - Method in class org.apache.drill.exec.cache.DistributedCache.CacheConfig
 
getKeyExprsBuild() - Method in class org.apache.drill.exec.physical.impl.common.HashTableConfig
 
getKeyExprsProbe() - Method in class org.apache.drill.exec.physical.impl.common.HashTableConfig
 
getKeyMatchBitVector() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelper.BuildInfo
 
getKeyPassword() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
getKeyPassword() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
getKeyPassword() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
getKeys() - Method in class org.apache.drill.exec.physical.config.StreamingAggregate
 
getKeys() - Method in class org.apache.drill.exec.planner.physical.AggPrelBase
 
getKeyStorePassword() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
getKeyStorePassword() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
getKeyStorePassword() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
getKeyStorePath() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
getKeyStorePath() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
getKeyStorePath() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
getKeyStoreType() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
getKeyStoreType() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
getKeyStoreType() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
getKind() - Method in class org.apache.drill.exec.server.options.OptionValidator
Gets the kind of this option value for this validator.
getKind() - Method in class org.apache.drill.exec.server.options.PersistedOptionValue
This is present for forward compatibility.
getKind() - Method in class org.apache.drill.exec.server.options.TypeValidators.TypeValidator
 
getKind() - Method in class org.apache.drill.exec.server.rest.StatusResources.OptionWrapper
 
getLast() - Method in class org.apache.drill.exec.physical.config.Limit
 
getLastLineNumber() - Method in class org.apache.drill.exec.compile.bytecode.InstructionModifier
 
getLastModified() - Method in class org.apache.drill.exec.server.rest.LogsResources.Log
 
getLastOutcome() - Method in class org.apache.drill.exec.record.RecordIterator
 
getLastSegment() - Method in class org.apache.drill.exec.record.TypedFieldId
 
getLastUsedColumnReference(List<RexNode>) - Static method in class org.apache.drill.exec.planner.physical.PrelUtil
 
getLatch(ExecutionControls, String) - Method in interface org.apache.drill.exec.testing.ControlsInjector
Used to insert a latch in site class.
getLatch(ExecutionControls, String) - Method in class org.apache.drill.exec.testing.ExecutionControlsInjector
 
getLatch(ExecutionControls, String) - Method in class org.apache.drill.exec.testing.NoOpControlsInjector
 
getLeastRestrictiveDataMode(List<TypeProtos.DataMode>) - Static method in class org.apache.drill.exec.resolver.TypeCastRules
 
getLeastRestrictiveType(List<TypeProtos.MinorType>) - Static method in class org.apache.drill.exec.resolver.TypeCastRules
 
getLeft() - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
 
getLeft() - Method in class org.apache.drill.exec.physical.config.MergeJoinPOP
 
getLeft() - Method in class org.apache.drill.exec.physical.config.NestedLoopJoinPOP
 
getLeftKeys() - Method in class org.apache.drill.exec.planner.common.DrillJoinRelBase
 
getLeftStatus() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
getLength() - Method in class org.apache.drill.exec.expr.fn.impl.DrillByteArray
 
getLength() - Method in class org.apache.drill.exec.physical.impl.window.Partition
 
getLength(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
Deprecated.
getLength() - Method in interface org.apache.drill.exec.store.dfs.easy.FileWork
 
getLength() - Method in class org.apache.drill.exec.store.dfs.ReadEntryFromHDFS
 
getLength() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata
 
getLength() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v1
 
getLength() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v2
 
getLength() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v3
 
getLength() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata
 
getLength() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v1
 
getLength() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v2
 
getLength() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v3
 
getLength() - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork.FileWorkImpl
 
getLength() - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork
 
getLengthForMinorType(TypeProtos.MinorType) - Static method in class org.apache.drill.exec.store.parquet.ParquetTypeHelper
 
getLikePattern() - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowSchemas
 
getLikePattern() - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowTables
 
getLimit() - Method in class org.apache.drill.exec.physical.config.TopN
 
getLine() - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
Deprecated. 
getLineDelimiter() - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
getLines() - Method in class org.apache.drill.exec.server.rest.LogsResources.LogContent
 
getLineSeparatorString() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
getLink() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.ProfileInfo
 
getLinks() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelper.BuildInfo
 
getLinkTarget(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getLiterals() - Method in enum org.apache.drill.exec.expr.BooleanType
 
getLoadFactor() - Method in class org.apache.drill.exec.physical.impl.common.HashTableConfig
 
getLocalEntries() - Method in interface org.apache.drill.exec.cache.DistributedMap
 
getLocalServiceSet() - Static method in class org.apache.drill.exec.server.RemoteServiceSet
 
getLocation() - Method in class org.apache.drill.exec.store.dfs.easy.EasyWriter
 
getLocation() - Method in class org.apache.drill.exec.store.dfs.WorkspaceConfig
 
getLocation() - Method in class org.apache.drill.exec.store.parquet.ParquetWriter
 
getLog(String) - Method in class org.apache.drill.exec.server.rest.LogsResources
 
getLogDir() - Static method in class org.apache.drill.exec.store.sys.store.LocalPersistentStore
 
getLogFormat() - Method in class org.apache.drill.exec.store.httpd.HttpdLogFormatPlugin.HttpdLogFormatConfig
 
getLogger() - Method in class org.apache.drill.exec.compile.AbstractClassCompiler
 
getLogger() - Method in class org.apache.drill.exec.rpc.AbstractClientConnection
 
getLogger() - Method in class org.apache.drill.exec.rpc.AbstractServerConnection
 
getLogger() - Method in class org.apache.drill.exec.rpc.control.ControlConnection
 
getLogger() - Method in class org.apache.drill.exec.rpc.data.DataClientConnection
 
getLogger() - Method in class org.apache.drill.exec.rpc.data.DataServerConnection
 
getLogger() - Method in class org.apache.drill.exec.rpc.user.UserClient.UserToBitConnection
 
getLogger() - Method in class org.apache.drill.exec.rpc.user.UserServer.BitToUserConnection
 
getLogicalOptimizerRules(OptimizerRulesContext) - Method in class org.apache.drill.exec.store.AbstractStoragePlugin
Deprecated.
Marking for deprecation in next major version release. Use #getPhysicalOptimizerRules(org.apache.drill.exec.ops.OptimizerRulesContext, org.apache.drill.exec.planner.PlannerPhase)
getLogicalTraits() - Method in class org.apache.drill.exec.planner.torel.ConversionContext
 
getLoginPage(HttpServletRequest, HttpServletResponse, SecurityContext, UriInfo, String) - Method in class org.apache.drill.exec.server.rest.LogInLogOutResources
 
getLoginPageAfterValidationError() - Method in class org.apache.drill.exec.server.rest.LogInLogOutResources
 
getLogJSON(String) - Method in class org.apache.drill.exec.server.rest.LogsResources
 
getLogs() - Method in class org.apache.drill.exec.server.rest.LogsResources
 
getLogsJSON() - Method in class org.apache.drill.exec.server.rest.LogsResources
 
getLong(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getLong(String) - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
getLong(String) - Method in interface org.apache.drill.exec.server.options.OptionSet
Return the value of a long option.
getLong(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getLong(int) - Method in class org.apache.drill.exec.vector.accessor.BigIntAccessor
 
getLong(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getLong(int) - Method in class org.apache.drill.exec.vector.accessor.NullableBigIntAccessor
 
getLong(int) - Method in class org.apache.drill.exec.vector.accessor.NullableUInt8Accessor
 
getLong(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getLong(int) - Method in class org.apache.drill.exec.vector.accessor.UInt8Accessor
 
getLong(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
getLongLittleEndian(long) - Static method in class org.apache.drill.exec.expr.fn.impl.DrillHash
 
getLongs() - Method in class org.apache.drill.exec.store.httpd.HttpdLogRecord
 
getLpPersistence() - Method in class org.apache.drill.exec.ops.QueryContext
 
getLpPersistence() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getMajor() - Method in class org.apache.drill.exec.store.parquet.MetadataVersion
 
getMajorFragmentId() - Method in class org.apache.drill.exec.planner.fragment.Wrapper
 
getMajorType() - Method in class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
 
getMajorType() - Method in class org.apache.drill.exec.expr.DrillFuncHolderExpr
 
getMajorType() - Method in class org.apache.drill.exec.expr.fn.WorkspaceReference
 
getMajorType() - Method in class org.apache.drill.exec.expr.HoldingContainerExpression
 
getMajorType() - Method in class org.apache.drill.exec.expr.stat.TypedFieldExpr
 
getMajorType() - Method in class org.apache.drill.exec.expr.ValueVectorReadExpression
 
getMajorType() - Method in class org.apache.drill.exec.expr.ValueVectorWriteExpression
 
getMajorType() - Method in class org.apache.drill.exec.physical.impl.filter.ReturnValueExpression
 
getMajorType() - Method in class org.apache.drill.exec.record.MajorTypeSerDe.MajorTypeHolder
 
getMajorType() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
getMajorType() - Method in class org.apache.drill.exec.store.parquet.stat.ColumnStatistics
 
getMajorVersion() - Static method in class org.apache.drill.common.util.DrillVersionInfo
Get the Drill major version from pom
getManagedBuffer() - Method in class org.apache.drill.exec.ops.BaseFragmentContext
 
getManagedBuffer(int) - Method in class org.apache.drill.exec.ops.BaseFragmentContext
 
getManagedBuffer() - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
getManagedBuffer(int) - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
getManagedBuffer() - Method in class org.apache.drill.exec.ops.BufferManagerImpl
 
getManagedBuffer(int) - Method in class org.apache.drill.exec.ops.BufferManagerImpl
 
getManagedBuffer() - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
 
getManagedBuffer(int) - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
 
getManagedBuffer() - Method in interface org.apache.drill.exec.ops.OperatorContext
 
getManagedBuffer(int) - Method in interface org.apache.drill.exec.ops.OperatorContext
 
getManagedBuffer() - Method in class org.apache.drill.exec.ops.QueryContext
 
getManagedBuffer() - Method in interface org.apache.drill.exec.ops.UdfUtilities
For UDFs to allocate general purpose intermediate buffers we provide the DrillBuf type as an injectable, which provides access to an off-heap buffer that can be tracked by Drill and re-allocated as needed.
getManagedBuffer() - Method in interface org.apache.drill.exec.physical.impl.OutputMutator
Allows a scanner to request a set of managed block of memory.
getManagedBuffer() - Method in class org.apache.drill.exec.physical.impl.ScanBatch.Mutator
 
getMap(DistributedCache.CacheConfig<K, V>) - Method in interface org.apache.drill.exec.cache.DistributedCache
 
getMapping(DrillConfig, Executor) - Static method in class org.apache.drill.exec.rpc.control.ControlRpcConfig
 
getMapping(DrillConfig, Executor) - Static method in class org.apache.drill.exec.rpc.data.DataRpcConfig
 
getMapping(DrillConfig, Executor) - Static method in class org.apache.drill.exec.rpc.user.UserRpcConfig
 
getMappings(List<CoordinationProtos.DrillbitEndpoint>, List<T>) - Static method in class org.apache.drill.exec.store.schedule.AssignmentCreator
Assign each unit of work to a minor fragment, given that a list of DrillbitEndpoints, whose index in the list correspond to the minor fragment id for each fragment.
getMappingSet() - Method in class org.apache.drill.exec.expr.ClassGenerator
 
getMapVector() - Method in class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
 
getMatcher() - Method in class org.apache.drill.exec.store.avro.AvroFormatPlugin
 
getMatcher() - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
getMatcher() - Method in interface org.apache.drill.exec.store.dfs.FormatPlugin
 
getMatcher() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
getMatcher() - Method in class org.apache.drill.exec.store.pcap.PcapFormatPlugin
 
getMaterializedClassName() - Method in class org.apache.drill.exec.expr.CodeGenerator
 
getMax() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
getMaxAllocation() - Method in class org.apache.drill.exec.physical.base.AbstractBase
 
getMaxAllocation() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
getMaxAllocation() - Method in interface org.apache.drill.exec.physical.base.PhysicalOperator
 
getMaxAllocation() - Method in class org.apache.drill.exec.planner.fragment.Wrapper
 
getMaxAllocation() - Method in class org.apache.drill.exec.store.sys.SystemTableScan
 
getMaxBytes() - Method in interface org.apache.drill.exec.store.schedule.EndpointByteMap
 
getMaxBytes() - Method in class org.apache.drill.exec.store.schedule.EndpointByteMapImpl
 
getMaxCharsPerColumn() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
getMaxCost() - Method in class org.apache.drill.exec.planner.fragment.Stats
 
getMaxFetchedQueries() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.QProfiles
 
getMaxGlobalWidth() - Method in interface org.apache.drill.exec.planner.fragment.ParallelizationParameters
 
getMaxGlobalWidth() - Method in class org.apache.drill.exec.planner.fragment.SimpleParallelizer
 
getMaxHierarchyLevel() - Method in class org.apache.drill.exec.planner.FileSystemPartitionDescriptor
 
getMaxHierarchyLevel() - Method in class org.apache.drill.exec.planner.ParquetPartitionDescriptor
 
getMaxHierarchyLevel() - Method in interface org.apache.drill.exec.planner.PartitionDescriptor
 
getMaxLines() - Method in class org.apache.drill.exec.server.rest.LogsResources.LogContent
 
getMaxNumericPrecision() - Method in class org.apache.drill.exec.planner.types.DrillRelDataTypeSystem
 
getMaxNumericScale() - Method in class org.apache.drill.exec.planner.types.DrillRelDataTypeSystem
 
getMaxParallelizationWidth() - Method in interface org.apache.drill.exec.physical.base.GroupScan
 
getMaxParallelizationWidth() - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
getMaxParallelizationWidth() - Method in class org.apache.drill.exec.store.direct.DirectGroupScan
 
getMaxParallelizationWidth() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaGroupScan
 
getMaxParallelizationWidth() - Method in class org.apache.drill.exec.store.mock.MockGroupScanPOP
 
getMaxParallelizationWidth() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
getMaxParallelizationWidth() - Method in class org.apache.drill.exec.store.sys.SystemTableScan
 
getMaxValue() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata
 
getMaxValue() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
getMaxValue() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2
 
getMaxValue() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3
 
getMaxWidth() - Method in interface org.apache.drill.exec.physical.base.Store
The maximum allowable width for the Store operation.
getMaxWidth() - Method in class org.apache.drill.exec.physical.config.Screen
 
getMaxWidth() - Method in class org.apache.drill.exec.physical.EndpointAffinity
 
getMaxWidth() - Method in class org.apache.drill.exec.planner.fragment.ParallelizationInfo
 
getMaxWidth() - Method in class org.apache.drill.exec.store.mock.MockStorePOP
 
getMaxWidthPerNode() - Method in interface org.apache.drill.exec.planner.fragment.ParallelizationParameters
 
getMaxWidthPerNode() - Method in class org.apache.drill.exec.planner.fragment.SimpleParallelizer
 
getMechanismNames(Map<String, ?>) - Method in class org.apache.drill.exec.rpc.security.FastSaslClientFactory
 
getMechanismNames(Map<String, ?>) - Method in class org.apache.drill.exec.rpc.security.FastSaslServerFactory
 
getMedium(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getMemory() - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
getMemoryLimit() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
getMergeBatchRowCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
getMergeBatchSize() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
getMergeCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
 
getMergeMemoryLimit() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
getMessage() - Method in exception org.apache.drill.exec.planner.sql.parser.impl.ParseException
This method has the standard behavior when this object has been created using the standard constructors.
getMessage() - Method in error org.apache.drill.exec.planner.sql.parser.impl.TokenMgrError
You can also modify the body of this method to customize your error messages.
getMessage() - Method in interface org.apache.drill.exec.rpc.control.Controller.CustomResponse
The structured portion of the response.
getMetaContext() - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
getMetadata() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
getMetaData() - Method in class org.apache.drill.exec.server.options.OptionDefinition
 
getMetadataVersion() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v1
 
getMetadataVersion() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
getMetadataVersion() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
getMetadataVersion() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataBase
 
getMethod(String) - Method in class org.apache.drill.exec.expr.fn.FunctionInitializer
 
getMethodName() - Method in class org.apache.drill.exec.compile.sig.CodeGeneratorMethod
 
getMethodName(ClassGenerator.BlockType) - Method in class org.apache.drill.exec.compile.sig.GeneratorMapping
 
getMethods(Java.CompilationUnit, Class<?>) - Static method in class org.apache.drill.exec.expr.fn.MethodGrabbingVisitor
 
getMethods(String, AtomicLong) - Method in class org.apache.drill.exec.expr.fn.registry.LocalFunctionRegistry
 
getMethods(String) - Method in class org.apache.drill.exec.expr.fn.registry.LocalFunctionRegistry
 
getMetricNames(int) - Static method in class org.apache.drill.exec.ops.OperatorMetricRegistry
Given an operator type, this method returns an array of metric names (indexable by metric id).
getMetrics() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl
 
getMetrics() - Method in class org.apache.drill.exec.server.BootStrapContext
 
getMetrics() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getMetrics() - Method in class org.apache.drill.exec.server.rest.MetricsResources
 
getMetrics() - Method in class org.apache.drill.exec.server.rest.ThreadsResources
 
getMetricsTable() - Method in class org.apache.drill.exec.server.rest.profile.OperatorWrapper
 
getMin() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
getMinor() - Method in class org.apache.drill.exec.store.parquet.MetadataVersion
 
getMinorFragmentDefns() - Method in class org.apache.drill.exec.work.QueryWorkUnit
 
getMinorFragmentId() - Method in class org.apache.drill.exec.planner.fragment.Materializer.IndexedFragmentNode
 
getMinorType() - Method in class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
 
getMinorType() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
getMinorVersion() - Static method in class org.apache.drill.common.util.DrillVersionInfo
Get the Drill minor version from pom
getMinParallelizationWidth() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
getMinParallelizationWidth() - Method in interface org.apache.drill.exec.physical.base.GroupScan
At minimum, the GroupScan requires these many fragments to run.
getMinParallelizationWidth() - Method in class org.apache.drill.exec.store.sys.SystemTableScan
 
getMinValue() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata
 
getMinValue() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
getMinValue() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2
 
getMinValue() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3
 
getMinVersion() - Method in enum org.apache.drill.exec.client.ServerMethod
 
getMinWidth() - Method in class org.apache.drill.exec.planner.fragment.ParallelizationInfo
 
getMismatchedVersions() - Method in class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
 
getMode() - Method in class org.apache.drill.exec.cache.DistributedCache.CacheConfig
 
getMode() - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
 
getMode() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
getMode() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
getMode() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
getMode() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
getMode() - Method in interface org.apache.drill.exec.store.sys.PersistentStore
Returns storage mode of this store.
getMode() - Method in class org.apache.drill.exec.store.sys.PersistentStoreConfig
 
getMode() - Method in class org.apache.drill.exec.store.sys.store.InMemoryStore
 
getMode() - Method in class org.apache.drill.exec.store.sys.store.LocalPersistentStore
 
getMode() - Method in class org.apache.drill.exec.store.sys.store.ZookeeperPersistentStore
 
getMode() - Method in class org.apache.drill.exec.testing.store.NoWriteLocalStore
 
getModel() - Method in class org.apache.drill.exec.expr.ClassGenerator
 
getMonotonicity(SqlOperatorBinding) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
getMonotonicity(SqlOperatorBinding) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
getMonotonicity(SqlOperatorBinding) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
getMSortBatchSize() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
 
getMultiMap(DistributedCache.CacheConfig<K, V>) - Method in interface org.apache.drill.exec.cache.DistributedCache
 
getName() - Method in class org.apache.drill.exec.cache.DistributedCache.CacheConfig
 
getName() - Method in class org.apache.drill.exec.compile.sig.CodeGeneratorArgument
 
getName() - Method in class org.apache.drill.exec.coord.store.TransientStoreConfig
 
getName() - Method in class org.apache.drill.exec.dotdrill.View.FieldType
Gets the name of this field.
getName() - Method in class org.apache.drill.exec.dotdrill.View
 
getName() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionHolder
 
getName() - Method in class org.apache.drill.exec.expr.fn.ValueReference
 
getName() - Method in class org.apache.drill.exec.expr.fn.WorkspaceReference
 
getName() - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
getName(int) - Method in class org.apache.drill.exec.planner.FileSystemPartitionDescriptor
 
getName() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateTable
 
getName() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateView
 
getName() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropTable
 
getName() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropView
 
getName() - Method in class org.apache.drill.exec.planner.sql.parser.SqlRefreshMetadata
 
getName() - Method in interface org.apache.drill.exec.rpc.ConnectionConfig
 
getName() - Method in class org.apache.drill.exec.server.options.OptionValue
 
getName() - Method in class org.apache.drill.exec.server.options.PersistedOptionValue
This is present for forward compatibility.
getName() - Method in class org.apache.drill.exec.server.rest.auth.DrillRestLoginService
 
getName() - Method in class org.apache.drill.exec.server.rest.auth.DrillUserPrincipal
 
getName() - Method in class org.apache.drill.exec.server.rest.LogsResources.Log
 
getName() - Method in class org.apache.drill.exec.server.rest.LogsResources.LogContent
 
getName() - Method in class org.apache.drill.exec.server.rest.PluginConfigWrapper
 
getName() - Method in class org.apache.drill.exec.server.rest.StatusResources.OptionWrapper
 
getName() - Method in class org.apache.drill.exec.store.AbstractSchema
 
getName() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
Deprecated.
getName() - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
getName() - Method in interface org.apache.drill.exec.store.dfs.FormatPlugin
 
getName() - Method in class org.apache.drill.exec.store.mock.ColumnDef
 
getName() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
getName() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata
 
getName() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
getName() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2
 
getName() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3
 
getName() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
getName() - Method in class org.apache.drill.exec.store.sys.PersistentStoreConfig
 
getNestedLoopJoinFactor() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getNettySslContext() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
getNetwork() - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
getNetwork() - Method in interface org.apache.drill.exec.planner.cost.DrillRelOptCost
 
getNetwork() - Method in class org.apache.drill.exec.store.pcap.decoder.PacketDecoder
 
getNewBigIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewBigIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewBigIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewBigIntConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewBigIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewBitConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewBitConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewBitConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewBitConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewBitConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewChildAllocator(String, int, long, long) - Method in class org.apache.drill.exec.ops.FragmentContext
 
getNewClient() - Method in class org.apache.drill.exec.rpc.control.ControlConnectionManager
 
getNewClient() - Method in class org.apache.drill.exec.rpc.data.DataConnectionManager
 
getNewDateConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewDateConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewDateConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewDateConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewDateConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewDecimal18Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewDecimal18Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewDecimal18Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewDecimal18Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewDecimal18Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewDecimal28DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewDecimal28DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewDecimal28DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewDecimal28DenseConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewDecimal28DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewDecimal28SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewDecimal28SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewDecimal28SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewDecimal28SparseConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewDecimal28SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewDecimal38DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewDecimal38DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewDecimal38DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewDecimal38DenseConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewDecimal38DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewDecimal38SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewDecimal38SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewDecimal38SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewDecimal38SparseConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewDecimal38SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewDecimal9Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewDecimal9Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewDecimal9Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewDecimal9Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewDecimal9Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewDefaultSchema() - Method in class org.apache.drill.exec.ops.QueryContext
Return reference to default schema instance in a schema tree.
getNewFloat4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewFloat4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewFloat4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewFloat4Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewFloat4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewFloat8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewFloat8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewFloat8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewFloat8Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewFloat8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewIncoming() - Method in interface org.apache.drill.exec.physical.impl.aggregate.HashAggregator
 
getNewIncoming() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
get new incoming: (when reading spilled files like an "incoming")
getNewIndex() - Method in class org.apache.drill.exec.planner.physical.PrelUtil.InputRefRemap
 
getNewIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewIntConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewIntervalConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewIntervalConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewIntervalConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewIntervalConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewIntervalConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewIntervalDayConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewIntervalDayConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewIntervalDayConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewIntervalDayConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewIntervalDayConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewIntervalYearConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewIntervalYearConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewIntervalYearConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewIntervalYearConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewIntervalYearConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewLineDelimiter() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
getNewMapConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewMapConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter
 
getNewMapConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
 
getNewMapConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewMapConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewMapConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.text.DrillTextRecordWriter
 
getNewNullableBigIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableBigIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableBigIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableBigIntConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableBigIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableBitConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableBitConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableBitConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableBitConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableBitConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableDateConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableDateConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableDateConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableDateConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableDateConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableDecimal18Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableDecimal18Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableDecimal18Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableDecimal18Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableDecimal18Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableDecimal28DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableDecimal28DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableDecimal28DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableDecimal28DenseConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableDecimal28DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableDecimal28SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableDecimal28SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableDecimal28SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableDecimal28SparseConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableDecimal28SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableDecimal38DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableDecimal38DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableDecimal38DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableDecimal38DenseConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableDecimal38DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableDecimal38SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableDecimal38SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableDecimal38SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableDecimal38SparseConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableDecimal38SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableDecimal9Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableDecimal9Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableDecimal9Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableDecimal9Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableDecimal9Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableFloat4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableFloat4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableFloat4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableFloat4Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableFloat4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableFloat8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableFloat8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableFloat8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableFloat8Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableFloat8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableIntConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableIntervalConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableIntervalConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableIntervalConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableIntervalConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableIntervalConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableIntervalDayConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableIntervalDayConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableIntervalDayConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableIntervalDayConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableIntervalDayConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableIntervalYearConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableIntervalYearConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableIntervalYearConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableIntervalYearConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableIntervalYearConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableSmallIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableSmallIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableSmallIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableSmallIntConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableSmallIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableTimeConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableTimeConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableTimeConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableTimeConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableTimeConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableTimeStampConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableTimeStampConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableTimeStampConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableTimeStampConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableTimeStampConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableTinyIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableTinyIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableTinyIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableTinyIntConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableTinyIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableUInt1Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableUInt1Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableUInt1Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableUInt1Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableUInt1Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableUInt2Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableUInt2Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableUInt2Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableUInt2Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableUInt2Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableUInt4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableUInt4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableUInt4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableUInt4Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableUInt4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableUInt8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableUInt8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableUInt8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableUInt8Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableUInt8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableVar16CharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableVar16CharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableVar16CharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableVar16CharConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableVar16CharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableVarBinaryConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableVarBinaryConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableVarBinaryConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableVarBinaryConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableVarBinaryConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewNullableVarCharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewNullableVarCharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewNullableVarCharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewNullableVarCharConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewNullableVarCharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedBigIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedBigIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedBigIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedBigIntConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedBigIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedBitConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedBitConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedBitConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedBitConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedBitConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedDateConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedDateConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedDateConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedDateConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedDateConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedDecimal18Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedDecimal18Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedDecimal18Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedDecimal18Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedDecimal18Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedDecimal28DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedDecimal28DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedDecimal28DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedDecimal28DenseConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedDecimal28DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedDecimal28SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedDecimal28SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedDecimal28SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedDecimal28SparseConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedDecimal28SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedDecimal38DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedDecimal38DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedDecimal38DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedDecimal38DenseConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedDecimal38DenseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedDecimal38SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedDecimal38SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedDecimal38SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedDecimal38SparseConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedDecimal38SparseConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedDecimal9Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedDecimal9Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedDecimal9Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedDecimal9Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedDecimal9Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedFloat4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedFloat4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedFloat4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedFloat4Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedFloat4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedFloat8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedFloat8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedFloat8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedFloat8Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedFloat8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedIntConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedIntervalConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedIntervalConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedIntervalConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedIntervalConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedIntervalConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedIntervalDayConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedIntervalDayConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedIntervalDayConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedIntervalDayConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedIntervalDayConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedIntervalYearConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedIntervalYearConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedIntervalYearConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedIntervalYearConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedIntervalYearConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedListConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedListConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter
 
getNewRepeatedListConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
 
getNewRepeatedListConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedListConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.text.DrillTextRecordWriter
 
getNewRepeatedMapConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedMapConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter
 
getNewRepeatedMapConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
 
getNewRepeatedMapConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
 
getNewRepeatedMapConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedMapConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.text.DrillTextRecordWriter
 
getNewRepeatedSmallIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedSmallIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedSmallIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedSmallIntConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedSmallIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedTimeConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedTimeConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedTimeConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedTimeConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedTimeConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedTimeStampConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedTimeStampConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedTimeStampConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedTimeStampConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedTimeStampConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedTinyIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedTinyIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedTinyIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedTinyIntConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedTinyIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedUInt1Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedUInt1Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedUInt1Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedUInt1Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedUInt1Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedUInt2Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedUInt2Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedUInt2Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedUInt2Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedUInt2Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedUInt4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedUInt4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedUInt4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedUInt4Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedUInt4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedUInt8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedUInt8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedUInt8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedUInt8Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedUInt8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedVar16CharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedVar16CharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedVar16CharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedVar16CharConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedVar16CharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedVarBinaryConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedVarBinaryConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedVarBinaryConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedVarBinaryConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedVarBinaryConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewRepeatedVarCharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewRepeatedVarCharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewRepeatedVarCharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewRepeatedVarCharConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewRepeatedVarCharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewSmallIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewSmallIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewSmallIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewSmallIntConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewSmallIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewStat() - Method in class org.apache.drill.exec.planner.physical.visitor.ExcessiveExchangeIdentifier
 
getNewSV4(int) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelper
 
getNewTimeConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewTimeConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewTimeConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewTimeConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewTimeConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewTimeStampConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewTimeStampConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewTimeStampConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewTimeStampConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewTimeStampConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewTinyIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewTinyIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewTinyIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewTinyIntConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewTinyIntConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewUInt1Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewUInt1Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewUInt1Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewUInt1Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewUInt1Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewUInt2Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewUInt2Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewUInt2Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewUInt2Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewUInt2Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewUInt4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewUInt4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewUInt4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewUInt4Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewUInt4Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewUInt8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewUInt8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewUInt8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewUInt8Converter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewUInt8Converter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewUnionConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewUnionConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter
 
getNewUnionConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
 
getNewVar16CharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewVar16CharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewVar16CharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewVar16CharConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewVar16CharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewVarBinaryConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewVarBinaryConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewVarBinaryConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewVarBinaryConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewVarBinaryConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewVarCharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
getNewVarCharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
getNewVarCharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
getNewVarCharConverter(int, String, FieldReader) - Method in interface org.apache.drill.exec.store.RecordWriter
Add the field value given in valueHolder at the given column number fieldId.
getNewVarCharConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.base.AbstractSingle
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.BroadcastExchange
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.BroadcastSender
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.ComplexToJson
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.ExternalSort
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.Filter
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.FlattenPOP
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.HashAggregate
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.HashPartitionSender
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.HashToMergeExchange
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.HashToRandomExchange
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.IteratorValidator
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.Limit
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.OrderedPartitionExchange
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.OrderedPartitionSender
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.ProducerConsumer
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.Project
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.RangeSender
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.Screen
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.SelectionVectorRemover
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.SingleMergeExchange
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.SingleSender
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.Sort
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.StreamingAggregate
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.TopN
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.Trace
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.UnionExchange
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.UnorderedDeMuxExchange
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.UnorderedMuxExchange
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.WindowPOP
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.store.dfs.easy.EasyWriter
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.store.mock.MockStorePOP
 
getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.store.parquet.ParquetWriter
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.physical.base.AbstractReceiver
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.physical.base.AbstractSingle
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.physical.base.AbstractSubScan
 
getNewWithChildren(List<PhysicalOperator>) - Method in interface org.apache.drill.exec.physical.base.PhysicalOperator
Regenerate with this node with a new set of children.
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.physical.config.MergeJoinPOP
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.physical.config.NestedLoopJoinPOP
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.physical.config.UnionAll
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.physical.config.Values
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.store.direct.DirectGroupScan
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.store.direct.MetadataDirectGroupScan
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaGroupScan
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.store.mock.MockGroupScanPOP
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.store.mock.MockSubScanPOP
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
 
getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.exec.store.sys.SystemTableScan
 
getNext() - Method in interface org.apache.drill.exec.record.RawFragmentBatchProvider
 
getNext(int) - Method in class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
getNext() - Method in class org.apache.drill.exec.work.batch.BaseRawBatchBuffer
 
getNextBuilder() - Method in class org.apache.drill.exec.planner.fragment.MakeFragmentsVisitor
 
getNextClassIndex() - Method in class org.apache.drill.exec.compile.QueryClassLoader
 
getNextClassNumber() - Method in class org.apache.drill.exec.compile.TemplateClassDefinition
 
getNextId() - Method in interface org.apache.drill.exec.schema.IdGenerator
 
getNextId() - Method in class org.apache.drill.exec.schema.SchemaIdGenerator
 
getNextIndex(int) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelper
 
getNextIndex() - Method in class org.apache.drill.exec.physical.impl.xsort.BatchGroup
 
getNextIndex() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
getNextIndex() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.InputBatch
 
getNextIndex() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.SpilledRun
 
getNextSpillFile() - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet
 
getNextSpillFile(String) - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet
 
getNextToken() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
getNextToken() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplTokenManager
 
getNextUnmatchedIndex() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelper
 
getNextVar() - Method in class org.apache.drill.exec.expr.ClassGenerator
 
getNextVar(String) - Method in class org.apache.drill.exec.expr.ClassGenerator
 
getNode() - Method in class org.apache.drill.exec.planner.fragment.Fragment.ExchangeFragmentPair
 
getNode() - Method in class org.apache.drill.exec.planner.fragment.Materializer.IndexedFragmentNode
 
getNode() - Method in class org.apache.drill.exec.planner.fragment.Wrapper
 
getNormalizedNewLine() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
getNullableColumnReader(ParquetRecordReader, int, ColumnDescriptor, ColumnChunkMetaData, boolean, ValueVector, SchemaElement) - Static method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReaderFactory
 
getNullHandling() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
getNullHandling() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
 
getNulls() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata
 
getNulls() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
getNulls() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2
 
getNulls() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3
 
getNumberOfColumns() - Method in class org.apache.drill.exec.record.VectorContainer
 
getNumberOfColumns() - Method in class org.apache.drill.exec.store.pcap.schema.Schema
 
getNumberOfRecordsToRead() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
The number of valid records to be parsed before the process is stopped.
getNumericValue() - Method in enum org.apache.drill.exec.expr.BooleanType
 
getNumRecordsToRead() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan.RowGroupInfo
 
getNumRecordsToRead() - Method in class org.apache.drill.exec.store.parquet.RowGroupReadEntry
 
getNumSenders() - Method in class org.apache.drill.exec.physical.base.AbstractReceiver
 
getNumVal() - Method in class org.apache.drill.exec.server.options.PersistedOptionValue
This is present for forward compatibility.
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.BigIntAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.BitAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
Returns an instance sitting at the given index if exists, null otherwise.
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.DateAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal18Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal28DenseAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal28SparseAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal38DenseAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal38SparseAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal9Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.Float4Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.Float8Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.GenericAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.IntAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.IntervalAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.IntervalDayAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.IntervalYearAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableBigIntAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableBitAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDateAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal18Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal28DenseAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal28SparseAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal38DenseAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal38SparseAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal9Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableFloat4Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableFloat8Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableIntAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableIntervalAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableIntervalDayAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableIntervalYearAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableSmallIntAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableTimeAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableTimeStampAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableTinyIntAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableUInt1Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableUInt2Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableUInt4Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableUInt8Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVar16CharAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVarBinaryAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVarCharAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.SmallIntAccessor
 
getObject(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.TimeAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.TimeStampAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.TinyIntAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.UInt1Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.UInt2Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.UInt4Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.UInt8Accessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.Var16CharAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.VarBinaryAccessor
 
getObject(int) - Method in class org.apache.drill.exec.vector.accessor.VarCharAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.BigIntAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.BitAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.DateAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.Decimal18Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.Decimal28DenseAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.Decimal28SparseAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.Decimal38DenseAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.Decimal38SparseAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.Decimal9Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.Float4Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.Float8Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.GenericAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.IntAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.IntervalAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.IntervalDayAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.IntervalYearAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableBigIntAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableBitAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableDateAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal18Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal28DenseAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal28SparseAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal38DenseAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal38SparseAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal9Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableFloat4Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableFloat8Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableIntAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableIntervalAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableIntervalDayAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableIntervalYearAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableSmallIntAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableTimeAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableTimeStampAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableTinyIntAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableUInt1Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableUInt2Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableUInt4Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableUInt8Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableVar16CharAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableVarBinaryAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.NullableVarCharAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.SmallIntAccessor
 
getObjectClass() - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
Reports the class returned by getObject() of this accessor.
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.TimeAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.TimeStampAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.TinyIntAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.UInt1Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.UInt2Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.UInt4Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.UInt8Accessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.Var16CharAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.VarBinaryAccessor
 
getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.VarCharAccessor
 
getOffset() - Method in class org.apache.drill.exec.physical.config.WindowPOP.Bound
 
getOffset() - Method in class org.apache.drill.exec.planner.common.DrillLimitRelBase
 
getOffset() - Method in class org.apache.drill.exec.store.dfs.MagicString
 
getOldIndex() - Method in class org.apache.drill.exec.planner.physical.PrelUtil.InputRefRemap
 
getOnlineEndPoints() - Method in class org.apache.drill.exec.coord.ClusterCoordinator
Get a collection of ONLINE drillbit endpoints by excluding the drillbits that are in QUIESCENT state (drillbits that are shutting down).
getOnlineEndPoints() - Method in class org.apache.drill.exec.coord.local.LocalClusterCoordinator
Get a collection of ONLINE Drillbit endpoints by excluding the drillbits that are in QUIESCENT state (drillbits shutting down).
getOnlineEndPoints() - Method in class org.apache.drill.exec.coord.zk.ZKClusterCoordinator
 
getOnlineEndpoints() - Method in class org.apache.drill.exec.ops.QueryContext
 
getOp() - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions.OpState
 
getOperandList() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateFunction
 
getOperandList() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateTable
 
getOperandList() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateView
 
getOperandList() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDescribeSchema
 
getOperandList() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDescribeTable
 
getOperandList() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropFunction
 
getOperandList() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropTable
 
getOperandList() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropView
 
getOperandList() - Method in class org.apache.drill.exec.planner.sql.parser.SqlRefreshMetadata
 
getOperandList() - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowFiles
 
getOperandList() - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowSchemas
 
getOperandList() - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowTables
 
getOperandList() - Method in class org.apache.drill.exec.planner.sql.parser.SqlUseSchema
 
getOperator() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
getOperator() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
getOperator() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
getOperator() - Method in interface org.apache.drill.exec.planner.sql.DrillCalciteSqlWrapper
Get the wrapped SqlOperator
getOperator() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateFunction
 
getOperator() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateTable
 
getOperator() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateView
 
getOperator() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDescribeSchema
 
getOperator() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDescribeTable
 
getOperator() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropFunction
 
getOperator() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropTable
 
getOperator() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropView
 
getOperator() - Method in class org.apache.drill.exec.planner.sql.parser.SqlRefreshMetadata
 
getOperator() - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowFiles
 
getOperator() - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowSchemas
 
getOperator() - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowTables
 
getOperator() - Method in class org.apache.drill.exec.planner.sql.parser.SqlUseSchema
 
getOperatorAffinity() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
getOperatorAffinity() - Method in interface org.apache.drill.exec.physical.base.HasAffinity
Get the list of Endpoints with associated affinities that this operator has preference for.
getOperatorAffinity() - Method in class org.apache.drill.exec.physical.config.Screen
 
getOperatorAffinity() - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
getOperatorAffinity() - Method in class org.apache.drill.exec.store.mock.MockStorePOP
 
getOperatorAffinity() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
Calculates the affinity each endpoint has for this scan, by adding up the affinity each endpoint has for each rowGroup
getOperatorAffinity() - Method in class org.apache.drill.exec.store.sys.SystemTableScan
If distributed, the scan needs to happen on every node.
getOperatorContext() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
getOperatorCreator(Class<?>) - Method in class org.apache.drill.exec.physical.impl.OperatorCreatorRegistry
 
getOperatorCreatorRegistry() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getOperatorDefn() - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
getOperatorDefn() - Method in interface org.apache.drill.exec.ops.OperatorContext
Return the physical operator definition created by the planner and passed into the Drillbit executing the query.
getOperatorId() - Method in class org.apache.drill.exec.ops.OpProfileDef
 
getOperatorId() - Method in class org.apache.drill.exec.physical.base.AbstractBase
 
getOperatorId() - Method in interface org.apache.drill.exec.physical.base.PhysicalOperator
 
getOperatorList() - Method in class org.apache.drill.exec.planner.sql.DrillOperatorTable
 
getOperatorPhase() - Method in class org.apache.drill.exec.planner.physical.AggPrelBase
 
getOperatorProfiles() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
 
getOperatorsJSON() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
 
getOperatorsOverview() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
 
getOperatorTable() - Method in class org.apache.drill.exec.server.DrillbitContext
Use the operator table built during startup when "exec.udf.use_dynamic" option is set to false.
getOperatorType() - Method in class org.apache.drill.exec.ops.OpProfileDef
 
getOperatorType() - Method in class org.apache.drill.exec.physical.base.AbstractExchange
 
getOperatorType() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
getOperatorType() - Method in interface org.apache.drill.exec.physical.base.PhysicalOperator
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.BroadcastSender
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.ComplexToJson
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.ExternalSort
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.Filter
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.FlattenPOP
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.HashAggregate
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.HashPartitionSender
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.IteratorValidator
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.Limit
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.MergeJoinPOP
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.MergingReceiverPOP
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.NestedLoopJoinPOP
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.OrderedPartitionSender
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.ProducerConsumer
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.Project
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.RangeSender
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.Screen
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.SelectionVectorRemover
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.SingleSender
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.Sort
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.StreamingAggregate
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.TopN
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.Trace
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.UnionAll
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.UnorderedReceiver
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.Values
 
getOperatorType() - Method in class org.apache.drill.exec.physical.config.WindowPOP
 
getOperatorType() - Method in class org.apache.drill.exec.store.dfs.easy.EasySubScan
 
getOperatorType() - Method in class org.apache.drill.exec.store.dfs.easy.EasyWriter
 
getOperatorType() - Method in class org.apache.drill.exec.store.direct.DirectSubScan
 
getOperatorType() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaSubScan
 
getOperatorType() - Method in class org.apache.drill.exec.store.mock.MockStorePOP
 
getOperatorType() - Method in class org.apache.drill.exec.store.mock.MockSubScanPOP
 
getOperatorType() - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
 
getOperatorType() - Method in class org.apache.drill.exec.store.parquet.ParquetWriter
 
getOperatorType() - Method in class org.apache.drill.exec.store.sys.SystemTableScan
 
getOpId() - Method in class org.apache.drill.exec.planner.physical.explain.PrelSequencer.OpId
 
getOppositeMajorFragmentId() - Method in class org.apache.drill.exec.physical.base.AbstractReceiver
 
getOppositeMajorFragmentId() - Method in class org.apache.drill.exec.physical.base.AbstractSender
 
getOppositeMajorFragmentId() - Method in interface org.apache.drill.exec.physical.base.Receiver
 
getOppositeMajorFragmentId() - Method in interface org.apache.drill.exec.physical.base.Sender
Get the receiver major fragment id that is opposite this sender.
getOppositeMajorFragmentId() - Method in class org.apache.drill.exec.work.batch.AbstractDataCollector
 
getOppositeMinorFragmentId() - Method in class org.apache.drill.exec.physical.config.SingleSender
 
getOpTab() - Method in class org.apache.drill.exec.planner.sql.SqlConverter
 
getOptimizer(DrillConfig) - Static method in class org.apache.drill.exec.opt.Optimizer
 
getOptimizerRules(OptimizerRulesContext) - Method in class org.apache.drill.exec.store.AbstractStoragePlugin
Deprecated.
Marking for deprecation in next major version release. Use #getPhysicalOptimizerRules(org.apache.drill.exec.ops.OptimizerRulesContext, org.apache.drill.exec.planner.PlannerPhase)
getOptimizerRules(OptimizerRulesContext, PlannerPhase) - Method in class org.apache.drill.exec.store.AbstractStoragePlugin
Note: Move this method to StoragePlugin interface in next major version release.
getOptimizerRules() - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
getOptimizerRules() - Method in interface org.apache.drill.exec.store.dfs.FormatPlugin
 
getOptimizerRules() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
getOptimizerRules(OptimizerRulesContext) - Method in interface org.apache.drill.exec.store.StoragePlugin
Deprecated.
getOptimizerRulesContext() - Method in class org.apache.drill.exec.planner.logical.partition.PruneScanRule
 
getOption(String) - Method in class org.apache.drill.exec.ops.QueryContext
 
getOption(TypeValidators.BooleanValidator) - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
getOption(TypeValidators.DoubleValidator) - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
getOption(TypeValidators.LongValidator) - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
getOption(TypeValidators.StringValidator) - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
getOption(String) - Method in class org.apache.drill.exec.server.options.FallbackOptionManager
 
getOption(String) - Method in interface org.apache.drill.exec.server.options.OptionSet
Gets the option value for the given option name.
getOption(TypeValidators.BooleanValidator) - Method in interface org.apache.drill.exec.server.options.OptionSet
Gets the boolean value (from the option value) for the given boolean validator.
getOption(TypeValidators.DoubleValidator) - Method in interface org.apache.drill.exec.server.options.OptionSet
Gets the double value (from the option value) for the given double validator.
getOption(TypeValidators.LongValidator) - Method in interface org.apache.drill.exec.server.options.OptionSet
Gets the long value (from the option value) for the given long validator.
getOption(TypeValidators.StringValidator) - Method in interface org.apache.drill.exec.server.options.OptionSet
Gets the string value (from the option value) for the given string validator.
getOption(String) - Method in class org.apache.drill.exec.server.options.SystemOptionManager
 
getOption(String) - Method in class org.apache.drill.exec.store.SchemaConfig
 
getOption(String) - Method in interface org.apache.drill.exec.store.SchemaConfig.SchemaConfigInfoProvider
 
getOptionDefinition(String) - Method in class org.apache.drill.exec.server.options.FallbackOptionManager
 
getOptionDefinition(String) - Method in interface org.apache.drill.exec.server.options.OptionManager
Get the option definition corresponding to the given option name.
getOptionDefinition(String) - Method in class org.apache.drill.exec.server.options.SystemOptionManager
Gets the OptionDefinition associated with the name.
getOptionList() - Method in class org.apache.drill.exec.server.options.FallbackOptionManager
 
getOptionList() - Method in interface org.apache.drill.exec.server.options.OptionManager
Gets the list of options managed this manager.
getOptionList() - Method in class org.apache.drill.exec.server.options.QueryOptionManager
 
getOptionList() - Method in class org.apache.drill.exec.server.options.SystemOptionManager
 
getOptionManager() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getOptionManager(OptionValue.OptionScope) - Method in class org.apache.drill.exec.server.options.QueryOptionManager
 
getOptionName() - Method in class org.apache.drill.exec.server.options.OptionValidator
Gets the name of the option for this validator.
getOptions() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getOptions() - Method in class org.apache.drill.exec.ops.QueryContext
 
getOptions() - Method in class org.apache.drill.exec.opt.BasicOptimizer.BasicOptimizationContext
 
getOptions() - Method in interface org.apache.drill.exec.opt.Optimizer.OptimizationContext
 
getOptions() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getOptions() - Method in class org.apache.drill.exec.rpc.user.UserSession
 
getOptions() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
Generates sorted map with properties used to display on Web UI, where key is property name and value is property string value.
getOptionScope() - Method in class org.apache.drill.exec.server.rest.StatusResources.OptionWrapper
 
getOptionSet() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getOptionSet() - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
Returns a read-only version of the session options.
getOrCreateStore(TransientStoreConfig<V>) - Method in class org.apache.drill.exec.coord.store.CachingTransientStoreFactory
 
getOrCreateStore(TransientStoreConfig<V>) - Method in interface org.apache.drill.exec.coord.store.TransientStoreFactory
Returns a transient store instance for the given configuration.
getOrCreateStore(TransientStoreConfig<V>) - Method in class org.apache.drill.exec.coord.zk.ZkTransientStoreFactory
 
getOrCreateStore(PersistentStoreConfig<V>) - Method in interface org.apache.drill.exec.store.sys.PersistentStoreProvider
Gets or creates a persistent store for the given configuration.
getOrCreateStore(PersistentStoreConfig<V>) - Method in class org.apache.drill.exec.store.sys.store.provider.CachingPersistentStoreProvider
 
getOrCreateStore(PersistentStoreConfig<V>) - Method in class org.apache.drill.exec.store.sys.store.provider.InMemoryStoreProvider
 
getOrCreateStore(PersistentStoreConfig<V>) - Method in class org.apache.drill.exec.store.sys.store.provider.LocalPersistentStoreProvider
 
getOrCreateStore(PersistentStoreConfig<V>) - Method in class org.apache.drill.exec.store.sys.store.provider.ZookeeperPersistentStoreProvider
 
getOrCreateTransientStore(TransientStoreConfig<V>) - Method in class org.apache.drill.exec.coord.ClusterCoordinator
Returns a store instance with the given configuration.
getOrCreateTransientStore(TransientStoreConfig<V>) - Method in class org.apache.drill.exec.coord.local.LocalClusterCoordinator
 
getOrCreateTransientStore(TransientStoreConfig<V>) - Method in class org.apache.drill.exec.coord.zk.ZKClusterCoordinator
 
getOrderExpressions() - Method in class org.apache.drill.exec.physical.config.HashToMergeExchange
 
getOrdering(RelCollation, RelDataType) - Static method in class org.apache.drill.exec.planner.physical.PrelUtil
 
getOrderingComparator(boolean, ClassGenerator.HoldingContainer, ClassGenerator.HoldingContainer, FunctionLookupContext) - Static method in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
Finds ordering comparator ("compare_to...") FunctionHolderExpression with a specified ordering for NULL (and considering NULLS equal).
getOrderingComparatorNullsHigh(ClassGenerator.HoldingContainer, ClassGenerator.HoldingContainer, FunctionImplementationRegistry) - Static method in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
Finds ordering comparator ("compare_to...") FunctionHolderExpression with a "NULL high" ordering (and considering NULLS equal).
getOrderings() - Method in class org.apache.drill.exec.physical.config.MergingReceiverPOP
 
getOrderings() - Method in class org.apache.drill.exec.physical.config.OrderedPartitionSender
 
getOrderings() - Method in class org.apache.drill.exec.physical.config.SingleMergeExchange
 
getOrderings() - Method in class org.apache.drill.exec.physical.config.Sort
 
getOrderings() - Method in class org.apache.drill.exec.physical.config.TopN
 
getOrderings() - Method in class org.apache.drill.exec.physical.config.WindowPOP
 
getOriginalAccess() - Method in class org.apache.drill.exec.compile.InnerClassAccessStripper
Return the original class' access bits.
getOriginalType() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata
 
getOriginalType() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
getOriginalType() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2
 
getOriginalType() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3
 
getOriginalType(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v1
 
getOriginalType(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
getOriginalType(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
getOriginalType(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataBase
 
getOriginalTypeForMinorType(TypeProtos.MinorType) - Static method in class org.apache.drill.exec.store.parquet.ParquetTypeHelper
 
getOutcome() - Method in interface org.apache.drill.exec.physical.impl.aggregate.HashAggregator
 
getOutcome() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
 
getOutcome() - Method in interface org.apache.drill.exec.physical.impl.aggregate.StreamingAggregator
 
getOutcome() - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
 
getOutcome() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
Return state of join based on status of left and right iterator.
getOutcome() - Method in class org.apache.drill.exec.work.foreman.LoggedQuery
 
getOuterPosition() - Method in class org.apache.drill.exec.record.RecordIterator
 
getOutgoing() - Method in class org.apache.drill.exec.compile.sig.MappingSet
 
getOutgoingBatch(int) - Method in interface org.apache.drill.exec.physical.impl.partitionsender.Partitioner
Method to get PartitionOutgoingBatch based on the fact that there can be > 1 Partitioner
getOutgoingBatch(int) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate
 
getOutgoingBatches() - Method in interface org.apache.drill.exec.physical.impl.partitionsender.Partitioner
 
getOutgoingBatches(int) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerDecorator
Helper method to get PartitionOutgoingBatch based on the index since we may have more then one Partitioner As number of Partitioners should be very small AND this method it used very rarely, so it is OK to loop in order to find right partitioner
getOutgoingBatches() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate
 
getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
 
getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenRecordBatch
 
getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.project.ProjectRecordBatch
 
getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
 
getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
 
getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
getOutgoingContainer() - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
getOutgoingContainer() - Method in interface org.apache.drill.exec.record.RecordBatch
 
getOutgoingContainer() - Method in class org.apache.drill.exec.record.SimpleRecordBatch
 
getOutOfMemoryHandler() - Method in class org.apache.drill.exec.rpc.data.DataServer
 
getOutPosition() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
getOutputCount() - Method in interface org.apache.drill.exec.physical.impl.aggregate.HashAggregator
 
getOutputCount() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
 
getOutputCount() - Method in interface org.apache.drill.exec.physical.impl.aggregate.StreamingAggregator
 
getOutputCount() - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
 
getOutputCount() - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
 
getOutputCount() - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
 
getOutputCount() - Method in interface org.apache.drill.exec.physical.impl.window.WindowFramer
 
getOutputRecords() - Method in interface org.apache.drill.exec.physical.impl.orderedpartitioner.SampleCopier
 
getOutputRecords() - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.SampleCopierTemplate
 
getOutputType(SqlNode) - Method in class org.apache.drill.exec.planner.sql.SqlConverter
 
getOwner() - Method in class org.apache.drill.exec.dotdrill.DotDrillFile
 
getPacketLength() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
getPacketType() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
getPageAsBytesInput(int) - Method in class org.apache.drill.exec.store.parquet.ColumnDataReader
 
getPageReader(ColumnDescriptor) - Method in class org.apache.parquet.hadoop.ColumnChunkIncReadStore
 
getPageWriter(ColumnDescriptor) - Method in class org.apache.parquet.hadoop.ParquetColumnChunkPageWriteStore
 
getParallelizationDependency() - Method in class org.apache.drill.exec.physical.base.AbstractExchange
 
getParallelizationDependency() - Method in interface org.apache.drill.exec.physical.base.Exchange
Get the parallelization dependency of the Exchange.
getParallelizationDependency() - Method in class org.apache.drill.exec.physical.config.AbstractDeMuxExchange
In DeMuxExchange, sender fragment parallelization and endpoint assignment depends on receiver fragment endpoint assignments.
getParallelizationInfo() - Method in class org.apache.drill.exec.planner.fragment.Stats
 
getParamCount() - Method in class org.apache.drill.exec.expr.fn.AbstractFuncHolder
 
getParamCount() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
getParameters() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
getParameters() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
 
getParameterTypes(RelDataTypeFactory) - Method in class org.apache.drill.exec.planner.physical.AggPrelBase.SqlSumCountAggFunction
 
getParamNames() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
getParamNames() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
getParmMajorType(int) - Method in class org.apache.drill.exec.expr.fn.AbstractFuncHolder
 
getParmMajorType(int) - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
getParquetRowGroupFilterPushDownThreshold() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getParquetTableMetadata(FileSystem, String, ParquetFormatConfig) - Static method in class org.apache.drill.exec.store.parquet.Metadata
Get the parquet metadata for the parquet files in the given directory, including those in subdirectories
getParquetTableMetadata(FileSystem, List<FileStatus>, ParquetFormatConfig) - Static method in class org.apache.drill.exec.store.parquet.Metadata
Get the parquet metadata for a list of parquet files
getPartitionColumns() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
getPartitionColumns() - Method in interface org.apache.drill.exec.physical.base.GroupScan
Returns a list of columns that can be used for partition pruning
getPartitionColumns() - Method in interface org.apache.drill.exec.planner.logical.CreateTableEntry
 
getPartitionColumns() - Method in class org.apache.drill.exec.planner.logical.FileSystemCreateTableEntry
 
getPartitionColumns() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateTable
 
getPartitionColumns() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
getPartitionColumns() - Method in class org.apache.drill.exec.store.parquet.ParquetWriter
 
getPartitionDescriptor(PlannerSettings, TableScan) - Method in class org.apache.drill.exec.planner.logical.partition.PruneScanRule
 
getPartitioner() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec
 
getPartitioners() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerDecorator
 
getPartitionExplorer() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getPartitionExplorer() - Method in class org.apache.drill.exec.ops.QueryContext
 
getPartitionExplorer() - Method in interface org.apache.drill.exec.ops.UdfUtilities
A partition explorer allows UDFs to view the sub-partitions below a particular partition.
getPartitionHierarchyIndex(String) - Method in class org.apache.drill.exec.planner.FileSystemPartitionDescriptor
 
getPartitionHierarchyIndex(String) - Method in class org.apache.drill.exec.planner.ParquetPartitionDescriptor
 
getPartitionHierarchyIndex(String) - Method in interface org.apache.drill.exec.planner.PartitionDescriptor
 
getPartitionKeys() - Method in class org.apache.drill.exec.planner.logical.DrillWriterRel
 
getPartitionLocationRecursive() - Method in class org.apache.drill.exec.planner.DFSDirPartitionLocation
 
getPartitionLocationRecursive() - Method in interface org.apache.drill.exec.planner.PartitionLocation
Returns the list of the non-composite partitions that this partition consists of.
getPartitionLocationRecursive() - Method in class org.apache.drill.exec.planner.SimplePartitionLocation
 
getPartitionValue(int) - Method in class org.apache.drill.exec.planner.DFSDirPartitionLocation
 
getPartitionValue(int) - Method in class org.apache.drill.exec.planner.DFSFilePartitionLocation
Returns the value for a give partition key
getPartitionValue(int) - Method in class org.apache.drill.exec.planner.ParquetPartitionLocation
Parquet CTAS auto partitioning scheme does not support getting the partition value based on the location string.
getPartitionValue(int) - Method in interface org.apache.drill.exec.planner.PartitionLocation
Returns the value of the 'index' partition column
getPatchVersion() - Static method in class org.apache.drill.common.util.DrillVersionInfo
Get the Drill patch version from pom
getPath(String, String) - Method in enum org.apache.drill.exec.dotdrill.DotDrillType
For a given parent directory and base file name return complete path including file type specific extensions.
getPath() - Method in class org.apache.drill.exec.expr.stat.TypedFieldExpr
 
getPath() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.SpilledRun
 
getPath() - Method in interface org.apache.drill.exec.store.dfs.easy.FileWork
 
getPath() - Method in class org.apache.drill.exec.store.dfs.ReadEntryWithPath
 
getPath() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata
 
getPath() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v1
 
getPath() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v2
 
getPath() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v3
 
getPath() - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork.FileWorkImpl
 
getPath() - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork
 
getPathWithProtocol(URL) - Static method in class org.apache.drill.exec.coord.zk.PathUtils
Creates and returns path with the protocol at the beginning from specified url.
getPatternType() - Method in class org.apache.drill.exec.expr.fn.impl.RegexpUtil.SqlPatternInfo
 
getPeakBatchCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
 
getPhase2AggCalls() - Method in class org.apache.drill.exec.planner.physical.AggPrelBase
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.BroadcastExchangePrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.ComplexToJsonPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.FilterPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.FlattenPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.HashAggPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.HashJoinPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.HashToMergeExchangePrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.HashToRandomExchangePrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.LimitPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.MergeJoinPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.NestedLoopJoinPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.OrderedPartitionExchangePrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in interface org.apache.drill.exec.planner.physical.Prel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.ProducerConsumerPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.ProjectAllowDupPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.ProjectPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.ScanPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.ScreenPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.SelectionVectorRemoverPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.SingleMergeExchangePrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.SortPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.StreamAggPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.TopNPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.UnionAllPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.UnionDistinctPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.UnionExchangePrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.UnorderedDeMuxExchangePrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.UnorderedMuxExchangePrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.ValuesPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.WindowPrel
 
getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.WriterPrel
 
getPhysicalOptimizerRules(OptimizerRulesContext) - Method in class org.apache.drill.exec.store.AbstractStoragePlugin
Deprecated.
Marking for deprecation in next major version release. Use #getPhysicalOptimizerRules(org.apache.drill.exec.ops.OptimizerRulesContext, org.apache.drill.exec.planner.PlannerPhase)
getPhysicalOptimizerRules(OptimizerRulesContext) - Method in class org.apache.drill.exec.store.dfs.FileSystemPlugin
 
getPhysicalOptimizerRules(OptimizerRulesContext) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaStoragePlugin
 
getPhysicalScan(String, JSONOptions) - Method in class org.apache.drill.exec.store.AbstractStoragePlugin
 
getPhysicalScan(String, JSONOptions, List<SchemaPath>) - Method in class org.apache.drill.exec.store.AbstractStoragePlugin
 
getPhysicalScan(String, JSONOptions, List<SchemaPath>) - Method in class org.apache.drill.exec.store.dfs.FileSystemPlugin
 
getPhysicalScan(String, JSONOptions, List<SchemaPath>) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaStoragePlugin
 
getPhysicalScan(String, JSONOptions, List<SchemaPath>) - Method in class org.apache.drill.exec.store.mock.MockStorageEngine
 
getPhysicalScan(String, JSONOptions) - Method in interface org.apache.drill.exec.store.StoragePlugin
Get the physical scan operator for the particular GroupScan (read) node.
getPhysicalScan(String, JSONOptions, List<SchemaPath>) - Method in interface org.apache.drill.exec.store.StoragePlugin
Get the physical scan operator for the particular GroupScan (read) node.
getPhysicalScan(String, JSONOptions, List<SchemaPath>) - Method in class org.apache.drill.exec.store.sys.SystemTablePlugin
 
getPlan() - Method in class org.apache.drill.exec.planner.logical.DrillImplementor
 
getPlan(QueryContext, String) - Static method in class org.apache.drill.exec.planner.sql.DrillSqlWorker
Converts sql query string into query physical plan.
getPlan(QueryContext, String, Pointer<String>) - Static method in class org.apache.drill.exec.planner.sql.DrillSqlWorker
Converts sql query string into query physical plan.
getPlan(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.AbstractSqlHandler
 
getPlan(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.CreateFunctionHandler
Registers UDFs dynamically.
getPlan(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.CreateTableHandler
 
getPlan(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
 
getPlan(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.DescribeSchemaHandler
 
getPlan(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.DropFunctionHandler
Unregisters UDFs dynamically.
getPlan(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.DropTableHandler
Function resolves the schema and invokes the drop method (while IF EXISTS statement is used function invokes the drop method only if table exists).
getPlan(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.ExplainHandler
 
getPlan(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.RefreshMetadataHandler
 
getPlan(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.SetOptionHandler
 
getPlan(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.ShowFileHandler
 
getPlan(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.UseSchemaHandler
 
getPlan(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.ViewHandler.CreateView
 
getPlan(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.ViewHandler.DropView
 
getPlannerSettings() - Method in interface org.apache.drill.exec.ops.OptimizerRulesContext
Method returns the planner options
getPlannerSettings() - Method in class org.apache.drill.exec.ops.QueryContext
 
getPlannerSettings() - Method in class org.apache.drill.exec.planner.logical.DrillParseContext
 
getPlannerSettings(RelOptCluster) - Static method in class org.apache.drill.exec.planner.physical.PrelUtil
 
getPlannerSettings(RelOptPlanner) - Static method in class org.apache.drill.exec.planner.physical.PrelUtil
 
getPlanningDuration() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
 
getPlanningMemoryLimit() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getPlanReader() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getPlugin() - Method in class org.apache.drill.exec.planner.logical.DrillTable
 
getPlugin() - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory
 
getPlugin(String) - Method in interface org.apache.drill.exec.store.StoragePluginRegistry
Get a plugin by name.
getPlugin(StoragePluginConfig) - Method in interface org.apache.drill.exec.store.StoragePluginRegistry
Get a plugin by configuration.
getPlugin(String) - Method in class org.apache.drill.exec.store.StoragePluginRegistryImpl
 
getPlugin(StoragePluginConfig) - Method in class org.apache.drill.exec.store.StoragePluginRegistryImpl
 
getPlugin() - Method in class org.apache.drill.exec.store.sys.SystemTableScan
 
getPojoClass() - Method in class org.apache.drill.exec.store.pojo.PojoDataType
 
getPojoClass() - Method in enum org.apache.drill.exec.store.sys.SystemTable
 
getPopConfig() - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
getPops(PhysicalOperator) - Static method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
 
getPort() - Method in class org.apache.drill.exec.server.rest.WebServer
 
getPortNum() - Method in class org.apache.drill.exec.server.rest.DrillRoot
 
getPos() - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
getPos() - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalInputStream
 
getPos() - Method in class org.apache.drill.exec.store.ResourceInputStream
 
getPos() - Method in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
 
getPos() - Method in class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
getPos() - Method in class org.apache.drill.exec.vector.complex.fn.DrillBufInputStream
 
getPos() - Method in class org.apache.drill.exec.vector.complex.fn.SeekableBAIS
 
getPosition() - Method in class org.apache.drill.exec.expr.HoldingContainerExpression
 
getPosition() - Method in class org.apache.drill.exec.expr.ValueVectorReadExpression
 
getPosition() - Method in class org.apache.drill.exec.expr.ValueVectorWriteExpression
 
getPosition() - Method in class org.apache.drill.exec.physical.impl.filter.ReturnValueExpression
 
getPosition(InputStream) - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet
 
getPosition(OutputStream) - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet
 
getPrecedenceList() - Method in class org.apache.drill.exec.planner.types.DrillFixedRelDataTypeImpl
 
getPrecedenceList() - Method in class org.apache.drill.exec.planner.types.RelDataTypeDrillImpl
 
getPrecision() - Method in class org.apache.drill.exec.dotdrill.View.FieldType
Gets the precision of the data type descriptor of this field.
getPrecision() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
getPreferredMergeBatchSize() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
getPreferredSpillBatchSize() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
getPrefixSchemaPath(String, String, boolean) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
Utility function to get the commonPrefix schema between two supplied schemas.
getPrimitiveType() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata
 
getPrimitiveType() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
getPrimitiveType() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2
 
getPrimitiveType() - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3
 
getPrimitiveType(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v1
 
getPrimitiveType(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
getPrimitiveType(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
getPrimitiveType(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataBase
 
getPrimitiveTypeNameForMinorType(TypeProtos.MinorType) - Static method in class org.apache.drill.exec.store.parquet.ParquetTypeHelper
 
getPriority() - Method in class org.apache.drill.exec.opt.BasicOptimizer.BasicOptimizationContext
 
getPriority() - Method in interface org.apache.drill.exec.opt.Optimizer.OptimizationContext
 
getProcessingNanos() - Method in class org.apache.drill.exec.ops.OperatorStats
 
getProcessUser() - Method in class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
 
getProcessUserGroupNames() - Static method in class org.apache.drill.exec.util.ImpersonationUtil
Return the list of groups to which the process user belongs.
getProcessUserGroups() - Method in class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
 
getProcessUserName() - Static method in class org.apache.drill.exec.util.ImpersonationUtil
Return the name of the user who is running the Drillbit.
getProcessUserUGI() - Static method in class org.apache.drill.exec.util.ImpersonationUtil
Return the UserGroupInformation of user who is running the Drillbit.
getProfile() - Method in class org.apache.drill.exec.ops.OperatorStats
 
getProfile(String) - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources
 
getProfile() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
 
getProfile() - Method in class org.apache.drill.exec.work.foreman.FragmentData
 
getProfileDuration() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
 
getProfileJSON(String) - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources
 
getProfiles(UriInfo) - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources
 
getProfilesJSON(UriInfo) - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources
 
getProfileStoreConfig() - Method in class org.apache.drill.exec.server.QueryProfileStoreContext
 
getProfileStoreContext() - Method in class org.apache.drill.exec.ops.QueryContext
 
getProfileStoreContext() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getProjectExpressions(DrillParseContext) - Method in class org.apache.drill.exec.planner.common.DrillProjectRelBase
 
getProjectExpressions(DrillParseContext) - Method in class org.apache.drill.exec.planner.physical.ProjectAllowDupPrel
 
getProjection(MessageType, Collection<SchemaPath>, List<SchemaPath>) - Static method in class org.apache.drill.exec.store.parquet2.DrillParquetReader
 
getProperties() - Method in class org.apache.drill.exec.physical.PhysicalPlan
 
getProperties() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
getProtocol() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
getProtocol() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
getProtocol() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
getProvider() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources
 
getProvider() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
getProvider() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
getProvider() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
getProvidingEndpoints() - Method in class org.apache.drill.exec.physical.base.AbstractReceiver
 
getProvidingEndpoints() - Method in interface org.apache.drill.exec.physical.base.Receiver
A receiver is expecting streams from one or more providing endpoints.
getPruneStatus() - Method in class org.apache.drill.exec.store.dfs.MetadataContext
 
getPublicOptionList() - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
getPublicOptionList() - Method in interface org.apache.drill.exec.server.options.OptionManager
Returns all the public options contained in this option manager.
getQualifier() - Static method in class org.apache.drill.common.util.DrillVersionInfo
Get the Drill version qualifier from pom
getQuery() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateTable
 
getQuery() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateView
 
getQuery() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.ProfileInfo
 
getQuery() - Method in class org.apache.drill.exec.server.rest.QueryResources
 
getQuery() - Method in class org.apache.drill.exec.server.rest.QueryWrapper
 
getQueryContext() - Method in class org.apache.drill.exec.work.foreman.Foreman
Get the QueryContext created for the query.
getQueryContextInfo() - Method in class org.apache.drill.exec.ops.QueryContext
 
getQueryCount() - Method in class org.apache.drill.exec.rpc.user.UserSession
 
getQueryId() - Method in class org.apache.drill.exec.ops.QueryContext
 
getQueryId(UserBitShared.QueryId) - Static method in class org.apache.drill.exec.proto.helper.QueryIdHelper
 
getQueryId() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.ProfileInfo
 
getQueryId() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
 
getQueryId() - Method in class org.apache.drill.exec.work.foreman.Foreman
 
getQueryId() - Method in class org.apache.drill.exec.work.foreman.LoggedQuery
 
getQueryIdentifier(ExecProtos.FragmentHandle) - Static method in class org.apache.drill.exec.proto.helper.QueryIdHelper
 
getQueryIdentifiers(UserBitShared.QueryId, int, List<Integer>) - Static method in class org.apache.drill.exec.proto.helper.QueryIdHelper
 
getQueryIdFromString(String) - Static method in class org.apache.drill.exec.proto.helper.QueryIdHelper
 
getQueryManager() - Method in class org.apache.drill.exec.work.foreman.Foreman
Get the QueryManager created for the query.
getQueryPlan(UserClientConnection, UserProtos.GetQueryPlanFragments) - Method in class org.apache.drill.exec.work.user.UserWorker
 
getQueryProfile() - Method in class org.apache.drill.exec.work.foreman.QueryManager
 
getQueryStartDate(ContextInformation) - Static method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions
 
getQueryStartTime() - Method in class org.apache.drill.exec.ops.ContextInformation
 
getQueryStateDisplayName(UserBitShared.QueryResult.QueryState) - Static method in class org.apache.drill.exec.server.rest.profile.ProfileUtil
Utility to return display name for query state
getQueryStateDisplayName() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
 
getQueryText() - Method in class org.apache.drill.exec.work.foreman.Foreman
 
getQueryText() - Method in class org.apache.drill.exec.work.foreman.LoggedQuery
 
getQueryType() - Method in class org.apache.drill.exec.server.rest.QueryWrapper
 
getQueryUser() - Method in class org.apache.drill.exec.ops.ContextInformation
 
getQueryUserName() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getQueryUserName() - Method in class org.apache.drill.exec.ops.QueryContext
Get the user name of the user who issued the query that is managed by this QueryContext.
getQueryUserName() - Method in interface org.apache.drill.exec.store.SchemaConfig.SchemaConfigInfoProvider
 
getQueuedDuration() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
 
getQueueName() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.ProfileInfo
 
getQuote() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Returns the character used for escaping values where the field delimiter is part of the value.
getQuote() - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
getQuoteEscape() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Returns the character used for escaping quotes inside an already quoted value.
getQuotingIdentifiers() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getRange() - Method in class org.apache.drill.exec.physical.config.RangeSender.EndpointPartition
 
getRange(int, int) - Method in interface org.apache.drill.exec.store.sys.PersistentStore
Returns an iterator of desired number of entries offsetting by the skip value.
getRange(int, int) - Method in class org.apache.drill.exec.store.sys.store.InMemoryStore
 
getRange(int, int) - Method in class org.apache.drill.exec.store.sys.store.LocalPersistentStore
 
getRange(int, int) - Method in class org.apache.drill.exec.store.sys.store.ZookeeperPersistentStore
 
getRange(int, int) - Method in class org.apache.drill.exec.testing.store.NoWriteLocalStore
 
getReadBytes() - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet
 
getReadCount(ColumnReader<?>) - Method in class org.apache.drill.exec.store.parquet.columnreaders.BatchReader.FixedWidthReader
 
getReadCount(ColumnReader<?>) - Method in class org.apache.drill.exec.store.parquet.columnreaders.BatchReader
 
getReadCount(ColumnReader<?>) - Method in class org.apache.drill.exec.store.parquet.columnreaders.BatchReader.MockBatchReader
 
getReadCount(ColumnReader<?>) - Method in class org.apache.drill.exec.store.parquet.columnreaders.BatchReader.VariableWidthReader
 
getReadEntries() - Method in class org.apache.drill.exec.store.mock.MockGroupScanPOP
 
getReadEntries() - Method in class org.apache.drill.exec.store.mock.MockSubScanPOP
 
getReader() - Method in class org.apache.drill.exec.store.direct.DirectSubScan
 
getReader(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getReader(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getReader(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVar16CharAccessor
 
getReader(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVarCharAccessor
 
getReader(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getReader(int) - Method in class org.apache.drill.exec.vector.accessor.Var16CharAccessor
 
getReader(int) - Method in class org.apache.drill.exec.vector.accessor.VarCharAccessor
 
getReaderOperatorType() - Method in class org.apache.drill.exec.store.avro.AvroFormatPlugin
 
getReaderOperatorType() - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
getReaderOperatorType() - Method in class org.apache.drill.exec.store.easy.json.JSONFormatPlugin
 
getReaderOperatorType() - Method in class org.apache.drill.exec.store.easy.sequencefile.SequenceFileFormatPlugin
 
getReaderOperatorType() - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin
 
getReaderOperatorType() - Method in class org.apache.drill.exec.store.httpd.HttpdLogFormatPlugin
 
getReaderOperatorType() - Method in class org.apache.drill.exec.store.pcap.PcapFormatPlugin
 
getReadPath() - Method in class org.apache.drill.exec.expr.ValueVectorReadExpression
 
getReceiver(int) - Method in interface org.apache.drill.exec.physical.base.Exchange
Get the Receiver associated with the given minorFragmentId.
getReceiver(int) - Method in class org.apache.drill.exec.physical.config.BroadcastExchange
 
getReceiver(int) - Method in class org.apache.drill.exec.physical.config.HashToMergeExchange
 
getReceiver(int) - Method in class org.apache.drill.exec.physical.config.HashToRandomExchange
 
getReceiver(int) - Method in class org.apache.drill.exec.physical.config.OrderedPartitionExchange
 
getReceiver(int) - Method in class org.apache.drill.exec.physical.config.SingleMergeExchange
 
getReceiver(int) - Method in class org.apache.drill.exec.physical.config.UnionExchange
 
getReceiver(int) - Method in class org.apache.drill.exec.physical.config.UnorderedDeMuxExchange
 
getReceiver(int) - Method in class org.apache.drill.exec.physical.config.UnorderedMuxExchange
 
getReceiverParallelizationInfo(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.physical.base.AbstractExchange
Default receiver parallelization width range is [1, Integer.MAX_VALUE] and affinity to nodes where sender fragments are running.
getReceiverParallelizationInfo(List<CoordinationProtos.DrillbitEndpoint>) - Method in interface org.apache.drill.exec.physical.base.Exchange
Provide parallelization parameters for receiver side of the exchange.
getReceiverParallelizationInfo(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.physical.config.AbstractDeMuxExchange
 
getReceiverParallelizationInfo(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.physical.config.AbstractMuxExchange
 
getReceiverParallelizationInfo(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.physical.config.SingleMergeExchange
 
getReceiverParallelizationInfo(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.physical.config.UnionExchange
 
getReceivingExchangePairs() - Method in class org.apache.drill.exec.planner.fragment.Fragment
 
getRecordBatch(PhysicalOperator, FragmentContext) - Method in class org.apache.drill.exec.physical.impl.ImplCreator
Create a RecordBatch and its children for given PhysicalOperator
getRecordCount() - Method in class org.apache.drill.exec.physical.base.ScanStats
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.filter.FilterRecordBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenRecordBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.join.MergeJoinBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.limit.LimitRecordBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.producer.ProducerConsumerBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.project.ProjectRecordBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.sort.RecordBatchData
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.sort.SortBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.svremover.RemovingRecordBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch.SimpleSV4RecordBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.trace.TraceRecordBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.union.UnionAllRecordBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.window.WindowDataBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.window.WindowFrameRecordBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.WriterRecordBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.xsort.BatchGroup
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.InputBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MergeSortWrapper
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierWrapper.BatchMerger
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.EmptyResults
 
getRecordCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SingleBatchResults
 
getRecordCount() - Method in interface org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SortResults
 
getRecordCount() - Method in interface org.apache.drill.exec.record.RecordBatch
Gets the number of records that are within this record.
getRecordCount() - Method in class org.apache.drill.exec.record.RecordBatchLoader
 
getRecordCount() - Method in class org.apache.drill.exec.record.RecordIterator
 
getRecordCount() - Method in class org.apache.drill.exec.record.SimpleRecordBatch
 
getRecordCount() - Method in interface org.apache.drill.exec.record.VectorAccessible
Get the number of records.
getRecordCount() - Method in class org.apache.drill.exec.record.VectorContainer
 
getRecordCount() - Method in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
 
getRecordGenerator(OptionManager) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaTable.Catalogs
 
getRecordGenerator(OptionManager) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaTable.Columns
 
getRecordGenerator(OptionManager) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaTable
 
getRecordGenerator(OptionManager) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaTable.Schemata
 
getRecordGenerator(OptionManager) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaTable.Tables
 
getRecordGenerator(OptionManager) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaTable.Views
 
getRecordIndex() - Method in class org.apache.drill.exec.expr.BatchReference
 
getRecordIndex(int) - Static method in class org.apache.drill.exec.record.selection.SelectionVector4
 
getRecordReader(FragmentContext, DrillFileSystem, FileWork, List<SchemaPath>, String) - Method in class org.apache.drill.exec.store.avro.AvroFormatPlugin
 
getRecordReader(FragmentContext, DrillFileSystem, FileWork, List<SchemaPath>, String) - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
getRecordReader(FragmentContext, DrillFileSystem, FileWork, List<SchemaPath>, String) - Method in class org.apache.drill.exec.store.easy.json.JSONFormatPlugin
 
getRecordReader(FragmentContext, DrillFileSystem, FileWork, List<SchemaPath>, String) - Method in class org.apache.drill.exec.store.easy.sequencefile.SequenceFileFormatPlugin
 
getRecordReader(FragmentContext, DrillFileSystem, FileWork, List<SchemaPath>, String) - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin
 
getRecordReader(FragmentContext, DrillFileSystem, FileWork, List<SchemaPath>, String) - Method in class org.apache.drill.exec.store.httpd.HttpdLogFormatPlugin
 
getRecordReader() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Catalogs
 
getRecordReader() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Columns
 
getRecordReader() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
 
getRecordReader() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Schemata
 
getRecordReader() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Tables
 
getRecordReader() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Views
 
getRecordReader(SchemaPlus, InfoSchemaFilter, OptionManager) - Method in enum org.apache.drill.exec.store.ischema.InfoSchemaTableType
 
getRecordReader(FragmentContext, DrillFileSystem, FileWork, List<SchemaPath>, String) - Method in class org.apache.drill.exec.store.pcap.PcapFormatPlugin
 
getRecords() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockScanEntry
 
getRecordsPerBatch() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetSchema
 
getRecordsReadInCurrentPass() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
getRecordsReadInCurrentPass() - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
 
getRecordsToRead() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
 
getRecordsToSample() - Method in class org.apache.drill.exec.physical.config.OrderedPartitionSender
 
getRecordWriter(FragmentContext, EasyWriter) - Method in class org.apache.drill.exec.store.avro.AvroFormatPlugin
 
getRecordWriter(FragmentContext, EasyWriter) - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
getRecordWriter(FragmentContext, EasyWriter) - Method in class org.apache.drill.exec.store.easy.json.JSONFormatPlugin
 
getRecordWriter(FragmentContext, EasyWriter) - Method in class org.apache.drill.exec.store.easy.sequencefile.SequenceFileFormatPlugin
 
getRecordWriter(FragmentContext, EasyWriter) - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin
 
getRecordWriter(FragmentContext, EasyWriter) - Method in class org.apache.drill.exec.store.httpd.HttpdLogFormatPlugin
 
getRecordWriter(FragmentContext, ParquetWriter) - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
getRecordWriter(FragmentContext, EasyWriter) - Method in class org.apache.drill.exec.store.pcap.PcapFormatPlugin
 
getRef() - Method in class org.apache.drill.exec.physical.config.OrderedPartitionSender
 
getReferencedDirs() - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
 
getRegisteredNames() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
getRegisteredNames() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
 
getRegistrationHandle() - Method in class org.apache.drill.exec.server.Drillbit
 
getRegistry(DataChangeVersion) - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
 
getRegistryArea() - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
 
getRegistryVersion() - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
Returns current remote function registry version.
getRelDataType(RelDataTypeFactory, TypeProtos.MajorType) - Static method in class org.apache.drill.exec.store.ischema.InfoSchemaTable
 
getRemainder() - Method in class org.apache.drill.exec.record.TypedFieldId
 
getRemaining() - Method in class org.apache.drill.exec.physical.impl.window.Partition
 
getRemainingQueries() - Method in class org.apache.drill.exec.server.rest.DrillRoot
 
getRemainingQueries() - Method in class org.apache.drill.exec.work.WorkManager
Get the number of queries that are running on a drillbit.
getRemainingRequired() - Method in class org.apache.drill.exec.work.batch.IncomingBuffers
 
getRemoteAddress() - Method in class org.apache.drill.exec.rpc.user.UserServer.BitToUserConnection
 
getRemoteAddress() - Method in interface org.apache.drill.exec.rpc.UserClientConnection
 
getRemoteAddress() - Method in class org.apache.drill.exec.server.rest.WebSessionResources
 
getRemoteAddress() - Method in class org.apache.drill.exec.server.rest.WebUserConnection
 
getRemoteAddress() - Method in class org.apache.drill.exec.work.foreman.LoggedQuery
 
getRemoteFunctionRegistry() - Method in class org.apache.drill.exec.expr.fn.FunctionImplementationRegistry
 
getRemoteFunctionRegistry() - Method in class org.apache.drill.exec.ops.QueryContext
 
getRemoteFunctionRegistry() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getRepeat() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
getRepeat() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockScanEntry
 
getRepeatCount() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
getRepetitionForDataMode(TypeProtos.DataMode) - Static method in class org.apache.drill.exec.store.parquet.ParquetTypeHelper
 
getRepetitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v1
 
getRepetitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
getRepetitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
getRepetitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataBase
 
getReplication(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
Deprecated.
getResetBlock() - Method in class org.apache.drill.exec.expr.ClassGenerator
 
getResolver(FunctionCall) - Static method in class org.apache.drill.exec.resolver.FunctionResolverFactory
 
getResourceManager() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getResponseDefaultInstance(int) - Method in class org.apache.drill.exec.rpc.control.ControlClient
 
getResponseDefaultInstance(int) - Method in class org.apache.drill.exec.rpc.control.ControlServer
 
getResponseDefaultInstance(int) - Static method in class org.apache.drill.exec.rpc.control.DefaultInstanceHandler
 
getResponseDefaultInstance(int) - Method in class org.apache.drill.exec.rpc.data.DataClient
 
getResponseDefaultInstance(int) - Method in class org.apache.drill.exec.rpc.data.DataServer
 
getResponseDefaultInstance(int) - Method in class org.apache.drill.exec.rpc.user.UserClient
 
getResponseDefaultInstance(int) - Method in class org.apache.drill.exec.rpc.user.UserServer
 
getResponseDefaultInstanceClient(int) - Static method in class org.apache.drill.exec.rpc.data.DataDefaultInstanceHandler
 
getResponseDefaultInstanceServer(int) - Static method in class org.apache.drill.exec.rpc.data.DataDefaultInstanceHandler
 
getResult() - Method in class org.apache.drill.exec.server.rest.StorageResources.JsonResult
 
getRetryAttempts() - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
 
getReturnDataType(RelDataTypeFactory) - Method in class org.apache.drill.exec.planner.sql.DrillSqlOperatorWithoutInference
 
getReturnType() - Method in class org.apache.drill.exec.compile.sig.CodeGeneratorMethod
 
getReturnType(List<LogicalExpression>) - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
getReturnType() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
getReturnType() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
 
getReturnType(RelDataTypeFactory) - Method in class org.apache.drill.exec.planner.physical.AggPrelBase.SqlSumCountAggFunction
 
getReturnTypeDataMode(List<LogicalExpression>, FunctionAttributes) - Static method in class org.apache.drill.exec.expr.fn.FunctionUtils
Calculates return type data mode based on give logical expressions.
getReturnValue() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
getReturnValue() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
 
getReverse() - Method in class org.apache.drill.exec.physical.config.Sort
 
getReverse() - Method in class org.apache.drill.exec.physical.config.TopN
 
getRexBuilder() - Method in class org.apache.drill.exec.planner.torel.ConversionContext
 
getRight() - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
 
getRight() - Method in class org.apache.drill.exec.physical.config.MergeJoinPOP
 
getRight() - Method in class org.apache.drill.exec.physical.config.NestedLoopJoinPOP
 
getRightKeys() - Method in class org.apache.drill.exec.planner.common.DrillJoinRelBase
 
getRightStatus() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
getRoot() - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
 
getRoot() - Method in class org.apache.drill.exec.expr.CodeGenerator
 
getRoot(TemplateClassDefinition<T>, OptionSet) - Static method in class org.apache.drill.exec.expr.CodeGenerator
 
getRoot(MappingSet, TemplateClassDefinition<T>, OptionSet) - Static method in class org.apache.drill.exec.expr.CodeGenerator
 
getRoot(FragmentContext, BroadcastSender, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.broadcastsender.BroadcastSenderCreator
 
getRoot(FragmentContext, OrderedPartitionSender, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionSenderCreator
 
getRoot(FragmentContext, HashPartitionSender, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderCreator
 
getRoot(FragmentContext, T, List<RecordBatch>) - Method in interface org.apache.drill.exec.physical.impl.RootCreator
 
getRoot(FragmentContext, Screen, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.ScreenCreator
 
getRoot(FragmentContext, SingleSender, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.SingleSenderCreator
 
getRoot() - Method in class org.apache.drill.exec.planner.fragment.Fragment
 
getRootConverter() - Method in class org.apache.drill.exec.store.parquet2.DrillParquetRecordMaterializer
 
getRootFragment() - Method in class org.apache.drill.exec.work.QueryWorkUnit
 
getRootFragmentDefn() - Method in class org.apache.drill.exec.work.QueryWorkUnit
 
getRootFragmentTimeZone() - Method in class org.apache.drill.exec.ops.ContextInformation
 
getRootOperator() - Method in class org.apache.drill.exec.work.QueryWorkUnit
 
getRootSchema() - Method in class org.apache.drill.exec.ops.QueryContext
Get root schema with schema owner as the user who issued the query that is managed by this QueryContext.
getRootSchema(String) - Method in class org.apache.drill.exec.ops.QueryContext
Return root schema with schema owner as the given user.
getRootSchema(SchemaConfig) - Method in class org.apache.drill.exec.ops.QueryContext
Create and return a SchemaTree with given schemaConfig but some schemas (from storage plugins) could be initialized later.
getRootSchema() - Method in class org.apache.drill.exec.planner.sql.SqlConverter
 
getRootSchema(String) - Method in interface org.apache.drill.exec.store.SchemaConfig.SchemaConfigInfoProvider
 
getRowCount() - Method in class org.apache.drill.exec.expr.stat.RangeExprEvaluator
 
getRowCount(Aggregate, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.cost.DrillRelMdRowCount
 
getRowCount(Filter, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.cost.DrillRelMdRowCount
 
getRowCount(DrillLimitRelBase, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.cost.DrillRelMdRowCount
 
getRowCount(Union, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.cost.DrillRelMdRowCount
 
getRowCount(Project, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.cost.DrillRelMdRowCount
 
getRowCount(Sort, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.cost.DrillRelMdRowCount
 
getRowCount(SingleRel, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.cost.DrillRelMdRowCount
 
getRowCount(Join, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.cost.DrillRelMdRowCount
 
getRowCount() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata
 
getRowCount() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v1
 
getRowCount() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v2
 
getRowCount() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v3
 
getRowCount() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan.RowGroupInfo
 
getRowCount() - Method in class org.apache.parquet.hadoop.ColumnChunkIncReadStore
 
getRowCountEstimateFactor() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getRowGroupIndex() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
getRowGroupIndex() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan.RowGroupInfo
 
getRowGroupIndex() - Method in class org.apache.drill.exec.store.parquet.RowGroupReadEntry
 
getRowGroupMetadata() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetSchema
 
getRowGroupReadEntries() - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
 
getRowGroupReadEntry() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan.RowGroupInfo
 
getRowGroupReadEntry() - Method in class org.apache.drill.exec.store.parquet.RowGroupReadEntry
 
getRowGroups() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata
 
getRowGroups() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v1
 
getRowGroups() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v2
 
getRowGroups() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v3
 
getRows() - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
getRows() - Method in class org.apache.drill.exec.server.rest.QueryResources.TabularResult
 
getRowType(RelDataTypeFactory) - Method in class org.apache.drill.exec.dotdrill.View
 
getRowType(RelDataTypeFactory) - Method in class org.apache.drill.exec.planner.logical.DrillTranslatableTable
 
getRowType(RelDataTypeFactory) - Method in class org.apache.drill.exec.planner.logical.DrillViewTable
 
getRowType(RelDataTypeFactory) - Method in class org.apache.drill.exec.planner.logical.DynamicDrillTable
 
getRowType(RelDataTypeFactory) - Method in class org.apache.drill.exec.store.avro.AvroDrillTable
 
getRowType(RelDataTypeFactory) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaDrillTable
 
getRowType(RelDataTypeFactory) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaTable
 
getRowType(RelDataTypeFactory) - Method in enum org.apache.drill.exec.store.ischema.InfoSchemaTableType
 
getRowType(RelDataTypeFactory) - Method in class org.apache.drill.exec.store.pcap.PcapDrillTable
 
getRowType(RelDataTypeFactory) - Method in class org.apache.drill.exec.store.RecordDataType
This method constructs a RelDataType based on the RecordDataType's field sql types and field names.
getRowType(RelDataTypeFactory) - Method in class org.apache.drill.exec.store.sys.StaticDrillTable
 
getRowWidth() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
getRpcEndpointInfos(String) - Static method in class org.apache.drill.exec.rpc.user.UserRpcUtils
Returns a RpcEndpointInfos instance The instance is populated based on Drill version informations from the classpath and runtime information for the application name.
getRules(OptimizerRulesContext, Collection<StoragePlugin>) - Method in enum org.apache.drill.exec.planner.PlannerPhase
 
getRules(PlannerPhase) - Method in class org.apache.drill.exec.planner.sql.handlers.SqlHandlerConfig
 
getRunnable() - Method in class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
getRunnable() - Method in interface org.apache.drill.exec.work.fragment.FragmentManager
Get the fragment runner for this incoming fragment.
getRunnable() - Method in class org.apache.drill.exec.work.fragment.NonRootFragmentManager
 
getRunningProfileStore() - Method in class org.apache.drill.exec.server.QueryProfileStoreContext
 
getRunningQueries() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.QProfiles
 
getSamplingFactor() - Method in class org.apache.drill.exec.physical.config.OrderedPartitionSender
 
getSaslClient() - Method in class org.apache.drill.exec.rpc.AbstractClientConnection
 
getSaslClient() - Method in class org.apache.drill.exec.rpc.control.ControlConnection
 
getSaslClientProperties(CoordinationProtos.DrillbitEndpoint, Map<String, String>) - Method in class org.apache.drill.exec.rpc.BitConnectionConfig
 
getSaslProperties(boolean, int) - Static method in class org.apache.drill.exec.rpc.security.SaslProperties
Get's the map of minimum set of SaslProperties required during negotiation process either for encryption or authentication
getSaslServer() - Method in class org.apache.drill.exec.rpc.AbstractServerConnection
 
getScale() - Method in class org.apache.drill.exec.dotdrill.View.FieldType
Gets the numeric scale of the data type descriptor of this field, for numeric types.
getScale() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
getScanDecodeExecutor() - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
getScanDecodeExecutor() - Method in interface org.apache.drill.exec.ops.OperatorContext
 
getScanDecodeExecutor() - Method in class org.apache.drill.exec.server.BootStrapContext
 
getScanDecodeExecutor() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getScanExecutor() - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
getScanExecutor() - Method in interface org.apache.drill.exec.ops.OperatorContext
 
getScanExecutor() - Method in class org.apache.drill.exec.server.BootStrapContext
 
getScanExecutor() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getScanResult() - Method in class org.apache.drill.exec.expr.fn.registry.JarScan
 
getScanStats(PlannerSettings) - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
getScanStats() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
getScanStats(PlannerSettings) - Method in interface org.apache.drill.exec.physical.base.GroupScan
 
getScanStats(PlannerSettings, EasyGroupScan) - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
getScanStats(PlannerSettings) - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
getScanStats() - Method in class org.apache.drill.exec.store.direct.DirectGroupScan
 
getScanStats(PlannerSettings, EasyGroupScan) - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin
 
getScanStats() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaGroupScan
 
getScanStats() - Method in class org.apache.drill.exec.store.mock.MockGroupScanPOP
 
getScanStats() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
getScanStats() - Method in class org.apache.drill.exec.store.sys.SystemTableScan
System tables do not need stats.
getSchema() - Method in class org.apache.drill.exec.physical.impl.aggregate.InternalBatch
 
getSchema() - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
 
getSchema() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
getSchema() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
getSchema() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
 
getSchema() - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
 
getSchema() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
getSchema() - Method in class org.apache.drill.exec.physical.impl.window.WindowDataBatch
 
getSchema() - Method in class org.apache.drill.exec.physical.impl.WriterRecordBatch
 
getSchema() - Method in class org.apache.drill.exec.physical.impl.xsort.BatchGroup
 
getSchema() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
getSchema() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDescribeSchema
 
getSchema() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropTable
 
getSchema() - Method in class org.apache.drill.exec.planner.sql.parser.SqlUseSchema
Get the schema name.
getSchema() - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
getSchema() - Method in class org.apache.drill.exec.record.AbstractSingleRecordBatch
 
getSchema() - Method in interface org.apache.drill.exec.record.RecordBatch
Gets the current schema of this record batch.
getSchema() - Method in class org.apache.drill.exec.record.RecordBatchLoader
 
getSchema() - Method in class org.apache.drill.exec.record.RecordIterator
 
getSchema() - Method in class org.apache.drill.exec.record.SimpleRecordBatch
 
getSchema() - Method in interface org.apache.drill.exec.record.VectorAccessible
Get the schema of the current RecordBatch.
getSchema() - Method in class org.apache.drill.exec.record.VectorContainer
 
getSchema() - Method in class org.apache.drill.exec.work.foreman.LoggedQuery
 
getSchemaChanges() - Method in class org.apache.drill.exec.schema.BackedRecord
 
getSchemaChanges() - Method in interface org.apache.drill.exec.schema.Record
 
getSchemaFactories() - Method in class org.apache.drill.exec.planner.sql.DynamicRootSchema
 
getSchemaFactory() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getSchemaFactory() - Method in interface org.apache.drill.exec.store.StoragePluginRegistry
Get the Schema factory associated with this storage plugin registry.
getSchemaFactory() - Method in class org.apache.drill.exec.store.StoragePluginRegistryImpl
 
getSchemaName() - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory
 
getSchemaPath() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateTable
 
getSchemaPath() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateView
 
getSchemaPath() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropView
 
getSchemaPath() - Method in class org.apache.drill.exec.planner.sql.parser.SqlRefreshMetadata
 
getSchemaPath(SchemaPlus) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
Utility method to get the schema path for given schema instance.
getSchemaPath(List<String>) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
Utility method to get the schema path for given list of schema path.
getSchemaPath() - Method in class org.apache.drill.exec.store.AbstractSchema
 
getSchemaPathAsList(SchemaPlus) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
Utility method to get the schema path as list for given schema instance.
getSchemas(UserProtos.LikeFilter, UserProtos.LikeFilter) - Method in class org.apache.drill.exec.client.DrillClient
Get the list of schemas in INFORMATION_SCHEMA.SCHEMATA table satisfying the given filters.
getSchemaTree() - Method in class org.apache.drill.exec.ops.ViewExpansionContext.ViewExpansionToken
Get schema tree for view owner who owns this token.
getScheme() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getScope() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
 
getScope() - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
getScope() - Method in class org.apache.drill.exec.server.options.FragmentOptionManager
 
getScope() - Method in class org.apache.drill.exec.server.options.QueryOptionManager
 
getScope() - Method in class org.apache.drill.exec.server.options.SessionOptionManager
 
getScope() - Method in class org.apache.drill.exec.server.options.SystemOptionManager
 
getSecondaryFinal() - Method in class org.apache.drill.exec.record.TypedFieldId
 
getSelection() - Method in class org.apache.drill.exec.planner.logical.DrillTable
 
getSelection() - Method in class org.apache.drill.exec.store.dfs.FormatSelection
 
getSelectionRoot() - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
getSelectionRoot() - Method in class org.apache.drill.exec.store.dfs.easy.EasySubScan
 
getSelectionRoot() - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
getSelectionRoot() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
getSelectionRoot() - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
 
getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
 
getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.filter.FilterRecordBatch
 
getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.limit.LimitRecordBatch
 
getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
 
getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.sort.SortBatch
 
getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.trace.TraceRecordBatch
 
getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
 
getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.window.WindowDataBatch
 
getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.xsort.BatchGroup
 
getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
 
getSelectionVector2() - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
getSelectionVector2() - Method in class org.apache.drill.exec.record.RecordBatchLoader
 
getSelectionVector2() - Method in class org.apache.drill.exec.record.RecordIterator
 
getSelectionVector2() - Method in class org.apache.drill.exec.record.SimpleRecordBatch
 
getSelectionVector2() - Method in interface org.apache.drill.exec.record.VectorAccessible
 
getSelectionVector2() - Method in class org.apache.drill.exec.record.VectorContainer
 
getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
 
getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.filter.FilterRecordBatch
 
getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
 
getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.sort.SortBatch
 
getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch.SimpleSV4RecordBatch
 
getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
 
getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.window.WindowDataBatch
 
getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.xsort.BatchGroup
 
getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch
 
getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
 
getSelectionVector4() - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
getSelectionVector4() - Method in class org.apache.drill.exec.record.RecordBatchLoader
 
getSelectionVector4() - Method in class org.apache.drill.exec.record.RecordIterator
 
getSelectionVector4() - Method in class org.apache.drill.exec.record.SimpleRecordBatch
 
getSelectionVector4() - Method in interface org.apache.drill.exec.record.VectorAccessible
 
getSelectionVector4() - Method in class org.apache.drill.exec.record.VectorContainer
 
getSelectionVectorMode() - Method in class org.apache.drill.exec.record.BatchSchema
 
getSelfCost() - Method in class org.apache.drill.exec.expr.DrillFuncHolderExpr
 
getSelfCost() - Method in class org.apache.drill.exec.expr.HoldingContainerExpression
 
getSelfCost() - Method in class org.apache.drill.exec.expr.ValueVectorReadExpression
 
getSelfCost() - Method in class org.apache.drill.exec.expr.ValueVectorWriteExpression
 
getSelfCost() - Method in class org.apache.drill.exec.physical.impl.filter.ReturnValueExpression
 
getSemaphore(String, int) - Method in class org.apache.drill.exec.coord.ClusterCoordinator
 
getSemaphore(String, int) - Method in class org.apache.drill.exec.coord.local.LocalClusterCoordinator
 
getSemaphore(String, int) - Method in class org.apache.drill.exec.coord.zk.ZKClusterCoordinator
 
getSender(int, PhysicalOperator) - Method in interface org.apache.drill.exec.physical.base.Exchange
Get the Sender associated with the given minorFragmentId.
getSender(int, PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.AbstractDeMuxExchange
 
getSender(int, PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.AbstractMuxExchange
 
getSender(int, PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.BroadcastExchange
 
getSender(int, PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.HashToMergeExchange
 
getSender(int, PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.HashToRandomExchange
 
getSender(int, PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.OrderedPartitionExchange
 
getSender(int, PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.SingleMergeExchange
 
getSender(int, PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.UnionExchange
 
getSender() - Method in class org.apache.drill.exec.record.RawFragmentBatch
 
getSenderParallelizationInfo(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.physical.base.AbstractExchange
Default sender parallelization width range is [1, Integer.MAX_VALUE] and no endpoint affinity
getSenderParallelizationInfo(List<CoordinationProtos.DrillbitEndpoint>) - Method in interface org.apache.drill.exec.physical.base.Exchange
Provide parallelization parameters for sender side of the exchange.
getSenderParallelizationInfo(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.physical.config.AbstractDeMuxExchange
 
getSendingExchange() - Method in class org.apache.drill.exec.planner.fragment.Fragment
 
getSendingExchangePair() - Method in class org.apache.drill.exec.planner.fragment.Fragment
 
getSendingWidth() - Method in class org.apache.drill.exec.physical.config.OrderedPartitionSender
 
getSequenceNumber() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
getSerializer() - Method in class org.apache.drill.exec.coord.store.TransientStoreConfig
 
getSerializer() - Method in class org.apache.drill.exec.store.sys.PersistentStoreConfig
 
getServerDefaults() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
Deprecated.
getServerDefaults(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getServerInfos() - Method in class org.apache.drill.exec.client.DrillClient
Deprecated.
use DrillClient#getServerVersion()
getServerInfos() - Method in class org.apache.drill.exec.rpc.user.UserClient
 
getServerMeta() - Method in class org.apache.drill.exec.client.DrillClient
Get server meta information Get meta information about the server like the the available functions or the identifier quoting string used by the current session
getServerName() - Method in class org.apache.drill.exec.client.DrillClient
Return the server name.
getServerVersion() - Method in class org.apache.drill.exec.client.DrillClient
Return the server version.
getSession() - Method in class org.apache.drill.exec.ops.QueryContext
 
getSession() - Method in class org.apache.drill.exec.rpc.user.UserServer.BitToUserConnection
 
getSession() - Method in interface org.apache.drill.exec.rpc.UserClientConnection
 
getSession() - Method in class org.apache.drill.exec.server.rest.WebSessionResources
 
getSession() - Method in class org.apache.drill.exec.server.rest.WebUserConnection
 
getSessionHash() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
getSessionId() - Method in class org.apache.drill.exec.ops.ContextInformation
 
getSessionId() - Method in class org.apache.drill.exec.rpc.user.UserSession
 
getSessionOptionManager() - Method in class org.apache.drill.exec.server.options.QueryOptionManager
 
getSettings(RelOptCluster) - Static method in class org.apache.drill.exec.planner.physical.PrelUtil
 
getSetupBlock() - Method in class org.apache.drill.exec.expr.ClassGenerator
 
GetSetVectorHelper - Class in org.apache.drill.exec.expr
 
GetSetVectorHelper() - Constructor for class org.apache.drill.exec.expr.GetSetVectorHelper
 
getShort(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getShort(byte[], int) - Static method in class org.apache.drill.exec.store.pcap.PcapFormatUtils
 
getShort(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getShort(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getShort(int) - Method in class org.apache.drill.exec.vector.accessor.NullableSmallIntAccessor
 
getShort(int) - Method in class org.apache.drill.exec.vector.accessor.SmallIntAccessor
 
getShort(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getShort(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
getShortFileOrder(boolean, byte[], int) - Static method in class org.apache.drill.exec.store.pcap.PcapFormatUtils
 
getSignature() - Method in class org.apache.drill.exec.compile.TemplateClassDefinition
 
getSignature() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionHolder
 
getSignatureClass() - Method in class org.apache.drill.exec.compile.sig.SignatureHolder
 
getSignatureTemplate(int) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
getSignatureTemplate(int) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
getSignatureTemplate(int) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
getSimpleName() - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTraitDef
 
getSimpleName() - Method in interface org.apache.drill.exec.rpc.security.AuthenticatorFactory
Name of the mechanism, in upper case.
getSimpleName() - Method in class org.apache.drill.exec.rpc.security.kerberos.KerberosFactory
 
getSimpleName() - Method in class org.apache.drill.exec.rpc.security.plain.PlainFactory
 
getSimplePatternString() - Method in class org.apache.drill.exec.expr.fn.impl.RegexpUtil.SqlPatternInfo
 
getSiteClass() - Method in interface org.apache.drill.exec.testing.ControlsInjector
Get the injector's owning class.
getSiteClass() - Method in class org.apache.drill.exec.testing.ExecutionControlsInjector
 
getSiteClass() - Method in class org.apache.drill.exec.testing.Injection
 
getSiteClass() - Method in class org.apache.drill.exec.testing.NoOpControlsInjector
 
getSize() - Method in class org.apache.drill.exec.physical.config.ProducerConsumer
 
getSize() - Method in class org.apache.drill.exec.server.rest.LogsResources.Log
 
getSliceTarget() - Method in interface org.apache.drill.exec.planner.fragment.ParallelizationParameters
 
getSliceTarget() - Method in class org.apache.drill.exec.planner.fragment.SimpleParallelizer
 
getSliceTarget() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
getSortedOperators() - Method in class org.apache.drill.exec.physical.PhysicalPlan
 
getSortedOperators(boolean) - Method in class org.apache.drill.exec.physical.PhysicalPlan
 
getSourceName(String) - Static method in class org.apache.drill.exec.util.JarUtil
Generates source jar name based on binary jar name.
getSpecificScan(int) - Method in interface org.apache.drill.exec.physical.base.GroupScan
 
getSpecificScan(int) - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
getSpecificScan(int) - Method in class org.apache.drill.exec.store.direct.DirectGroupScan
 
getSpecificScan(int) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaGroupScan
 
getSpecificScan(int) - Method in class org.apache.drill.exec.store.mock.MockGroupScanPOP
 
getSpecificScan(int) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
getSpecificScan(int) - Method in class org.apache.drill.exec.store.sys.SystemTableScan
 
getSpecificStore(PhysicalOperator, int) - Method in interface org.apache.drill.exec.physical.base.Store
Provides full materialized Store operators for execution purposes.
getSpecificStore(PhysicalOperator, int) - Method in class org.apache.drill.exec.physical.config.Screen
 
getSpecificStore(PhysicalOperator, int) - Method in class org.apache.drill.exec.store.mock.MockStorePOP
 
getSpillBatchRowCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
getSpillBatchSize() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
getSpillCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
 
getSplitFragments(OptionList, CoordinationProtos.DrillbitEndpoint, UserBitShared.QueryId, Collection<CoordinationProtos.DrillbitEndpoint>, PhysicalPlanReader, Fragment, UserSession, BitControl.QueryContextInformation) - Method in class org.apache.drill.exec.planner.fragment.contrib.SplittingParallelizer
Create multiple physical plans from original query planning, it will allow execute them eventually independently
getSplitFragments(OptionList, CoordinationProtos.DrillbitEndpoint, UserBitShared.QueryId, Collection<CoordinationProtos.DrillbitEndpoint>, PhysicalPlanReader, Fragment, UserSession, BitControl.QueryContextInformation) - Method in class org.apache.drill.exec.planner.fragment.SimpleParallelizer
Create multiple physical plans from original query planning, it will allow execute them eventually independently
getSql() - Method in class org.apache.drill.exec.dotdrill.View
 
getSqlAccessor(ValueVector) - Static method in class org.apache.drill.exec.expr.TypeHelper
 
getSqlHandler(SqlHandlerConfig) - Method in class org.apache.drill.exec.planner.sql.parser.DrillSqlCall
 
getSqlHandler(SqlHandlerConfig, Pointer<String>) - Method in class org.apache.drill.exec.planner.sql.parser.DrillSqlCall
 
getSqlHandler(SqlHandlerConfig) - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateFunction
 
getSqlHandler(SqlHandlerConfig) - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateTable
 
getSqlHandler(SqlHandlerConfig, Pointer<String>) - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateTable
 
getSqlHandler(SqlHandlerConfig) - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateView
 
getSqlHandler(SqlHandlerConfig) - Method in class org.apache.drill.exec.planner.sql.parser.SqlDescribeSchema
 
getSqlHandler(SqlHandlerConfig) - Method in class org.apache.drill.exec.planner.sql.parser.SqlDescribeTable
 
getSqlHandler(SqlHandlerConfig) - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropFunction
 
getSqlHandler(SqlHandlerConfig) - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropTable
 
getSqlHandler(SqlHandlerConfig) - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropView
 
getSqlHandler(SqlHandlerConfig) - Method in class org.apache.drill.exec.planner.sql.parser.SqlRefreshMetadata
 
getSqlHandler(SqlHandlerConfig) - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowFiles
 
getSqlHandler(SqlHandlerConfig) - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowSchemas
 
getSqlHandler(SqlHandlerConfig) - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowTables
 
getSqlHandler(SqlHandlerConfig) - Method in class org.apache.drill.exec.planner.sql.parser.SqlUseSchema
 
getSqlOperator(String) - Method in class org.apache.drill.exec.planner.sql.DrillOperatorTable
 
getSqlPatternMatcher(RegexpUtil.SqlPatternInfo) - Static method in class org.apache.drill.exec.expr.fn.impl.SqlPatternFactory
 
getSqlTypeName() - Method in class org.apache.drill.exec.planner.types.DrillFixedRelDataTypeImpl
 
getSqlTypeName() - Method in class org.apache.drill.exec.planner.types.RelDataTypeDrillImpl
 
getSqlTypeNameForTimeUnit(String) - Static method in class org.apache.drill.exec.planner.sql.TypeInferenceUtils
For Extract and date_part functions, infer the return types based on timeUnit
getSrc_ip() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
getSrc_port() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
getStagingArea() - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
 
getStart() - Method in class org.apache.drill.exec.physical.config.PartitionRange
 
getStart() - Method in class org.apache.drill.exec.physical.config.WindowPOP
 
getStart() - Method in interface org.apache.drill.exec.store.dfs.easy.FileWork
 
getStart() - Method in class org.apache.drill.exec.store.dfs.ReadEntryFromHDFS
 
getStart() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata
 
getStart() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v1
 
getStart() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v2
 
getStart() - Method in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v3
 
getStart() - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork.FileWorkImpl
 
getStart() - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork
 
getStart() - Method in class org.apache.drill.exec.work.foreman.LoggedQuery
 
getStartIndex(int) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelper
 
getStartTime() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.ProfileInfo
 
getStartUnit() - Method in class org.apache.drill.exec.dotdrill.View.FieldType
Gets the time range start unit of the type qualifier of the interval data type descriptor of this field (iff interval type).
getState() - Method in class org.apache.drill.exec.server.DrillbitStateManager
 
getState() - Method in class org.apache.drill.exec.server.rest.DrillRoot.DrillbitInfo
 
getState() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.ProfileInfo
 
getState() - Method in class org.apache.drill.exec.work.foreman.Foreman
 
getState() - Method in class org.apache.drill.exec.work.foreman.FragmentData
 
getStatistic() - Method in class org.apache.drill.exec.planner.logical.DrillTable
 
getStatistic() - Method in class org.apache.drill.exec.planner.logical.DrillTranslatableTable
 
getStatistic() - Method in class org.apache.drill.exec.planner.logical.DrillViewTable
 
getStatistics() - Method in class org.apache.drill.exec.store.parquet.stat.ColumnStatistics
 
getStats() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getStats() - Method in interface org.apache.drill.exec.ops.OperatorContext
Full operator stats (for legacy code).
getStats(HashTableStats) - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
 
getStats(HashTableStats) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
getStats() - Method in interface org.apache.drill.exec.physical.impl.partitionsender.Partitioner
 
getStats() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate
 
getStats() - Method in class org.apache.drill.exec.planner.fragment.Wrapper
 
getStatsWriter() - Method in interface org.apache.drill.exec.ops.OperatorContext
A write-only interface to the Drill statistics mechanism.
getStatus() - Method in class org.apache.drill.exec.server.rest.StatusResources
 
getStatus() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getStatus(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getStatus(String) - Method in class org.apache.drill.exec.store.dfs.MetadataContext
 
getStatus() - Method in class org.apache.drill.exec.work.fragment.FragmentExecutor
Returns the current fragment status if the fragment is running.
getStatuses(DrillFileSystem) - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
getStatusJSON() - Method in class org.apache.drill.exec.server.rest.StatusResources
 
getStorage() - Method in class org.apache.drill.exec.ops.QueryContext
 
getStorage() - Method in class org.apache.drill.exec.planner.logical.StoragePlugins
 
getStorage() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getStorageConfig() - Method in class org.apache.drill.exec.planner.logical.FileSystemCreateTableEntry
 
getStorageConfig() - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
getStorageConfig() - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
getStorageConfig() - Method in class org.apache.drill.exec.store.dfs.easy.EasySubScan
 
getStorageConfig() - Method in class org.apache.drill.exec.store.dfs.easy.EasyWriter
 
getStorageConfig() - Method in interface org.apache.drill.exec.store.dfs.FormatPlugin
 
getStorageConfig() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
getStorageConfig() - Method in class org.apache.drill.exec.store.parquet.ParquetWriter
 
getStorageEngine() - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
 
getStorageEngineConfig() - Method in class org.apache.drill.exec.planner.logical.DrillTable
 
getStorageEngineName() - Method in class org.apache.drill.exec.planner.logical.DrillTable
 
getStoragePlugin(String) - Method in class org.apache.drill.exec.server.rest.StorageResources
 
getStoragePluginJSON(String) - Method in class org.apache.drill.exec.server.rest.StorageResources
 
getStoragePlugins() - Method in class org.apache.drill.exec.server.rest.StorageResources
 
getStoragePluginsJSON() - Method in class org.apache.drill.exec.server.rest.StorageResources
 
getStorageStrategy() - Method in class org.apache.drill.exec.physical.base.AbstractWriter
 
getStore() - Method in interface org.apache.drill.exec.store.StoragePluginRegistry
Get the PStore for this StoragePluginRegistry.
getStore() - Method in class org.apache.drill.exec.store.StoragePluginRegistryImpl
 
getStoreProvider() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getStream(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getStream(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getStream(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVar16CharAccessor
 
getStream(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVarBinaryAccessor
 
getStream(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVarCharAccessor
 
getStream(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getStream(int) - Method in class org.apache.drill.exec.vector.accessor.Var16CharAccessor
 
getStream(int) - Method in class org.apache.drill.exec.vector.accessor.VarBinaryAccessor
 
getStream(int) - Method in class org.apache.drill.exec.vector.accessor.VarCharAccessor
 
getStream(int, int, DrillBuf) - Static method in class org.apache.drill.exec.vector.complex.fn.DrillBufInputStream
 
getString(String) - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
getString(String) - Method in interface org.apache.drill.exec.server.options.OptionSet
Return the value of a String option.
getString(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getString(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getString(int) - Method in class org.apache.drill.exec.vector.accessor.IntervalAccessor
 
getString(int) - Method in class org.apache.drill.exec.vector.accessor.IntervalDayAccessor
 
getString(int) - Method in class org.apache.drill.exec.vector.accessor.IntervalYearAccessor
 
getString(int) - Method in class org.apache.drill.exec.vector.accessor.NullableIntervalAccessor
 
getString(int) - Method in class org.apache.drill.exec.vector.accessor.NullableIntervalDayAccessor
 
getString(int) - Method in class org.apache.drill.exec.vector.accessor.NullableIntervalYearAccessor
 
getString(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVar16CharAccessor
 
getString(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVarBinaryAccessor
 
getString(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVarCharAccessor
 
getString(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getString(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
getString(int) - Method in class org.apache.drill.exec.vector.accessor.Var16CharAccessor
 
getString(int) - Method in class org.apache.drill.exec.vector.accessor.VarBinaryAccessor
 
getString(int) - Method in class org.apache.drill.exec.vector.accessor.VarCharAccessor
 
getStringFromVarCharHolder(VarCharHolder) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionHelpers
Convert a VarCharHolder to a String.
getStringFromVarCharHolder(NullableVarCharHolder) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionHelpers
Convert a NullableVarCharHolder to a String.
getStrings() - Method in class org.apache.drill.exec.store.httpd.HttpdLogRecord
 
getStringVal() - Method in class org.apache.drill.exec.server.options.PersistedOptionValue
This is present for forward compatibility.
getSubPartitions(String, List<String>, List<String>) - Method in class org.apache.drill.exec.store.AbstractSchema
 
getSubPartitions(String, List<String>, List<String>) - Method in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory.FileSystemSchema
 
getSubPartitions(String, List<String>, List<String>) - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
getSubPartitions(String, String, List<String>, List<String>) - Method in interface org.apache.drill.exec.store.PartitionExplorer
For the schema provided, get a list of sub-partitions of a particular table and the partitions specified by partition columns and values.
getSubPartitions(String, String, List<String>, List<String>) - Method in class org.apache.drill.exec.store.PartitionExplorerImpl
 
getSubPartitions(String, List<String>, List<String>) - Method in interface org.apache.drill.exec.store.SchemaPartitionExplorer
Get a list of sub-partitions of a particular table and the partitions specified by partition columns and values.
getSubPartitions(String, List<String>, List<String>) - Method in class org.apache.drill.exec.store.SubSchemaWrapper
 
getSubSchema(String, boolean) - Method in class org.apache.drill.exec.planner.sql.DynamicRootSchema
 
getSubSchema(String, boolean) - Method in class org.apache.drill.exec.planner.sql.DynamicSchema
 
getSubSchema(String) - Method in class org.apache.drill.exec.store.AbstractSchema
 
getSubSchema(String) - Method in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory.FileSystemSchema
 
getSubSchema(String) - Method in class org.apache.drill.exec.store.SubSchemaWrapper
 
getSubSchemaNames() - Method in class org.apache.drill.exec.store.AbstractSchema
 
getSubSchemaNames() - Method in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory.FileSystemSchema
 
getSubSchemaNames() - Method in class org.apache.drill.exec.store.SubSchemaWrapper
 
getSubTypes(ScanResult) - Static method in class org.apache.drill.exec.physical.base.PhysicalOperatorUtil
 
GetSuffix(int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.BroadcastExchangePrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.ComplexToJsonPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.FilterPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.HashAggPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.HashJoinPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.HashToRandomExchangePrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.LimitPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.MergeJoinPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.NestedLoopJoinPrel
 
getSupportedEncodings() - Method in interface org.apache.drill.exec.planner.physical.Prel
Supported 'encodings' of a Prel indicates what are the acceptable modes of SelectionVector of its child Prel
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.ProducerConsumerPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.ProjectPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.ScanPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.ScreenPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.SinglePrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.SortPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.StreamAggPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.TopNPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.UnionAllPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.UnionDistinctPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.UnorderedDeMuxExchangePrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.ValuesPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.WindowPrel
 
getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.WriterPrel
 
getSupportedMethods() - Method in class org.apache.drill.exec.client.DrillClient
Returns the list of methods supported by the server based on its advertised information.
getSupportedMethods() - Method in class org.apache.drill.exec.rpc.user.UserClient
 
getSv2() - Method in class org.apache.drill.exec.cache.VectorAccessibleSerializable
 
getSv2() - Method in class org.apache.drill.exec.physical.impl.aggregate.InternalBatch
 
getSv2() - Method in class org.apache.drill.exec.physical.impl.sort.RecordBatchData
 
getSv2() - Method in class org.apache.drill.exec.physical.impl.xsort.BatchGroup
 
getSv2() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.InputBatch
 
getSv2() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MergeSortWrapper
 
getSv2() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierWrapper.BatchMerger
 
getSv2() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.EmptyResults
 
getSv2() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SingleBatchResults
 
getSv2() - Method in interface org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SortResults
 
getSv4() - Method in class org.apache.drill.exec.physical.impl.aggregate.InternalBatch
 
getSv4() - Method in class org.apache.drill.exec.physical.impl.sort.SortRecordBatchBuilder
 
getSv4() - Method in interface org.apache.drill.exec.physical.impl.TopN.PriorityQueue
 
getSv4() - Method in class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
 
getSv4() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MergeSortWrapper
 
getSV4() - Method in interface org.apache.drill.exec.physical.impl.xsort.managed.MSorter
 
getSV4() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MSortTemplate
 
getSv4() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierWrapper.BatchMerger
 
getSv4() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.EmptyResults
 
getSv4() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SingleBatchResults
 
getSv4() - Method in interface org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SortResults
 
getSV4() - Method in interface org.apache.drill.exec.physical.impl.xsort.MSorter
 
getSV4() - Method in class org.apache.drill.exec.physical.impl.xsort.MSortTemplate
 
getSVMode() - Method in class org.apache.drill.exec.physical.base.AbstractBase
 
getSVMode() - Method in class org.apache.drill.exec.physical.base.AbstractSubScan
 
getSVMode() - Method in interface org.apache.drill.exec.physical.base.PhysicalOperator
Describes the SelectionVector Mode for the output steam from this physical op.
getSVMode() - Method in class org.apache.drill.exec.physical.config.ComplexToJson
 
getSVMode() - Method in class org.apache.drill.exec.physical.config.Filter
 
getSVMode() - Method in class org.apache.drill.exec.physical.config.Limit
 
getSVMode() - Method in class org.apache.drill.exec.physical.config.Project
 
getSVMode() - Method in class org.apache.drill.exec.physical.config.SelectionVectorRemover
 
getSVMode() - Method in class org.apache.drill.exec.physical.config.Sort
 
getSyntax() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
getSyntax() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
getSyntax() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
getSyntax() - Method in class org.apache.drill.exec.planner.sql.DrillSqlOperator
 
getSystemInternalOptions() - Method in class org.apache.drill.exec.server.rest.StatusResources
 
getSystemInternalOptionsJSON() - Method in class org.apache.drill.exec.server.rest.StatusResources
 
getSystemOptionManager() - Method in class org.apache.drill.exec.server.options.SessionOptionManager
Gets the SystemOptionManager.
getSystemOptions() - Method in class org.apache.drill.exec.work.user.UserWorker
 
getSystemPublicOptions() - Method in class org.apache.drill.exec.server.rest.StatusResources
 
getSystemPublicOptionsJSON() - Method in class org.apache.drill.exec.server.rest.StatusResources
 
getTable() - Method in class org.apache.drill.exec.planner.FileSystemPartitionDescriptor
 
getTable() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDescribeTable
 
getTable(Scan) - Method in class org.apache.drill.exec.planner.torel.ConversionContext
 
getTable(String) - Method in class org.apache.drill.exec.store.AbstractSchema
 
getTable(String) - Method in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory.FileSystemSchema
 
getTable(String) - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
getTable() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaGroupScan
 
getTable() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaSubScan
 
getTable(String) - Method in class org.apache.drill.exec.store.SubSchemaWrapper
 
getTable() - Method in class org.apache.drill.exec.store.sys.SystemTableScan
 
getTableColumns() - Method in class org.apache.drill.exec.store.ColumnExplorer
 
getTableFromSchema(AbstractSchema, String) - Static method in class org.apache.drill.exec.planner.sql.handlers.SqlHandlerUtil
 
getTableIdentifier() - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropTable
 
getTableName() - Method in enum org.apache.drill.exec.store.sys.SystemTable
 
getTableNames() - Method in class org.apache.drill.exec.planner.sql.DynamicRootSchema
 
getTableNames() - Method in class org.apache.drill.exec.store.AbstractSchema
 
getTableNames() - Method in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory.FileSystemSchema
 
getTableNames() - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
getTableNames() - Method in class org.apache.drill.exec.store.SubSchemaWrapper
 
getTableNamesAndTypes(boolean, int) - Method in class org.apache.drill.exec.store.AbstractSchema
 
getTableNamesAndTypes(boolean, int) - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
getTables(UserProtos.LikeFilter, UserProtos.LikeFilter, UserProtos.LikeFilter, List<String>) - Method in class org.apache.drill.exec.client.DrillClient
Get the list of tables in INFORMATION_SCHEMA.TABLES table satisfying the given filters.
getTablesByNames(List<String>) - Method in class org.apache.drill.exec.store.AbstractSchema
Get the collection of Table tables specified in the tableNames.
getTablesByNamesByBulkLoad(List<String>, int) - Method in class org.apache.drill.exec.store.AbstractSchema
Get the collection of Table tables specified in the tableNames with bulk-load (if the underlying storage plugin supports).
getTabSize(int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
getTargetUserName() - Method in class org.apache.drill.exec.rpc.user.UserSession
 
getTemplateClass() - Method in class org.apache.drill.exec.compile.TemplateClassDefinition
 
getTemplateClassName() - Method in class org.apache.drill.exec.compile.TemplateClassDefinition
 
getTemporaryWorkspace(SchemaPlus, DrillConfig) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
Looks in schema tree for default temporary workspace instance.
getThreadStart() - Method in class org.apache.drill.exec.store.TimedRunnable
 
getThrowsIterable() - Method in class org.apache.drill.exec.compile.sig.CodeGeneratorMethod
 
getTime() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.ProfileInfo
 
getTime(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getTime(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getTime(int) - Method in class org.apache.drill.exec.vector.accessor.NullableTimeAccessor
 
getTime(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getTime(int) - Method in class org.apache.drill.exec.vector.accessor.TimeAccessor
 
getTimeNs() - Method in class org.apache.drill.exec.cache.VectorAccessibleSerializable
 
getTimeSpentNanos() - Method in class org.apache.drill.exec.store.TimedRunnable
 
getTimestamp() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
getTimestamp(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
getTimestamp(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getTimestamp(int) - Method in class org.apache.drill.exec.vector.accessor.NullableTimeStampAccessor
 
getTimestamp(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
getTimestamp(int) - Method in class org.apache.drill.exec.vector.accessor.TimeStampAccessor
 
getTimestampFormat() - Method in class org.apache.drill.exec.store.httpd.HttpdLogFormatPlugin.HttpdLogFormatConfig
 
getTmpArea() - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
 
getToken(int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
getTotalBytes() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan.RowGroupInfo
 
getTotalBytes() - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork
 
getTotalBytes() - Method in interface org.apache.drill.exec.store.schedule.CompleteWork
 
getTotalCost() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.ProfileInfo
 
getTotalCount() - Method in class org.apache.drill.exec.record.selection.SelectionVector4
 
getTotalIncomingFragments() - Method in class org.apache.drill.exec.work.batch.AbstractDataCollector
 
getTotalRecordCount() - Method in class org.apache.drill.exec.record.RecordIterator
 
getTotalRecords() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
getTotalRecords() - Method in interface org.apache.drill.exec.physical.impl.partitionsender.PartitionOutgoingBatch
 
getTotalValueCount() - Method in class org.apache.parquet.hadoop.ColumnChunkIncReadStore.ColumnChunkIncPageReader
 
getTraitClass() - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTraitDef
 
getTraitDef() - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
 
getTransferClone(VectorAccessible, OperatorContext) - Static method in class org.apache.drill.exec.record.VectorContainer
Get a set of transferred clones of this container.
getTransferClone(VectorAccessible, BufferAllocator) - Static method in class org.apache.drill.exec.record.VectorContainer
 
getTransferClone(VectorAccessible, VectorWrapper<?>[], OperatorContext) - Static method in class org.apache.drill.exec.record.VectorContainer
 
getTrustStorePassword() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
getTrustStorePassword() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
getTrustStorePassword() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
getTrustStorePath() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
getTrustStorePath() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
getTrustStorePath() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
getTrustStoreType() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
getTrustStoreType() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
getTrustStoreType() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
getTtl() - Method in class org.apache.drill.exec.server.options.OptionValidator
If an option is short-lived, this method returns the number of queries for which the option is valid.
getTtl() - Method in class org.apache.drill.exec.testing.ExecutionControls.ControlsOptionValidator
 
getTunnel(CoordinationProtos.DrillbitEndpoint) - Method in interface org.apache.drill.exec.rpc.control.Controller
Get a Bit to Bit communication tunnel.
getTunnel(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.rpc.control.ControllerImpl
 
getTunnel(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.rpc.data.DataConnectionCreator
 
getType() - Method in class org.apache.drill.exec.compile.sig.CodeGeneratorArgument
 
getType() - Method in class org.apache.drill.exec.coord.store.TransientStoreEvent
 
getType() - Method in class org.apache.drill.exec.dotdrill.DotDrillFile
 
getType() - Method in class org.apache.drill.exec.dotdrill.View.FieldType
Gets the data type of this field.
getType(List<LogicalExpression>, FunctionAttributes) - Method in enum org.apache.drill.exec.expr.annotations.FunctionTemplate.ReturnType
 
getType(List<LogicalExpression>, FunctionAttributes) - Method in class org.apache.drill.exec.expr.fn.output.ConcatReturnTypeInference
Defines function return type and sets precision if it can be calculated.
getType(List<LogicalExpression>, FunctionAttributes) - Method in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalAddReturnTypeInference
This return type is used by add and subtract functions for decimal data type.
getType(List<LogicalExpression>, FunctionAttributes) - Method in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalAggReturnTypeInference
 
getType(List<LogicalExpression>, FunctionAttributes) - Method in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalCastReturnTypeInference
 
getType(List<LogicalExpression>, FunctionAttributes) - Method in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalDivScaleReturnTypeInference
Return type is used by divide functions for decimal data type.
getType(List<LogicalExpression>, FunctionAttributes) - Method in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalMaxScaleReturnTypeInference
 
getType(List<LogicalExpression>, FunctionAttributes) - Method in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalModScaleReturnTypeInference
Return type is used by divide functions for decimal data type.
getType(List<LogicalExpression>, FunctionAttributes) - Method in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalSetScaleReturnTypeInference
 
getType(List<LogicalExpression>, FunctionAttributes) - Method in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalSumAggReturnTypeInference
 
getType(List<LogicalExpression>, FunctionAttributes) - Method in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalSumScaleReturnTypeInference
 
getType(List<LogicalExpression>, FunctionAttributes) - Method in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalZeroScaleReturnTypeInference
Return type is used for functions where we need to remove the scale part.
getType(List<LogicalExpression>, FunctionAttributes) - Method in class org.apache.drill.exec.expr.fn.output.DefaultReturnTypeInference
Calculates return type and its nullability.
getType(List<LogicalExpression>, FunctionAttributes) - Method in class org.apache.drill.exec.expr.fn.output.PadReturnTypeInference
Defines function return type and sets precision if it pad length parameter is int expression.
getType(List<LogicalExpression>, FunctionAttributes) - Method in interface org.apache.drill.exec.expr.fn.output.ReturnTypeInference
 
getType(List<LogicalExpression>, FunctionAttributes) - Method in class org.apache.drill.exec.expr.fn.output.SameInOutLengthReturnTypeInference
Defines function return type and sets precision and scale if input type has them.
getType(List<LogicalExpression>, FunctionAttributes) - Method in class org.apache.drill.exec.expr.fn.output.StringCastReturnTypeInference
Defines function return type and sets cast length as type precision if cast length is simple long expression.
getType() - Method in class org.apache.drill.exec.expr.fn.ValueReference
 
getType() - Method in class org.apache.drill.exec.expr.fn.WorkspaceReference
 
getType() - Method in class org.apache.drill.exec.planner.physical.AggPrelBase.SqlSumCountAggFunction
 
getType() - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
 
getType() - Method in class org.apache.drill.exec.server.options.PersistedOptionValue
This is present for forward compatibility.
getType() - Method in class org.apache.drill.exec.server.rest.QueryWrapper
 
getType(PrimitiveType.PrimitiveTypeName, OriginalType, int, int) - Static method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
Builds major type using given OriginalType originalType or PrimitiveTypeName type.
getType() - Method in class org.apache.drill.exec.vector.accessor.BigIntAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.BitAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.DateAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.Decimal18Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.Decimal28DenseAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.Decimal28SparseAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.Decimal38DenseAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.Decimal38SparseAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.Decimal9Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.Float4Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.Float8Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.GenericAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.IntAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.IntervalAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.IntervalDayAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.IntervalYearAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableBigIntAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableBitAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableDateAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal18Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal28DenseAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal28SparseAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal38DenseAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal38SparseAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal9Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableFloat4Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableFloat8Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableIntAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableIntervalAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableIntervalDayAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableIntervalYearAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableSmallIntAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableTimeAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableTimeStampAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableTinyIntAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableUInt1Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableUInt2Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableUInt4Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableUInt8Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableVar16CharAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableVarBinaryAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.NullableVarCharAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.SmallIntAccessor
 
getType() - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
Reports the (native) type of data accessed by this accessor.
getType() - Method in class org.apache.drill.exec.vector.accessor.TimeAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.TimeStampAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.TinyIntAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.UInt1Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.UInt2Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.UInt4Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.UInt8Accessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.Var16CharAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.VarBinaryAccessor
 
getType() - Method in class org.apache.drill.exec.vector.accessor.VarCharAccessor
 
getTypedFieldId() - Method in class org.apache.drill.exec.expr.ValueVectorReadExpression
 
getTypeFactory() - Method in class org.apache.drill.exec.planner.sql.SqlConverter
 
getTypeFactory() - Method in class org.apache.drill.exec.planner.torel.ConversionContext
 
getTypeForColumn(SchemaPath) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
getTypeLengthInBits(PrimitiveType.PrimitiveTypeName) - Static method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetColumnMetadata
 
getTypeName() - Method in class org.apache.drill.exec.store.AbstractSchema
 
getTypeName() - Method in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory.FileSystemSchema
 
getTypeName() - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
getTypeName() - Method in class org.apache.drill.exec.store.SubSchemaWrapper
 
getTypes() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockScanEntry
 
getUmask() - Method in class org.apache.drill.exec.store.StorageStrategy
 
getUnEncryptedConnectionCount() - Method in class org.apache.drill.exec.rpc.control.ControlRpcMetrics
 
getUnEncryptedConnectionCount() - Method in class org.apache.drill.exec.rpc.data.DataRpcMetrics
 
getUnEncryptedConnectionCount() - Method in class org.apache.drill.exec.rpc.user.UserRpcMetrics
 
getUnfilteredRecordCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
getUnsignedByte(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getUnsignedInt(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getUnsignedMedium(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getUnsignedShort(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
getUri() - Method in class org.apache.drill.exec.store.ClassPathFileSystem
 
getUri() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getUri() - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem
 
getUrl() - Method in class org.apache.drill.exec.store.mock.MockGroupScanPOP
 
getUrl() - Method in class org.apache.drill.exec.store.mock.MockStorageEngineConfig
 
getUrl() - Method in class org.apache.drill.exec.store.mock.MockSubScanPOP
 
getUsed() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getUser() - Method in class org.apache.drill.exec.server.rest.profile.ProfileResources.ProfileInfo
 
getUserDataTunnel() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getUserName() - Method in class org.apache.drill.exec.physical.base.AbstractBase
 
getUserName() - Method in interface org.apache.drill.exec.physical.base.PhysicalOperator
Name of the user whom to impersonate while setting up the implementation (RecordBatch) of this PhysicalOperator.
getUserName() - Method in class org.apache.drill.exec.planner.logical.DrillTable
 
getUserName() - Method in class org.apache.drill.exec.store.SchemaConfig
 
getUsername() - Method in class org.apache.drill.exec.work.foreman.LoggedQuery
 
getUserPort() - Method in class org.apache.drill.exec.server.Drillbit
 
getUserPort() - Method in class org.apache.drill.exec.server.rest.DrillRoot.DrillbitInfo
 
getUserPort() - Method in class org.apache.drill.exec.service.ServiceEngine
 
getUserWorker() - Method in class org.apache.drill.exec.work.WorkManager
 
getUTF8CharLength(ByteBuf, int, int) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionUtil
 
getUTF8CharPosition(ByteBuf, int, int, int) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionUtil
 
getValidatedRowType() - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler.ConvertedRelNode
 
getValidator() - Method in class org.apache.drill.exec.server.options.OptionDefinition
 
getValue() - Method in class org.apache.drill.exec.coord.store.TransientStoreEvent
 
getValue() - Method in enum org.apache.drill.exec.expr.annotations.FunctionTemplate.FunctionCostCategory
 
getValue() - Method in class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
 
getValue() - Method in class org.apache.drill.exec.server.options.OptionValue
 
getValue() - Method in class org.apache.drill.exec.server.options.PersistedOptionValue
This is ignored for forward compatibility.
getValue() - Method in class org.apache.drill.exec.server.rest.StatusResources.OptionWrapper
 
getValue(Path) - Method in enum org.apache.drill.exec.store.ColumnExplorer.ImplicitFileColumns
Using file path calculates value for each implicit file column
getValue() - Method in class org.apache.drill.exec.store.TimedRunnable
 
getValue() - Method in class org.apache.drill.exec.work.EndpointListener
 
getValueAccessorById(Class<?>, int[]) - Method in class org.apache.drill.exec.physical.impl.aggregate.InternalBatch
 
getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
 
getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.physical.impl.ScanBatch
 
getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
 
getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.physical.impl.window.WindowDataBatch
 
getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.physical.impl.xsort.BatchGroup
 
getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
getValueAccessorById(Class<?>, int...) - Method in interface org.apache.drill.exec.record.RecordBatch
 
getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.record.RecordBatchLoader
 
getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.record.RecordIterator
 
getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.record.SimpleRecordBatch
 
getValueAccessorById(Class<?>, int...) - Method in interface org.apache.drill.exec.record.VectorAccessible
 
getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.record.VectorContainer
 
getValueAsString() - Method in class org.apache.drill.exec.server.rest.StatusResources.OptionWrapper
 
getValueCapacity() - Method in class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
 
getValueClass() - Method in class org.apache.drill.exec.cache.DistributedCache.CacheConfig
 
getValueFromFieldType(JsonParser, TypeProtos.MinorType) - Static method in class org.apache.drill.exec.schema.json.jackson.JacksonHelper
 
getValueReadIndex() - Method in class org.apache.drill.exec.compile.sig.MappingSet
 
getValueVector() - Method in class org.apache.drill.exec.record.HyperVectorWrapper
 
getValueVector() - Method in class org.apache.drill.exec.record.SimpleVectorWrapper
 
getValueVector(int) - Method in class org.apache.drill.exec.record.VectorContainer
 
getValueVector() - Method in interface org.apache.drill.exec.record.VectorWrapper
 
getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
 
getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.physical.impl.ScanBatch
 
getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
 
getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.physical.impl.window.WindowDataBatch
 
getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.physical.impl.xsort.BatchGroup
 
getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
getValueVectorId(SchemaPath) - Method in interface org.apache.drill.exec.record.RecordBatch
Gets the value vector type and ID for the given schema path.
getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.record.RecordBatchLoader
 
getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.record.RecordIterator
 
getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.record.SimpleRecordBatch
 
getValueVectorId(SchemaPath) - Method in interface org.apache.drill.exec.record.VectorAccessible
Get the value vector type and id for the given schema path.
getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.record.VectorContainer
 
getValueVectors() - Method in class org.apache.drill.exec.record.HyperVectorWrapper
 
getValueVectors() - Method in class org.apache.drill.exec.record.SimpleVectorWrapper
 
getValueVectors() - Method in interface org.apache.drill.exec.record.VectorWrapper
 
getValueWriteIndex() - Method in class org.apache.drill.exec.compile.sig.MappingSet
 
getVectorClass() - Method in class org.apache.drill.exec.record.HyperVectorWrapper
 
getVectorClass() - Method in class org.apache.drill.exec.record.SimpleVectorWrapper
 
getVectorClass() - Method in interface org.apache.drill.exec.record.VectorWrapper
 
getVectorIndex(int) - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
 
getVectorIndex(int) - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
 
getVectors() - Method in class org.apache.drill.exec.physical.impl.sort.RecordBatchData
 
getVectorType(SchemaPath, PlannerSettings) - Method in class org.apache.drill.exec.planner.FileSystemPartitionDescriptor
 
getVectorType(SchemaPath, PlannerSettings) - Method in class org.apache.drill.exec.planner.ParquetPartitionDescriptor
 
getVectorType(SchemaPath, PlannerSettings) - Method in interface org.apache.drill.exec.planner.PartitionDescriptor
Method returns the Major type associated with the given column
getVersion() - Static method in class org.apache.drill.common.util.DrillVersionInfo
Get the Drill version from pom
getVersion() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
This is read operation, so several users at a time can get this data.
getVersion() - Method in class org.apache.drill.exec.expr.fn.registry.LocalFunctionRegistry
 
getVersion(UserProtos.RpcEndpointInfos) - Static method in class org.apache.drill.exec.rpc.user.UserRpcUtils
Get the version from a RpcEndpointInfos instance
getVersion() - Method in class org.apache.drill.exec.server.rest.DrillRoot.DrillbitInfo
 
getVersion() - Method in class org.apache.drill.exec.store.sys.store.DataChangeVersion
 
getView(LogicalPlanPersistence) - Method in class org.apache.drill.exec.dotdrill.DotDrillFile
 
getViewExpansionContext() - Method in class org.apache.drill.exec.ops.QueryContext
 
getViewExpansionContext() - Method in class org.apache.drill.exec.store.SchemaConfig
 
getViewExpansionContext() - Method in interface org.apache.drill.exec.store.SchemaConfig.SchemaConfigInfoProvider
 
getViewSql() - Method in interface org.apache.drill.exec.planner.logical.DrillViewInfoProvider
Get the query part of the view.
getViewSql() - Method in class org.apache.drill.exec.planner.logical.DrillViewTable
 
getVIntSize(long) - Static method in class org.apache.drill.exec.util.ByteBufUtil.HadoopWritables
Get the encoded length if an integer is stored in a variable-length format
getWaitNanos() - Method in class org.apache.drill.exec.ops.OperatorStats
 
getWebServerPort() - Method in class org.apache.drill.exec.server.Drillbit
 
getWhereClause() - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowSchemas
 
getWhereClause() - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowTables
 
getWidth() - Method in class org.apache.drill.exec.planner.fragment.Wrapper
 
getWidth() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
getWidthValue() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
getWithins() - Method in class org.apache.drill.exec.physical.config.WindowPOP
 
getWorkBuf() - Method in class org.apache.drill.exec.vector.complex.fn.JsonReader
 
getWorkBus() - Method in class org.apache.drill.exec.server.DrillbitContext
 
getWorkBus() - Method in class org.apache.drill.exec.work.WorkManager
 
getWorkEventbus() - Method in class org.apache.drill.exec.ops.FragmentContext
 
getWorkingDirectory() - Method in class org.apache.drill.exec.store.ClassPathFileSystem
 
getWorkingDirectory() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getWorkingDirectory() - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem
 
getWorkIterable() - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
getWorkspace() - Method in class org.apache.drill.exec.compile.sig.MappingSet
 
getWorkspaceIndex() - Method in class org.apache.drill.exec.compile.sig.MappingSet
 
getWorkspaceSchemaPath() - Method in class org.apache.drill.exec.dotdrill.View
 
getWorkspaceTypes() - Method in class org.apache.drill.exec.expr.ClassGenerator
 
getWorkspaceVars() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
getWorkspaceVars() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
 
getWorkspaceVectors() - Method in class org.apache.drill.exec.expr.ClassGenerator
 
getWorkUnits() - Method in class org.apache.drill.exec.store.dfs.easy.EasySubScan
 
getWrappedConnectionHandler(RpcConnectionHandler<UserClient.UserToBitConnection>) - Method in class org.apache.drill.exec.rpc.user.QueryResultHandler
 
getWrappedListener(UserResultsListener) - Method in class org.apache.drill.exec.rpc.user.QueryResultHandler
 
getWrappedStream() - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
getWritableBatch() - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
 
getWritableBatch() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
getWritableBatch() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
getWritableBatch() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
 
getWritableBatch() - Method in class org.apache.drill.exec.physical.impl.sort.SortBatch
 
getWritableBatch() - Method in class org.apache.drill.exec.physical.impl.svremover.RemovingRecordBatch
 
getWritableBatch() - Method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
getWritableBatch() - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
 
getWritableBatch() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
getWritableBatch() - Method in class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch
 
getWritableBatch() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
 
getWritableBatch() - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
getWritableBatch() - Method in interface org.apache.drill.exec.record.RecordBatch
Gets a writable version of this batch.
getWritableBatch() - Method in class org.apache.drill.exec.record.RecordBatchLoader
 
getWritableBatch() - Method in class org.apache.drill.exec.record.SimpleRecordBatch
 
getWriteBytes() - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet
 
getWriteBytes() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
 
getWriteBytes() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SpilledRuns
 
getWriter(PhysicalOperator) - Method in interface org.apache.drill.exec.planner.logical.CreateTableEntry
 
getWriter(PhysicalOperator) - Method in class org.apache.drill.exec.planner.logical.FileSystemCreateTableEntry
 
getWriter(String, VectorContainer) - Static method in class org.apache.drill.exec.record.VectorAccessibleComplexWriter
 
getWriter(PhysicalOperator, String, List<String>) - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
getWriter(PhysicalOperator, String, List<String>) - Method in interface org.apache.drill.exec.store.dfs.FormatPlugin
 
getWriter(PhysicalOperator, String, List<String>) - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
getWriter(Class<?>, String, DrillBuf) - Static method in class org.apache.drill.exec.store.pojo.PojoWriters
Creates matching writer to the given field type.
getWriter() - Method in class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
 
getWriterBatch(FragmentContext, RecordBatch, EasyWriter) - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
getWriterBatch(FragmentContext, RecordBatch, ParquetWriter) - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
getWriterOperatorType() - Method in class org.apache.drill.exec.store.avro.AvroFormatPlugin
 
getWriterOperatorType() - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
getWriterOperatorType() - Method in class org.apache.drill.exec.store.easy.json.JSONFormatPlugin
 
getWriterOperatorType() - Method in class org.apache.drill.exec.store.easy.sequencefile.SequenceFileFormatPlugin
 
getWriterOperatorType() - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin
 
getWriterOperatorType() - Method in class org.apache.drill.exec.store.httpd.HttpdLogFormatPlugin
 
getWriterOperatorType() - Method in class org.apache.drill.exec.store.pcap.PcapFormatPlugin
 
getXAttr(Path, String) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getXAttrs(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
getXAttrs(Path, List<String>) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
GExtract - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract
 
GExtract.DayFromDate - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.DayFromDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.DayFromDate
 
GExtract.DayFromInterval - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.DayFromInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.DayFromInterval
 
GExtract.DayFromIntervalDay - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.DayFromIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.DayFromIntervalDay
 
GExtract.DayFromIntervalYear - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.DayFromIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.DayFromIntervalYear
 
GExtract.DayFromTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.DayFromTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.DayFromTimeStamp
 
GExtract.HourFromDate - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.HourFromDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromDate
 
GExtract.HourFromInterval - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.HourFromInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromInterval
 
GExtract.HourFromIntervalDay - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.HourFromIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromIntervalDay
 
GExtract.HourFromIntervalYear - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.HourFromIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromIntervalYear
 
GExtract.HourFromTime - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.HourFromTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromTime
 
GExtract.HourFromTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.HourFromTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromTimeStamp
 
GExtract.MinuteFromDate - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.MinuteFromDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromDate
 
GExtract.MinuteFromInterval - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.MinuteFromInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromInterval
 
GExtract.MinuteFromIntervalDay - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.MinuteFromIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromIntervalDay
 
GExtract.MinuteFromIntervalYear - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.MinuteFromIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromIntervalYear
 
GExtract.MinuteFromTime - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.MinuteFromTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromTime
 
GExtract.MinuteFromTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.MinuteFromTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromTimeStamp
 
GExtract.MonthFromDate - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.MonthFromDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.MonthFromDate
 
GExtract.MonthFromInterval - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.MonthFromInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.MonthFromInterval
 
GExtract.MonthFromIntervalDay - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.MonthFromIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.MonthFromIntervalDay
 
GExtract.MonthFromIntervalYear - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.MonthFromIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.MonthFromIntervalYear
 
GExtract.MonthFromTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.MonthFromTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.MonthFromTimeStamp
 
GExtract.SecondFromDate - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.SecondFromDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromDate
 
GExtract.SecondFromInterval - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.SecondFromInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromInterval
 
GExtract.SecondFromIntervalDay - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.SecondFromIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromIntervalDay
 
GExtract.SecondFromIntervalYear - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.SecondFromIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromIntervalYear
 
GExtract.SecondFromTime - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.SecondFromTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromTime
 
GExtract.SecondFromTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.SecondFromTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromTimeStamp
 
GExtract.YearFromDate - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.YearFromDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.YearFromDate
 
GExtract.YearFromInterval - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.YearFromInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.YearFromInterval
 
GExtract.YearFromIntervalDay - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.YearFromIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.YearFromIntervalDay
 
GExtract.YearFromIntervalYear - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.YearFromIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.YearFromIntervalYear
 
GExtract.YearFromTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GExtract.YearFromTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GExtract.YearFromTimeStamp
 
GFloat4ToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GFloat4ToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GFloat4ToChar
 
GFloat4ToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GFloat4ToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GFloat4ToTimeStamp
 
GFloat8ToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GFloat8ToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GFloat8ToChar
 
GFloat8ToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GFloat8ToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GFloat8ToTimeStamp
 
GIntToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GIntToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GIntToChar
 
GIntToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GIntToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GIntToTimeStamp
 
GLOBAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
globStatus(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
globStatus(Path, PathFilter) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
GM(String, String) - Static method in class org.apache.drill.exec.compile.sig.GeneratorMapping
 
GM(String, String, String, String) - Static method in class org.apache.drill.exec.compile.sig.GeneratorMapping
 
GMathFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.AbsBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.AbsBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsBigInt
 
GMathFunctions.AbsFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.AbsFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsFloat4
 
GMathFunctions.AbsFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.AbsFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsFloat8
 
GMathFunctions.AbsInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.AbsInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsInt
 
GMathFunctions.AbsSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.AbsSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsSmallInt
 
GMathFunctions.AbsTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.AbsTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsTinyInt
 
GMathFunctions.AbsUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.AbsUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsUInt1
 
GMathFunctions.AbsUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.AbsUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsUInt2
 
GMathFunctions.AbsUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.AbsUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsUInt4
 
GMathFunctions.AbsUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.AbsUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsUInt8
 
GMathFunctions.CeilBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.CeilBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilBigInt
 
GMathFunctions.CeilFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.CeilFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilFloat4
 
GMathFunctions.CeilFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.CeilFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilFloat8
 
GMathFunctions.CeilInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.CeilInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilInt
 
GMathFunctions.CeilSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.CeilSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilSmallInt
 
GMathFunctions.CeilTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.CeilTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilTinyInt
 
GMathFunctions.CeilUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.CeilUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilUInt1
 
GMathFunctions.CeilUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.CeilUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilUInt2
 
GMathFunctions.CeilUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.CeilUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilUInt4
 
GMathFunctions.CeilUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.CeilUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilUInt8
 
GMathFunctions.DivBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.DivBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivBigInt
 
GMathFunctions.DivFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.DivFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivFloat4
 
GMathFunctions.DivFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.DivFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivFloat8
 
GMathFunctions.DivInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.DivInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivInt
 
GMathFunctions.DivSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.DivSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivSmallInt
 
GMathFunctions.DivTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.DivTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivTinyInt
 
GMathFunctions.DivUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.DivUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivUInt1
 
GMathFunctions.DivUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.DivUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivUInt2
 
GMathFunctions.DivUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.DivUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivUInt4
 
GMathFunctions.DivUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.DivUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivUInt8
 
GMathFunctions.FloorBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.FloorBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorBigInt
 
GMathFunctions.FloorFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.FloorFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorFloat4
 
GMathFunctions.FloorFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.FloorFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorFloat8
 
GMathFunctions.FloorInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.FloorInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorInt
 
GMathFunctions.FloorSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.FloorSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorSmallInt
 
GMathFunctions.FloorTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.FloorTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorTinyInt
 
GMathFunctions.FloorUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.FloorUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorUInt1
 
GMathFunctions.FloorUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.FloorUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorUInt2
 
GMathFunctions.FloorUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.FloorUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorUInt4
 
GMathFunctions.FloorUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.FloorUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorUInt8
 
GMathFunctions.LeftShiftBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.LeftShiftBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftBigInt
 
GMathFunctions.LeftShiftInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.LeftShiftInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftInt
 
GMathFunctions.LeftShiftSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.LeftShiftSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftSmallInt
 
GMathFunctions.LeftShiftTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.LeftShiftTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftTinyInt
 
GMathFunctions.LeftShiftUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.LeftShiftUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftUInt1
 
GMathFunctions.LeftShiftUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.LeftShiftUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftUInt2
 
GMathFunctions.LeftShiftUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.LeftShiftUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftUInt4
 
GMathFunctions.LeftShiftUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.LeftShiftUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftUInt8
 
GMathFunctions.ModBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.ModBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModBigInt
 
GMathFunctions.ModFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.ModFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModFloat4
 
GMathFunctions.ModFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.ModFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModFloat8
 
GMathFunctions.ModInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.ModInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModInt
 
GMathFunctions.ModSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.ModSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModSmallInt
 
GMathFunctions.ModTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.ModTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModTinyInt
 
GMathFunctions.ModUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.ModUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModUInt1
 
GMathFunctions.ModUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.ModUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModUInt2
 
GMathFunctions.ModUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.ModUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModUInt4
 
GMathFunctions.ModUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.ModUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModUInt8
 
GMathFunctions.NegativeBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.NegativeBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeBigInt
 
GMathFunctions.NegativeFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.NegativeFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeFloat4
 
GMathFunctions.NegativeFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.NegativeFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeFloat8
 
GMathFunctions.NegativeInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.NegativeInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeInt
 
GMathFunctions.NegativeSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.NegativeSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeSmallInt
 
GMathFunctions.NegativeTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.NegativeTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeTinyInt
 
GMathFunctions.NegativeUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.NegativeUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeUInt1
 
GMathFunctions.NegativeUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.NegativeUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeUInt2
 
GMathFunctions.NegativeUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.NegativeUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeUInt4
 
GMathFunctions.NegativeUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.NegativeUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeUInt8
 
GMathFunctions.RightShiftBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RightShiftBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftBigInt
 
GMathFunctions.RightShiftInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RightShiftInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftInt
 
GMathFunctions.RightShiftSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RightShiftSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftSmallInt
 
GMathFunctions.RightShiftTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RightShiftTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftTinyInt
 
GMathFunctions.RightShiftUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RightShiftUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftUInt1
 
GMathFunctions.RightShiftUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RightShiftUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftUInt2
 
GMathFunctions.RightShiftUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RightShiftUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftUInt4
 
GMathFunctions.RightShiftUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RightShiftUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftUInt8
 
GMathFunctions.RounddBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RounddBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddBigInt
 
GMathFunctions.RounddFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RounddFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddFloat4
 
GMathFunctions.RounddFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RounddFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddFloat8
 
GMathFunctions.RounddInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RounddInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddInt
 
GMathFunctions.RounddSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RounddSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddSmallInt
 
GMathFunctions.RounddTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RounddTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddTinyInt
 
GMathFunctions.RounddUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RounddUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddUInt1
 
GMathFunctions.RounddUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RounddUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddUInt2
 
GMathFunctions.RounddUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RounddUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddUInt4
 
GMathFunctions.RounddUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.RounddUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddUInt8
 
GMathFunctions.SignBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SignBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignBigInt
 
GMathFunctions.SignFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SignFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignFloat4
 
GMathFunctions.SignFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SignFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignFloat8
 
GMathFunctions.SignInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SignInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignInt
 
GMathFunctions.SignSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SignSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignSmallInt
 
GMathFunctions.SignTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SignTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignTinyInt
 
GMathFunctions.SignUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SignUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignUInt1
 
GMathFunctions.SignUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SignUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignUInt2
 
GMathFunctions.SignUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SignUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignUInt4
 
GMathFunctions.SignUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SignUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignUInt8
 
GMathFunctions.SqrtBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SqrtBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtBigInt
 
GMathFunctions.SqrtFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SqrtFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtFloat4
 
GMathFunctions.SqrtFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SqrtFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtFloat8
 
GMathFunctions.SqrtInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SqrtInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtInt
 
GMathFunctions.SqrtSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SqrtSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtSmallInt
 
GMathFunctions.SqrtTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SqrtTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtTinyInt
 
GMathFunctions.SqrtUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SqrtUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtUInt1
 
GMathFunctions.SqrtUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SqrtUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtUInt2
 
GMathFunctions.SqrtUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SqrtUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtUInt4
 
GMathFunctions.SqrtUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.SqrtUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtUInt8
 
GMathFunctions.TruncateBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncateBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateBigInt
 
GMathFunctions.TruncateFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncateFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateFloat4
 
GMathFunctions.TruncateFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncateFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateFloat8
 
GMathFunctions.TruncateInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncateInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateInt
 
GMathFunctions.TruncateSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncateSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateSmallInt
 
GMathFunctions.TruncateTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncateTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateTinyInt
 
GMathFunctions.TruncateUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncateUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateUInt1
 
GMathFunctions.TruncateUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncateUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateUInt2
 
GMathFunctions.TruncateUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncateUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateUInt4
 
GMathFunctions.TruncateUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncateUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateUInt8
 
GMathFunctions.TruncBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncBigInt
 
GMathFunctions.TruncFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncFloat4
 
GMathFunctions.TruncFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncFloat8
 
GMathFunctions.TruncInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncInt
 
GMathFunctions.TruncSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncSmallInt
 
GMathFunctions.TruncTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncTinyInt
 
GMathFunctions.TruncUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncUInt1
 
GMathFunctions.TruncUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncUInt2
 
GMathFunctions.TruncUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncUInt4
 
GMathFunctions.TruncUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GMathFunctions.TruncUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncUInt8
 
GNewValueFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions
 
GNewValueFunctions.NewValueBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueBigInt
 
GNewValueFunctions.NewValueBigIntNullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueBigIntNullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueBigIntNullable
 
GNewValueFunctions.NewValueBit - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueBit() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueBit
 
GNewValueFunctions.NewValueBitNullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueBitNullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueBitNullable
 
GNewValueFunctions.NewValueDate - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDate
 
GNewValueFunctions.NewValueDateNullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueDateNullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDateNullable
 
GNewValueFunctions.NewValueDecimal18 - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueDecimal18() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDecimal18
 
GNewValueFunctions.NewValueDecimal18Nullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueDecimal18Nullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDecimal18Nullable
 
GNewValueFunctions.NewValueDecimal9 - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueDecimal9() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDecimal9
 
GNewValueFunctions.NewValueDecimal9Nullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueDecimal9Nullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDecimal9Nullable
 
GNewValueFunctions.NewValueFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueFloat4
 
GNewValueFunctions.NewValueFloat4Nullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueFloat4Nullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueFloat4Nullable
 
GNewValueFunctions.NewValueFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueFloat8
 
GNewValueFunctions.NewValueFloat8Nullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueFloat8Nullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueFloat8Nullable
 
GNewValueFunctions.NewValueInt - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueInt
 
GNewValueFunctions.NewValueIntNullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueIntNullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueIntNullable
 
GNewValueFunctions.NewValueSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueSmallInt
 
GNewValueFunctions.NewValueSmallIntNullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueSmallIntNullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueSmallIntNullable
 
GNewValueFunctions.NewValueTime - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTime
 
GNewValueFunctions.NewValueTimeNullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueTimeNullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTimeNullable
 
GNewValueFunctions.NewValueTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTimeStamp
 
GNewValueFunctions.NewValueTimeStampNullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueTimeStampNullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTimeStampNullable
 
GNewValueFunctions.NewValueTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTinyInt
 
GNewValueFunctions.NewValueTinyIntNullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueTinyIntNullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTinyIntNullable
 
GNewValueFunctions.NewValueUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt1
 
GNewValueFunctions.NewValueUInt1Nullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueUInt1Nullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt1Nullable
 
GNewValueFunctions.NewValueUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt2
 
GNewValueFunctions.NewValueUInt2Nullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueUInt2Nullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt2Nullable
 
GNewValueFunctions.NewValueUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt4
 
GNewValueFunctions.NewValueUInt4Nullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueUInt4Nullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt4Nullable
 
GNewValueFunctions.NewValueUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt8
 
GNewValueFunctions.NewValueUInt8Nullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueUInt8Nullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt8Nullable
 
GNewValueFunctions.NewValueVar16Char - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueVar16Char() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVar16Char
 
GNewValueFunctions.NewValueVar16CharNullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueVar16CharNullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVar16CharNullable
 
GNewValueFunctions.NewValueVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVarBinary
 
GNewValueFunctions.NewValueVarBinaryNullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueVarBinaryNullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVarBinaryNullable
 
GNewValueFunctions.NewValueVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVarChar
 
GNewValueFunctions.NewValueVarCharNullable - Class in org.apache.drill.exec.expr.fn.impl
 
GNewValueFunctions.NewValueVarCharNullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVarCharNullable
 
GNullOpBigIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpBigIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpBigIntHolder
 
GNullOpBigIntHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpBigIntHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpBigIntHolder.IsNotNull
 
GNullOpBigIntHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpBigIntHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpBigIntHolder.IsNull
 
GNullOpBitHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpBitHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpBitHolder
 
GNullOpBitHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpBitHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpBitHolder.IsNotNull
 
GNullOpBitHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpBitHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpBitHolder.IsNull
 
GNullOpDateHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDateHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDateHolder
 
GNullOpDateHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDateHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDateHolder.IsNotNull
 
GNullOpDateHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDateHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDateHolder.IsNull
 
GNullOpDecimal18Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal18Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal18Holder
 
GNullOpDecimal18Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal18Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal18Holder.IsNotNull
 
GNullOpDecimal18Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal18Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal18Holder.IsNull
 
GNullOpDecimal28DenseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal28DenseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal28DenseHolder
 
GNullOpDecimal28DenseHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal28DenseHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal28DenseHolder.IsNotNull
 
GNullOpDecimal28DenseHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal28DenseHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal28DenseHolder.IsNull
 
GNullOpDecimal28SparseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal28SparseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal28SparseHolder
 
GNullOpDecimal28SparseHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal28SparseHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal28SparseHolder.IsNotNull
 
GNullOpDecimal28SparseHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal28SparseHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal28SparseHolder.IsNull
 
GNullOpDecimal38DenseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal38DenseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal38DenseHolder
 
GNullOpDecimal38DenseHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal38DenseHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal38DenseHolder.IsNotNull
 
GNullOpDecimal38DenseHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal38DenseHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal38DenseHolder.IsNull
 
GNullOpDecimal38SparseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal38SparseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal38SparseHolder
 
GNullOpDecimal38SparseHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal38SparseHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal38SparseHolder.IsNotNull
 
GNullOpDecimal38SparseHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal38SparseHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal38SparseHolder.IsNull
 
GNullOpDecimal9Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal9Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal9Holder
 
GNullOpDecimal9Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal9Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal9Holder.IsNotNull
 
GNullOpDecimal9Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpDecimal9Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal9Holder.IsNull
 
GNullOpFloat4Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpFloat4Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpFloat4Holder
 
GNullOpFloat4Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpFloat4Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpFloat4Holder.IsNotNull
 
GNullOpFloat4Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpFloat4Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpFloat4Holder.IsNull
 
GNullOpFloat8Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpFloat8Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpFloat8Holder
 
GNullOpFloat8Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpFloat8Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpFloat8Holder.IsNotNull
 
GNullOpFloat8Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpFloat8Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpFloat8Holder.IsNull
 
GNullOpIntervalDayHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpIntervalDayHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalDayHolder
 
GNullOpIntervalDayHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpIntervalDayHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalDayHolder.IsNotNull
 
GNullOpIntervalDayHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpIntervalDayHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalDayHolder.IsNull
 
GNullOpIntervalHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpIntervalHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalHolder
 
GNullOpIntervalHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpIntervalHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalHolder.IsNotNull
 
GNullOpIntervalHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpIntervalHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalHolder.IsNull
 
GNullOpIntervalYearHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpIntervalYearHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalYearHolder
 
GNullOpIntervalYearHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpIntervalYearHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalYearHolder.IsNotNull
 
GNullOpIntervalYearHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpIntervalYearHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalYearHolder.IsNull
 
GNullOpIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpIntHolder
 
GNullOpIntHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpIntHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpIntHolder.IsNotNull
 
GNullOpIntHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpIntHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpIntHolder.IsNull
 
GNullOpNullableBigIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableBigIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableBigIntHolder
 
GNullOpNullableBigIntHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableBigIntHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableBigIntHolder.IsNotNull
 
GNullOpNullableBigIntHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableBigIntHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableBigIntHolder.IsNull
 
GNullOpNullableBitHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableBitHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableBitHolder
 
GNullOpNullableBitHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableBitHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableBitHolder.IsNotNull
 
GNullOpNullableBitHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableBitHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableBitHolder.IsNull
 
GNullOpNullableDateHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDateHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDateHolder
 
GNullOpNullableDateHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDateHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDateHolder.IsNotNull
 
GNullOpNullableDateHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDateHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDateHolder.IsNull
 
GNullOpNullableDecimal18Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal18Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal18Holder
 
GNullOpNullableDecimal18Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal18Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal18Holder.IsNotNull
 
GNullOpNullableDecimal18Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal18Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal18Holder.IsNull
 
GNullOpNullableDecimal28DenseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal28DenseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal28DenseHolder
 
GNullOpNullableDecimal28DenseHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal28DenseHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal28DenseHolder.IsNotNull
 
GNullOpNullableDecimal28DenseHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal28DenseHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal28DenseHolder.IsNull
 
GNullOpNullableDecimal28SparseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal28SparseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal28SparseHolder
 
GNullOpNullableDecimal28SparseHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal28SparseHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal28SparseHolder.IsNotNull
 
GNullOpNullableDecimal28SparseHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal28SparseHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal28SparseHolder.IsNull
 
GNullOpNullableDecimal38DenseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal38DenseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal38DenseHolder
 
GNullOpNullableDecimal38DenseHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal38DenseHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal38DenseHolder.IsNotNull
 
GNullOpNullableDecimal38DenseHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal38DenseHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal38DenseHolder.IsNull
 
GNullOpNullableDecimal38SparseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal38SparseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal38SparseHolder
 
GNullOpNullableDecimal38SparseHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal38SparseHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal38SparseHolder.IsNotNull
 
GNullOpNullableDecimal38SparseHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal38SparseHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal38SparseHolder.IsNull
 
GNullOpNullableDecimal9Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal9Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal9Holder
 
GNullOpNullableDecimal9Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal9Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal9Holder.IsNotNull
 
GNullOpNullableDecimal9Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableDecimal9Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal9Holder.IsNull
 
GNullOpNullableFloat4Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableFloat4Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableFloat4Holder
 
GNullOpNullableFloat4Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableFloat4Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableFloat4Holder.IsNotNull
 
GNullOpNullableFloat4Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableFloat4Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableFloat4Holder.IsNull
 
GNullOpNullableFloat8Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableFloat8Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableFloat8Holder
 
GNullOpNullableFloat8Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableFloat8Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableFloat8Holder.IsNotNull
 
GNullOpNullableFloat8Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableFloat8Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableFloat8Holder.IsNull
 
GNullOpNullableIntervalDayHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableIntervalDayHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalDayHolder
 
GNullOpNullableIntervalDayHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableIntervalDayHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalDayHolder.IsNotNull
 
GNullOpNullableIntervalDayHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableIntervalDayHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalDayHolder.IsNull
 
GNullOpNullableIntervalHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableIntervalHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalHolder
 
GNullOpNullableIntervalHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableIntervalHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalHolder.IsNotNull
 
GNullOpNullableIntervalHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableIntervalHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalHolder.IsNull
 
GNullOpNullableIntervalYearHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableIntervalYearHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalYearHolder
 
GNullOpNullableIntervalYearHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableIntervalYearHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalYearHolder.IsNotNull
 
GNullOpNullableIntervalYearHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableIntervalYearHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalYearHolder.IsNull
 
GNullOpNullableIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntHolder
 
GNullOpNullableIntHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableIntHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntHolder.IsNotNull
 
GNullOpNullableIntHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableIntHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntHolder.IsNull
 
GNullOpNullableSmallIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableSmallIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableSmallIntHolder
 
GNullOpNullableSmallIntHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableSmallIntHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableSmallIntHolder.IsNotNull
 
GNullOpNullableSmallIntHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableSmallIntHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableSmallIntHolder.IsNull
 
GNullOpNullableTimeHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableTimeHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTimeHolder
 
GNullOpNullableTimeHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableTimeHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTimeHolder.IsNotNull
 
GNullOpNullableTimeHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableTimeHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTimeHolder.IsNull
 
GNullOpNullableTimeStampHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableTimeStampHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTimeStampHolder
 
GNullOpNullableTimeStampHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableTimeStampHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTimeStampHolder.IsNotNull
 
GNullOpNullableTimeStampHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableTimeStampHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTimeStampHolder.IsNull
 
GNullOpNullableTinyIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableTinyIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTinyIntHolder
 
GNullOpNullableTinyIntHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableTinyIntHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTinyIntHolder.IsNotNull
 
GNullOpNullableTinyIntHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableTinyIntHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTinyIntHolder.IsNull
 
GNullOpNullableUInt1Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableUInt1Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt1Holder
 
GNullOpNullableUInt1Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableUInt1Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt1Holder.IsNotNull
 
GNullOpNullableUInt1Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableUInt1Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt1Holder.IsNull
 
GNullOpNullableUInt2Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableUInt2Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt2Holder
 
GNullOpNullableUInt2Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableUInt2Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt2Holder.IsNotNull
 
GNullOpNullableUInt2Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableUInt2Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt2Holder.IsNull
 
GNullOpNullableUInt4Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableUInt4Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt4Holder
 
GNullOpNullableUInt4Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableUInt4Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt4Holder.IsNotNull
 
GNullOpNullableUInt4Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableUInt4Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt4Holder.IsNull
 
GNullOpNullableUInt8Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableUInt8Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt8Holder
 
GNullOpNullableUInt8Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableUInt8Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt8Holder.IsNotNull
 
GNullOpNullableUInt8Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableUInt8Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt8Holder.IsNull
 
GNullOpNullableVar16CharHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableVar16CharHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVar16CharHolder
 
GNullOpNullableVar16CharHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableVar16CharHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVar16CharHolder.IsNotNull
 
GNullOpNullableVar16CharHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableVar16CharHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVar16CharHolder.IsNull
 
GNullOpNullableVarBinaryHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableVarBinaryHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVarBinaryHolder
 
GNullOpNullableVarBinaryHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableVarBinaryHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVarBinaryHolder.IsNotNull
 
GNullOpNullableVarBinaryHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableVarBinaryHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVarBinaryHolder.IsNull
 
GNullOpNullableVarCharHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableVarCharHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVarCharHolder
 
GNullOpNullableVarCharHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableVarCharHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVarCharHolder.IsNotNull
 
GNullOpNullableVarCharHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpNullableVarCharHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVarCharHolder.IsNull
 
GNullOpRepeatedBigIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedBigIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedBigIntHolder
 
GNullOpRepeatedBigIntHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedBigIntHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedBigIntHolder.IsNotNull
 
GNullOpRepeatedBigIntHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedBigIntHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedBigIntHolder.IsNull
 
GNullOpRepeatedBitHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedBitHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedBitHolder
 
GNullOpRepeatedBitHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedBitHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedBitHolder.IsNotNull
 
GNullOpRepeatedBitHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedBitHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedBitHolder.IsNull
 
GNullOpRepeatedDateHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDateHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDateHolder
 
GNullOpRepeatedDateHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDateHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDateHolder.IsNotNull
 
GNullOpRepeatedDateHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDateHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDateHolder.IsNull
 
GNullOpRepeatedDecimal18Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal18Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal18Holder
 
GNullOpRepeatedDecimal18Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal18Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal18Holder.IsNotNull
 
GNullOpRepeatedDecimal18Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal18Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal18Holder.IsNull
 
GNullOpRepeatedDecimal28DenseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal28DenseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal28DenseHolder
 
GNullOpRepeatedDecimal28DenseHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal28DenseHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal28DenseHolder.IsNotNull
 
GNullOpRepeatedDecimal28DenseHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal28DenseHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal28DenseHolder.IsNull
 
GNullOpRepeatedDecimal28SparseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal28SparseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal28SparseHolder
 
GNullOpRepeatedDecimal28SparseHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal28SparseHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal28SparseHolder.IsNotNull
 
GNullOpRepeatedDecimal28SparseHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal28SparseHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal28SparseHolder.IsNull
 
GNullOpRepeatedDecimal38DenseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal38DenseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal38DenseHolder
 
GNullOpRepeatedDecimal38DenseHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal38DenseHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal38DenseHolder.IsNotNull
 
GNullOpRepeatedDecimal38DenseHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal38DenseHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal38DenseHolder.IsNull
 
GNullOpRepeatedDecimal38SparseHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal38SparseHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal38SparseHolder
 
GNullOpRepeatedDecimal38SparseHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal38SparseHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal38SparseHolder.IsNotNull
 
GNullOpRepeatedDecimal38SparseHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal38SparseHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal38SparseHolder.IsNull
 
GNullOpRepeatedDecimal9Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal9Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal9Holder
 
GNullOpRepeatedDecimal9Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal9Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal9Holder.IsNotNull
 
GNullOpRepeatedDecimal9Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedDecimal9Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal9Holder.IsNull
 
GNullOpRepeatedFloat4Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedFloat4Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedFloat4Holder
 
GNullOpRepeatedFloat4Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedFloat4Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedFloat4Holder.IsNotNull
 
GNullOpRepeatedFloat4Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedFloat4Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedFloat4Holder.IsNull
 
GNullOpRepeatedFloat8Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedFloat8Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedFloat8Holder
 
GNullOpRepeatedFloat8Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedFloat8Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedFloat8Holder.IsNotNull
 
GNullOpRepeatedFloat8Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedFloat8Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedFloat8Holder.IsNull
 
GNullOpRepeatedIntervalDayHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedIntervalDayHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalDayHolder
 
GNullOpRepeatedIntervalDayHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedIntervalDayHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalDayHolder.IsNotNull
 
GNullOpRepeatedIntervalDayHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedIntervalDayHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalDayHolder.IsNull
 
GNullOpRepeatedIntervalHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedIntervalHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalHolder
 
GNullOpRepeatedIntervalHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedIntervalHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalHolder.IsNotNull
 
GNullOpRepeatedIntervalHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedIntervalHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalHolder.IsNull
 
GNullOpRepeatedIntervalYearHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedIntervalYearHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalYearHolder
 
GNullOpRepeatedIntervalYearHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedIntervalYearHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalYearHolder.IsNotNull
 
GNullOpRepeatedIntervalYearHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedIntervalYearHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalYearHolder.IsNull
 
GNullOpRepeatedIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntHolder
 
GNullOpRepeatedIntHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedIntHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntHolder.IsNotNull
 
GNullOpRepeatedIntHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedIntHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntHolder.IsNull
 
GNullOpRepeatedSmallIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedSmallIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedSmallIntHolder
 
GNullOpRepeatedSmallIntHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedSmallIntHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedSmallIntHolder.IsNotNull
 
GNullOpRepeatedSmallIntHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedSmallIntHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedSmallIntHolder.IsNull
 
GNullOpRepeatedTimeHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedTimeHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTimeHolder
 
GNullOpRepeatedTimeHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedTimeHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTimeHolder.IsNotNull
 
GNullOpRepeatedTimeHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedTimeHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTimeHolder.IsNull
 
GNullOpRepeatedTimeStampHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedTimeStampHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTimeStampHolder
 
GNullOpRepeatedTimeStampHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedTimeStampHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTimeStampHolder.IsNotNull
 
GNullOpRepeatedTimeStampHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedTimeStampHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTimeStampHolder.IsNull
 
GNullOpRepeatedTinyIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedTinyIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTinyIntHolder
 
GNullOpRepeatedTinyIntHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedTinyIntHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTinyIntHolder.IsNotNull
 
GNullOpRepeatedTinyIntHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedTinyIntHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTinyIntHolder.IsNull
 
GNullOpRepeatedUInt1Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedUInt1Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt1Holder
 
GNullOpRepeatedUInt1Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedUInt1Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt1Holder.IsNotNull
 
GNullOpRepeatedUInt1Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedUInt1Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt1Holder.IsNull
 
GNullOpRepeatedUInt2Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedUInt2Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt2Holder
 
GNullOpRepeatedUInt2Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedUInt2Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt2Holder.IsNotNull
 
GNullOpRepeatedUInt2Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedUInt2Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt2Holder.IsNull
 
GNullOpRepeatedUInt4Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedUInt4Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt4Holder
 
GNullOpRepeatedUInt4Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedUInt4Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt4Holder.IsNotNull
 
GNullOpRepeatedUInt4Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedUInt4Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt4Holder.IsNull
 
GNullOpRepeatedUInt8Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedUInt8Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt8Holder
 
GNullOpRepeatedUInt8Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedUInt8Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt8Holder.IsNotNull
 
GNullOpRepeatedUInt8Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedUInt8Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt8Holder.IsNull
 
GNullOpRepeatedVar16CharHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedVar16CharHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVar16CharHolder
 
GNullOpRepeatedVar16CharHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedVar16CharHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVar16CharHolder.IsNotNull
 
GNullOpRepeatedVar16CharHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedVar16CharHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVar16CharHolder.IsNull
 
GNullOpRepeatedVarBinaryHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedVarBinaryHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVarBinaryHolder
 
GNullOpRepeatedVarBinaryHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedVarBinaryHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVarBinaryHolder.IsNotNull
 
GNullOpRepeatedVarBinaryHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedVarBinaryHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVarBinaryHolder.IsNull
 
GNullOpRepeatedVarCharHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedVarCharHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVarCharHolder
 
GNullOpRepeatedVarCharHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedVarCharHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVarCharHolder.IsNotNull
 
GNullOpRepeatedVarCharHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpRepeatedVarCharHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVarCharHolder.IsNull
 
GNullOpSmallIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpSmallIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpSmallIntHolder
 
GNullOpSmallIntHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpSmallIntHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpSmallIntHolder.IsNotNull
 
GNullOpSmallIntHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpSmallIntHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpSmallIntHolder.IsNull
 
GNullOpTimeHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpTimeHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpTimeHolder
 
GNullOpTimeHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpTimeHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpTimeHolder.IsNotNull
 
GNullOpTimeHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpTimeHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpTimeHolder.IsNull
 
GNullOpTimeStampHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpTimeStampHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpTimeStampHolder
 
GNullOpTimeStampHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpTimeStampHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpTimeStampHolder.IsNotNull
 
GNullOpTimeStampHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpTimeStampHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpTimeStampHolder.IsNull
 
GNullOpTinyIntHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpTinyIntHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpTinyIntHolder
 
GNullOpTinyIntHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpTinyIntHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpTinyIntHolder.IsNotNull
 
GNullOpTinyIntHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpTinyIntHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpTinyIntHolder.IsNull
 
GNullOpUInt1Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpUInt1Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpUInt1Holder
 
GNullOpUInt1Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpUInt1Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpUInt1Holder.IsNotNull
 
GNullOpUInt1Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpUInt1Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpUInt1Holder.IsNull
 
GNullOpUInt2Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpUInt2Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpUInt2Holder
 
GNullOpUInt2Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpUInt2Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpUInt2Holder.IsNotNull
 
GNullOpUInt2Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpUInt2Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpUInt2Holder.IsNull
 
GNullOpUInt4Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpUInt4Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpUInt4Holder
 
GNullOpUInt4Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpUInt4Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpUInt4Holder.IsNotNull
 
GNullOpUInt4Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpUInt4Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpUInt4Holder.IsNull
 
GNullOpUInt8Holder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpUInt8Holder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpUInt8Holder
 
GNullOpUInt8Holder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpUInt8Holder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpUInt8Holder.IsNotNull
 
GNullOpUInt8Holder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpUInt8Holder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpUInt8Holder.IsNull
 
GNullOpVar16CharHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpVar16CharHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpVar16CharHolder
 
GNullOpVar16CharHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpVar16CharHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpVar16CharHolder.IsNotNull
 
GNullOpVar16CharHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpVar16CharHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpVar16CharHolder.IsNull
 
GNullOpVarBinaryHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpVarBinaryHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpVarBinaryHolder
 
GNullOpVarBinaryHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpVarBinaryHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpVarBinaryHolder.IsNotNull
 
GNullOpVarBinaryHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpVarBinaryHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpVarBinaryHolder.IsNull
 
GNullOpVarCharHolder - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpVarCharHolder() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpVarCharHolder
 
GNullOpVarCharHolder.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpVarCharHolder.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpVarCharHolder.IsNotNull
 
GNullOpVarCharHolder.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
GNullOpVarCharHolder.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.GNullOpVarCharHolder.IsNull
 
go(DrillRel) - Method in class org.apache.drill.exec.planner.logical.DrillImplementor
 
go(Prel) - Method in class org.apache.drill.exec.planner.physical.explain.PrelSequencer
 
GO - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
GOTO - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
GRACE_PERIOD - Static variable in class org.apache.drill.exec.ExecConstants
Boot-time config option provided to modify duration of the grace period.
GRANT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
GRANTED - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
graph() - Method in class org.apache.drill.exec.physical.PhysicalPlan
 
grossRowWidth() - Method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
 
group - Variable in class org.apache.drill.exec.planner.sql.handlers.ShowFilesCommandResult
 
GROUP - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
GroupByOpt() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses the optional GROUP BY clause for SELECT.
GROUPING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
GroupingElement() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
GroupingElementList() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
GroupScan - Interface in org.apache.drill.exec.physical.base
A GroupScan operator represents all data which will be scanned by a given physical plan.
groupScan - Variable in class org.apache.drill.exec.planner.physical.ScanPrel
 
GSmallIntToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GSmallIntToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GSmallIntToChar
 
GSmallIntToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GSmallIntToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GSmallIntToTimeStamp
 
GT - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
 
GT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
GTimeArithmetic - Class in org.apache.drill.exec.expr.fn.impl
 
GTimeArithmetic() - Constructor for class org.apache.drill.exec.expr.fn.impl.GTimeArithmetic
 
GTimeArithmetic.GTimeDifference - Class in org.apache.drill.exec.expr.fn.impl
 
GTimeArithmetic.GTimeDifference() - Constructor for class org.apache.drill.exec.expr.fn.impl.GTimeArithmetic.GTimeDifference
 
GTimeStampArithmetic - Class in org.apache.drill.exec.expr.fn.impl
 
GTimeStampArithmetic() - Constructor for class org.apache.drill.exec.expr.fn.impl.GTimeStampArithmetic
 
GTimeStampArithmetic.GTimeStampDifference - Class in org.apache.drill.exec.expr.fn.impl
 
GTimeStampArithmetic.GTimeStampDifference() - Constructor for class org.apache.drill.exec.expr.fn.impl.GTimeStampArithmetic.GTimeStampDifference
 
GTimeStampToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GTimeStampToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GTimeStampToChar
 
GTimeToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GTimeToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GTimeToChar
 
GTinyIntToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GTinyIntToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GTinyIntToChar
 
GTinyIntToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GTinyIntToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GTinyIntToTimeStamp
 
GToDate - Class in org.apache.drill.exec.expr.fn.impl
 
GToDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GToDate
 
GToTime - Class in org.apache.drill.exec.expr.fn.impl
 
GToTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.GToTime
 
GToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GToTimeStamp
 
GuavaPatcher - Class in org.apache.drill.exec.util
 
GuavaPatcher() - Constructor for class org.apache.drill.exec.util.GuavaPatcher
 
GUInt1ToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GUInt1ToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUInt1ToChar
 
GUInt1ToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GUInt1ToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUInt1ToTimeStamp
 
GUInt2ToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GUInt2ToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUInt2ToChar
 
GUInt2ToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GUInt2ToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUInt2ToTimeStamp
 
GUInt4ToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GUInt4ToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUInt4ToChar
 
GUInt4ToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GUInt4ToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUInt4ToTimeStamp
 
GUInt8ToChar - Class in org.apache.drill.exec.expr.fn.impl
 
GUInt8ToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUInt8ToChar
 
GUInt8ToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GUInt8ToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUInt8ToTimeStamp
 
GUnionFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions
 
GUnionFunctions.CastUnionBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionBigInt
 
GUnionFunctions.CastUnionBit - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionBit() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionBit
 
GUnionFunctions.CastUnionDate - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionDate
 
GUnionFunctions.CastUnionFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionFloat4
 
GUnionFunctions.CastUnionFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionFloat8
 
GUnionFunctions.CastUnionInt - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionInt
 
GUnionFunctions.CastUnionInterval - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionInterval
 
GUnionFunctions.CastUnionIntervalDay - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionIntervalDay
 
GUnionFunctions.CastUnionIntervalYear - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionIntervalYear
 
GUnionFunctions.CastUnionSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionSmallInt
 
GUnionFunctions.CastUnionTime - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionTime
 
GUnionFunctions.CastUnionTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionTimeStamp
 
GUnionFunctions.CastUnionTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionTinyInt
 
GUnionFunctions.CastUnionUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionUInt1
 
GUnionFunctions.CastUnionUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionUInt2
 
GUnionFunctions.CastUnionUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionUInt4
 
GUnionFunctions.CastUnionUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionUInt8
 
GUnionFunctions.CastUnionVar16Char - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionVar16Char() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionVar16Char
 
GUnionFunctions.CastUnionVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionVarBinary
 
GUnionFunctions.CastUnionVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.CastUnionVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionVarChar
 
GUnionFunctions.UnionIsBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsBigInt
 
GUnionFunctions.UnionIsBit - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsBit() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsBit
 
GUnionFunctions.UnionIsDate - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsDate
 
GUnionFunctions.UnionIsFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsFloat4
 
GUnionFunctions.UnionIsFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsFloat8
 
GUnionFunctions.UnionIsInt - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsInt
 
GUnionFunctions.UnionIsInterval - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsInterval() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsInterval
 
GUnionFunctions.UnionIsIntervalDay - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsIntervalDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsIntervalDay
 
GUnionFunctions.UnionIsIntervalYear - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsIntervalYear() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsIntervalYear
 
GUnionFunctions.UnionIsSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsSmallInt
 
GUnionFunctions.UnionIsTime - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsTime
 
GUnionFunctions.UnionIsTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsTimeStamp
 
GUnionFunctions.UnionIsTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsTinyInt
 
GUnionFunctions.UnionIsUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsUInt1
 
GUnionFunctions.UnionIsUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsUInt2
 
GUnionFunctions.UnionIsUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsUInt4
 
GUnionFunctions.UnionIsUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsUInt8
 
GUnionFunctions.UnionIsVar16Char - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsVar16Char() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsVar16Char
 
GUnionFunctions.UnionIsVarBinary - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsVarBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsVarBinary
 
GUnionFunctions.UnionIsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
GUnionFunctions.UnionIsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsVarChar
 

H

HADOOP_SSL_CONF_TPL_KEY - Static variable in class org.apache.drill.exec.ssl.SSLConfig
 
HADOOP_SSL_KEYSTORE_KEYPASSWORD_TPL_KEY - Static variable in class org.apache.drill.exec.ssl.SSLConfig
 
HADOOP_SSL_KEYSTORE_LOCATION_TPL_KEY - Static variable in class org.apache.drill.exec.ssl.SSLConfig
 
HADOOP_SSL_KEYSTORE_PASSWORD_TPL_KEY - Static variable in class org.apache.drill.exec.ssl.SSLConfig
 
HADOOP_SSL_KEYSTORE_TYPE_TPL_KEY - Static variable in class org.apache.drill.exec.ssl.SSLConfig
 
HADOOP_SSL_TRUSTSTORE_LOCATION_TPL_KEY - Static variable in class org.apache.drill.exec.ssl.SSLConfig
 
HADOOP_SSL_TRUSTSTORE_PASSWORD_TPL_KEY - Static variable in class org.apache.drill.exec.ssl.SSLConfig
 
HADOOP_SSL_TRUSTSTORE_TYPE_TPL_KEY - Static variable in class org.apache.drill.exec.ssl.SSLConfig
 
hadoopConfig(Configuration) - Method in class org.apache.drill.exec.ssl.SSLConfigBuilder
 
hadWildcard() - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
handle(ControlConnection, int, ByteBuf, ByteBuf, ResponseSender) - Method in class org.apache.drill.exec.rpc.control.ControlClient
 
handle(BitControl.CustomMessage, DrillBuf) - Method in class org.apache.drill.exec.rpc.control.CustomHandlerRegistry
 
handle(DataClientConnection, int, ByteBuf, ByteBuf, ResponseSender) - Method in class org.apache.drill.exec.rpc.data.DataClient
 
handle(S, int, ByteBuf, ByteBuf, ResponseSender) - Method in class org.apache.drill.exec.rpc.FailingRequestHandler
 
handle(S, int, ByteBuf, ByteBuf, ResponseSender) - Method in class org.apache.drill.exec.rpc.security.ServerAuthenticationHandler
 
handle(UserClient.UserToBitConnection, int, ByteBuf, ByteBuf, ResponseSender) - Method in class org.apache.drill.exec.rpc.user.UserClient
 
handle(ControlConnection, int, ByteBuf, ByteBuf, ResponseSender) - Method in class org.apache.drill.exec.work.batch.ControlMessageHandler
 
handle(IncomingDataBatch) - Method in class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
handle(IncomingDataBatch) - Method in interface org.apache.drill.exec.work.fragment.FragmentManager
Handle the next incoming record batch.
handleAndRaise(String, Exception) - Method in class org.apache.drill.exec.store.easy.json.JSONRecordReader
 
handleAndRaise(String, Exception) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLenBinaryReader
 
handleAndRaise(String, Exception) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetReader
 
handleAndRaise(String, Exception) - Method in class org.apache.drill.exec.store.text.DrillTextRecordReader
 
handleException(String, Exception) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
handleNullInput() - Method in class org.apache.drill.exec.physical.impl.project.ProjectRecordBatch
Handle Null input specially when Project operator is for query output.
handleNullInput() - Method in class org.apache.drill.exec.record.AbstractSingleRecordBatch
Default behavior to handle NULL input (aka FAST NONE): incoming return NONE before return a OK_NEW_SCHEMA: This could happen when the underneath Scan operators do not produce any batch with schema.
HardAffinityFragmentParallelizer - Class in org.apache.drill.exec.planner.fragment
Implementation of FragmentParallelizer where fragment requires running on a given set of endpoints.
hasAdminPrivileges(String, String, String) - Static method in class org.apache.drill.exec.util.ImpersonationUtil
Given admin user/group list, finds whether the given username has admin privileges.
HasAffinity - Interface in org.apache.drill.exec.physical.base
Describes a physical operator that has affinity to particular nodes.
hasArray() - Method in class org.apache.drill.exec.record.DeadBuf
 
hasColumnMetadata() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v1
 
hasColumnMetadata() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
hasColumnMetadata() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
hasColumnMetadata() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataBase
 
hasData() - Method in class org.apache.drill.exec.rpc.user.QueryDataBatch
 
HasDistributionAffinity - Interface in org.apache.drill.exec.planner.physical
Implement this interface if a Prel has distribution affinity requirements.
hasEmbeddedConstant() - Method in class org.apache.drill.exec.compile.sig.MappingSet
 
hasError() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
 
hasExactColumnValueCount() - Method in enum org.apache.drill.exec.physical.base.ScanStats.GroupScanProperty
 
hasExactRowCount() - Method in enum org.apache.drill.exec.physical.base.ScanStats.GroupScanProperty
 
hasFiles() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
hasFiles() - Method in interface org.apache.drill.exec.physical.base.GroupScan
Return true if this GroupScan can return its selection as a list of file names (retrieved by getFiles()).
hasFiles() - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
hasFiles() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
hash(ByteBuffer, int) - Static method in class org.apache.drill.exec.expr.fn.impl.HashHelper
taken from mahout
hash(int) - Method in class org.apache.drill.exec.store.pcap.decoder.Murmur128
 
hash(long) - Method in class org.apache.drill.exec.store.pcap.decoder.Murmur128
 
hash(byte[], int, int) - Method in class org.apache.drill.exec.store.pcap.decoder.Murmur128
 
hash32(int, long) - Static method in class org.apache.drill.exec.expr.fn.impl.HashHelper
 
hash32(long, long) - Static method in class org.apache.drill.exec.expr.fn.impl.HashHelper
 
hash32(float, long) - Static method in class org.apache.drill.exec.expr.fn.impl.HashHelper
 
hash32(double, long) - Static method in class org.apache.drill.exec.expr.fn.impl.HashHelper
 
hash32(int, int, DrillBuf, int) - Static method in class org.apache.drill.exec.expr.fn.impl.HashHelper
 
hash32(double, long) - Static method in class org.apache.drill.exec.expr.fn.impl.MurmurHash3
 
hash32(int, int, DrillBuf, int) - Static method in class org.apache.drill.exec.expr.fn.impl.MurmurHash3
 
hash32(double, long) - Static method in class org.apache.drill.exec.expr.fn.impl.XXHash
 
hash32(int, int, DrillBuf, int) - Static method in class org.apache.drill.exec.expr.fn.impl.XXHash
 
Hash32AsDouble - Class in org.apache.drill.exec.expr.fn.impl
hash32 function definitions for numeric data types.
Hash32AsDouble() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble
 
Hash32AsDouble.BigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.BigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.BigIntHash
 
Hash32AsDouble.Decimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.Decimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.Decimal18Hash
 
Hash32AsDouble.Decimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.Decimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.Decimal28Hash
 
Hash32AsDouble.Decimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.Decimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.Decimal38Hash
 
Hash32AsDouble.Decimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.Decimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.Decimal9Hash
 
Hash32AsDouble.DoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.DoubleHash
 
Hash32AsDouble.FloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.FloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.FloatHash
 
Hash32AsDouble.IntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.IntHash
 
Hash32AsDouble.NullableBigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.NullableBigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableBigIntHash
 
Hash32AsDouble.NullableDecimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.NullableDecimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableDecimal18Hash
 
Hash32AsDouble.NullableDecimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.NullableDecimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableDecimal28Hash
 
Hash32AsDouble.NullableDecimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.NullableDecimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableDecimal38Hash
 
Hash32AsDouble.NullableDecimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.NullableDecimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableDecimal9Hash
 
Hash32AsDouble.NullableDoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.NullableDoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableDoubleHash
 
Hash32AsDouble.NullableFloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.NullableFloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableFloatHash
 
Hash32AsDouble.NullableIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32AsDouble.NullableIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableIntHash
 
Hash32Functions - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions
 
Hash32Functions.BigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.BigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.BigIntHash
 
Hash32Functions.BitHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.BitHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.BitHash
 
Hash32Functions.DateHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.DateHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.DateHash
 
Hash32Functions.Decimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.Decimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Decimal18Hash
 
Hash32Functions.Decimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.Decimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Decimal28Hash
 
Hash32Functions.Decimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.Decimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Decimal38Hash
 
Hash32Functions.Decimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.Decimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Decimal9Hash
 
Hash32Functions.DoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.DoubleHash
 
Hash32Functions.FloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.FloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.FloatHash
 
Hash32Functions.IntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.IntHash
 
Hash32Functions.NullableBigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.NullableBigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableBigIntHash
 
Hash32Functions.NullableBitHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.NullableBitHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableBitHash
 
Hash32Functions.NullableDateHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.NullableDateHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDateHash
 
Hash32Functions.NullableDecimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.NullableDecimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDecimal18Hash
 
Hash32Functions.NullableDecimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.NullableDecimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDecimal28Hash
 
Hash32Functions.NullableDecimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.NullableDecimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDecimal38Hash
 
Hash32Functions.NullableDecimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.NullableDecimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDecimal9Hash
 
Hash32Functions.NullableDoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.NullableDoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDoubleHash
 
Hash32Functions.NullableFloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.NullableFloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableFloatHash
 
Hash32Functions.NullableIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.NullableIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableIntHash
 
Hash32Functions.NullableTimeHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.NullableTimeHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableTimeHash
 
Hash32Functions.NullableTimeStampHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.NullableTimeStampHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableTimeStampHash
 
Hash32Functions.NullableVar16CharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.NullableVar16CharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableVar16CharHash
 
Hash32Functions.NullableVarBinaryHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.NullableVarBinaryHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableVarBinaryHash
 
Hash32Functions.NullableVarCharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.NullableVarCharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableVarCharHash
 
Hash32Functions.TimeHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.TimeHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.TimeHash
 
Hash32Functions.TimeStampHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.TimeStampHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.TimeStampHash
 
Hash32Functions.Var16CharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.Var16CharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Var16CharHash
 
Hash32Functions.VarBinaryHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.VarBinaryHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.VarBinaryHash
 
Hash32Functions.VarCharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32Functions.VarCharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.VarCharHash
 
Hash32FunctionsWithSeed - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed
 
Hash32FunctionsWithSeed.BigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.BigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.BigIntHash
 
Hash32FunctionsWithSeed.BitHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.BitHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.BitHash
 
Hash32FunctionsWithSeed.DateHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.DateHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.DateHash
 
Hash32FunctionsWithSeed.Decimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.Decimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Decimal18Hash
 
Hash32FunctionsWithSeed.Decimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.Decimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Decimal28Hash
 
Hash32FunctionsWithSeed.Decimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.Decimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Decimal38Hash
 
Hash32FunctionsWithSeed.Decimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.Decimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Decimal9Hash
 
Hash32FunctionsWithSeed.DoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.DoubleHash
 
Hash32FunctionsWithSeed.FloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.FloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.FloatHash
 
Hash32FunctionsWithSeed.IntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.IntHash
 
Hash32FunctionsWithSeed.NullableBigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.NullableBigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableBigIntHash
 
Hash32FunctionsWithSeed.NullableBitHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.NullableBitHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableBitHash
 
Hash32FunctionsWithSeed.NullableDateHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.NullableDateHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDateHash
 
Hash32FunctionsWithSeed.NullableDecimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.NullableDecimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDecimal18Hash
 
Hash32FunctionsWithSeed.NullableDecimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.NullableDecimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDecimal28Hash
 
Hash32FunctionsWithSeed.NullableDecimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.NullableDecimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDecimal38Hash
 
Hash32FunctionsWithSeed.NullableDecimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.NullableDecimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDecimal9Hash
 
Hash32FunctionsWithSeed.NullableDoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.NullableDoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDoubleHash
 
Hash32FunctionsWithSeed.NullableFloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.NullableFloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableFloatHash
 
Hash32FunctionsWithSeed.NullableIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.NullableIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableIntHash
 
Hash32FunctionsWithSeed.NullableTimeHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.NullableTimeHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableTimeHash
 
Hash32FunctionsWithSeed.NullableTimeStampHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.NullableTimeStampHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableTimeStampHash
 
Hash32FunctionsWithSeed.NullableVar16CharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.NullableVar16CharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableVar16CharHash
 
Hash32FunctionsWithSeed.NullableVarBinaryHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.NullableVarBinaryHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableVarBinaryHash
 
Hash32FunctionsWithSeed.NullableVarCharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.NullableVarCharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableVarCharHash
 
Hash32FunctionsWithSeed.TimeHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.TimeHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.TimeHash
 
Hash32FunctionsWithSeed.TimeStampHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.TimeStampHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.TimeStampHash
 
Hash32FunctionsWithSeed.Var16CharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.Var16CharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Var16CharHash
 
Hash32FunctionsWithSeed.VarBinaryHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.VarBinaryHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.VarBinaryHash
 
Hash32FunctionsWithSeed.VarCharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32FunctionsWithSeed.VarCharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.VarCharHash
 
Hash32WithSeedAsDouble - Class in org.apache.drill.exec.expr.fn.impl
hash32 with seed function definitions for numeric data types.
Hash32WithSeedAsDouble() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble
 
Hash32WithSeedAsDouble.BigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.BigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.BigIntHash
 
Hash32WithSeedAsDouble.Decimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.Decimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.Decimal18Hash
 
Hash32WithSeedAsDouble.Decimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.Decimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.Decimal28Hash
 
Hash32WithSeedAsDouble.Decimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.Decimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.Decimal38Hash
 
Hash32WithSeedAsDouble.Decimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.Decimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.Decimal9Hash
 
Hash32WithSeedAsDouble.DoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.DoubleHash
 
Hash32WithSeedAsDouble.FloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.FloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.FloatHash
 
Hash32WithSeedAsDouble.IntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.IntHash
 
Hash32WithSeedAsDouble.NullableBigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.NullableBigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableBigIntHash
 
Hash32WithSeedAsDouble.NullableDecimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.NullableDecimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableDecimal18Hash
 
Hash32WithSeedAsDouble.NullableDecimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.NullableDecimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableDecimal28Hash
 
Hash32WithSeedAsDouble.NullableDecimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.NullableDecimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableDecimal38Hash
 
Hash32WithSeedAsDouble.NullableDecimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.NullableDecimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableDecimal9Hash
 
Hash32WithSeedAsDouble.NullableDoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.NullableDoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableDoubleHash
 
Hash32WithSeedAsDouble.NullableFloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.NullableFloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableFloatHash
 
Hash32WithSeedAsDouble.NullableIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash32WithSeedAsDouble.NullableIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableIntHash
 
hash64(float, long) - Static method in class org.apache.drill.exec.expr.fn.impl.HashHelper
 
hash64(long, long) - Static method in class org.apache.drill.exec.expr.fn.impl.HashHelper
 
hash64(double, long) - Static method in class org.apache.drill.exec.expr.fn.impl.HashHelper
 
hash64(long, long, DrillBuf, long) - Static method in class org.apache.drill.exec.expr.fn.impl.HashHelper
 
hash64(double, long) - Static method in class org.apache.drill.exec.expr.fn.impl.MurmurHash3
 
hash64(long, long, DrillBuf, long) - Static method in class org.apache.drill.exec.expr.fn.impl.MurmurHash3
 
hash64(double, long) - Static method in class org.apache.drill.exec.expr.fn.impl.XXHash
 
hash64(long, long, DrillBuf, long) - Static method in class org.apache.drill.exec.expr.fn.impl.XXHash
 
Hash64AsDouble - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble
 
Hash64AsDouble.BigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.BigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.BigIntHash
 
Hash64AsDouble.Decimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.Decimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.Decimal18Hash
 
Hash64AsDouble.Decimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.Decimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.Decimal28Hash
 
Hash64AsDouble.Decimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.Decimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.Decimal38Hash
 
Hash64AsDouble.Decimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.Decimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.Decimal9Hash
 
Hash64AsDouble.DoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.DoubleHash
 
Hash64AsDouble.FloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.FloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.FloatHash
 
Hash64AsDouble.IntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.IntHash
 
Hash64AsDouble.NullableBigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.NullableBigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableBigIntHash
 
Hash64AsDouble.NullableDecimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.NullableDecimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableDecimal18Hash
 
Hash64AsDouble.NullableDecimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.NullableDecimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableDecimal28Hash
 
Hash64AsDouble.NullableDecimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.NullableDecimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableDecimal38Hash
 
Hash64AsDouble.NullableDecimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.NullableDecimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableDecimal9Hash
 
Hash64AsDouble.NullableDoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.NullableDoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableDoubleHash
 
Hash64AsDouble.NullableFloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.NullableFloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableFloatHash
 
Hash64AsDouble.NullableIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64AsDouble.NullableIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableIntHash
 
Hash64Functions - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions
 
Hash64Functions.BigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.BigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.BigIntHash
 
Hash64Functions.BitHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.BitHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.BitHash
 
Hash64Functions.DateHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.DateHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.DateHash
 
Hash64Functions.Decimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.Decimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Decimal18Hash
 
Hash64Functions.Decimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.Decimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Decimal28Hash
 
Hash64Functions.Decimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.Decimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Decimal38Hash
 
Hash64Functions.Decimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.Decimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Decimal9Hash
 
Hash64Functions.DoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.DoubleHash
 
Hash64Functions.FloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.FloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.FloatHash
 
Hash64Functions.IntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.IntHash
 
Hash64Functions.NullableBigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.NullableBigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableBigIntHash
 
Hash64Functions.NullableBitHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.NullableBitHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableBitHash
 
Hash64Functions.NullableDateHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.NullableDateHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDateHash
 
Hash64Functions.NullableDecimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.NullableDecimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDecimal18Hash
 
Hash64Functions.NullableDecimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.NullableDecimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDecimal28Hash
 
Hash64Functions.NullableDecimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.NullableDecimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDecimal38Hash
 
Hash64Functions.NullableDecimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.NullableDecimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDecimal9Hash
 
Hash64Functions.NullableDoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.NullableDoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDoubleHash
 
Hash64Functions.NullableFloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.NullableFloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableFloatHash
 
Hash64Functions.NullableIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.NullableIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableIntHash
 
Hash64Functions.NullableTimeHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.NullableTimeHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableTimeHash
 
Hash64Functions.NullableTimeStampHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.NullableTimeStampHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableTimeStampHash
 
Hash64Functions.NullableVar16CharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.NullableVar16CharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableVar16CharHash
 
Hash64Functions.NullableVarBinaryHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.NullableVarBinaryHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableVarBinaryHash
 
Hash64Functions.NullableVarCharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.NullableVarCharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableVarCharHash
 
Hash64Functions.TimeHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.TimeHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.TimeHash
 
Hash64Functions.TimeStampHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.TimeStampHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.TimeStampHash
 
Hash64Functions.Var16CharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.Var16CharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Var16CharHash
 
Hash64Functions.VarBinaryHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.VarBinaryHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.VarBinaryHash
 
Hash64Functions.VarCharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64Functions.VarCharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.VarCharHash
 
Hash64FunctionsWithSeed - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed
 
Hash64FunctionsWithSeed.BigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.BigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.BigIntHash
 
Hash64FunctionsWithSeed.BitHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.BitHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.BitHash
 
Hash64FunctionsWithSeed.DateHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.DateHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.DateHash
 
Hash64FunctionsWithSeed.Decimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.Decimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Decimal18Hash
 
Hash64FunctionsWithSeed.Decimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.Decimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Decimal28Hash
 
Hash64FunctionsWithSeed.Decimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.Decimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Decimal38Hash
 
Hash64FunctionsWithSeed.Decimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.Decimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Decimal9Hash
 
Hash64FunctionsWithSeed.DoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.DoubleHash
 
Hash64FunctionsWithSeed.FloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.FloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.FloatHash
 
Hash64FunctionsWithSeed.IntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.IntHash
 
Hash64FunctionsWithSeed.NullableBigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.NullableBigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableBigIntHash
 
Hash64FunctionsWithSeed.NullableBitHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.NullableBitHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableBitHash
 
Hash64FunctionsWithSeed.NullableDateHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.NullableDateHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDateHash
 
Hash64FunctionsWithSeed.NullableDecimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.NullableDecimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDecimal18Hash
 
Hash64FunctionsWithSeed.NullableDecimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.NullableDecimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDecimal28Hash
 
Hash64FunctionsWithSeed.NullableDecimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.NullableDecimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDecimal38Hash
 
Hash64FunctionsWithSeed.NullableDecimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.NullableDecimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDecimal9Hash
 
Hash64FunctionsWithSeed.NullableDoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.NullableDoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDoubleHash
 
Hash64FunctionsWithSeed.NullableFloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.NullableFloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableFloatHash
 
Hash64FunctionsWithSeed.NullableIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.NullableIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableIntHash
 
Hash64FunctionsWithSeed.NullableTimeHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.NullableTimeHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableTimeHash
 
Hash64FunctionsWithSeed.NullableTimeStampHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.NullableTimeStampHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableTimeStampHash
 
Hash64FunctionsWithSeed.NullableVar16CharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.NullableVar16CharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableVar16CharHash
 
Hash64FunctionsWithSeed.NullableVarBinaryHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.NullableVarBinaryHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableVarBinaryHash
 
Hash64FunctionsWithSeed.NullableVarCharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.NullableVarCharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableVarCharHash
 
Hash64FunctionsWithSeed.TimeHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.TimeHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.TimeHash
 
Hash64FunctionsWithSeed.TimeStampHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.TimeStampHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.TimeStampHash
 
Hash64FunctionsWithSeed.Var16CharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.Var16CharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Var16CharHash
 
Hash64FunctionsWithSeed.VarBinaryHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.VarBinaryHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.VarBinaryHash
 
Hash64FunctionsWithSeed.VarCharHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64FunctionsWithSeed.VarCharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.VarCharHash
 
hash64Internal(long, long) - Static method in class org.apache.drill.exec.expr.fn.impl.XXHash
 
Hash64WithSeedAsDouble - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble
 
Hash64WithSeedAsDouble.BigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.BigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.BigIntHash
 
Hash64WithSeedAsDouble.Decimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.Decimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.Decimal18Hash
 
Hash64WithSeedAsDouble.Decimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.Decimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.Decimal28Hash
 
Hash64WithSeedAsDouble.Decimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.Decimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.Decimal38Hash
 
Hash64WithSeedAsDouble.Decimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.Decimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.Decimal9Hash
 
Hash64WithSeedAsDouble.DoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.DoubleHash
 
Hash64WithSeedAsDouble.FloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.FloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.FloatHash
 
Hash64WithSeedAsDouble.IntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.IntHash
 
Hash64WithSeedAsDouble.NullableBigIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.NullableBigIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableBigIntHash
 
Hash64WithSeedAsDouble.NullableDecimal18Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.NullableDecimal18Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableDecimal18Hash
 
Hash64WithSeedAsDouble.NullableDecimal28Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.NullableDecimal28Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableDecimal28Hash
 
Hash64WithSeedAsDouble.NullableDecimal38Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.NullableDecimal38Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableDecimal38Hash
 
Hash64WithSeedAsDouble.NullableDecimal9Hash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.NullableDecimal9Hash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableDecimal9Hash
 
Hash64WithSeedAsDouble.NullableDoubleHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.NullableDoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableDoubleHash
 
Hash64WithSeedAsDouble.NullableFloatHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.NullableFloatHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableFloatHash
 
Hash64WithSeedAsDouble.NullableIntHash - Class in org.apache.drill.exec.expr.fn.impl
 
Hash64WithSeedAsDouble.NullableIntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableIntHash
 
HASH_AGG_TABLE_FACTOR - Static variable in class org.apache.drill.exec.ExecConstants
 
HASH_AGG_TABLE_FACTOR_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
HASH_CPU_COST - Static variable in class org.apache.drill.exec.planner.cost.DrillCostBase
 
HASH_EXPR_NAME - Static variable in class org.apache.drill.exec.planner.physical.HashPrelUtil
 
HASH_HELPER_LOGICALEXPRESSION - Static variable in class org.apache.drill.exec.planner.physical.HashPrelUtil
HASH_JOIN_SWAP - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
HASH_JOIN_SWAP_MARGIN_FACTOR - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
HASH_JOIN_TABLE_FACTOR - Static variable in class org.apache.drill.exec.ExecConstants
 
HASH_JOIN_TABLE_FACTOR_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
HASH_SINGLE_KEY - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
HASHAGG - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
HASHAGG_FALLBACK_ENABLED_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
HASHAGG_FALLBACK_ENABLED_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
HASHAGG_MAX_MEMORY_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
HASHAGG_MAX_MEMORY_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
HASHAGG_MIN_BATCHES_PER_PARTITION_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
HASHAGG_MIN_BATCHES_PER_PARTITION_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
HASHAGG_NUM_PARTITIONS_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
HASHAGG_NUM_PARTITIONS_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
HASHAGG_SPILL_DIRS - Static variable in class org.apache.drill.exec.ExecConstants
 
HASHAGG_SPILL_FILESYSTEM - Static variable in class org.apache.drill.exec.ExecConstants
 
HASHAGG_USE_MEMORY_PREDICTION_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
HASHAGG_USE_MEMORY_PREDICTION_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
HashAggBatch - Class in org.apache.drill.exec.physical.impl.aggregate
 
HashAggBatch(HashAggregate, RecordBatch, FragmentContext) - Constructor for class org.apache.drill.exec.physical.impl.aggregate.HashAggBatch
 
HashAggBatchCreator - Class in org.apache.drill.exec.physical.impl.aggregate
 
HashAggBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.aggregate.HashAggBatchCreator
 
HashAggPrel - Class in org.apache.drill.exec.planner.physical
 
HashAggPrel(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>, AggPrelBase.OperatorPhase) - Constructor for class org.apache.drill.exec.planner.physical.HashAggPrel
 
HashAggPrule - Class in org.apache.drill.exec.planner.physical
 
HashAggregate - Class in org.apache.drill.exec.physical.config
 
HashAggregate(PhysicalOperator, AggPrelBase.OperatorPhase, List<NamedExpression>, List<NamedExpression>, float) - Constructor for class org.apache.drill.exec.physical.config.HashAggregate
 
HashAggregator - Interface in org.apache.drill.exec.physical.impl.aggregate
 
HashAggregator.AggIterOutcome - Enum in org.apache.drill.exec.physical.impl.aggregate
 
HashAggregator.AggOutcome - Enum in org.apache.drill.exec.physical.impl.aggregate
 
HashAggTemplate - Class in org.apache.drill.exec.physical.impl.aggregate
 
HashAggTemplate() - Constructor for class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
 
HashAggTemplate.BatchHolder - Class in org.apache.drill.exec.physical.impl.aggregate
 
HashAggTemplate.BatchHolder() - Constructor for class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate.BatchHolder
 
HashAggTemplate.Metric - Enum in org.apache.drill.exec.physical.impl.aggregate
 
hashCode() - Method in class org.apache.drill.exec.cache.DistributedCache.CacheConfig
 
hashCode() - Method in class org.apache.drill.exec.compile.ClassTransformer.ClassNames
 
hashCode() - Method in class org.apache.drill.exec.compile.ClassTransformer.ClassSet
 
hashCode() - Method in class org.apache.drill.exec.coord.store.TransientStoreConfig
 
hashCode() - Method in class org.apache.drill.exec.coord.store.TransientStoreEvent
 
hashCode() - Method in class org.apache.drill.exec.expr.CodeGenerator
 
hashCode() - Method in class org.apache.drill.exec.expr.DirectExpression
 
hashCode() - Method in class org.apache.drill.exec.physical.EndpointAffinity
 
hashCode() - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
hashCode() - Method in class org.apache.drill.exec.planner.fragment.Fragment.ExchangeFragmentPair
 
hashCode() - Method in class org.apache.drill.exec.planner.fragment.Fragment
 
hashCode() - Method in class org.apache.drill.exec.planner.logical.DrillTable
 
hashCode() - Method in class org.apache.drill.exec.planner.logical.DrillTranslatableTable
 
hashCode() - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTrait.DistributionField
 
hashCode() - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
 
hashCode() - Method in class org.apache.drill.exec.planner.physical.explain.PrelSequencer.OpId
 
hashCode() - Method in class org.apache.drill.exec.planner.physical.PrelUtil.DesiredField
 
hashCode() - Method in class org.apache.drill.exec.planner.types.RelDataTypeDrillImpl
 
hashCode() - Method in class org.apache.drill.exec.planner.types.RelDataTypeHolder
 
hashCode() - Method in class org.apache.drill.exec.record.BatchSchema
 
hashCode() - Method in class org.apache.drill.exec.record.DeadBuf
 
hashCode() - Method in class org.apache.drill.exec.record.TypedFieldId
 
hashCode() - Method in class org.apache.drill.exec.rpc.control.ControlConnection
 
hashCode() - Method in class org.apache.drill.exec.rpc.data.DataClientConnection
 
hashCode() - Method in class org.apache.drill.exec.schema.Field
 
hashCode() - Method in class org.apache.drill.exec.serialization.JacksonSerializer
 
hashCode() - Method in class org.apache.drill.exec.serialization.ProtoSerializer
 
hashCode() - Method in class org.apache.drill.exec.server.options.OptionMetaData
 
hashCode() - Method in class org.apache.drill.exec.server.options.OptionValue
 
hashCode() - Method in class org.apache.drill.exec.server.options.PersistedOptionValue
 
hashCode() - Method in class org.apache.drill.exec.store.avro.AvroFormatConfig
 
hashCode() - Method in class org.apache.drill.exec.store.dfs.FileSystemConfig
 
hashCode() - Method in class org.apache.drill.exec.store.dfs.NamedFormatPluginConfig
 
hashCode() - Method in class org.apache.drill.exec.store.dfs.WorkspaceConfig
 
hashCode() - Method in class org.apache.drill.exec.store.easy.json.JSONFormatPlugin.JSONFormatConfig
 
hashCode() - Method in class org.apache.drill.exec.store.easy.sequencefile.SequenceFileFormatConfig
 
hashCode() - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
hashCode() - Method in class org.apache.drill.exec.store.httpd.HttpdLogFormatPlugin.HttpdLogFormatConfig
 
hashCode() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaConfig
 
hashCode() - Method in class org.apache.drill.exec.store.mock.MockStorageEngineConfig
 
hashCode() - Method in class org.apache.drill.exec.store.NamedStoragePluginConfig
 
hashCode() - Method in class org.apache.drill.exec.store.parquet.MetadataVersion
 
hashCode() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatConfig
 
hashCode() - Method in class org.apache.drill.exec.store.pcap.dto.ColumnDto
 
hashCode() - Method in class org.apache.drill.exec.store.pcap.PcapFormatConfig
 
hashCode() - Method in class org.apache.drill.exec.store.sys.PersistentStoreConfig
 
hashCode() - Method in class org.apache.drill.exec.store.sys.SystemTablePluginConfig
 
hashCode() - Method in class org.apache.drill.exec.testing.InjectionSite
 
HashHelper - Class in org.apache.drill.exec.expr.fn.impl
 
HashHelper() - Constructor for class org.apache.drill.exec.expr.fn.impl.HashHelper
 
HASHJOIN - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
HashJoinBatch - Class in org.apache.drill.exec.physical.impl.join
 
HashJoinBatch(HashJoinPOP, FragmentContext, RecordBatch, RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.join.HashJoinBatch
 
HashJoinBatch.Metric - Enum in org.apache.drill.exec.physical.impl.join
 
HashJoinBatchCreator - Class in org.apache.drill.exec.physical.impl.join
 
HashJoinBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.join.HashJoinBatchCreator
 
HashJoinHelper - Class in org.apache.drill.exec.physical.impl.join
 
HashJoinHelper(FragmentContext, BufferAllocator) - Constructor for class org.apache.drill.exec.physical.impl.join.HashJoinHelper
 
HashJoinHelper.BuildInfo - Class in org.apache.drill.exec.physical.impl.join
 
HashJoinHelper.BuildInfo(SelectionVector4, BitSet, int) - Constructor for class org.apache.drill.exec.physical.impl.join.HashJoinHelper.BuildInfo
 
HashJoinPOP - Class in org.apache.drill.exec.physical.config
 
HashJoinPOP(PhysicalOperator, PhysicalOperator, List<JoinCondition>, JoinRelType) - Constructor for class org.apache.drill.exec.physical.config.HashJoinPOP
 
HashJoinPrel - Class in org.apache.drill.exec.planner.physical
 
HashJoinPrel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType) - Constructor for class org.apache.drill.exec.planner.physical.HashJoinPrel
 
HashJoinPrel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, boolean) - Constructor for class org.apache.drill.exec.planner.physical.HashJoinPrel
 
HashJoinProbe - Interface in org.apache.drill.exec.physical.impl.join
 
HashJoinProbe.ProbeState - Enum in org.apache.drill.exec.physical.impl.join
 
HashJoinProbeTemplate - Class in org.apache.drill.exec.physical.impl.join
 
HashJoinProbeTemplate() - Constructor for class org.apache.drill.exec.physical.impl.join.HashJoinProbeTemplate
 
HashJoinPrule - Class in org.apache.drill.exec.planner.physical
 
HashPartitionSender - Class in org.apache.drill.exec.physical.config
 
HashPartitionSender(int, PhysicalOperator, LogicalExpression, List<MinorFragmentEndpoint>) - Constructor for class org.apache.drill.exec.physical.config.HashPartitionSender
 
HashPrelUtil - Class in org.apache.drill.exec.planner.physical
Contains utility methods for creating hash expression for either distribution (in PartitionSender) or for HashTable.
HashPrelUtil() - Constructor for class org.apache.drill.exec.planner.physical.HashPrelUtil
 
HashPrelUtil.HashExpressionCreatorHelper<T> - Interface in org.apache.drill.exec.planner.physical
Interface for creating different forms of hash expression types.
HashTable - Interface in org.apache.drill.exec.physical.impl.common
 
HashTable.PutStatus - Enum in org.apache.drill.exec.physical.impl.common
 
HashTableConfig - Class in org.apache.drill.exec.physical.impl.common
 
HashTableConfig(int, float, List<NamedExpression>, List<NamedExpression>, List<Comparator>) - Constructor for class org.apache.drill.exec.physical.impl.common.HashTableConfig
 
HashTableStats - Class in org.apache.drill.exec.physical.impl.common
 
HashTableStats() - Constructor for class org.apache.drill.exec.physical.impl.common.HashTableStats
 
HashTableTemplate - Class in org.apache.drill.exec.physical.impl.common
 
HashTableTemplate() - Constructor for class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
HashTableTemplate.BatchHolder - Class in org.apache.drill.exec.physical.impl.common
 
HashTableTemplate.BatchHolder(int) - Constructor for class org.apache.drill.exec.physical.impl.common.HashTableTemplate.BatchHolder
 
HashToMergeExchange - Class in org.apache.drill.exec.physical.config
 
HashToMergeExchange(PhysicalOperator, LogicalExpression, List<Order.Ordering>) - Constructor for class org.apache.drill.exec.physical.config.HashToMergeExchange
 
HashToMergeExchangePrel - Class in org.apache.drill.exec.planner.physical
 
HashToMergeExchangePrel(RelOptCluster, RelTraitSet, RelNode, List<DrillDistributionTrait.DistributionField>, RelCollation, int) - Constructor for class org.apache.drill.exec.planner.physical.HashToMergeExchangePrel
 
HashToRandomExchange - Class in org.apache.drill.exec.physical.config
 
HashToRandomExchange(PhysicalOperator, LogicalExpression) - Constructor for class org.apache.drill.exec.physical.config.HashToRandomExchange
 
HashToRandomExchangePrel - Class in org.apache.drill.exec.planner.physical
 
HashToRandomExchangePrel(RelOptCluster, RelTraitSet, RelNode, List<DrillDistributionTrait.DistributionField>) - Constructor for class org.apache.drill.exec.planner.physical.HashToRandomExchangePrel
 
HashVisitor - Class in org.apache.drill.exec.expr
 
HashVisitor() - Constructor for class org.apache.drill.exec.expr.HashVisitor
 
hasImpersonationPrivileges(String, String, String) - Static method in class org.apache.drill.exec.rpc.user.InboundImpersonationManager
 
hasMemoryAddress() - Method in class org.apache.drill.exec.record.DeadBuf
 
hasMemoryMergeCapacity(long, long) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
hasMoreData - Variable in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
hasNext() - Method in class org.apache.drill.exec.server.options.DrillConfigIterator.Iter
 
hasNext() - Method in class org.apache.drill.exec.store.sys.DrillbitIterator
 
hasNext() - Method in class org.apache.drill.exec.store.sys.ExtendedOptionIterator
 
hasNext() - Method in class org.apache.drill.exec.store.sys.MemoryIterator
 
hasNext() - Method in class org.apache.drill.exec.store.sys.OptionIterator
 
hasNext() - Method in class org.apache.drill.exec.store.sys.ThreadsIterator
 
hasNext() - Method in class org.apache.drill.exec.store.sys.VersionIterator
 
hasNulls(Statistics) - Static method in class org.apache.drill.exec.expr.stat.ParquetPredicates
 
hasPath(String) - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
Returns true if path exists in the cache, false otherwise.
hasPath(String, boolean) - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
Returns true if path exists, false otherwise.
hasPath(String, boolean, DataChangeVersion) - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
Checks if the given path exists.
hasPerformanceWarning() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
hasQueue() - Method in class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager.DefaultQueryResourceManager
 
hasQueue() - Method in interface org.apache.drill.exec.work.foreman.rm.QueryResourceManager
Hint that this resource manager queues.
hasQueue() - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedQueryResourceManager
 
hasReadPath() - Method in class org.apache.drill.exec.expr.ValueVectorReadExpression
 
hasRecordCount() - Method in class org.apache.drill.exec.record.VectorContainer
 
hasRegistry() - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
Report whether a remote registry exists.
hasRemainder() - Method in class org.apache.drill.exec.record.TypedFieldId
 
hasRemainder() - Method in class org.apache.drill.exec.store.parquet.ColumnDataReader
 
hasRemainder() - Method in class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
hasScalarSubqueryInput(RelNode, RelNode) - Static method in class org.apache.drill.exec.physical.impl.join.JoinUtils
Utility method to check if a any of input RelNodes is provably scalar.
hasSchema() - Method in class org.apache.drill.exec.record.VectorContainer
 
hasSchema() - Method in class org.apache.drill.exec.schema.Field
 
hasSelectionVector - Variable in enum org.apache.drill.exec.record.BatchSchema.SelectionVectorMode
 
hasSingleValue(long) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata
 
hasSingleValue(long) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
Checks that the column chunk has a single value.
hasSingleValue(long) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2
Checks that the column chunk has a single value.
hasSingleValue(long) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3
Checks that the column chunk has a single value.
hasSpilled() - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet
 
hasSpilled() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SpilledRuns
 
hasStar() - Method in class org.apache.drill.exec.dotdrill.View
 
hasSv2() - Method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
 
hasTrustStorePassword() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
hasTrustStorePassword() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
hasTrustStorePassword() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
hasTrustStorePath() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
hasTrustStorePath() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
hasTrustStorePath() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
HAVING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
HavingOpt() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses the optional HAVING clause for SELECT.
HAZELCAST_SUBNETS - Static variable in class org.apache.drill.exec.ExecConstants
 
HeaderBuilder - Class in org.apache.drill.exec.store.easy.text.compliant
Text output that implements a header reader/parser.
HeaderBuilder() - Constructor for class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
 
HeaderBuilder.HeaderError - Exception in org.apache.drill.exec.store.easy.text.compliant
Exception that reports header errors.
HeaderBuilder.HeaderError(String) - Constructor for exception org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder.HeaderError
 
HeaderBuilder.HeaderError(int, String) - Constructor for exception org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder.HeaderError
 
headers - Variable in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
 
heap_current - Variable in class org.apache.drill.exec.store.sys.MemoryIterator.MemoryInfo
 
heap_max - Variable in class org.apache.drill.exec.store.sys.MemoryIterator.MemoryInfo
 
HEP_OPT - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
HEP_PARTITION_PRUNING - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
HEXDIGIT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
hflush() - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalSyncableOutputStream
 
HIERARCHY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
hint(String) - Method in class org.apache.drill.exec.record.VectorInitializer
 
hitRowGroupEnd() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
hitRowGroupEnd() - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
 
HIVE_OPTIMIZE_SCAN_WITH_NATIVE_READERS - Static variable in class org.apache.drill.exec.ExecConstants
 
HIVE_OPTIMIZE_SCAN_WITH_NATIVE_READERS_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
HOLD - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
HOLDER_DESCRIPTORS - Static variable in class org.apache.drill.exec.compile.bytecode.ReplacingInterpreter
 
HoldingContainerExpression - Class in org.apache.drill.exec.expr
 
HoldingContainerExpression(ClassGenerator.HoldingContainer) - Constructor for class org.apache.drill.exec.expr.HoldingContainerExpression
 
HOOK - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
HOP_BY_HOP_EXTENSION_V6 - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
hostAffinity - Variable in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v1
 
hostAffinity - Variable in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v2
 
hostAffinity - Variable in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v3
 
hostname - Variable in class org.apache.drill.exec.store.sys.DrillbitIterator.DrillbitInstance
 
hostname - Variable in class org.apache.drill.exec.store.sys.MemoryIterator.MemoryInfo
 
hostname - Variable in class org.apache.drill.exec.store.sys.ThreadsIterator.ThreadsInfo
 
HOUR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
hsync() - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalSyncableOutputStream
 
HTTP_CORS_ALLOWED_HEADERS - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_CORS_ALLOWED_METHODS - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_CORS_ALLOWED_ORIGINS - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_CORS_CREDENTIALS - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_CORS_ENABLED - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_ENABLE - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_ENABLE_SSL - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_KEYSTORE_PASSWORD - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_KEYSTORE_PATH - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_MAX_PROFILES - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_PORT - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_PORT_HUNT - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_SESSION_MAX_IDLE_SECS - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_SESSION_MEMORY_MAXIMUM - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_SESSION_MEMORY_RESERVATION - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_TRUSTSTORE_PASSWORD - Static variable in class org.apache.drill.exec.ExecConstants
 
HTTP_TRUSTSTORE_PATH - Static variable in class org.apache.drill.exec.ExecConstants
 
HttpdLogFormatPlugin - Class in org.apache.drill.exec.store.httpd
 
HttpdLogFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig, HttpdLogFormatPlugin.HttpdLogFormatConfig) - Constructor for class org.apache.drill.exec.store.httpd.HttpdLogFormatPlugin
 
HttpdLogFormatPlugin.HttpdLogFormatConfig - Class in org.apache.drill.exec.store.httpd
This class is a POJO to hold the configuration for the HttpdLogFormat Parser.
HttpdLogFormatPlugin.HttpdLogFormatConfig() - Constructor for class org.apache.drill.exec.store.httpd.HttpdLogFormatPlugin.HttpdLogFormatConfig
 
HttpdLogRecord - Class in org.apache.drill.exec.store.httpd
 
HttpdLogRecord(DrillBuf) - Constructor for class org.apache.drill.exec.store.httpd.HttpdLogRecord
 
HttpdParser - Class in org.apache.drill.exec.store.httpd
 
HttpdParser(BaseWriter.MapWriter, DrillBuf, String, String, Map<String, String>) - Constructor for class org.apache.drill.exec.store.httpd.HttpdParser
 
HttpdParserTest - Class in org.apache.drill.exec.store.httpd
 
HttpdParserTest() - Constructor for class org.apache.drill.exec.store.httpd.HttpdParserTest
 
hyper() - Method in class org.apache.drill.exec.record.TypedFieldId.Builder
 
HyperVectorWrapper<T extends ValueVector> - Class in org.apache.drill.exec.record
 
HyperVectorWrapper(MaterializedField, T[]) - Constructor for class org.apache.drill.exec.record.HyperVectorWrapper
 
HyperVectorWrapper(MaterializedField, T[], boolean) - Constructor for class org.apache.drill.exec.record.HyperVectorWrapper
 

I

ICMP_PROTOCOL - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
id - Variable in enum org.apache.drill.exec.cache.SerializationDefinition
 
id - Variable in class org.apache.drill.exec.coord.zk.ZKRegistrationHandle
 
Identifier() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a simple identifier as a string.
IDENTIFIER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
IDENTIFIER_MAX_LENGTH - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
identifierMaxLength() - Method in class org.apache.drill.exec.planner.sql.DrillParserConfig
 
IDENTITY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
IdentityOptimizer - Class in org.apache.drill.exec.opt
 
IdentityOptimizer() - Constructor for class org.apache.drill.exec.opt.IdentityOptimizer
 
IdGenerator<T> - Interface in org.apache.drill.exec.schema
 
IF - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ignoreJSONParseError() - Method in interface org.apache.drill.exec.store.easy.json.JsonProcessor
 
ignoreJSONParseError() - Method in class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
 
image - Variable in class org.apache.drill.exec.planner.sql.parser.impl.Token
The string image of the token.
IMMEDIATE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
IMPERSONATION_ENABLED - Static variable in class org.apache.drill.exec.ExecConstants
 
IMPERSONATION_MAX_CHAINED_USER_HOPS - Static variable in class org.apache.drill.exec.ExecConstants
 
IMPERSONATION_POLICIES_KEY - Static variable in class org.apache.drill.exec.ExecConstants
Option whose value is a string representing list of inbound impersonation policies.
IMPERSONATION_POLICY_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
ImpersonationUtil - Class in org.apache.drill.exec.util
Utilities for impersonation purpose.
ImplCreator - Class in org.apache.drill.exec.physical.impl
Create RecordBatch tree (PhysicalOperator implementations) for a given PhysicalOperator tree.
implement(DrillImplementor) - Method in class org.apache.drill.exec.planner.logical.DrillAggregateRel
 
implement(DrillImplementor) - Method in class org.apache.drill.exec.planner.logical.DrillDirectScanRel
 
implement(DrillImplementor) - Method in class org.apache.drill.exec.planner.logical.DrillFilterRel
 
implement(DrillImplementor) - Method in class org.apache.drill.exec.planner.logical.DrillJoinRel
 
implement(DrillImplementor) - Method in class org.apache.drill.exec.planner.logical.DrillLimitRel
 
implement(DrillImplementor) - Method in class org.apache.drill.exec.planner.logical.DrillProjectRel
 
implement(DrillImplementor) - Method in interface org.apache.drill.exec.planner.logical.DrillRel
 
implement(DrillImplementor) - Method in class org.apache.drill.exec.planner.logical.DrillScanRel
 
implement(DrillImplementor) - Method in class org.apache.drill.exec.planner.logical.DrillScreenRel
 
implement(DrillImplementor) - Method in class org.apache.drill.exec.planner.logical.DrillSortRel
 
implement(DrillImplementor) - Method in class org.apache.drill.exec.planner.logical.DrillStoreRel
 
implement(DrillImplementor) - Method in class org.apache.drill.exec.planner.logical.DrillUnionRel
 
implement(DrillImplementor) - Method in class org.apache.drill.exec.planner.logical.DrillValuesRel
 
implement(DrillImplementor) - Method in class org.apache.drill.exec.planner.logical.DrillWindowRel
 
implement(DrillImplementor) - Method in class org.apache.drill.exec.planner.logical.DrillWriterRel
 
IMPLEMENTATION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
IMPLICIT_FILENAME_COLUMN_LABEL - Static variable in class org.apache.drill.exec.ExecConstants
Implicit file columns
IMPLICIT_FILENAME_COLUMN_LABEL_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
IMPLICIT_FILEPATH_COLUMN_LABEL - Static variable in class org.apache.drill.exec.ExecConstants
 
IMPLICIT_FILEPATH_COLUMN_LABEL_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
IMPLICIT_FQN_COLUMN_LABEL - Static variable in class org.apache.drill.exec.ExecConstants
 
IMPLICIT_FQN_COLUMN_LABEL_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
IMPLICIT_SUFFIX_COLUMN_LABEL - Static variable in class org.apache.drill.exec.ExecConstants
 
IMPLICIT_SUFFIX_COLUMN_LABEL_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
implicitFieldVectorMap() - Method in class org.apache.drill.exec.physical.impl.ScanBatch.Mutator
 
IMPORT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ImportGrabber - Class in org.apache.drill.exec.expr.fn
 
ImportGrabber.ImportFinder - Class in org.apache.drill.exec.expr.fn
 
ImportGrabber.ImportFinder() - Constructor for class org.apache.drill.exec.expr.fn.ImportGrabber.ImportFinder
 
IN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
IN_FORMAL_COMMENT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
IN_MULTI_LINE_COMMENT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
IN_SINGLE_LINE_COMMENT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
IN_SUBQUERY_THRESHOLD - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
InboundImpersonationManager - Class in org.apache.drill.exec.rpc.user
Helper class to manage inbound impersonation.
InboundImpersonationManager() - Constructor for class org.apache.drill.exec.rpc.user.InboundImpersonationManager
 
InboundImpersonationManager.InboundImpersonationPolicyValidator - Class in org.apache.drill.exec.rpc.user
Validator for impersonation policies.
InboundImpersonationManager.InboundImpersonationPolicyValidator(String) - Constructor for class org.apache.drill.exec.rpc.user.InboundImpersonationManager.InboundImpersonationPolicyValidator
 
inBuf - Variable in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
incConnectionCounter() - Method in class org.apache.drill.exec.rpc.control.ControlConnection
 
incConnectionCounter() - Method in class org.apache.drill.exec.rpc.data.DataClientConnection
 
incConnectionCounter() - Method in class org.apache.drill.exec.rpc.data.DataServerConnection
 
incConnectionCounter() - Method in class org.apache.drill.exec.rpc.user.UserClient.UserToBitConnection
 
incConnectionCounter() - Method in class org.apache.drill.exec.rpc.user.UserServer.BitToUserConnection
 
incCounter() - Method in class org.apache.drill.exec.expr.SizedJBlock
 
INCLUDING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
incoming - Variable in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
 
incoming - Variable in class org.apache.drill.exec.record.AbstractSingleRecordBatch
 
INCOMING_BUFFER_IMPL - Static variable in class org.apache.drill.exec.ExecConstants
 
INCOMING_BUFFER_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
incoming buffer size (number of batches)
IncomingBuffers - Class in org.apache.drill.exec.work.batch
Determines when a particular fragment has enough data for each of its receiving exchanges to commence execution.
IncomingBuffers(BitControl.PlanFragment, FragmentContext) - Constructor for class org.apache.drill.exec.work.batch.IncomingBuffers
 
incomingCount - Variable in class org.apache.drill.exec.ops.OpProfileDef
 
IncomingDataBatch - Class in org.apache.drill.exec.rpc.data
An incoming batch of data.
IncomingDataBatch(BitData.FragmentRecordBatch, DrillBuf, AckSender) - Constructor for class org.apache.drill.exec.rpc.data.IncomingDataBatch
Create a new batch.
incomingMapping - Variable in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
 
incOutputPos() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
INCREMENT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
increment(UserSession) - Method in interface org.apache.drill.exec.rpc.user.UserSession.QueryCountIncrementer
 
incrementAndGet() - Method in interface org.apache.drill.exec.cache.Counter
 
incrementQueryCount(UserSession.QueryCountIncrementer) - Method in class org.apache.drill.exec.rpc.user.UserSession
 
incrMergeCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
 
incrSpillCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
 
INDENT - Static variable in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor.VisualizationState
 
indexOf(int, int, byte) - Method in class org.apache.drill.exec.record.DeadBuf
 
IndexPointer - Class in org.apache.drill.exec.physical.impl.common
 
IndexPointer() - Constructor for class org.apache.drill.exec.physical.impl.common.IndexPointer
 
INDICATOR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
inferReturnType(SqlOperatorBinding) - Method in class org.apache.drill.exec.planner.sql.DrillSqlOperatorWithoutInference
 
INFORMATION_SCHEMA_PLUGIN - Static variable in interface org.apache.drill.exec.store.StoragePluginRegistry
 
informReceiverFinished(RpcOutcomeListener<GeneralRPCProtos.Ack>, BitControl.FinishedReceiver) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel
 
InfoSchemaBatchCreator - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaBatchCreator() - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaBatchCreator
 
InfoSchemaConfig - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaConfig() - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaConfig
 
InfoSchemaConstants - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaDrillTable - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaDrillTable(InfoSchemaStoragePlugin, String, InfoSchemaTableType, StoragePluginConfig) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaDrillTable
 
InfoSchemaFilter - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaFilter(InfoSchemaFilter.ExprNode) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaFilter
 
InfoSchemaFilter.ConstantExprNode - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaFilter.ConstantExprNode(String) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaFilter.ConstantExprNode
 
InfoSchemaFilter.ExprNode - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaFilter.ExprNode(InfoSchemaFilter.ExprNode.Type) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaFilter.ExprNode
 
InfoSchemaFilter.ExprNode.Type - Enum in org.apache.drill.exec.store.ischema
 
InfoSchemaFilter.FieldExprNode - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaFilter.FieldExprNode(String) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaFilter.FieldExprNode
 
InfoSchemaFilter.FunctionExprNode - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaFilter.FunctionExprNode(String, List<InfoSchemaFilter.ExprNode>) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaFilter.FunctionExprNode
 
InfoSchemaFilter.Result - Enum in org.apache.drill.exec.store.ischema
 
InfoSchemaFilterBuilder - Class in org.apache.drill.exec.store.ischema
Builds a InfoSchemaFilter out of the Filter condition.
InfoSchemaFilterBuilder(LogicalExpression) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaFilterBuilder
 
InfoSchemaGroupScan - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaGroupScan(InfoSchemaTableType) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaGroupScan
 
InfoSchemaGroupScan(InfoSchemaTableType, InfoSchemaFilter) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaGroupScan
 
InfoSchemaPushFilterIntoRecordGenerator - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaRecordGenerator<S> - Class in org.apache.drill.exec.store.ischema
Generates records for POJO RecordReader by scanning the given schema.
InfoSchemaRecordGenerator(OptionManager) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
 
InfoSchemaRecordGenerator.Catalogs - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaRecordGenerator.Catalogs(OptionManager) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Catalogs
 
InfoSchemaRecordGenerator.Columns - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaRecordGenerator.Columns(OptionManager) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Columns
 
InfoSchemaRecordGenerator.Schemata - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaRecordGenerator.Schemata(OptionManager) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Schemata
 
InfoSchemaRecordGenerator.Tables - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaRecordGenerator.Tables(OptionManager) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Tables
 
InfoSchemaRecordGenerator.Views - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaRecordGenerator.Views(OptionManager) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Views
 
InfoSchemaStoragePlugin - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaStoragePlugin(InfoSchemaConfig, DrillbitContext, String) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaStoragePlugin
 
InfoSchemaSubScan - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaSubScan(InfoSchemaTableType, InfoSchemaFilter) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaSubScan
 
InfoSchemaTable<S> - Class in org.apache.drill.exec.store.ischema
Base class for tables in INFORMATION_SCHEMA.
InfoSchemaTable(String, List<InfoSchemaTable.Field>) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaTable
 
InfoSchemaTable.Catalogs - Class in org.apache.drill.exec.store.ischema
Layout for the CATALOGS table.
InfoSchemaTable.Columns - Class in org.apache.drill.exec.store.ischema
Layout for the COLUMNS table.
InfoSchemaTable.Columns() - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaTable.Columns
 
InfoSchemaTable.Field - Class in org.apache.drill.exec.store.ischema
 
InfoSchemaTable.Field() - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaTable.Field
 
InfoSchemaTable.Schemata - Class in org.apache.drill.exec.store.ischema
Layout for the SCHEMATA table.
InfoSchemaTable.Schemata() - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaTable.Schemata
 
InfoSchemaTable.Tables - Class in org.apache.drill.exec.store.ischema
Layout for the TABLES table.
InfoSchemaTable.Tables() - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaTable.Tables
 
InfoSchemaTable.Views - Class in org.apache.drill.exec.store.ischema
Layout for the VIEWS table.
InfoSchemaTable.Views() - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaTable.Views
 
InfoSchemaTableType - Enum in org.apache.drill.exec.store.ischema
The set of tables/views in INFORMATION_SCHEMA.
init(DrillConfig, PersistentStoreProvider, ClusterCoordinator) - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
 
init(DrillConfig) - Method in class org.apache.drill.exec.opt.BasicOptimizer
 
init(DrillConfig) - Method in class org.apache.drill.exec.opt.IdentityOptimizer
 
init(DrillConfig) - Method in class org.apache.drill.exec.opt.Optimizer
 
init(int, BufferAllocator, boolean) - Method in interface org.apache.drill.exec.physical.impl.TopN.PriorityQueue
Initializes the priority queue.
init(int, BufferAllocator, boolean) - Method in class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
 
init() - Method in class org.apache.drill.exec.server.options.SystemOptionManager
Initializes this option manager.
init(FilterConfig) - Method in class org.apache.drill.exec.server.rest.UserNameFilter
 
init(Map<String, String>) - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter
 
init(Map<String, String>) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
 
init(OutputMutator) - Method in class org.apache.drill.exec.store.pojo.AbstractPojoWriter
 
init(OutputMutator) - Method in interface org.apache.drill.exec.store.pojo.PojoWriter
Initializes value vector.
init(Map<String, String>) - Method in interface org.apache.drill.exec.store.RecordWriter
Initialize the writer.
init() - Method in interface org.apache.drill.exec.store.StoragePluginRegistry
Initialize the storage plugin registry.
init() - Method in class org.apache.drill.exec.store.StoragePluginRegistryImpl
 
init(Map<String, String>) - Method in class org.apache.drill.exec.store.text.DrillTextRecordWriter
 
init() - Method in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
 
init() - Method in class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
INIT_ALLOCATION - Static variable in class org.apache.drill.exec.physical.base.AbstractBase
 
initCap(int, int, DrillBuf, DrillBuf) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionHelpers
Capitalizes first letter in each word.
initContext() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
initFragmentWrappers(Fragment, PlanningSet) - Method in class org.apache.drill.exec.planner.fragment.SimpleParallelizer
 
INITIAL_ALLOCATION - Static variable in interface org.apache.drill.exec.physical.impl.xsort.PriorityQueueCopier
 
INITIAL_BIT_PORT - Static variable in class org.apache.drill.exec.ExecConstants
 
INITIAL_DATA_PORT - Static variable in class org.apache.drill.exec.ExecConstants
 
INITIAL_USER_PORT - Static variable in class org.apache.drill.exec.ExecConstants
 
initialAllocation - Variable in class org.apache.drill.exec.physical.base.AbstractBase
 
initialize() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
initialize() - Method in interface org.apache.drill.exec.physical.impl.partitionsender.Partitioner
 
initialize() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerDecorator
decorator method to call multiple Partitioners initialize()
initialize() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate
 
initialize(boolean, BufferAllocator) - Method in class org.apache.drill.exec.rpc.AbstractRpcMetrics
 
initialize(boolean, BufferAllocator) - Method in class org.apache.drill.exec.rpc.control.ControlRpcMetrics
Should only be called when first access to getInstance is made.
initialize(boolean, BufferAllocator) - Method in class org.apache.drill.exec.rpc.data.DataRpcMetrics
Should only be called when first access to getInstance is made.
initialize(boolean, BufferAllocator) - Method in class org.apache.drill.exec.rpc.user.UserRpcMetrics
Should only be called when first access to getInstance is made.
initialize(URI, Configuration) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
initialize(int) - Method in interface org.apache.drill.exec.testing.CountDownLatchInjection
Initializes the underlying latch
initialize(int) - Method in class org.apache.drill.exec.testing.CountDownLatchInjectionImpl
 
initializeBatch() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
Initialize the OutgoingBatch based on the current schema in incoming RecordBatch
initializeKeyManagerFactory() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
initializeSSLContext(boolean) - Method in class org.apache.drill.exec.ssl.SSLConfigBuilder
 
initializeTrustManagerFactory() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
INITIALLY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
initiate(String) - Method in class org.apache.drill.exec.rpc.security.AuthenticationOutcomeListener
 
initImplicitFileColumns(OptionManager) - Static method in class org.apache.drill.exec.store.ColumnExplorer
Creates case insensitive map with implicit file columns as keys and appropriate ImplicitFileColumns enum as values
initJDKSSLContext() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
initJDKSSLContext() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
initJDKSSLContext() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
initNettySslContext() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
initNettySslContext() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
initNettySslContext() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
initRemoteConnection(SocketChannel) - Method in class org.apache.drill.exec.rpc.control.ControlClient
 
initRemoteConnection(SocketChannel) - Method in class org.apache.drill.exec.rpc.control.ControlServer
 
initRemoteConnection(SocketChannel) - Method in class org.apache.drill.exec.rpc.data.DataClient
 
initRemoteConnection(SocketChannel) - Method in class org.apache.drill.exec.rpc.data.DataServer
 
initRemoteConnection(SocketChannel) - Method in class org.apache.drill.exec.rpc.user.UserClient
 
initRemoteConnection(SocketChannel) - Method in class org.apache.drill.exec.rpc.user.UserServer
 
initSaslServer(String) - Method in class org.apache.drill.exec.rpc.AbstractServerConnection
 
initWriter(Class<?>, String, OutputMutator) - Method in class org.apache.drill.exec.store.pojo.AbstractPojoRecordReader
Creates writer based input class type and then initiates it.
INJECTABLE_GETTER_METHODS - Static variable in interface org.apache.drill.exec.ops.UdfUtilities
 
injectByteCode(String, byte[]) - Method in class org.apache.drill.exec.compile.QueryClassLoader
 
injectChecked(String, Class<T>) - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
injectChecked(String, Class<T>) - Method in interface org.apache.drill.exec.ops.OperatorContext
Insert a checked fault (exception) of the given class.
injectChecked(ExecutionControls, String, Class<T>) - Method in interface org.apache.drill.exec.testing.ControlsInjector
Inject (throw) a checked exception at this point, if an injection is specified, and it is time for it to be thrown.
injectChecked(ExecutionControls, String, Class<T>) - Method in class org.apache.drill.exec.testing.ExecutionControlsInjector
 
injectChecked(ExecutionControls, String, Class<T>) - Method in class org.apache.drill.exec.testing.NoOpControlsInjector
 
injectInterruptiblePause(ExecutionControls, String, Logger) - Method in interface org.apache.drill.exec.testing.ControlsInjector
Insert a pause that can be interrupted using Thread.interrupt() at the given site point, if such an injection is specified (i.e.
injectInterruptiblePause(ExecutionControls, String, Logger) - Method in class org.apache.drill.exec.testing.ExecutionControlsInjector
 
injectInterruptiblePause(ExecutionControls, String, Logger) - Method in class org.apache.drill.exec.testing.NoOpControlsInjector
 
Injection - Class in org.apache.drill.exec.testing
The base class for all types of injections (currently, pause and exception).
Injection(String, int, String, String, int, int) - Constructor for class org.apache.drill.exec.testing.Injection
 
InjectionConfigurationException - Exception in org.apache.drill.exec.testing
An Exception thrown when injection configuration is incorrect.
InjectionConfigurationException(String, Throwable) - Constructor for exception org.apache.drill.exec.testing.InjectionConfigurationException
 
InjectionConfigurationException(String) - Constructor for exception org.apache.drill.exec.testing.InjectionConfigurationException
 
InjectionConfigurationException(Throwable) - Constructor for exception org.apache.drill.exec.testing.InjectionConfigurationException
 
InjectionSite - Class in org.apache.drill.exec.testing
 
InjectionSite(Class<?>, String) - Constructor for class org.apache.drill.exec.testing.InjectionSite
 
InjectionSite.InjectionSiteKeyDeserializer - Class in org.apache.drill.exec.testing
Key Deserializer for InjectionSite.
InjectionSite.InjectionSiteKeyDeserializer() - Constructor for class org.apache.drill.exec.testing.InjectionSite.InjectionSiteKeyDeserializer
 
injectNow() - Method in class org.apache.drill.exec.testing.CountDownLatchInjectionImpl
 
injectNow() - Method in class org.apache.drill.exec.testing.Injection
This function checks if it is the right time for the injection to happen.
injector - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
 
injectPause(ExecutionControls, String, Logger) - Method in interface org.apache.drill.exec.testing.ControlsInjector
Pauses at this point, if such an injection is specified (i.e.
injectPause(ExecutionControls, String, Logger) - Method in class org.apache.drill.exec.testing.ExecutionControlsInjector
 
injectPause(ExecutionControls, String, Logger) - Method in class org.apache.drill.exec.testing.NoOpControlsInjector
 
injectUnchecked(String) - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
injectUnchecked(String) - Method in interface org.apache.drill.exec.ops.OperatorContext
Insert an unchecked fault (exception).
injectUnchecked(ExecutionControls, String) - Method in interface org.apache.drill.exec.testing.ControlsInjector
Inject (throw) an unchecked exception at this point, if an injection is specified, and it is time for it to be thrown.
injectUnchecked(FragmentContext, String) - Method in interface org.apache.drill.exec.testing.ControlsInjector
Inject (throw) an unchecked exception at this point, if the fragmentContext is not null, an injection is specified, and it is time for it to be thrown.
injectUnchecked(ExecutionControls, String) - Method in class org.apache.drill.exec.testing.ExecutionControlsInjector
 
injectUnchecked(FragmentContext, String) - Method in class org.apache.drill.exec.testing.ExecutionControlsInjector
 
injectUnchecked(ExecutionControls, String) - Method in class org.apache.drill.exec.testing.NoOpControlsInjector
 
injectUnchecked(FragmentContext, String) - Method in class org.apache.drill.exec.testing.NoOpControlsInjector
 
InMemoryOptionManager - Class in org.apache.drill.exec.server.options
This is an OptionManager that holds options in memory rather than in a persistent store.
InMemoryStore<V> - Class in org.apache.drill.exec.store.sys.store
 
InMemoryStore(int) - Constructor for class org.apache.drill.exec.store.sys.store.InMemoryStore
 
InMemoryStoreProvider - Class in org.apache.drill.exec.store.sys.store.provider
 
InMemoryStoreProvider(int) - Constructor for class org.apache.drill.exec.store.sys.store.provider.InMemoryStoreProvider
 
INNER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
InnerClassAccessStripper - Class in org.apache.drill.exec.compile
An ASM ClassVisitor that strips class the access bits that are only possible on inner classes (ACC_PROTECTED, ACC_PRIVATE, and ACC_FINAL).
InnerClassAccessStripper(int) - Constructor for class org.apache.drill.exec.compile.InnerClassAccessStripper
See ClassVisitor.ClassVisitor(int).
InnerClassAccessStripper(int, ClassVisitor) - Constructor for class org.apache.drill.exec.compile.InnerClassAccessStripper
See ClassVisitor.ClassVisitor(int, ClassVisitor).
innerNext() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.BaseRootExec
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.broadcastsender.BroadcastSenderRootExec
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenRecordBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.join.MergeJoinBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch
Method drains the right side input of the NLJ and accumulates the data in a hyper container.
innerNext() - Method in class org.apache.drill.exec.physical.impl.limit.LimitRecordBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.producer.ProducerConsumerBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.project.ProjectRecordBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.ScreenCreator.ScreenRoot
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.SingleSenderCreator.SingleSenderRootExec
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.sort.SortBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.svremover.RemovingRecordBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.union.UnionAllRecordBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.window.WindowFrameRecordBatch
Hold incoming batches in memory until all window functions are ready to process the batch on top of the queue
innerNext() - Method in class org.apache.drill.exec.physical.impl.WriterRecordBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch
 
innerNext() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
Process each request for a batch.
innerNext() - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
innerNext() - Method in class org.apache.drill.exec.record.AbstractSingleRecordBatch
 
INOUT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
INPUT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
input - Variable in class org.apache.drill.exec.store.parquet.ColumnDataReader
 
input_stream - Variable in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplTokenManager
 
inputStream - Variable in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
inScopeOf(OptionValue.OptionScope) - Method in enum org.apache.drill.exec.server.options.OptionValue.AccessibleScopes
 
INSENSITIVE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
INSERT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
insertLocalExchanges(Prel, OptionManager) - Static method in class org.apache.drill.exec.planner.physical.visitor.InsertLocalExchangeVisitor
 
InsertLocalExchangeVisitor - Class in org.apache.drill.exec.planner.physical.visitor
 
InsertLocalExchangeVisitor(boolean, boolean) - Constructor for class org.apache.drill.exec.planner.physical.visitor.InsertLocalExchangeVisitor
 
InsertLocalExchangeVisitor.RexNodeBasedHashExpressionCreatorHelper - Class in org.apache.drill.exec.planner.physical.visitor
 
InsertLocalExchangeVisitor.RexNodeBasedHashExpressionCreatorHelper(RexBuilder) - Constructor for class org.apache.drill.exec.planner.physical.visitor.InsertLocalExchangeVisitor.RexNodeBasedHashExpressionCreatorHelper
 
insertRenameProject(Prel) - Static method in class org.apache.drill.exec.planner.physical.visitor.JoinPrelRenameVisitor
 
insertRenameProject(Prel) - Static method in class org.apache.drill.exec.planner.physical.visitor.StarColumnConverter
 
insertTopProject(Prel, RelDataType) - Static method in class org.apache.drill.exec.planner.physical.visitor.TopProjectVisitor
Traverses passed physical relational node and its children and checks if top project should be added under screen or writer to preserve final output fields names.
inShutDown() - Method in interface org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue.StatusAdapter
 
INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.ConcatReturnTypeInference
 
INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalAddReturnTypeInference
 
INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalAggReturnTypeInference
 
INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalCastReturnTypeInference
 
INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalDivScaleReturnTypeInference
 
INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalMaxScaleReturnTypeInference
 
INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalModScaleReturnTypeInference
 
INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalSetScaleReturnTypeInference
 
INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalSumAggReturnTypeInference
 
INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalSumScaleReturnTypeInference
 
INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalZeroScaleReturnTypeInference
 
INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.DefaultReturnTypeInference
 
INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.PadReturnTypeInference
 
INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.SameInOutLengthReturnTypeInference
 
INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.StringCastReturnTypeInference
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.cost.DrillDefaultRelMetadataProvider
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.fragment.contrib.ExchangeRemoverMaterializer
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.fragment.contrib.OperatorIdVisitor
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.fragment.HardAffinityFragmentParallelizer
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.fragment.MakeFragmentsVisitor
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.fragment.Materializer
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.fragment.SoftAffinityFragmentParallelizer
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillAggregateRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillFilterAggregateTransposeRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillFilterRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillJoinRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillLimitRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillMergeFilterRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillProjectRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillProjectSetOpTransposeRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillPushFilterPastProjectRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillPushProjectPastFilterRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillPushProjectPastJoinRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillPushProjIntoScan
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillReduceAggregatesRule
The singleton.
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillScanRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillSortRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillUnionAllRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillValuesRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillWindowRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.EnumerableDrillRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.DirectScanPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.DrillDistributionTraitDef
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.FilterPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.HashAggPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.LimitPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.LimitUnionExchangeTransposeRule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.NestedLoopJoinPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.ProjectPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.PushLimitToTopN
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.ScanPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.ScreenPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.SortConvertPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.SortPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.StreamAggPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.UnionAllPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.UnionDistinctPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.ValuesPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.WindowPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.WriterPrule
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.sql.DrillConvertletTable
 
INSTANCE - Static variable in class org.apache.drill.exec.planner.sql.DrillExtractConvertlet
 
INSTANCE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
INSTANCE - Static variable in class org.apache.drill.exec.store.mock.MockStorageEngineConfig
 
INSTANCE - Static variable in class org.apache.drill.exec.store.sys.SystemTablePluginConfig
 
INSTANCE_SUM - Static variable in class org.apache.drill.exec.planner.logical.DrillReduceAggregatesRule
 
INSTANCE_WINDOW_SUM - Static variable in class org.apache.drill.exec.planner.logical.DrillReduceAggregatesRule
 
InstanceSerializer<T> - Interface in org.apache.drill.exec.serialization
 
INSTANTIABLE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
InstructionModifier - Class in org.apache.drill.exec.compile.bytecode
 
InstructionModifier(int, String, String, String, String[], TrackingInstructionList, MethodVisitor) - Constructor for class org.apache.drill.exec.compile.bytecode.InstructionModifier
 
INT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
INT - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaTable
 
INT_TYPE - Static variable in class org.apache.drill.exec.schema.json.jackson.JacksonHelper
 
IntAccessor - Class in org.apache.drill.exec.vector.accessor
 
IntAccessor(IntVector) - Constructor for class org.apache.drill.exec.vector.accessor.IntAccessor
 
IntBEConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
IntBEConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.IntBEConvertFrom
 
IntBEConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
IntBEConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.IntBEConvertTo
 
IntConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
IntConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.IntConvertFrom
 
IntConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
IntConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.IntConvertTo
 
INTEGER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
INTEGER - Static variable in interface org.apache.drill.exec.vector.complex.fn.ExtendedTypeName
 
intermediateType(TypeProtos.MajorType) - Method in class org.apache.drill.exec.record.TypedFieldId.Builder
 
INTERNAL_FRAGMENTATION_ESTIMATE - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
Estimate for typical internal fragmentation in a buffer due to power-of-two rounding on vectors.
InternalBatch - Class in org.apache.drill.exec.physical.impl.aggregate
 
InternalBatch(RecordBatch, OperatorContext) - Constructor for class org.apache.drill.exec.physical.impl.aggregate.InternalBatch
 
InternalBatch(RecordBatch, VectorWrapper<?>[], OperatorContext) - Constructor for class org.apache.drill.exec.physical.impl.aggregate.InternalBatch
 
internalBuffer - Variable in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
The internal buffer to keep data read from the underlying inputStream.
internalNioBuffer(int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
InterpreterEvaluator - Class in org.apache.drill.exec.expr.fn.interpreter
 
InterpreterEvaluator() - Constructor for class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator
 
InterpreterEvaluator.EvalVisitor - Class in org.apache.drill.exec.expr.fn.interpreter
 
InterpreterEvaluator.EvalVisitor(VectorAccessible, UdfUtilities) - Constructor for class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
InterpreterEvaluator.EvalVisitor.Trivalent - Enum in org.apache.drill.exec.expr.fn.interpreter
 
interrupt(InterruptedException) - Method in interface org.apache.drill.exec.ops.Consumer
 
interrupted(InterruptedException) - Method in class org.apache.drill.exec.ops.StatusHandler
 
interrupted(InterruptedException) - Method in class org.apache.drill.exec.rpc.security.AuthenticationOutcomeListener
 
interruptiblePause() - Method in class org.apache.drill.exec.testing.PauseInjection
 
INTERRUPTION_AFTER_SETUP - Static variable in class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch
 
INTERRUPTION_AFTER_SETUP - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
 
INTERRUPTION_AFTER_SORT - Static variable in class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch
 
INTERRUPTION_AFTER_SORT - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
 
INTERRUPTION_WHILE_MERGING - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
 
INTERRUPTION_WHILE_SPILLING - Static variable in class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch
 
INTERRUPTION_WHILE_SPILLING - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
 
INTERSECT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
INTERSECTION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
INTERVAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
INTERVAL - Static variable in interface org.apache.drill.exec.vector.complex.fn.ExtendedTypeName
 
INTERVAL_PRECISION - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
INTERVAL_TYPE - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
IntervalAccessor - Class in org.apache.drill.exec.vector.accessor
 
IntervalAccessor(IntervalVector) - Constructor for class org.apache.drill.exec.vector.accessor.IntervalAccessor
 
IntervalBigIntFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalBigIntFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalBigIntFunctions
 
IntervalBigIntFunctions.BigIntIntervalMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalBigIntFunctions.BigIntIntervalMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalBigIntFunctions.BigIntIntervalMultiplyFunction
 
IntervalBigIntFunctions.IntervalBigIntDivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalBigIntFunctions.IntervalBigIntDivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalBigIntFunctions.IntervalBigIntDivideFunction
 
IntervalBigIntFunctions.IntervalBigIntMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalBigIntFunctions.IntervalBigIntMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalBigIntFunctions.IntervalBigIntMultiplyFunction
 
IntervalDayAccessor - Class in org.apache.drill.exec.vector.accessor
 
IntervalDayAccessor(IntervalDayVector) - Constructor for class org.apache.drill.exec.vector.accessor.IntervalDayAccessor
 
IntervalDayBigIntFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayBigIntFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayBigIntFunctions
 
IntervalDayBigIntFunctions.BigIntIntervalDayMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayBigIntFunctions.BigIntIntervalDayMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayBigIntFunctions.BigIntIntervalDayMultiplyFunction
 
IntervalDayBigIntFunctions.IntervalDayBigIntDivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayBigIntFunctions.IntervalDayBigIntDivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayBigIntFunctions.IntervalDayBigIntDivideFunction
 
IntervalDayBigIntFunctions.IntervalDayBigIntMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayBigIntFunctions.IntervalDayBigIntMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayBigIntFunctions.IntervalDayBigIntMultiplyFunction
 
IntervalDayFloat4Functions - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayFloat4Functions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat4Functions
 
IntervalDayFloat4Functions.Float4IntervalDayMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayFloat4Functions.Float4IntervalDayMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat4Functions.Float4IntervalDayMultiplyFunction
 
IntervalDayFloat4Functions.IntervalDayFloat4DivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayFloat4Functions.IntervalDayFloat4DivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat4Functions.IntervalDayFloat4DivideFunction
 
IntervalDayFloat4Functions.IntervalDayFloat4MultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayFloat4Functions.IntervalDayFloat4MultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat4Functions.IntervalDayFloat4MultiplyFunction
 
IntervalDayFloat8Functions - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayFloat8Functions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat8Functions
 
IntervalDayFloat8Functions.Float8IntervalDayMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayFloat8Functions.Float8IntervalDayMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat8Functions.Float8IntervalDayMultiplyFunction
 
IntervalDayFloat8Functions.IntervalDayFloat8DivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayFloat8Functions.IntervalDayFloat8DivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat8Functions.IntervalDayFloat8DivideFunction
 
IntervalDayFloat8Functions.IntervalDayFloat8MultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayFloat8Functions.IntervalDayFloat8MultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat8Functions.IntervalDayFloat8MultiplyFunction
 
IntervalDayFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayFunctions
 
IntervalDayFunctions.IntervalDayAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayFunctions.IntervalDayAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayFunctions.IntervalDayAddFunction
 
IntervalDayFunctions.IntervalDayNegateFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayFunctions.IntervalDayNegateFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayFunctions.IntervalDayNegateFunction
 
IntervalDayFunctions.IntervalDaySubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayFunctions.IntervalDaySubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayFunctions.IntervalDaySubtractFunction
 
IntervalDayIntFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayIntFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayIntFunctions
 
IntervalDayIntFunctions.IntervalDayIntDivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayIntFunctions.IntervalDayIntDivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayIntFunctions.IntervalDayIntDivideFunction
 
IntervalDayIntFunctions.IntervalDayIntMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayIntFunctions.IntervalDayIntMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayIntFunctions.IntervalDayIntMultiplyFunction
 
IntervalDayIntFunctions.IntIntervalDayMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalDayIntFunctions.IntIntervalDayMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalDayIntFunctions.IntIntervalDayMultiplyFunction
 
IntervalFloat4Functions - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalFloat4Functions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalFloat4Functions
 
IntervalFloat4Functions.Float4IntervalMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalFloat4Functions.Float4IntervalMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalFloat4Functions.Float4IntervalMultiplyFunction
 
IntervalFloat4Functions.IntervalFloat4DivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalFloat4Functions.IntervalFloat4DivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalFloat4Functions.IntervalFloat4DivideFunction
 
IntervalFloat4Functions.IntervalFloat4MultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalFloat4Functions.IntervalFloat4MultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalFloat4Functions.IntervalFloat4MultiplyFunction
 
IntervalFloat8Functions - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalFloat8Functions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalFloat8Functions
 
IntervalFloat8Functions.Float8IntervalMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalFloat8Functions.Float8IntervalMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalFloat8Functions.Float8IntervalMultiplyFunction
 
IntervalFloat8Functions.IntervalFloat8DivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalFloat8Functions.IntervalFloat8DivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalFloat8Functions.IntervalFloat8DivideFunction
 
IntervalFloat8Functions.IntervalFloat8MultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalFloat8Functions.IntervalFloat8MultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalFloat8Functions.IntervalFloat8MultiplyFunction
 
IntervalFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalFunctions
 
IntervalFunctions.IntervalAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalFunctions.IntervalAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalFunctions.IntervalAddFunction
 
IntervalFunctions.IntervalNegateFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalFunctions.IntervalNegateFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalFunctions.IntervalNegateFunction
 
IntervalFunctions.IntervalSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalFunctions.IntervalSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalFunctions.IntervalSubtractFunction
 
IntervalIntFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalIntFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalIntFunctions
 
IntervalIntFunctions.IntervalIntDivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalIntFunctions.IntervalIntDivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalIntFunctions.IntervalIntDivideFunction
 
IntervalIntFunctions.IntervalIntMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalIntFunctions.IntervalIntMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalIntFunctions.IntervalIntMultiplyFunction
 
IntervalIntFunctions.IntIntervalMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalIntFunctions.IntIntervalMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalIntFunctions.IntIntervalMultiplyFunction
 
IntervalLiteral() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses an interval literal.
IntervalQualifier() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
IntervalYearAccessor - Class in org.apache.drill.exec.vector.accessor
 
IntervalYearAccessor(IntervalYearVector) - Constructor for class org.apache.drill.exec.vector.accessor.IntervalYearAccessor
 
IntervalYearBigIntFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearBigIntFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearBigIntFunctions
 
IntervalYearBigIntFunctions.BigIntIntervalYearMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearBigIntFunctions.BigIntIntervalYearMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearBigIntFunctions.BigIntIntervalYearMultiplyFunction
 
IntervalYearBigIntFunctions.IntervalYearBigIntDivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearBigIntFunctions.IntervalYearBigIntDivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearBigIntFunctions.IntervalYearBigIntDivideFunction
 
IntervalYearBigIntFunctions.IntervalYearBigIntMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearBigIntFunctions.IntervalYearBigIntMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearBigIntFunctions.IntervalYearBigIntMultiplyFunction
 
IntervalYearFloat4Functions - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearFloat4Functions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat4Functions
 
IntervalYearFloat4Functions.Float4IntervalYearMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearFloat4Functions.Float4IntervalYearMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat4Functions.Float4IntervalYearMultiplyFunction
 
IntervalYearFloat4Functions.IntervalYearFloat4DivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearFloat4Functions.IntervalYearFloat4DivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat4Functions.IntervalYearFloat4DivideFunction
 
IntervalYearFloat4Functions.IntervalYearFloat4MultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearFloat4Functions.IntervalYearFloat4MultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat4Functions.IntervalYearFloat4MultiplyFunction
 
IntervalYearFloat8Functions - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearFloat8Functions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat8Functions
 
IntervalYearFloat8Functions.Float8IntervalYearMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearFloat8Functions.Float8IntervalYearMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat8Functions.Float8IntervalYearMultiplyFunction
 
IntervalYearFloat8Functions.IntervalYearFloat8DivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearFloat8Functions.IntervalYearFloat8DivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat8Functions.IntervalYearFloat8DivideFunction
 
IntervalYearFloat8Functions.IntervalYearFloat8MultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearFloat8Functions.IntervalYearFloat8MultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat8Functions.IntervalYearFloat8MultiplyFunction
 
IntervalYearFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearFunctions
 
IntervalYearFunctions.IntervalYearAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearFunctions.IntervalYearAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearFunctions.IntervalYearAddFunction
 
IntervalYearFunctions.IntervalYearNegateFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearFunctions.IntervalYearNegateFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearFunctions.IntervalYearNegateFunction
 
IntervalYearFunctions.IntervalYearSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearFunctions.IntervalYearSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearFunctions.IntervalYearSubtractFunction
 
IntervalYearIntFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearIntFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearIntFunctions
 
IntervalYearIntFunctions.IntervalYearIntDivideFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearIntFunctions.IntervalYearIntDivideFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearIntFunctions.IntervalYearIntDivideFunction
 
IntervalYearIntFunctions.IntervalYearIntMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearIntFunctions.IntervalYearIntMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearIntFunctions.IntervalYearIntMultiplyFunction
 
IntervalYearIntFunctions.IntIntervalYearMultiplyFunction - Class in org.apache.drill.exec.expr.fn.impl
 
IntervalYearIntFunctions.IntIntervalYearMultiplyFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.IntervalYearIntFunctions.IntIntervalYearMultiplyFunction
 
IntGen - Class in org.apache.drill.exec.store.mock
Generates integer values uniformly randomly distributed over the entire 32-bit integer range from Integer.MIN_VALUE to Integer.MAX_VALUE.
IntGen() - Constructor for class org.apache.drill.exec.store.mock.IntGen
 
IntLiteral() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
INTO - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
IntVIntConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
IntVIntConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.IntVIntConvertFrom
 
IntVIntConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
IntVIntConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.IntVIntConvertTo
 
INVALID_NODE - Static variable in class org.apache.drill.exec.vector.complex.fn.FieldSelection
 
InvalidAccessException - Exception in org.apache.drill.exec.vector.accessor
 
InvalidAccessException(String) - Constructor for exception org.apache.drill.exec.vector.accessor.InvalidAccessException
 
InvalidConnectionInfoException - Exception in org.apache.drill.exec.client
Exception for malformed connection string from client
InvalidConnectionInfoException(String) - Constructor for exception org.apache.drill.exec.client.InvalidConnectionInfoException
 
INVOKER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
IP4_DST_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
IP4_SRC_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
IP6_DST_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
IP6_SRC_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
IP_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
IPv4_TYPE - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
IPv6_TYPE - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
IS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
IS_CATALOG_CONNECT - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
Catalog connect string.
IS_CATALOG_DESCR - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
Catalog description
IS_CATALOG_NAME - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
Name of catalog containing information schema.
IS_FILTER_ON_PROJECT - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaPushFilterIntoRecordGenerator
 
IS_FILTER_ON_SCAN - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaPushFilterIntoRecordGenerator
 
IS_MUTABLE - Variable in class org.apache.drill.exec.store.ischema.Records.Schema
 
IS_NULLABLE - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
IS_SCHEMA_NAME - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
Name of information schema.
isAckSent() - Method in class org.apache.drill.exec.record.RawFragmentBatch
 
isActive() - Method in class org.apache.drill.exec.rpc.control.ControlConnection
 
isAdminOnly() - Method in class org.apache.drill.exec.server.options.OptionMetaData
 
isAdminUser() - Method in class org.apache.drill.exec.server.rest.auth.DrillUserPrincipal
 
isAggregating() - Method in class org.apache.drill.exec.expr.DrillFuncHolderExpr
 
isAggregating() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
isAggregator() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
isAllExpressionsConverted() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilterBuilder
 
isAllNulls(Statistics, long) - Static method in class org.apache.drill.exec.expr.stat.ParquetPredicates
 
isAlwaysValid() - Method in class org.apache.drill.exec.vector.complex.fn.FieldSelection
 
isArpPacket() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
isAssignedToMember() - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
Indicates whether or not this value is assigned to a class member variable.
isAssignmentRequired() - Method in class org.apache.drill.exec.physical.EndpointAffinity
Is this endpoint required to be in fragment endpoint assignment list?
isBigEndian() - Method in class org.apache.drill.exec.store.pcap.decoder.PacketDecoder
 
isBinaryCommutative() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
 
isBitEncryptionEnabled() - Method in class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
 
isBlockSplittable() - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
Whether or not you can split the format based on blocks within file boundaries.
isBroadcastJoinEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isBufferedOperator() - Method in class org.apache.drill.exec.physical.base.AbstractBase
Any operator that supports spilling should override this method (and return true)
isBufferedOperator() - Method in interface org.apache.drill.exec.physical.base.PhysicalOperator
 
isBufferedOperator() - Method in class org.apache.drill.exec.physical.config.ExternalSort
The External Sort operator supports spilling
isBufferedOperator() - Method in class org.apache.drill.exec.physical.config.HashAggregate
The Hash Aggregate operator supports spilling
isBuffersDone() - Method in class org.apache.drill.exec.ops.FragmentContext
 
isCancelled() - Method in class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
isCancelled() - Method in interface org.apache.drill.exec.work.fragment.FragmentManager
Find out if the FragmentManager has been cancelled.
isCastable(TypeProtos.MinorType, TypeProtos.MinorType) - Static method in class org.apache.drill.exec.resolver.TypeCastRules
 
isCastableWithNullHandling(TypeProtos.MajorType, TypeProtos.MajorType, FunctionTemplate.NullHandling) - Static method in class org.apache.drill.exec.resolver.TypeCastRules
 
isChanged() - Method in class org.apache.drill.exec.schema.DiffSchema
 
isClassBytesOk(Logger, String, byte[]) - Static method in class org.apache.drill.exec.compile.AsmUtil
Check to see if a class is well-formed.
isClassOk(Logger, String, ClassNode) - Static method in class org.apache.drill.exec.compile.AsmUtil
Check to see if a class is well-formed.
isCodeToBeSaved() - Method in class org.apache.drill.exec.expr.CodeGenerator
 
isCompatible(boolean, boolean) - Method in class org.apache.drill.exec.planner.common.DrillUnionRelBase
 
isComplexWriter() - Method in class org.apache.drill.exec.expr.fn.ValueReference
 
isComplexWriterFuncHolder() - Method in class org.apache.drill.exec.expr.fn.AbstractFuncHolder
Checks that the current function holder stores output value using field writer instead of vector holder.
isComplexWriterFuncHolder() - Method in class org.apache.drill.exec.expr.fn.DrillComplexWriterFuncHolder
 
isCompositePartition() - Method in class org.apache.drill.exec.planner.DFSDirPartitionLocation
 
isCompositePartition() - Method in interface org.apache.drill.exec.planner.PartitionLocation
Returns if this is a simple or composite partition.
isCompositePartition() - Method in class org.apache.drill.exec.planner.SimplePartitionLocation
 
isCompressible() - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
Method indicates whether or not this format could also be in a compression container (for example: csv.gz versus csv).
isConstant() - Method in class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
 
isConstant(int) - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
isConstant() - Method in class org.apache.drill.exec.expr.fn.ValueReference
 
isConstantFoldingEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isCurrent() - Method in class org.apache.drill.exec.physical.config.WindowPOP.Bound
 
isCurrent() - Method in class org.apache.drill.exec.server.rest.DrillRoot.DrillbitInfo
 
isCurrent(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.store.sys.DrillbitIterator
 
isDebug() - Method in class org.apache.drill.exec.server.StartupOptions
 
isDeleteOnExit() - Method in class org.apache.drill.exec.store.StorageStrategy
 
isDelimiter(byte) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Identifies whether or not a given character represents a field delimiter
isDeterministic() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
isDeterministic() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
 
isDeterministic() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
isDeterministic() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
isDeterministic() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
isDeterministic() - Method in class org.apache.drill.exec.planner.sql.DrillSqlOperator
 
isDirect() - Method in class org.apache.drill.exec.record.DeadBuf
 
isDirect() - Method in class org.apache.drill.exec.store.parquet.ParquetDirectByteBufferAllocator
 
isDirectory - Variable in class org.apache.drill.exec.planner.sql.handlers.ShowFilesCommandResult
 
isDirectory(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
isDistinct() - Method in class org.apache.drill.exec.planner.common.DrillUnionRelBase
 
isDistributed() - Method in enum org.apache.drill.exec.store.sys.SystemTable
 
isDone() - Method in class org.apache.drill.exec.physical.impl.window.Partition
 
isDone() - Method in class org.apache.drill.exec.work.batch.IncomingBuffers
 
isDrillbitInState(CoordinationProtos.DrillbitEndpoint, CoordinationProtos.DrillbitEndpoint.State) - Method in class org.apache.drill.exec.coord.ClusterCoordinator
 
isDynamic() - Method in class org.apache.drill.exec.dotdrill.View
 
isDynamicFunction() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
isDynamicFunction() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
isEmpty() - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
 
isEmpty() - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
isEmpty() - Method in class org.apache.drill.exec.physical.impl.sort.SortRecordBatchBuilder
 
isEmpty() - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
isEmpty() - Method in class org.apache.drill.exec.server.rest.QueryResources.TabularResult
 
isEmpty() - Method in interface org.apache.drill.exec.store.schedule.EndpointByteMap
 
isEmpty() - Method in class org.apache.drill.exec.store.schedule.EndpointByteMapImpl
 
isEmpty() - Method in interface org.apache.drill.exec.work.batch.BaseRawBatchBuffer.BufferQueue
 
isEnabled() - Method in class org.apache.drill.exec.server.rest.DrillRoot.QueueInfo
 
isEncryptionEnabled() - Method in class org.apache.drill.exec.rpc.AbstractConnectionConfig
 
isEncryptionEnabled() - Method in interface org.apache.drill.exec.rpc.ConnectionConfig
 
isEndpointsAssignmentDone() - Method in class org.apache.drill.exec.planner.fragment.Wrapper
Is the endpoints assignment done for this fragment?
isEquivalent(BatchSchema) - Method in class org.apache.drill.exec.record.BatchSchema
 
isEqWithEpsilon(RelOptCost) - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
isExecutable() - Method in class org.apache.drill.exec.physical.base.AbstractBase
 
isExecutable() - Method in class org.apache.drill.exec.physical.base.AbstractExchange
Exchanges are not executable.
isExecutable() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
isExecutable() - Method in class org.apache.drill.exec.physical.base.AbstractSubScan
 
isExecutable() - Method in interface org.apache.drill.exec.physical.base.PhysicalOperator
Describes whether or not a particular physical operator can actually be executed.
isExecutable() - Method in class org.apache.drill.exec.store.mock.MockSubScanPOP
 
isExecutable() - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
 
isExpandedFully() - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
isExpandedPartial() - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
isExtended() - Method in class org.apache.drill.exec.store.mock.MockSubScanPOP
 
isExtended() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockScanEntry
 
isFailed() - Method in interface org.apache.drill.exec.ops.FragmentContext.ExecutorState
Deprecated.
isFailed() - Method in class org.apache.drill.exec.ops.FragmentContext
Deprecated.
IsFalse - Class in org.apache.drill.exec.expr.fn.impl
 
IsFalse() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsFalse
 
IsFalse.Optional - Class in org.apache.drill.exec.expr.fn.impl
 
IsFalse.Optional() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsFalse.Optional
 
IsFalse.Required - Class in org.apache.drill.exec.expr.fn.impl
 
IsFalse.Required() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsFalse.Required
 
isFieldReader(int) - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
isFieldReader() - Method in class org.apache.drill.exec.expr.fn.ValueReference
 
isFile - Variable in class org.apache.drill.exec.planner.sql.handlers.ShowFilesCommandResult
 
isFile(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
isFileReadable(DrillFileSystem, FileStatus) - Method in class org.apache.drill.exec.store.dfs.BasicFormatMatcher
 
isFileReadable(DrillFileSystem, FileStatus) - Method in class org.apache.drill.exec.store.dfs.FormatMatcher
 
isFilterPushedDown() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaGroupScan
 
isFixedLength() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetColumnMetadata
 
isForce2phaseAggr() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isForeman(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.server.DrillbitContext
 
isForemanOnline() - Method in class org.apache.drill.exec.server.DrillbitContext
 
isFrameDone() - Method in class org.apache.drill.exec.physical.impl.window.Partition
 
isFrameUnitsRows() - Method in class org.apache.drill.exec.physical.config.WindowPOP
 
isFunctionArgument() - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
Indicates whether or not this value is used as a function argument.
isFunctionComplexOutput(String) - Method in class org.apache.drill.exec.expr.fn.FunctionImplementationRegistry
 
isFunctionReturn() - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
Indicates whether or not this value is used as a function return value.
isGuaranteed() - Method in class org.apache.drill.exec.planner.logical.EnumerableDrillRule
 
isHashAggEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isHashAggMapping() - Method in class org.apache.drill.exec.compile.sig.MappingSet
 
isHashJoinEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isHashJoinSwapEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isHashSingleKey() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isHasMoreData() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
isHeaderExtractionEnabled() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Indicates whether or not the first valid record parsed from the input should be considered as the row containing the names of each column
isHeaderExtractionEnabled() - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
isHepOptEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isHepPartitionPruningEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isHolder(String) - Static method in class org.apache.drill.exec.compile.bytecode.ScalarReplacementTypes
Determine if a class is a holder class.
isHttpsEnabled() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
isHttpsEnabled() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
isHttpsEnabled() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
isHyper() - Method in class org.apache.drill.exec.record.HyperVectorWrapper
 
isHyper() - Method in class org.apache.drill.exec.record.SimpleVectorWrapper
 
isHyper() - Method in interface org.apache.drill.exec.record.VectorWrapper
 
isHyperReader() - Method in class org.apache.drill.exec.record.TypedFieldId
 
isIcmpPacket() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
isIgnoreLeadingWhitespaces() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
isIgnoreTrailingWhitespaces() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
isImpersonationEnabled() - Method in class org.apache.drill.exec.ops.FragmentContext
 
isImpersonationEnabled() - Method in class org.apache.drill.exec.ops.QueryContext
 
isImpersonationEnabled() - Method in class org.apache.drill.exec.ops.ViewExpansionContext
 
isImpersonationOnlyEnabled(DrillConfig) - Static method in class org.apache.drill.exec.server.rest.WebServer
Checks if only impersonation is enabled.
isInfinite() - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
isInject() - Method in class org.apache.drill.exec.expr.fn.WorkspaceReference
 
isInternal() - Method in class org.apache.drill.exec.server.options.OptionMetaData
 
isIpV4Packet() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
isIpV6Packet() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
isJoinOptimizationEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isKeyMatchInternalBuild(int, int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate.BatchHolder
 
isKeyMatchInternalProbe(int, int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate.BatchHolder
 
isLe(RelOptCost) - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
isLessRestrictiveThan(DistributionAffinity) - Method in enum org.apache.drill.exec.planner.fragment.DistributionAffinity
Is the current DistributionAffinity less restrictive than the given DistributionAffinity?
isListVector() - Method in class org.apache.drill.exec.record.TypedFieldId
 
isLiteralNull(RexLiteral) - Static method in class org.apache.drill.exec.planner.logical.DrillOptiq
 
isLocal() - Method in class org.apache.drill.exec.work.foreman.FragmentData
 
isLowMemory() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
isLt(RelOptCost) - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
isMemoryEstimationEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isMergeJoinEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isMetadataCacheCorrupted() - Method in class org.apache.drill.exec.store.dfs.MetadataContext
 
isMultiPhaseAggEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isMutable() - Method in class org.apache.drill.exec.store.AbstractSchema
 
isMutable() - Method in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory.FileSystemSchema
 
isMutable() - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
isMutable() - Method in class org.apache.drill.exec.store.SubSchemaWrapper
 
isNegativeVInt(byte) - Static method in class org.apache.drill.exec.util.ByteBufUtil.HadoopWritables
Given the first byte of a vint/vlong, determine the sign
isNested() - Method in class org.apache.drill.exec.expr.fn.AbstractFuncHolder
 
isNested() - Method in class org.apache.drill.exec.expr.fn.DrillSimpleFuncHolder
 
isNestedLoopJoinEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isNeverValid() - Method in class org.apache.drill.exec.vector.complex.fn.FieldSelection
 
isNewSchema() - Method in interface org.apache.drill.exec.physical.impl.OutputMutator
Whether or not the fields added to the OutputMutator generated a new schema event.
isNewSchema() - Method in class org.apache.drill.exec.physical.impl.ScanBatch.Mutator
Reports whether schema has changed (field was added or re-added) since last call to ScanBatch.Mutator.isNewSchema().
isNiladic() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
isNiladic() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
 
isNiladic() - Method in class org.apache.drill.exec.planner.sql.DrillSqlOperator
 
isNlJoinForScalarOnly() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isNonPrefixedStarColumn(String) - Static method in class org.apache.drill.exec.planner.StarColumnHelper
 
IsNotFalse - Class in org.apache.drill.exec.expr.fn.impl
 
IsNotFalse() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNotFalse
 
IsNotFalse.Optional - Class in org.apache.drill.exec.expr.fn.impl
 
IsNotFalse.Optional() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNotFalse.Optional
 
IsNotFalse.Required - Class in org.apache.drill.exec.expr.fn.impl
 
IsNotFalse.Required() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNotFalse.Required
 
IsNotTrue - Class in org.apache.drill.exec.expr.fn.impl
 
IsNotTrue() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNotTrue
 
IsNotTrue.Optional - Class in org.apache.drill.exec.expr.fn.impl
 
IsNotTrue.Optional() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNotTrue.Optional
 
IsNotTrue.Required - Class in org.apache.drill.exec.expr.fn.impl
 
IsNotTrue.Required() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNotTrue.Required
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.BigIntAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.BitAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.DateAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal18Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal28DenseAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal28SparseAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal38DenseAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal38SparseAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.Decimal9Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.Float4Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.Float8Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.GenericAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.IntAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.IntervalAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.IntervalDayAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.IntervalYearAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableBigIntAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableBitAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDateAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal18Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal28DenseAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal28SparseAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal38DenseAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal38SparseAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableDecimal9Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableFloat4Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableFloat8Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableIntAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableIntervalAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableIntervalDayAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableIntervalYearAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableSmallIntAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableTimeAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableTimeStampAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableTinyIntAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableUInt1Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableUInt2Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableUInt4Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableUInt8Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVar16CharAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVarBinaryAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.NullableVarCharAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.SmallIntAccessor
 
isNull(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
Reports whether the logical value is a SQL NULL.
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.TimeAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.TimeStampAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.TinyIntAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.UInt1Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.UInt2Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.UInt4Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.UInt8Accessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.Var16CharAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.VarBinaryAccessor
 
isNull(int) - Method in class org.apache.drill.exec.vector.accessor.VarCharAccessor
 
isNullable() - Method in class org.apache.drill.exec.store.pcap.dto.ColumnDto
 
IsNumericFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions
 
IsNumericFunctions.BigIntIsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.BigIntIsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.BigIntIsNumeric
 
IsNumericFunctions.IntIsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.IntIsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.IntIsNumeric
 
IsNumericFunctions.NullableBigIntIsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.NullableBigIntIsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableBigIntIsNumeric
 
IsNumericFunctions.NullableIntIsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.NullableIntIsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableIntIsNumeric
 
IsNumericFunctions.NullableSmallIntIsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.NullableSmallIntIsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableSmallIntIsNumeric
 
IsNumericFunctions.NullableTinyIntIsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.NullableTinyIntIsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableTinyIntIsNumeric
 
IsNumericFunctions.NullableUInt1IsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.NullableUInt1IsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableUInt1IsNumeric
 
IsNumericFunctions.NullableUInt2IsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.NullableUInt2IsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableUInt2IsNumeric
 
IsNumericFunctions.NullableUInt4IsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.NullableUInt4IsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableUInt4IsNumeric
 
IsNumericFunctions.NullableUInt8IsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.NullableUInt8IsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableUInt8IsNumeric
 
IsNumericFunctions.NullableVarCharIsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.NullableVarCharIsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableVarCharIsNumeric
 
IsNumericFunctions.SmallIntIsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.SmallIntIsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.SmallIntIsNumeric
 
IsNumericFunctions.TinyIntIsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.TinyIntIsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.TinyIntIsNumeric
 
IsNumericFunctions.UInt1IsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.UInt1IsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.UInt1IsNumeric
 
IsNumericFunctions.UInt2IsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.UInt2IsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.UInt2IsNumeric
 
IsNumericFunctions.UInt4IsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.UInt4IsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.UInt4IsNumeric
 
IsNumericFunctions.UInt8IsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.UInt8IsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.UInt8IsNumeric
 
IsNumericFunctions.VarCharIsNumeric - Class in org.apache.drill.exec.expr.fn.impl
 
IsNumericFunctions.VarCharIsNumeric() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.VarCharIsNumeric
 
isNumericType(TypeProtos.MinorType) - Static method in class org.apache.drill.exec.resolver.TypeCastRules
 
ISOLATION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
isOnline(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.server.DrillbitContext
 
isOptional() - Method in class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
 
isOutgoingBatchFull() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
isOutputProj() - Method in class org.apache.drill.exec.physical.config.Project
 
isOverMemoryLimit() - Method in class org.apache.drill.exec.ops.FragmentContext
 
isParquetRowGroupFilterPushdownPlanningEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isParseUnescapedQuotes() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Indicates whether the CSV parser should accept unescaped quotes inside quoted values and parse them normally.
isPartitionColumn(OptionManager, SchemaPath) - Static method in class org.apache.drill.exec.store.ColumnExplorer
Checks if given column is partition or not.
isPartitionColumn(String, String) - Static method in class org.apache.drill.exec.store.ColumnExplorer
Checks if given column is partition or not.
isPartitionName(String) - Method in class org.apache.drill.exec.planner.FileSystemPartitionDescriptor
 
isPartitionName(String) - Method in class org.apache.drill.exec.planner.ParquetPartitionDescriptor
 
isPartitionName(String) - Method in interface org.apache.drill.exec.planner.PartitionDescriptor
 
isPeer(int, VectorAccessible, int, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
compares two rows from different batches (can be the same), if they have the same value for the order by expression
isPeer(int, VectorAccessible, int, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
compares two rows from different batches (can be the same), if they have the same value for the order by expression
isPeer(int, VectorAccessible, int, VectorAccessible) - Method in interface org.apache.drill.exec.physical.impl.window.WindowFramer
compares two rows from different batches (can be the same), if they have the same value for the order by expression
isPlainJava() - Method in class org.apache.drill.exec.expr.CodeGenerator
 
isPPPoV6Packet() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
isPrefixedStarColumn(String) - Static method in class org.apache.drill.exec.planner.StarColumnHelper
 
isPushDown() - Method in class org.apache.drill.exec.planner.common.DrillLimitRelBase
 
isQuote(byte) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Identifies whether or not a given character is used for escaping values where the field delimiter is part of the value
isQuoteEscape(byte) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Identifies whether or not a given character is used for escaping quotes inside an already quoted value.
isRandom() - Method in class org.apache.drill.exec.expr.DrillFuncHolderExpr
 
isRandom() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
Deprecated.
isRead() - Method in class org.apache.drill.exec.schema.Field
 
isReadable(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
isReadable() - Method in class org.apache.drill.exec.record.DeadBuf
 
isReadable(DrillFileSystem, FileSelection, FileSystemPlugin, String, String) - Method in class org.apache.drill.exec.store.dfs.BasicFormatMatcher
 
isReadable(DrillFileSystem, FileSelection, FileSystemPlugin, String, String) - Method in class org.apache.drill.exec.store.dfs.FormatMatcher
 
isReadableAsDate(DrillBuf, int, int) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionHelpers
Takes a string value, specified as a buffer with a start and end and returns true if the value can be read as a date.
isReader() - Method in class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
 
isRegularColumnOrExp(String) - Static method in class org.apache.drill.exec.planner.StarColumnHelper
 
isRepeated() - Method in class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
 
isRepeated() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetColumnMetadata
 
isReplaceable() - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
Indicates whether or not this value is replaceable.
isReturnTrueOnOne() - Method in class org.apache.drill.exec.physical.impl.filter.ReturnValueExpression
 
isRootSchema(SchemaPlus) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
 
isRowGroupPrunable() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v1
 
isRowGroupPrunable() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
isRowGroupPrunable() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
isRowGroupPrunable() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataBase
 
isSafe() - Method in class org.apache.drill.exec.expr.ValueVectorWriteExpression
 
isSame(int, int) - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
 
isSamePartition(int, VectorAccessible, int, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
compares two rows from different batches (can be the same), if they have the same value for the partition by expression
isSamePartition(int, VectorAccessible, int, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
compares two rows from different batches (can be the same), if they have the same value for the partition by expression
isSamePartition(int, VectorAccessible, int, VectorAccessible) - Method in interface org.apache.drill.exec.physical.impl.window.WindowFramer
compares two rows from different batches (can be the same), if they have the same value for the partition by expression
isSamePrev(int, InternalBatch, int) - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
 
isScalarStringType(SqlTypeName) - Static method in class org.apache.drill.exec.planner.sql.TypeInferenceUtils
Checks if given type is string scalar type.
isScalarSubquery(RelNode) - Static method in class org.apache.drill.exec.physical.impl.join.JoinUtils
Utility method to check if a subquery (represented by its root RelNode) is provably scalar.
isSchemaChanged() - Method in class org.apache.drill.exec.record.VectorContainer
 
isSet(CoordinationProtos.DrillbitEndpoint) - Method in interface org.apache.drill.exec.store.schedule.EndpointByteMap
 
isSet(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.store.schedule.EndpointByteMapImpl
 
isShortLived() - Method in class org.apache.drill.exec.server.options.OptionValidator
This function returns true if and only if this validator is meant for a short-lived option.
isShortLived() - Method in class org.apache.drill.exec.testing.ExecutionControls.ControlsOptionValidator
 
isSingleMode() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isSingleMode(RelOptRuleCall) - Static method in class org.apache.drill.exec.planner.physical.Prule
 
isSingleTyped() - Method in class org.apache.drill.exec.schema.ListSchema
 
isSingularRepeated() - Method in class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
 
isSkipFirstLine() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
isSkipFirstLine() - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
isSkipQuery() - Method in class org.apache.drill.exec.store.AbstractRecordReader
Returns true if reader should skip all of the columns, reporting number of records only.
isSkipQuery() - Method in class org.apache.drill.exec.store.easy.sequencefile.SequenceFileRecordReader
 
isSpillNeeded(long, long) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
isSpooling() - Method in class org.apache.drill.exec.physical.base.AbstractReceiver
 
isSpooling() - Method in interface org.apache.drill.exec.physical.base.Receiver
 
isSslEnabled() - Method in class org.apache.drill.exec.rpc.user.UserClient
 
isSslEnabled() - Method in class org.apache.drill.exec.rpc.user.UserServer
 
isSslValid() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
isSslValid() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
isSslValid() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
isStarColumn(String) - Static method in class org.apache.drill.exec.planner.StarColumnHelper
 
isStarQuery() - Method in class org.apache.drill.exec.planner.physical.PrelUtil.ProjectPushInfo
 
isStarQuery() - Method in class org.apache.drill.exec.store.AbstractRecordReader
 
isStarQuery() - Method in class org.apache.drill.exec.store.ColumnExplorer
 
isStarQuery() - Method in class org.apache.drill.exec.store.easy.text.compliant.CompliantTextRecordReader
 
isStarQuery() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetSchema
 
isStarQuery() - Method in class org.apache.drill.exec.store.text.DrillTextRecordReader
 
isStarQuery(Collection<SchemaPath>) - Static method in class org.apache.drill.exec.util.Utilities
Return true if list of schema path has star column.
isStreamAggEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isStruct() - Method in class org.apache.drill.exec.planner.types.DrillFixedRelDataTypeImpl
 
isStruct() - Method in class org.apache.drill.exec.planner.types.RelDataTypeDrillImpl
 
isSuperReader() - Method in class org.apache.drill.exec.expr.ValueVectorReadExpression
 
isSupportComplexTypes() - Method in class org.apache.drill.exec.rpc.user.UserSession
 
isSwapped() - Method in class org.apache.drill.exec.planner.physical.HashJoinPrel
 
isTcpPacket() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
isTemporary() - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateTable
 
isTemporaryTable(AbstractSchema, DrillConfig, String) - Method in class org.apache.drill.exec.rpc.user.UserSession
Checks if passed table is temporary, table name is case-insensitive.
isTemporaryWorkspace(String, DrillConfig) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
Checks that passed schema path is the same as temporary workspace path.
isTerminated() - Method in class org.apache.drill.exec.work.batch.BaseRawBatchBuffer
 
isThis() - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
Indicates whether or not this value is a "this" reference.
isTrivialProject(Project, boolean) - Static method in class org.apache.drill.exec.planner.common.DrillRelOptUtil
 
IsTrue - Class in org.apache.drill.exec.expr.fn.impl
 
IsTrue() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsTrue
 
IsTrue.Optional - Class in org.apache.drill.exec.expr.fn.impl
 
IsTrue.Optional() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsTrue.Optional
 
IsTrue.Required - Class in org.apache.drill.exec.expr.fn.impl
 
IsTrue.Required() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsTrue.Required
 
isTypeInferenceEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isUdpPacket() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
isUnbounded() - Method in class org.apache.drill.exec.physical.config.WindowPOP.Bound
 
isUnionAllDistributeEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
isUnique(List<T>) - Static method in class org.apache.drill.exec.planner.common.DrillJoinRelBase
 
isUserAuthenticationEnabled() - Method in class org.apache.drill.exec.ops.QueryContext
 
isUserEncryptionEnabled() - Method in class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
 
isUseRepeatedVarChar() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
isUserLoggedIn(SecurityContext) - Static method in class org.apache.drill.exec.server.rest.auth.AuthDynamicFeature
 
isUserSslEnabled() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
isUserSslEnabled() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
isUserSslEnabled() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
isValidForBit(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.testing.Injection
 
isVariableWidth - Variable in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer.ColumnSize
 
isVersionMatch() - Method in class org.apache.drill.exec.server.rest.DrillRoot.DrillbitInfo
 
isVersionSupported(String) - Static method in class org.apache.drill.exec.store.parquet.MetadataVersion.Constants
 
isWaiting() - Method in class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
isWaiting() - Method in interface org.apache.drill.exec.work.fragment.FragmentManager
 
isWithinConstant() - Method in class org.apache.drill.exec.compile.sig.MappingSet
 
isWritable(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
isWritable() - Method in class org.apache.drill.exec.record.DeadBuf
 
isWritable() - Method in class org.apache.drill.exec.store.dfs.WorkspaceConfig
 
isXadd(int) - Static method in class org.apache.drill.exec.compile.AsmUtil
Determine if the given opcode is an ADD of some kind (xADD).
isXconst(int) - Static method in class org.apache.drill.exec.compile.AsmUtil
Determine if the given opcode is a load of a constant (xCONST_y).
iter(RelNode...) - Static method in class org.apache.drill.exec.planner.physical.PrelUtil
 
iter(List<RelNode>) - Static method in class org.apache.drill.exec.planner.physical.PrelUtil
 
iterator() - Method in class org.apache.drill.exec.compile.sig.CodeGeneratorMethod
 
iterator() - Method in class org.apache.drill.exec.compile.sig.SignatureHolder
 
iterator() - Method in class org.apache.drill.exec.expr.DrillFuncHolderExpr
 
iterator() - Method in class org.apache.drill.exec.expr.HoldingContainerExpression
 
iterator() - Method in class org.apache.drill.exec.expr.stat.ParquetPredicates.ParquetCompPredicate
 
iterator() - Method in class org.apache.drill.exec.expr.stat.TypedFieldExpr
 
iterator() - Method in class org.apache.drill.exec.expr.ValueVectorReadExpression
 
iterator() - Method in class org.apache.drill.exec.expr.ValueVectorWriteExpression
 
iterator() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
iterator() - Method in class org.apache.drill.exec.physical.base.AbstractMultiple
 
iterator() - Method in class org.apache.drill.exec.physical.base.AbstractReceiver
 
iterator() - Method in class org.apache.drill.exec.physical.base.AbstractSingle
 
iterator() - Method in class org.apache.drill.exec.physical.base.AbstractSubScan
 
iterator() - Method in class org.apache.drill.exec.physical.config.FlattenPOP
 
iterator() - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
 
iterator() - Method in class org.apache.drill.exec.physical.config.MergeJoinPOP
 
iterator() - Method in class org.apache.drill.exec.physical.config.NestedLoopJoinPOP
 
iterator() - Method in class org.apache.drill.exec.physical.config.Values
 
iterator() - Method in class org.apache.drill.exec.physical.impl.aggregate.InternalBatch
 
iterator() - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
 
iterator() - Method in class org.apache.drill.exec.physical.impl.filter.ReturnValueExpression
 
iterator() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
iterator() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
iterator() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
 
iterator() - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
 
iterator() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
iterator() - Method in class org.apache.drill.exec.physical.impl.window.WindowDataBatch
 
iterator() - Method in class org.apache.drill.exec.physical.impl.xsort.BatchGroup
 
iterator() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
iterator() - Method in class org.apache.drill.exec.planner.AbstractPartitionDescriptor
Iterator that traverses over the super list of partition locations and each time returns a single sublist of partition locations.
iterator() - Method in class org.apache.drill.exec.planner.fragment.Fragment
 
iterator() - Method in class org.apache.drill.exec.planner.fragment.PlanningSet
 
iterator() - Method in class org.apache.drill.exec.planner.logical.StoragePlugins
 
iterator() - Method in class org.apache.drill.exec.planner.physical.AggPrelBase
 
iterator() - Method in class org.apache.drill.exec.planner.physical.ComplexToJsonPrel
 
iterator() - Method in class org.apache.drill.exec.planner.physical.FilterPrel
 
iterator() - Method in class org.apache.drill.exec.planner.physical.FlattenPrel
 
iterator() - Method in class org.apache.drill.exec.planner.physical.JoinPrel
 
iterator() - Method in class org.apache.drill.exec.planner.physical.LimitPrel
 
iterator() - Method in class org.apache.drill.exec.planner.physical.ProducerConsumerPrel
 
iterator() - Method in class org.apache.drill.exec.planner.physical.ProjectPrel
 
iterator() - Method in class org.apache.drill.exec.planner.physical.ScanPrel
 
iterator() - Method in class org.apache.drill.exec.planner.physical.ScreenPrel
 
iterator() - Method in class org.apache.drill.exec.planner.physical.SinglePrel
 
iterator() - Method in class org.apache.drill.exec.planner.physical.SortPrel
 
iterator() - Method in class org.apache.drill.exec.planner.physical.StreamAggPrel
 
iterator() - Method in class org.apache.drill.exec.planner.physical.UnionPrel
 
iterator() - Method in class org.apache.drill.exec.planner.physical.ValuesPrel
 
iterator() - Method in class org.apache.drill.exec.planner.physical.WindowPrel
 
iterator() - Method in class org.apache.drill.exec.planner.physical.WriterPrel
 
iterator() - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
iterator() - Method in class org.apache.drill.exec.record.BatchSchema
 
iterator() - Method in class org.apache.drill.exec.record.RecordBatchLoader
 
iterator() - Method in class org.apache.drill.exec.record.RecordIterator
 
iterator() - Method in class org.apache.drill.exec.record.SimpleRecordBatch
 
iterator() - Method in class org.apache.drill.exec.record.VectorContainer
 
iterator() - Method in class org.apache.drill.exec.rpc.control.ConnectionManagerRegistry
 
iterator() - Method in class org.apache.drill.exec.server.options.DrillConfigIterator
 
iterator() - Method in class org.apache.drill.exec.server.options.FallbackOptionManager
 
iterator() - Method in class org.apache.drill.exec.server.options.SystemOptionManager
 
iterator() - Method in class org.apache.drill.exec.store.dfs.SubDirectoryList
 
iterator() - Method in class org.apache.drill.exec.store.mock.MockSubScanPOP
 
iterator() - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
 
iterator() - Method in class org.apache.drill.exec.store.pojo.AbstractPojoRecordReader
 
iterator() - Method in class org.apache.drill.exec.store.schedule.EndpointByteMapImpl
 
iterator() - Method in class org.apache.drill.exec.store.StoragePluginRegistryImpl
 
IteratorValidator - Class in org.apache.drill.exec.physical.config
 
IteratorValidator(PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.config.IteratorValidator
 
IteratorValidatorBatchIterator - Class in org.apache.drill.exec.physical.impl.validate
 
IteratorValidatorBatchIterator(RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
IteratorValidatorCreator - Class in org.apache.drill.exec.physical.impl.validate
 
IteratorValidatorCreator() - Constructor for class org.apache.drill.exec.physical.impl.validate.IteratorValidatorCreator
 
IteratorValidatorInjector - Class in org.apache.drill.exec.physical.impl.validate
 
IteratorValidatorInjector() - Constructor for class org.apache.drill.exec.physical.impl.validate.IteratorValidatorInjector
 

J

jackson() - Method in class org.apache.drill.exec.cache.DistributedCache.CacheConfigBuilder
 
JacksonHelper - Class in org.apache.drill.exec.schema.json.jackson
 
JacksonHelper() - Constructor for class org.apache.drill.exec.schema.json.jackson.JacksonHelper
 
JacksonSerializer<T> - Class in org.apache.drill.exec.serialization
 
JacksonSerializer(ObjectMapper, Class<T>) - Constructor for class org.apache.drill.exec.serialization.JacksonSerializer
 
JAR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
JarScan - Class in org.apache.drill.exec.expr.fn.registry
Holder class that contains: jar name scan of packages, classes, annotations found in jar unique jar classLoader
JarScan(String, ScanResult, ClassLoader) - Constructor for class org.apache.drill.exec.expr.fn.registry.JarScan
 
JarUtil - Class in org.apache.drill.exec.util
 
JarUtil() - Constructor for class org.apache.drill.exec.util.JarUtil
 
JarValidationException - Exception in org.apache.drill.exec.exception
 
JarValidationException(String) - Constructor for exception org.apache.drill.exec.exception.JarValidationException
 
JAVA - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
JAVA_COMPILER_CONFIG - Static variable in class org.apache.drill.exec.compile.ClassCompilerSelector
 
JAVA_COMPILER_DEBUG - Static variable in class org.apache.drill.exec.compile.ClassCompilerSelector
 
JAVA_COMPILER_DEBUG_CONFIG - Static variable in class org.apache.drill.exec.compile.ClassCompilerSelector
 
JAVA_COMPILER_DEBUG_OPTION - Static variable in class org.apache.drill.exec.compile.ClassCompilerSelector
 
JAVA_COMPILER_JANINO_MAXSIZE - Static variable in class org.apache.drill.exec.compile.ClassCompilerSelector
 
JAVA_COMPILER_JANINO_MAXSIZE_CONFIG - Static variable in class org.apache.drill.exec.compile.ClassCompilerSelector
 
JAVA_COMPILER_JANINO_MAXSIZE_OPTION - Static variable in class org.apache.drill.exec.compile.ClassCompilerSelector
 
JAVA_COMPILER_OPTION - Static variable in class org.apache.drill.exec.compile.ClassCompilerSelector
 
JAVA_COMPILER_VALIDATOR - Static variable in class org.apache.drill.exec.compile.ClassCompilerSelector
 
JDBC_BATCH_QUEUE_THROTTLING_THRESHOLD - Static variable in class org.apache.drill.exec.ExecConstants
Size of JDBC batch queue (in batches) above which throttling begins.
JdbcFunctionCall() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a function call expression with JDBC syntax.
jdkSSlContext - Variable in class org.apache.drill.exec.ssl.SSLConfig
 
jj_nt - Variable in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
jjFillToken() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplTokenManager
 
jjnewLexState - Static variable in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplTokenManager
 
jjstrLiteralImages - Static variable in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplTokenManager
 
join(String...) - Static method in class org.apache.drill.exec.coord.zk.PathUtils
Returns a normalized, combined path out of the given path segments.
JOIN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
JOIN_OPTIMIZATION - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
JOIN_ROW_COUNT_ESTIMATE_FACTOR - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
joincategory - Variable in class org.apache.drill.exec.planner.physical.JoinPrel
 
JoinPrel - Class in org.apache.drill.exec.planner.physical
Base class for MergeJoinPrel and HashJoinPrel
JoinPrel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType) - Constructor for class org.apache.drill.exec.planner.physical.JoinPrel
 
JoinPrelRenameVisitor - Class in org.apache.drill.exec.planner.physical.visitor
 
JoinPrelRenameVisitor() - Constructor for class org.apache.drill.exec.planner.physical.visitor.JoinPrelRenameVisitor
 
JoinPruleBase - Class in org.apache.drill.exec.planner.physical
 
JoinPruleBase(RelOptRuleOperand, String) - Constructor for class org.apache.drill.exec.planner.physical.JoinPruleBase
 
JoinPruleBase.PhysicalJoinType - Enum in org.apache.drill.exec.planner.physical
 
JoinStatus - Class in org.apache.drill.exec.physical.impl.join
Maintain join state.
JoinStatus(RecordIterator, RecordIterator, MergeJoinBatch) - Constructor for class org.apache.drill.exec.physical.impl.join.JoinStatus
 
JoinTable(SqlNode) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Matches "LEFT JOIN t ON ...", "RIGHT JOIN t USING ...", "JOIN t".
JoinTemplate - Class in org.apache.drill.exec.physical.impl.join
Merge Join implementation using RecordIterator.
JoinTemplate() - Constructor for class org.apache.drill.exec.physical.impl.join.JoinTemplate
 
JoinType() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
JoinUtils - Class in org.apache.drill.exec.physical.impl.join
 
JoinUtils() - Constructor for class org.apache.drill.exec.physical.impl.join.JoinUtils
 
JoinUtils.JoinCategory - Enum in org.apache.drill.exec.physical.impl.join
 
JoinWorker - Interface in org.apache.drill.exec.physical.impl.join
 
JoinWorker.JoinOutcome - Enum in org.apache.drill.exec.physical.impl.join
 
json - Variable in class org.apache.drill.exec.planner.sql.handlers.ExplainHandler.LogicalExplain
 
json - Variable in class org.apache.drill.exec.planner.sql.handlers.ExplainHandler.PhysicalExplain
 
json - Variable in class org.apache.drill.exec.work.foreman.Foreman.PhysicalFromLogicalExplain
 
JSON_ACCESSIBLE_SCOPES - Static variable in class org.apache.drill.exec.server.options.OptionValue
 
JSON_ALL_TEXT_MODE - Static variable in class org.apache.drill.exec.ExecConstants
 
JSON_BOOL_VAL - Static variable in class org.apache.drill.exec.server.options.OptionValue
 
JSON_BOOL_VAL - Static variable in class org.apache.drill.exec.server.options.PersistedOptionValue
This constant cannot be changed for backward and forward compatibility reasons.
JSON_EXTENDED_TYPES - Static variable in class org.apache.drill.exec.ExecConstants
 
JSON_FLOAT_VAL - Static variable in class org.apache.drill.exec.server.options.OptionValue
 
JSON_FLOAT_VAL - Static variable in class org.apache.drill.exec.server.options.PersistedOptionValue
This constant cannot be changed for backward and forward compatibility reasons.
JSON_KIND - Static variable in class org.apache.drill.exec.server.options.OptionValue
 
JSON_KIND - Static variable in class org.apache.drill.exec.server.options.PersistedOptionValue
This constant cannot be changed for backward and forward compatibility reasons.
JSON_NAME - Static variable in class org.apache.drill.exec.server.options.OptionValue
 
JSON_NAME - Static variable in class org.apache.drill.exec.server.options.PersistedOptionValue
This constant cannot be changed for backward and forward compatibility reasons.
JSON_NUM_VAL - Static variable in class org.apache.drill.exec.server.options.OptionValue
 
JSON_NUM_VAL - Static variable in class org.apache.drill.exec.server.options.PersistedOptionValue
This constant cannot be changed for backward and forward compatibility reasons.
JSON_READ_NUMBERS_AS_DOUBLE - Static variable in class org.apache.drill.exec.ExecConstants
 
JSON_READ_NUMBERS_AS_DOUBLE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
JSON_READER_ALL_TEXT_MODE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
JSON_READER_PRINT_INVALID_RECORDS_LINE_NOS_FLAG - Static variable in class org.apache.drill.exec.ExecConstants
 
JSON_READER_PRINT_INVALID_RECORDS_LINE_NOS_FLAG_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
JSON_READER_SKIP_INVALID_RECORDS_FLAG - Static variable in class org.apache.drill.exec.ExecConstants
 
JSON_SCOPE - Static variable in class org.apache.drill.exec.server.options.OptionValue
 
JSON_SKIP_MALFORMED_RECORDS_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
JSON_STRING_VAL - Static variable in class org.apache.drill.exec.server.options.OptionValue
 
JSON_STRING_VAL - Static variable in class org.apache.drill.exec.server.options.PersistedOptionValue
This constant cannot be changed for backward and forward compatibility reasons.
JSON_TYPE - Static variable in class org.apache.drill.exec.server.options.PersistedOptionValue
This constant cannot be changed for backward and forward compatibility reasons.
JSON_WRITER_SKIPNULLFIELDS - Static variable in class org.apache.drill.exec.ExecConstants
 
JSON_WRITER_UGLIFY - Static variable in class org.apache.drill.exec.ExecConstants
 
JsonConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
JsonConvertFrom.ConvertFromJson - Class in org.apache.drill.exec.expr.fn.impl.conv
 
JsonConvertFrom.ConvertFromJson() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertFrom.ConvertFromJson
 
JsonConvertFrom.ConvertFromJsonVarchar - Class in org.apache.drill.exec.expr.fn.impl.conv
 
JsonConvertFrom.ConvertFromJsonVarchar() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertFrom.ConvertFromJsonVarchar
 
JsonConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
The two functions defined here convert_toJSON and convert_toEXTENDEDJSON are almost identical.
JsonConvertTo.ConvertToExtendedJson - Class in org.apache.drill.exec.expr.fn.impl.conv
 
JsonConvertTo.ConvertToExtendedJson() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertTo.ConvertToExtendedJson
 
JsonConvertTo.ConvertToJson - Class in org.apache.drill.exec.expr.fn.impl.conv
 
JsonConvertTo.ConvertToJson() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertTo.ConvertToJson
 
JSONFormatPlugin - Class in org.apache.drill.exec.store.easy.json
 
JSONFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig) - Constructor for class org.apache.drill.exec.store.easy.json.JSONFormatPlugin
 
JSONFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig, JSONFormatPlugin.JSONFormatConfig) - Constructor for class org.apache.drill.exec.store.easy.json.JSONFormatPlugin
 
JSONFormatPlugin.JSONFormatConfig - Class in org.apache.drill.exec.store.easy.json
 
JSONFormatPlugin.JSONFormatConfig() - Constructor for class org.apache.drill.exec.store.easy.json.JSONFormatPlugin.JSONFormatConfig
 
JsonOutput - Interface in org.apache.drill.exec.vector.complex.fn
Interface through which UDFs, RecordWriters and other systems can write out a JSON output.
JSONOutputRecordWriter - Class in org.apache.drill.exec.store
Abstract implementation of RecordWriter interface which exposes interface: #writeHeader(List) #addField(int,String) to output the data in string format instead of implementing addField for each type holder.
JSONOutputRecordWriter() - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter
 
JSONOutputRecordWriter.BigIntJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.BigIntJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.BigIntJsonConverter
 
JSONOutputRecordWriter.BitJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.BitJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.BitJsonConverter
 
JSONOutputRecordWriter.DateJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.DateJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.DateJsonConverter
 
JSONOutputRecordWriter.Decimal18JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.Decimal18JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal18JsonConverter
 
JSONOutputRecordWriter.Decimal28DenseJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.Decimal28DenseJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal28DenseJsonConverter
 
JSONOutputRecordWriter.Decimal28SparseJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.Decimal28SparseJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal28SparseJsonConverter
 
JSONOutputRecordWriter.Decimal38DenseJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.Decimal38DenseJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal38DenseJsonConverter
 
JSONOutputRecordWriter.Decimal38SparseJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.Decimal38SparseJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal38SparseJsonConverter
 
JSONOutputRecordWriter.Decimal9JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.Decimal9JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal9JsonConverter
 
JSONOutputRecordWriter.Float4JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.Float4JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.Float4JsonConverter
 
JSONOutputRecordWriter.Float8JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.Float8JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.Float8JsonConverter
 
JSONOutputRecordWriter.IntervalDayJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.IntervalDayJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.IntervalDayJsonConverter
 
JSONOutputRecordWriter.IntervalJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.IntervalJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.IntervalJsonConverter
 
JSONOutputRecordWriter.IntervalYearJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.IntervalYearJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.IntervalYearJsonConverter
 
JSONOutputRecordWriter.IntJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.IntJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.IntJsonConverter
 
JSONOutputRecordWriter.NullableBigIntJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableBigIntJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableBigIntJsonConverter
 
JSONOutputRecordWriter.NullableBitJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableBitJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableBitJsonConverter
 
JSONOutputRecordWriter.NullableDateJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableDateJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDateJsonConverter
 
JSONOutputRecordWriter.NullableDecimal18JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableDecimal18JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal18JsonConverter
 
JSONOutputRecordWriter.NullableDecimal28DenseJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableDecimal28DenseJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal28DenseJsonConverter
 
JSONOutputRecordWriter.NullableDecimal28SparseJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableDecimal28SparseJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal28SparseJsonConverter
 
JSONOutputRecordWriter.NullableDecimal38DenseJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableDecimal38DenseJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal38DenseJsonConverter
 
JSONOutputRecordWriter.NullableDecimal38SparseJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableDecimal38SparseJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal38SparseJsonConverter
 
JSONOutputRecordWriter.NullableDecimal9JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableDecimal9JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal9JsonConverter
 
JSONOutputRecordWriter.NullableFloat4JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableFloat4JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableFloat4JsonConverter
 
JSONOutputRecordWriter.NullableFloat8JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableFloat8JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableFloat8JsonConverter
 
JSONOutputRecordWriter.NullableIntervalDayJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableIntervalDayJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableIntervalDayJsonConverter
 
JSONOutputRecordWriter.NullableIntervalJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableIntervalJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableIntervalJsonConverter
 
JSONOutputRecordWriter.NullableIntervalYearJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableIntervalYearJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableIntervalYearJsonConverter
 
JSONOutputRecordWriter.NullableIntJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableIntJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableIntJsonConverter
 
JSONOutputRecordWriter.NullableSmallIntJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableSmallIntJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableSmallIntJsonConverter
 
JSONOutputRecordWriter.NullableTimeJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableTimeJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableTimeJsonConverter
 
JSONOutputRecordWriter.NullableTimeStampJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableTimeStampJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableTimeStampJsonConverter
 
JSONOutputRecordWriter.NullableTinyIntJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableTinyIntJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableTinyIntJsonConverter
 
JSONOutputRecordWriter.NullableUInt1JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableUInt1JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableUInt1JsonConverter
 
JSONOutputRecordWriter.NullableUInt2JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableUInt2JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableUInt2JsonConverter
 
JSONOutputRecordWriter.NullableUInt4JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableUInt4JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableUInt4JsonConverter
 
JSONOutputRecordWriter.NullableUInt8JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableUInt8JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableUInt8JsonConverter
 
JSONOutputRecordWriter.NullableVar16CharJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableVar16CharJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableVar16CharJsonConverter
 
JSONOutputRecordWriter.NullableVarBinaryJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableVarBinaryJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableVarBinaryJsonConverter
 
JSONOutputRecordWriter.NullableVarCharJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.NullableVarCharJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableVarCharJsonConverter
 
JSONOutputRecordWriter.RepeatedBigIntJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedBigIntJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedBigIntJsonConverter
 
JSONOutputRecordWriter.RepeatedBitJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedBitJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedBitJsonConverter
 
JSONOutputRecordWriter.RepeatedDateJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedDateJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDateJsonConverter
 
JSONOutputRecordWriter.RepeatedDecimal18JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedDecimal18JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal18JsonConverter
 
JSONOutputRecordWriter.RepeatedDecimal28DenseJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedDecimal28DenseJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal28DenseJsonConverter
 
JSONOutputRecordWriter.RepeatedDecimal28SparseJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedDecimal28SparseJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal28SparseJsonConverter
 
JSONOutputRecordWriter.RepeatedDecimal38DenseJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedDecimal38DenseJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal38DenseJsonConverter
 
JSONOutputRecordWriter.RepeatedDecimal38SparseJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedDecimal38SparseJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal38SparseJsonConverter
 
JSONOutputRecordWriter.RepeatedDecimal9JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedDecimal9JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal9JsonConverter
 
JSONOutputRecordWriter.RepeatedFloat4JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedFloat4JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedFloat4JsonConverter
 
JSONOutputRecordWriter.RepeatedFloat8JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedFloat8JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedFloat8JsonConverter
 
JSONOutputRecordWriter.RepeatedIntervalDayJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedIntervalDayJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedIntervalDayJsonConverter
 
JSONOutputRecordWriter.RepeatedIntervalJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedIntervalJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedIntervalJsonConverter
 
JSONOutputRecordWriter.RepeatedIntervalYearJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedIntervalYearJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedIntervalYearJsonConverter
 
JSONOutputRecordWriter.RepeatedIntJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedIntJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedIntJsonConverter
 
JSONOutputRecordWriter.RepeatedSmallIntJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedSmallIntJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedSmallIntJsonConverter
 
JSONOutputRecordWriter.RepeatedTimeJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedTimeJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedTimeJsonConverter
 
JSONOutputRecordWriter.RepeatedTimeStampJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedTimeStampJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedTimeStampJsonConverter
 
JSONOutputRecordWriter.RepeatedTinyIntJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedTinyIntJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedTinyIntJsonConverter
 
JSONOutputRecordWriter.RepeatedUInt1JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedUInt1JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedUInt1JsonConverter
 
JSONOutputRecordWriter.RepeatedUInt2JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedUInt2JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedUInt2JsonConverter
 
JSONOutputRecordWriter.RepeatedUInt4JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedUInt4JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedUInt4JsonConverter
 
JSONOutputRecordWriter.RepeatedUInt8JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedUInt8JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedUInt8JsonConverter
 
JSONOutputRecordWriter.RepeatedVar16CharJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedVar16CharJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedVar16CharJsonConverter
 
JSONOutputRecordWriter.RepeatedVarBinaryJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedVarBinaryJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedVarBinaryJsonConverter
 
JSONOutputRecordWriter.RepeatedVarCharJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.RepeatedVarCharJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedVarCharJsonConverter
 
JSONOutputRecordWriter.SmallIntJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.SmallIntJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.SmallIntJsonConverter
 
JSONOutputRecordWriter.TimeJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.TimeJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.TimeJsonConverter
 
JSONOutputRecordWriter.TimeStampJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.TimeStampJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.TimeStampJsonConverter
 
JSONOutputRecordWriter.TinyIntJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.TinyIntJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.TinyIntJsonConverter
 
JSONOutputRecordWriter.UInt1JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.UInt1JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.UInt1JsonConverter
 
JSONOutputRecordWriter.UInt2JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.UInt2JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.UInt2JsonConverter
 
JSONOutputRecordWriter.UInt4JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.UInt4JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.UInt4JsonConverter
 
JSONOutputRecordWriter.UInt8JsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.UInt8JsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.UInt8JsonConverter
 
JSONOutputRecordWriter.Var16CharJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.Var16CharJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.Var16CharJsonConverter
 
JSONOutputRecordWriter.VarBinaryJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.VarBinaryJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.VarBinaryJsonConverter
 
JSONOutputRecordWriter.VarCharJsonConverter - Class in org.apache.drill.exec.store
 
JSONOutputRecordWriter.VarCharJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.JSONOutputRecordWriter.VarCharJsonConverter
 
JsonProcessor - Interface in org.apache.drill.exec.store.easy.json
 
JsonProcessor.ReadState - Enum in org.apache.drill.exec.store.easy.json
 
JsonReader - Class in org.apache.drill.exec.vector.complex.fn
 
JsonReader(DrillBuf, boolean, boolean, boolean) - Constructor for class org.apache.drill.exec.vector.complex.fn.JsonReader
 
JsonReader(DrillBuf, List<SchemaPath>, boolean, boolean, boolean) - Constructor for class org.apache.drill.exec.vector.complex.fn.JsonReader
 
JsonReaderUtils - Class in org.apache.drill.exec.vector.complex.fn
 
JsonReaderUtils() - Constructor for class org.apache.drill.exec.vector.complex.fn.JsonReaderUtils
 
JSONRecordReader - Class in org.apache.drill.exec.store.easy.json
 
JSONRecordReader(FragmentContext, String, DrillFileSystem, List<SchemaPath>) - Constructor for class org.apache.drill.exec.store.easy.json.JSONRecordReader
Create a JSON Record Reader that uses a file based input stream.
JSONRecordReader(FragmentContext, JsonNode, DrillFileSystem, List<SchemaPath>) - Constructor for class org.apache.drill.exec.store.easy.json.JSONRecordReader
Create a new JSON Record Reader that uses a in memory materialized JSON stream.
JsonRecordWriter - Class in org.apache.drill.exec.store.easy.json
 
JsonRecordWriter(StorageStrategy) - Constructor for class org.apache.drill.exec.store.easy.json.JsonRecordWriter
 
JsonRecordWriter.MapJsonConverter - Class in org.apache.drill.exec.store.easy.json
 
JsonRecordWriter.MapJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.easy.json.JsonRecordWriter.MapJsonConverter
 
JsonRecordWriter.RepeatedListJsonConverter - Class in org.apache.drill.exec.store.easy.json
 
JsonRecordWriter.RepeatedListJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.easy.json.JsonRecordWriter.RepeatedListJsonConverter
 
JsonRecordWriter.RepeatedMapJsonConverter - Class in org.apache.drill.exec.store.easy.json
 
JsonRecordWriter.RepeatedMapJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.easy.json.JsonRecordWriter.RepeatedMapJsonConverter
 
JsonRecordWriter.UnionJsonConverter - Class in org.apache.drill.exec.store.easy.json
 
JsonRecordWriter.UnionJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.easy.json.JsonRecordWriter.UnionJsonConverter
 
JsonWriter - Class in org.apache.drill.exec.vector.complex.fn
 
JsonWriter(OutputStream, boolean, boolean) - Constructor for class org.apache.drill.exec.vector.complex.fn.JsonWriter
 
JsonWriter(JsonOutput) - Constructor for class org.apache.drill.exec.vector.complex.fn.JsonWriter
 
JULIAN_DAY_NUMBER_FOR_UNIX_EPOCH - Static variable in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
Number of days between Julian day epoch (January 1, 4713 BC) and Unix day epoch (January 1, 1970).
jvm_direct_current - Variable in class org.apache.drill.exec.store.sys.MemoryIterator.MemoryInfo
 

K

K - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
KAFKA_ALL_TEXT_MODE - Static variable in class org.apache.drill.exec.ExecConstants
 
KAFKA_POLL_TIMEOUT - Static variable in class org.apache.drill.exec.ExecConstants
 
KAFKA_POLL_TIMEOUT_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
KAFKA_READER_ALL_TEXT_MODE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
KAFKA_READER_READ_NUMBERS_AS_DOUBLE - Static variable in class org.apache.drill.exec.ExecConstants
 
KAFKA_READER_READ_NUMBERS_AS_DOUBLE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
KAFKA_RECORD_READER - Static variable in class org.apache.drill.exec.ExecConstants
 
KAFKA_RECORD_READER_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
KERBEROS_NAME_MAPPING - Static variable in class org.apache.drill.exec.server.BootStrapContext
 
KerberosFactory - Class in org.apache.drill.exec.rpc.security.kerberos
 
KerberosFactory() - Constructor for class org.apache.drill.exec.rpc.security.kerberos.KerberosFactory
 
KEY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
KEY_MEMBER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
KEY_TYPE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
keys() - Method in class org.apache.drill.exec.coord.store.BaseTransientStore
 
keys() - Method in interface org.apache.drill.exec.coord.store.TransientStore
Returns an iterator of keys.
keys - Variable in class org.apache.drill.exec.planner.physical.AggPrelBase
 
keySet() - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
kill(boolean) - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
 
kill(boolean) - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
kill(boolean) - Method in class org.apache.drill.exec.physical.impl.ScanBatch
 
kill(boolean) - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
 
kill(boolean) - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
kill(boolean) - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
kill(FragmentContext) - Method in interface org.apache.drill.exec.record.RawFragmentBatchProvider
 
kill(boolean) - Method in interface org.apache.drill.exec.record.RecordBatch
Informs child nodes that this query should be terminated.
kill(boolean) - Method in class org.apache.drill.exec.record.SimpleRecordBatch
 
kill(FragmentContext) - Method in class org.apache.drill.exec.work.batch.BaseRawBatchBuffer
 
kill(FragmentContext) - Method in class org.apache.drill.exec.work.batch.SpoolingRawBatchBuffer
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenRecordBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.join.MergeJoinBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.producer.ProducerConsumerBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.project.ProjectRecordBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.sort.SortBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.union.UnionAllRecordBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.window.WindowFrameRecordBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.WriterRecordBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
killIncoming(boolean) - Method in class org.apache.drill.exec.record.AbstractSingleRecordBatch
 
kind - Variable in class org.apache.drill.exec.planner.sql.parser.impl.Token
An integer that describes the kind of this token.
kind - Variable in class org.apache.drill.exec.server.options.OptionValue
 
kind - Variable in class org.apache.drill.exec.store.sys.ExtendedOptionIterator.ExtendedOptionValueWrapper
 
kind - Variable in class org.apache.drill.exec.store.sys.OptionIterator.OptionValueWrapper
 

L

LABEL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LANGUAGE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LARGE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LARGE_QUEUE_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
largeQueueMemory() - Method in class org.apache.drill.exec.server.rest.DrillRoot.QueueInfo
 
largeQueueSize() - Method in class org.apache.drill.exec.server.rest.DrillRoot.QueueInfo
 
largeQueueSize - Variable in class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue.ZKQueueInfo
 
LAST - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LAST_VALUE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
lastSeenJsonToken - Variable in class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
 
latch - Variable in class org.apache.drill.exec.rpc.AbstractDisposableUserClientConnection
 
LATCH - Static variable in class org.apache.drill.exec.testing.NoOpControlsInjector
When assertions are not enabled, this count down latch that does nothing is injected.
LATERAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LBRACE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LBRACE_D - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LBRACE_FN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LBRACE_T - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LBRACE_TS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LBRACKET - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LE - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
 
LE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LEADING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Leaf - Interface in org.apache.drill.exec.physical.base
An operator which specifically is a lowest level leaf node of a query plan across all possible fragments.
LeafQuery(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a leaf in a query expression (SELECT, VALUES or TABLE).
LeafQueryOrExpr(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses either a row expression, a leaf query expression, or a parenthesized expression of any kind.
left - Variable in class org.apache.drill.exec.expr.stat.ParquetPredicates.ParquetCompPredicate
 
left - Variable in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
LEFT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
left - Variable in class org.apache.drill.exec.record.AbstractBinaryRecordBatch
 
LEFT_INPUT - Static variable in class org.apache.drill.exec.physical.impl.join.HashJoinHelper
 
LEFT_INPUT - Static variable in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch
 
LEFT_MAPPING - Variable in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
LEFT_MAPPING - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.BaseSortWrapper
 
leftKeys - Variable in class org.apache.drill.exec.planner.common.DrillJoinRelBase
 
leftMapping - Variable in class org.apache.drill.exec.physical.impl.sort.SortBatch
 
leftMapping - Variable in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
leftUpstream - Variable in class org.apache.drill.exec.record.AbstractBinaryRecordBatch
 
length() - Method in class org.apache.drill.exec.expr.fn.impl.CharSequenceWrapper
 
length - Variable in class org.apache.drill.exec.planner.sql.handlers.ShowFilesCommandResult
 
LENGTH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
length - Variable in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v1
 
length - Variable in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v2
 
length - Variable in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v3
 
length - Variable in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v1
 
length - Variable in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v2
 
length - Variable in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v3
 
length - Variable in class org.apache.drill.exec.store.schedule.CompleteFileWork.FileWorkImpl
 
LETTER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LEVEL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LexicalError(boolean, int, int, int, String, char) - Static method in error org.apache.drill.exec.planner.sql.parser.impl.TokenMgrError
Returns a detailed message for the Error when it is thrown by the token manager to indicate a lexical error.
lexStateNames - Static variable in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplTokenManager
 
LIBRARY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LIKE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Limit - Class in org.apache.drill.exec.physical.config
 
Limit(PhysicalOperator, Integer, Integer) - Constructor for class org.apache.drill.exec.physical.config.Limit
 
limit - Variable in class org.apache.drill.exec.planner.physical.TopNPrel
 
LIMIT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LIMIT_ON_PROJECT - Static variable in class org.apache.drill.exec.planner.logical.DrillPushLimitToScanRule
 
LIMIT_ON_SCAN - Static variable in class org.apache.drill.exec.planner.logical.DrillPushLimitToScanRule
 
LimitBatchCreator - Class in org.apache.drill.exec.physical.impl.limit
 
LimitBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.limit.LimitBatchCreator
 
LimitPrel - Class in org.apache.drill.exec.planner.physical
 
LimitPrel(RelOptCluster, RelTraitSet, RelNode, RexNode, RexNode) - Constructor for class org.apache.drill.exec.planner.physical.LimitPrel
 
LimitPrel(RelOptCluster, RelTraitSet, RelNode, RexNode, RexNode, boolean) - Constructor for class org.apache.drill.exec.planner.physical.LimitPrel
 
LimitPrule - Class in org.apache.drill.exec.planner.physical
 
LimitPrule() - Constructor for class org.apache.drill.exec.planner.physical.LimitPrule
 
LimitRecordBatch - Class in org.apache.drill.exec.physical.impl.limit
 
LimitRecordBatch(Limit, FragmentContext, RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.limit.LimitRecordBatch
 
LimitUnionExchangeTransposeRule - Class in org.apache.drill.exec.planner.physical
 
line - Variable in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
lineDelimiter - Variable in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
listAll(FileSystem, Path, boolean, PathFilter...) - Static method in class org.apache.drill.exec.util.DrillFileSystemUtil
Returns statuses of all directories and files present in given path applying custom filters if present.
listAll(FileSystem, Path, boolean, PathFilter...) - Static method in class org.apache.drill.exec.util.FileSystemUtil
Returns statuses of all directories and files present in given path applying custom filters if present.
listContains(List<String>, String) - Static method in class org.apache.drill.exec.rpc.security.AuthStringUtil
 
listCorruptFileBlocks(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
listDirectories(FileSystem, Path, boolean, PathFilter...) - Static method in class org.apache.drill.exec.util.DrillFileSystemUtil
Returns statuses of all directories present in given path applying custom filters if present.
listDirectories(FileSystem, Path, boolean, PathFilter...) - Static method in class org.apache.drill.exec.util.FileSystemUtil
Returns statuses of all directories present in given path applying custom filters if present.
listeners - Variable in class org.apache.drill.exec.coord.ClusterCoordinator
 
listField(String, Object[]) - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor.VisualizationState
 
listFiles(Path, boolean) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
listFiles(FileSystem, Path, boolean, PathFilter...) - Static method in class org.apache.drill.exec.util.DrillFileSystemUtil
Returns statuses of all files present in given path applying custom filters if present.
listFiles(FileSystem, Path, boolean, PathFilter...) - Static method in class org.apache.drill.exec.util.FileSystemUtil
Returns statuses of all files present in given path applying custom filters if present.
listLocatedStatus(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
ListSchema - Class in org.apache.drill.exec.schema
 
ListSchema() - Constructor for class org.apache.drill.exec.schema.ListSchema
 
listStatus(Path) - Method in class org.apache.drill.exec.store.ClassPathFileSystem
 
listStatus(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
listStatus(Path, PathFilter) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
listStatus(Path[]) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
listStatus(Path[], PathFilter) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
listStatus(Path) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem
 
listStatusIterator(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
listVector() - Method in class org.apache.drill.exec.record.TypedFieldId.Builder
 
listXAttrs(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
Literal() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a literal expression, allowing continued string literals.
LN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
load(UserBitShared.RecordBatchDef, DrillBuf) - Method in class org.apache.drill.exec.record.RecordBatchLoader
Load a record batch from a single buffer.
loadPage(DrillBuf, int) - Method in class org.apache.drill.exec.store.parquet.ColumnDataReader
 
loadSchemaFactory(String, boolean) - Method in class org.apache.drill.exec.planner.sql.DynamicRootSchema
load schema factory(storage plugin) for schemaName
LOCAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LOCAL_FS_SCHEME - Static variable in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory
 
LocalClusterCoordinator - Class in org.apache.drill.exec.coord.local
 
LocalClusterCoordinator() - Constructor for class org.apache.drill.exec.coord.local.LocalClusterCoordinator
 
LocalClusterCoordinator.LocalSemaphore - Class in org.apache.drill.exec.coord.local
 
LocalClusterCoordinator.LocalSemaphore(int) - Constructor for class org.apache.drill.exec.coord.local.LocalClusterCoordinator.LocalSemaphore
 
localDrillbit - Variable in class org.apache.drill.exec.work.fragment.FragmentStatusReporter
 
LocalFunctionRegistry - Class in org.apache.drill.exec.expr.fn.registry
Registry of Drill functions.
LocalFunctionRegistry(ScanResult) - Constructor for class org.apache.drill.exec.expr.fn.registry.LocalFunctionRegistry
Registers all functions present in Drill classpath on start-up.
LocalPersistentStore<V> - Class in org.apache.drill.exec.store.sys.store
 
LocalPersistentStore(DrillFileSystem, Path, PersistentStoreConfig<V>) - Constructor for class org.apache.drill.exec.store.sys.store.LocalPersistentStore
 
LocalPersistentStoreProvider - Class in org.apache.drill.exec.store.sys.store.provider
A really simple provider that stores data in the local file system, one value per file.
LocalPersistentStoreProvider(PersistentStoreRegistry<?>) - Constructor for class org.apache.drill.exec.store.sys.store.provider.LocalPersistentStoreProvider
 
LocalPersistentStoreProvider(DrillConfig) - Constructor for class org.apache.drill.exec.store.sys.store.provider.LocalPersistentStoreProvider
 
LocalPStoreProvider - Class in org.apache.drill.exec.store.sys.local
Deprecated.
will be removed in 1.7 use LocalPersistentStoreProvider instead.
LocalPStoreProvider(PersistentStoreRegistry) - Constructor for class org.apache.drill.exec.store.sys.local.LocalPStoreProvider
Deprecated.
 
LocalSyncableFileSystem - Class in org.apache.drill.exec.store
This class provides a Syncable local extension of the hadoop FileSystem
LocalSyncableFileSystem() - Constructor for class org.apache.drill.exec.store.LocalSyncableFileSystem
 
LocalSyncableFileSystem.LocalInputStream - Class in org.apache.drill.exec.store
 
LocalSyncableFileSystem.LocalInputStream(Path) - Constructor for class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalInputStream
 
LocalSyncableFileSystem.LocalSyncableOutputStream - Class in org.apache.drill.exec.store
 
LocalSyncableFileSystem.LocalSyncableOutputStream(Path) - Constructor for class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalSyncableOutputStream
 
LOCALTIME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LOCALTIMESTAMP - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
locationSuperList - Variable in class org.apache.drill.exec.planner.AbstractPartitionDescriptor
A sequence of sublists of partition locations combined into a single super list.
LOCATOR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
log(PlannerType, PlannerPhase, RelNode, Logger, Stopwatch) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
 
log(String, RelNode, Logger, Stopwatch) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
 
log(String, PhysicalPlan, Logger) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
 
logAndSetTextPlan(String, Prel, Logger) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
 
logClass(Logger, String, ClassNode) - Static method in class org.apache.drill.exec.compile.AsmUtil
Write a class to the log.
logClassFromBytes(Logger, String, byte[]) - Static method in class org.apache.drill.exec.compile.AsmUtil
Write a class to the log.
LOGFIELDS - Static variable in class org.apache.drill.exec.store.httpd.HttpdParser
 
logFormat - Variable in class org.apache.drill.exec.store.httpd.HttpdLogFormatPlugin.HttpdLogFormatConfig
 
LoggedQuery - Class in org.apache.drill.exec.work.foreman
 
LoggedQuery(String, String, String, Date, Date, UserBitShared.QueryResult.QueryState, String, SocketAddress) - Constructor for class org.apache.drill.exec.work.foreman.LoggedQuery
 
logger - Static variable in interface org.apache.drill.exec.cache.Counter
 
logger - Static variable in interface org.apache.drill.exec.cache.DistributedCache
 
logger - Static variable in interface org.apache.drill.exec.cache.DistributedMap
 
logger - Static variable in interface org.apache.drill.exec.cache.DistributedMultiMap
 
logger - Static variable in interface org.apache.drill.exec.cache.DrillSerializable
 
logger - Static variable in interface org.apache.drill.exec.disk.Spool
 
logger - Static variable in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
logger - Static variable in interface org.apache.drill.exec.physical.impl.aggregate.BatchIterator
 
logger - Static variable in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
 
logger - Static variable in interface org.apache.drill.exec.physical.impl.BatchCreator
 
logger - Static variable in interface org.apache.drill.exec.physical.impl.filter.Filterer
 
logger - Static variable in interface org.apache.drill.exec.physical.impl.RootCreator
 
logger - Static variable in interface org.apache.drill.exec.physical.WriteEntry
 
logger - Static variable in interface org.apache.drill.exec.planner.physical.Prel
 
logger - Static variable in interface org.apache.drill.exec.planner.physical.visitor.PrelVisitor
 
logger - Static variable in interface org.apache.drill.exec.store.dfs.easy.FileWork
 
logger - Static variable in interface org.apache.drill.exec.store.schedule.CompleteWork
 
logger - Static variable in interface org.apache.drill.exec.store.SchemaFactory
 
logger - Static variable in interface org.apache.drill.exec.work.batch.RawBatchBuffer
 
login(String, Object) - Method in class org.apache.drill.exec.server.rest.auth.DrillRestLoginService
 
LOGIN_RESOURCE - Static variable in class org.apache.drill.exec.server.rest.LogInLogOutResources
 
LogInLogOutResources - Class in org.apache.drill.exec.server.rest
 
LogInLogOutResources() - Constructor for class org.apache.drill.exec.server.rest.LogInLogOutResources
 
logout(UserIdentity) - Method in class org.apache.drill.exec.server.rest.auth.DrillRestLoginService
This gets called whenever a session is invalidated (because of user logout) or timed out.
logout(HttpServletRequest, HttpServletResponse) - Method in class org.apache.drill.exec.server.rest.LogInLogOutResources
 
LogsResources - Class in org.apache.drill.exec.server.rest
 
LogsResources() - Constructor for class org.apache.drill.exec.server.rest.LogsResources
 
LogsResources.Log - Class in org.apache.drill.exec.server.rest
 
LogsResources.Log(String, long, long) - Constructor for class org.apache.drill.exec.server.rest.LogsResources.Log
 
LogsResources.LogContent - Class in org.apache.drill.exec.server.rest
 
LogsResources.LogContent(String, Collection<String>, int) - Constructor for class org.apache.drill.exec.server.rest.LogsResources.LogContent
 
logStats(Logger, Path) - Method in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
LogWriter - Class in org.apache.drill.exec.compile
A simple Writer that will forward whole lines (lines ending with a newline) to a Logger.
LogWriter(Logger, Level) - Constructor for class org.apache.drill.exec.compile.LogWriter
Constructor.
lookingAhead - Variable in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
lookupCountDownLatchInjection(ExecutionControlsInjector, String) - Method in class org.apache.drill.exec.testing.ExecutionControls
Look for a count down latch injection matching the given injector, site descriptor, and endpoint.
lookupExceptionInjection(ExecutionControlsInjector, String) - Method in class org.apache.drill.exec.testing.ExecutionControls
Look for an exception injection matching the given injector, site descriptor, and endpoint.
lookupOperatorOverloads(SqlIdentifier, SqlFunctionCategory, SqlSyntax, List<SqlOperator>) - Method in class org.apache.drill.exec.planner.sql.DrillOperatorTable
 
lookupPauseInjection(ExecutionControlsInjector, String) - Method in class org.apache.drill.exec.testing.ExecutionControls
Look for an pause injection matching the given injector, site descriptor, and endpoint.
LOW_MEMORY_MERGE_BATCH_RATIO - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
LOWER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LPAREN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
LT - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
 
LT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 

M

M - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
MagicString - Class in org.apache.drill.exec.store.dfs
 
MagicString(long, byte[]) - Constructor for class org.apache.drill.exec.store.dfs.MagicString
 
main(String[]) - Static method in class org.apache.drill.exec.client.DumpCat
 
main(String[]) - Static method in class org.apache.drill.exec.client.QuerySubmitter
 
main(String[]) - Static method in class org.apache.drill.exec.expr.fn.ModifiedUnparseVisitor
Testing of parsing/unparsing.
main(String[]) - Static method in class org.apache.drill.exec.planner.logical.StoragePlugins
 
main(String[]) - Static method in class org.apache.drill.exec.server.Drillbit
 
main(String[]) - Static method in class org.apache.drill.exec.store.ClassPathFileSystem
 
main(String[]) - Static method in class org.apache.drill.exec.TestMemoryRetention
 
MAIN_MAPPING - Variable in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
MAIN_MAPPING - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.BaseSortWrapper
 
mainMapping - Variable in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
 
mainMapping - Variable in class org.apache.drill.exec.physical.impl.sort.SortBatch
 
mainMapping - Variable in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
MAJOR_TYPE_BIGINT_OPTIONAL - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_BIGINT_REPEATED - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_BIGINT_REQUIRED - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_BOOL_OPTIONAL - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_BOOL_REPEATED - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_BOOL_REQUIRED - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_FLOAT4_OPTIONAL - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_FLOAT4_REPEATED - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_FLOAT4_REQUIRED - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_FLOAT8_OPTIONAL - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_FLOAT8_REPEATED - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_FLOAT8_REQUIRED - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_INT_OPTIONAL - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_INT_REPEATED - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_INT_REQUIRED - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_VARBINARY_OPTIONAL - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_VARBINARY_REPEATED - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_VARBINARY_REQUIRED - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_VARCHAR_OPTIONAL - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_VARCHAR_REPEATED - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MAJOR_TYPE_VARCHAR_REQUIRED - Static variable in class org.apache.drill.exec.store.avro.AvroTypeHelper
 
MajorTypeSerDe - Class in org.apache.drill.exec.record
 
MajorTypeSerDe() - Constructor for class org.apache.drill.exec.record.MajorTypeSerDe
 
MajorTypeSerDe.De - Class in org.apache.drill.exec.record
 
MajorTypeSerDe.De() - Constructor for class org.apache.drill.exec.record.MajorTypeSerDe.De
 
MajorTypeSerDe.MajorTypeHolder - Class in org.apache.drill.exec.record
 
MajorTypeSerDe.MajorTypeHolder(TypeProtos.MinorType, TypeProtos.DataMode, Integer, Integer, Integer) - Constructor for class org.apache.drill.exec.record.MajorTypeSerDe.MajorTypeHolder
 
MajorTypeSerDe.Se - Class in org.apache.drill.exec.record
 
MajorTypeSerDe.Se() - Constructor for class org.apache.drill.exec.record.MajorTypeSerDe.Se
 
makeCost(double, double, double, double, double) - Method in class org.apache.drill.exec.planner.cost.DrillCostBase.DrillCostFactory
 
makeCost(double, double, double, double) - Method in class org.apache.drill.exec.planner.cost.DrillCostBase.DrillCostFactory
 
makeCost(double, double, double) - Method in class org.apache.drill.exec.planner.cost.DrillCostBase.DrillCostFactory
 
makeCost(double, double, double, double) - Method in interface org.apache.drill.exec.planner.cost.DrillRelOptCostFactory
Creates a cost object.
MakeFragmentsVisitor - Class in org.apache.drill.exec.planner.fragment
Responsible for breaking a plan into its constituent Fragments.
makeHugeCost() - Method in class org.apache.drill.exec.planner.cost.DrillCostBase.DrillCostFactory
 
makeInfiniteCost() - Method in class org.apache.drill.exec.planner.cost.DrillCostBase.DrillCostFactory
 
makeQualified(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
makeTinyCost() - Method in class org.apache.drill.exec.planner.cost.DrillCostBase.DrillCostFactory
 
makeZeroCost() - Method in class org.apache.drill.exec.planner.cost.DrillCostBase.DrillCostFactory
 
manager - Variable in class org.apache.drill.exec.ops.BaseOperatorContext
 
map - Static variable in class org.apache.drill.exec.planner.sql.DrillConvertletTable
 
MAP - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
MAP_TYPE - Static variable in class org.apache.drill.exec.schema.json.jackson.JacksonHelper
 
MapBackedStore<V> - Class in org.apache.drill.exec.coord.local
 
MapBackedStore(TransientStoreConfig<V>) - Constructor for class org.apache.drill.exec.coord.local.MapBackedStore
 
MapConstructor() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses an MAP constructor
Mappify - Class in org.apache.drill.exec.expr.fn.impl
 
Mappify() - Constructor for class org.apache.drill.exec.expr.fn.impl.Mappify
 
mappify(FieldReader, BaseWriter.ComplexWriter, DrillBuf) - Static method in class org.apache.drill.exec.expr.fn.impl.MappifyUtility
 
Mappify.ConvertMapToKeyValuePairs - Class in org.apache.drill.exec.expr.fn.impl
 
Mappify.ConvertMapToKeyValuePairs() - Constructor for class org.apache.drill.exec.expr.fn.impl.Mappify.ConvertMapToKeyValuePairs
 
MappifyUtility - Class in org.apache.drill.exec.expr.fn.impl
 
MappifyUtility() - Constructor for class org.apache.drill.exec.expr.fn.impl.MappifyUtility
 
MAPPINGS - Static variable in class org.apache.drill.exec.coord.zk.EventDispatcher
 
MappingSet - Class in org.apache.drill.exec.compile.sig
 
MappingSet(GeneratorMapping) - Constructor for class org.apache.drill.exec.compile.sig.MappingSet
 
MappingSet(String, String, String, String, String, String, GeneratorMapping...) - Constructor for class org.apache.drill.exec.compile.sig.MappingSet
 
MappingSet(GeneratorMapping...) - Constructor for class org.apache.drill.exec.compile.sig.MappingSet
 
MappingSet(String, String, GeneratorMapping...) - Constructor for class org.apache.drill.exec.compile.sig.MappingSet
 
MappingSet(String, String, String, String, GeneratorMapping...) - Constructor for class org.apache.drill.exec.compile.sig.MappingSet
 
MapUtility - Class in org.apache.drill.exec.vector.complex
 
MapUtility() - Constructor for class org.apache.drill.exec.vector.complex.MapUtility
 
mark() - Method in class org.apache.drill.exec.record.RecordIterator
 
mark(int) - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
mark(int) - Method in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
 
markFunctionReturn() - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
Mark this value as being used as a function return value.
markReaderIndex() - Method in class org.apache.drill.exec.record.DeadBuf
 
markSupported() - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
markSupported() - Method in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
 
markWriterIndex() - Method in class org.apache.drill.exec.record.DeadBuf
 
match(int, int, DrillBuf) - Method in class org.apache.drill.exec.expr.fn.impl.SqlPatternComplexMatcher
 
match(int, int, DrillBuf) - Method in class org.apache.drill.exec.expr.fn.impl.SqlPatternConstantMatcher
 
match(int, int, DrillBuf) - Method in class org.apache.drill.exec.expr.fn.impl.SqlPatternContainsMatcher
 
match(int, int, DrillBuf) - Method in class org.apache.drill.exec.expr.fn.impl.SqlPatternEndsWithMatcher
 
match(int, int, DrillBuf) - Method in interface org.apache.drill.exec.expr.fn.impl.SqlPatternMatcher
 
match(int, int, DrillBuf) - Method in class org.apache.drill.exec.expr.fn.impl.SqlPatternStartsWithMatcher
 
MATCH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
MATCHED - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
matches(FileStatus) - Method in enum org.apache.drill.exec.dotdrill.DotDrillType
 
matches(TypeProtos.MajorType, List<TypeProtos.MajorType>) - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
matches(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillFilterAggregateTransposeRule
 
matches(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillLimitRule
 
matches(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillMergeProjectRule
 
matches(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillReduceAggregatesRule
 
matches(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillSortRule
 
matches(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.HashAggPrule
 
matches(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.HashJoinPrule
 
matches(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.LimitUnionExchangeTransposeRule
 
matches(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.MergeJoinPrule
 
matches(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.NestedLoopJoinPrule
 
matches(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.SortConvertPrule
 
matches(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.StreamAggPrule
 
matches(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.UnionAllPrule
 
matches(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.UnionDistinctPrule
 
materialize(LogicalExpression, VectorAccessible, ErrorCollector, FunctionLookupContext) - Static method in class org.apache.drill.exec.expr.ExpressionTreeMaterializer
 
materialize(LogicalExpression, VectorAccessible, ErrorCollector, FunctionLookupContext, boolean) - Static method in class org.apache.drill.exec.expr.ExpressionTreeMaterializer
 
materialize(LogicalExpression, VectorAccessible, ErrorCollector, FunctionLookupContext, boolean, boolean) - Static method in class org.apache.drill.exec.expr.ExpressionTreeMaterializer
Materializes logical expression taking into account passed parameters.
materialize(LogicalExpression, Map<VectorAccessible, BatchReference>, ErrorCollector, FunctionLookupContext, boolean, boolean) - Static method in class org.apache.drill.exec.expr.ExpressionTreeMaterializer
Materializes logical expression taking into account passed parameters.
materializeAndCheckErrors(LogicalExpression, VectorAccessible, FunctionLookupContext) - Static method in class org.apache.drill.exec.expr.ExpressionTreeMaterializer
 
materializeFilterExpr(LogicalExpression, Map<SchemaPath, ColumnStatistics>, ErrorCollector, FunctionLookupContext) - Static method in class org.apache.drill.exec.expr.ExpressionTreeMaterializer
 
materializePruneExpr(RexNode, PlannerSettings, RelNode, VectorContainer) - Method in class org.apache.drill.exec.planner.logical.partition.PruneScanRule
 
Materializer - Class in org.apache.drill.exec.planner.fragment
 
Materializer.IndexedFragmentNode - Class in org.apache.drill.exec.planner.fragment
 
Materializer.IndexedFragmentNode(int, Wrapper) - Constructor for class org.apache.drill.exec.planner.fragment.Materializer.IndexedFragmentNode
 
MaterializeVisitor - Interface in org.apache.drill.exec.record
 
MathFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
MathFunctions.Pi - Class in org.apache.drill.exec.expr.fn.impl
 
MathFunctions.Pi() - Constructor for class org.apache.drill.exec.expr.fn.impl.MathFunctions.Pi
 
MathFunctions.Power - Class in org.apache.drill.exec.expr.fn.impl
 
MathFunctions.Power() - Constructor for class org.apache.drill.exec.expr.fn.impl.MathFunctions.Power
 
MathFunctions.Random - Class in org.apache.drill.exec.expr.fn.impl
 
MathFunctions.Random() - Constructor for class org.apache.drill.exec.expr.fn.impl.MathFunctions.Random
 
MathFunctions.ToNumber - Class in org.apache.drill.exec.expr.fn.impl
 
MathFunctions.ToNumber() - Constructor for class org.apache.drill.exec.expr.fn.impl.MathFunctions.ToNumber
 
MAX - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
max - Variable in class org.apache.drill.exec.server.options.TypeValidators.PositiveLongValidator
 
max - Variable in class org.apache.drill.exec.server.options.TypeValidators.RangeDoubleValidator
 
max - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
MAX_ALLOCATION - Static variable in class org.apache.drill.exec.physical.base.AbstractBase
 
MAX_ALLOCATION - Static variable in interface org.apache.drill.exec.physical.impl.xsort.PriorityQueueCopier
 
MAX_BATCH_SIZE - Static variable in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch
 
MAX_BATCH_SIZE - Static variable in interface org.apache.drill.exec.record.RecordBatch
max batch size, limited by 2-byte length in SV2: 65536 = 2^16
MAX_BROADCAST_THRESHOLD - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
MAX_CPUS_PER_NODE - Static variable in class org.apache.drill.exec.ExecConstants
 
MAX_ERRORS - Static variable in class org.apache.drill.exec.physical.impl.validate.BatchValidator
 
MAX_HASH_TABLE_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
MAX_HASH_TABLE_SIZE_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
MAX_HEADER_LEN - Static variable in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
Maximum Drill symbol length, as enforced for headers.
MAX_IMPLICIT_CAST_COST - Static variable in class org.apache.drill.exec.resolver.ResolverTypePrecedence
 
MAX_LOADING_CACHE_SIZE_CONFIG - Static variable in class org.apache.drill.exec.compile.CodeCompiler
Maximum size of the compiled class cache.
MAX_MEMORY_PER_NODE - Static variable in class org.apache.drill.exec.ExecConstants
 
MAX_QUERY_MEMORY_PER_NODE - Static variable in class org.apache.drill.exec.ExecConstants
 
MAX_QUERY_MEMORY_PER_NODE_KEY - Static variable in class org.apache.drill.exec.ExecConstants
Maximum query memory per node (in MB).
MAX_RECORD_SIZE - Static variable in class org.apache.drill.exec.store.bson.BsonRecordReader
 
MAX_RECORD_SIZE - Static variable in class org.apache.drill.exec.vector.complex.fn.JsonReader
 
MAX_VECTOR_SIZE - Static variable in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
 
MAX_WIDTH_GLOBAL - Static variable in class org.apache.drill.exec.ExecConstants
 
MAX_WIDTH_GLOBAL_KEY - Static variable in class org.apache.drill.exec.ExecConstants
The maximum level or parallelization any stage of the query can do.
MAX_WIDTH_PER_NODE - Static variable in class org.apache.drill.exec.ExecConstants
 
MAX_WIDTH_PER_NODE_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
maxAllocation - Variable in class org.apache.drill.exec.physical.base.AbstractBase
 
maxAvgColumnSize() - Method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
 
maxCapacity() - Method in class org.apache.drill.exec.record.DeadBuf
 
MaxDateTypeFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxDateTypeFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions
 
MaxDateTypeFunctions.DateMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxDateTypeFunctions.DateMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.DateMax
 
MaxDateTypeFunctions.IntervalDayMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxDateTypeFunctions.IntervalDayMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.IntervalDayMax
 
MaxDateTypeFunctions.IntervalMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxDateTypeFunctions.IntervalMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.IntervalMax
 
MaxDateTypeFunctions.IntervalYearMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxDateTypeFunctions.IntervalYearMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.IntervalYearMax
 
MaxDateTypeFunctions.NullableDateMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxDateTypeFunctions.NullableDateMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableDateMax
 
MaxDateTypeFunctions.NullableIntervalDayMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxDateTypeFunctions.NullableIntervalDayMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableIntervalDayMax
 
MaxDateTypeFunctions.NullableIntervalMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxDateTypeFunctions.NullableIntervalMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableIntervalMax
 
MaxDateTypeFunctions.NullableIntervalYearMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxDateTypeFunctions.NullableIntervalYearMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableIntervalYearMax
 
MaxDateTypeFunctions.NullableTimeMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxDateTypeFunctions.NullableTimeMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableTimeMax
 
MaxDateTypeFunctions.NullableTimeStampMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxDateTypeFunctions.NullableTimeStampMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableTimeStampMax
 
MaxDateTypeFunctions.TimeMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxDateTypeFunctions.TimeMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.TimeMax
 
MaxDateTypeFunctions.TimeStampMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxDateTypeFunctions.TimeStampMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.TimeStampMax
 
MaxFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions
 
MaxFunctions.BigIntMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxFunctions.BigIntMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.BigIntMax
 
MaxFunctions.Float4Max - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxFunctions.Float4Max() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.Float4Max
 
MaxFunctions.Float8Max - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxFunctions.Float8Max() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.Float8Max
 
MaxFunctions.IntMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxFunctions.IntMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.IntMax
 
MaxFunctions.NullableBigIntMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxFunctions.NullableBigIntMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableBigIntMax
 
MaxFunctions.NullableFloat4Max - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxFunctions.NullableFloat4Max() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableFloat4Max
 
MaxFunctions.NullableFloat8Max - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxFunctions.NullableFloat8Max() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableFloat8Max
 
MaxFunctions.NullableIntMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxFunctions.NullableIntMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableIntMax
 
MAXIMUM_CAPACITY - Static variable in interface org.apache.drill.exec.physical.impl.common.HashTable
The maximum capacity of the hash table (in terms of number of buckets).
maxMemory() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
 
maxNextCharInd - Variable in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
maxSize - Variable in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
Maximum width of a column; used for memory estimation in case of Varchars
MAXVALUE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
maxValue - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3
 
MaxVarBytesFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxVarBytesFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions
 
MaxVarBytesFunctions.NullableVarBinaryMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxVarBytesFunctions.NullableVarBinaryMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.NullableVarBinaryMax
 
MaxVarBytesFunctions.NullableVarCharMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxVarBytesFunctions.NullableVarCharMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.NullableVarCharMax
 
MaxVarBytesFunctions.VarBinaryMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxVarBytesFunctions.VarBinaryMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.VarBinaryMax
 
MaxVarBytesFunctions.VarCharMax - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MaxVarBytesFunctions.VarCharMax() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.VarCharMax
 
maxWritableBytes() - Method in class org.apache.drill.exec.record.DeadBuf
 
mayOverflow() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
MEMBER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
MEMORY_TO_CPU_RATIO - Static variable in class org.apache.drill.exec.planner.cost.DrillCostBase
 
memoryAddress() - Method in class org.apache.drill.exec.record.DeadBuf
 
MemoryAllocationUtilities - Class in org.apache.drill.exec.util
 
MemoryAllocationUtilities() - Constructor for class org.apache.drill.exec.util.MemoryAllocationUtilities
 
MemoryEstimationVisitor - Class in org.apache.drill.exec.planner.physical.visitor
 
MemoryEstimationVisitor() - Constructor for class org.apache.drill.exec.planner.physical.visitor.MemoryEstimationVisitor
 
MemoryIterator - Class in org.apache.drill.exec.store.sys
 
MemoryIterator(FragmentContext) - Constructor for class org.apache.drill.exec.store.sys.MemoryIterator
 
MemoryIterator.MemoryInfo - Class in org.apache.drill.exec.store.sys
 
MemoryIterator.MemoryInfo() - Constructor for class org.apache.drill.exec.store.sys.MemoryIterator.MemoryInfo
 
memoryNeeded(int) - Static method in class org.apache.drill.exec.physical.impl.sort.SortRecordBatchBuilder
For given record count, return the memory that SortRecordBatchBuilder needs for its own purpose.
memoryNeeded(int) - Static method in class org.apache.drill.exec.physical.impl.xsort.managed.MSortTemplate
For given recordCount how much memory does MSorter needs for its own purpose.
memoryNeeded(int) - Static method in class org.apache.drill.exec.physical.impl.xsort.MSortTemplate
For given recordCount how much memory does MSorter needs for its own purpose.
memoryPerLargeQuery - Variable in class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue.ZKQueueInfo
 
memoryPerNode() - Method in class org.apache.drill.exec.work.foreman.rm.AbstractResourceManager
 
memoryPerNode - Variable in class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager
 
memoryPerNode() - Method in class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager
 
memoryPerNode - Variable in class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue.ZKQueueInfo
 
memoryPerNode() - Method in class org.apache.drill.exec.work.foreman.rm.DynamicResourceManager
 
memoryPerNode() - Method in interface org.apache.drill.exec.work.foreman.rm.ResourceManager
Returns the memory, in bytes, assigned to each node in a Drill cluster.
memoryPerSmallQuery - Variable in class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue.ZKQueueInfo
 
merge(List<BatchGroup.InputBatch>, int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MergeSortWrapper
Merge the set of in-memory batches to produce a single logical output in the given destination container, indexed by an SV4.
merge(int, int, int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MSortTemplate
Given two regions within the selection vector 4 (a left and a right), merge the two regions to produce a combined output region in the auxiliary selection vector.
MERGE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
merge(BatchSchema) - Method in class org.apache.drill.exec.record.BatchSchema
Merge two schema to produce a new, merged schema.
merge(VectorContainer) - Method in class org.apache.drill.exec.record.VectorContainer
Merge two batches to create a single, combined, batch.
merge(OptionList) - Method in class org.apache.drill.exec.server.options.OptionList
 
mergeAndSpill(LinkedList<BatchGroup>) - Method in class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch
 
mergeAndSpill(List<BatchGroup>, int, VectorInitializer) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SpilledRuns
 
mergeBatchSize() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
 
mergeFilters(PathFilter, PathFilter[]) - Static method in class org.apache.drill.exec.util.FileSystemUtil
Merges given filter with array of filters.
mergeFilters(PathFilter...) - Static method in class org.apache.drill.exec.util.FileSystemUtil
Will merge given array of filters into one.
MERGEJOIN - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
MergeJoinBatch - Class in org.apache.drill.exec.physical.impl.join
A join operator merges two sorted streams using record iterator.
MergeJoinBatch(MergeJoinPOP, FragmentContext, RecordBatch, RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.join.MergeJoinBatch
 
MergeJoinCreator - Class in org.apache.drill.exec.physical.impl.join
 
MergeJoinCreator() - Constructor for class org.apache.drill.exec.physical.impl.join.MergeJoinCreator
 
MergeJoinPOP - Class in org.apache.drill.exec.physical.config
 
MergeJoinPOP(PhysicalOperator, PhysicalOperator, List<JoinCondition>, JoinRelType) - Constructor for class org.apache.drill.exec.physical.config.MergeJoinPOP
 
MergeJoinPrel - Class in org.apache.drill.exec.planner.physical
 
MergeJoinPrel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType) - Constructor for class org.apache.drill.exec.planner.physical.MergeJoinPrel
Creates a MergeJoiPrel.
MergeJoinPrule - Class in org.apache.drill.exec.planner.physical
 
mergeLimit() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
 
mergeMetrics(OperatorStats) - Method in class org.apache.drill.exec.ops.OperatorStats
OperatorStats merger - to merge stats from other OperatorStats this is needed in case some processing is multithreaded that needs to have separate OperatorStats to deal with WARN - this will only work for metrics that can be added
mergeRuns(int, long, int, VectorInitializer) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SpilledRuns
 
mergeSchemas(BatchSchema...) - Static method in class org.apache.drill.exec.record.SchemaUtil
Returns the merger of schemas.
MergeSortWrapper - Class in org.apache.drill.exec.physical.impl.xsort.managed
Wrapper around the "MSorter" (in memory merge sorter).
MergeSortWrapper(OperatorContext, VectorContainer) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.MergeSortWrapper
 
MergeSortWrapper.State - Enum in org.apache.drill.exec.physical.impl.xsort.managed
 
MergingCollector - Class in org.apache.drill.exec.work.batch
 
MergingCollector(AtomicInteger, BitControl.Collector, FragmentContext) - Constructor for class org.apache.drill.exec.work.batch.MergingCollector
 
MergingReceiverCreator - Class in org.apache.drill.exec.physical.impl
 
MergingReceiverCreator() - Constructor for class org.apache.drill.exec.physical.impl.MergingReceiverCreator
 
MergingReceiverGeneratorBase - Interface in org.apache.drill.exec.physical.impl.mergereceiver
 
MergingReceiverPOP - Class in org.apache.drill.exec.physical.config
 
MergingReceiverPOP(int, List<MinorFragmentEndpoint>, List<Order.Ordering>, boolean) - Constructor for class org.apache.drill.exec.physical.config.MergingReceiverPOP
 
MergingReceiverTemplate - Class in org.apache.drill.exec.physical.impl.mergereceiver
 
MergingReceiverTemplate() - Constructor for class org.apache.drill.exec.physical.impl.mergereceiver.MergingReceiverTemplate
 
MergingRecordBatch - Class in org.apache.drill.exec.physical.impl.mergereceiver
The MergingRecordBatch merges pre-sorted record batches from remote senders.
MergingRecordBatch(FragmentContext, MergingReceiverPOP, RawFragmentBatchProvider[]) - Constructor for class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
MergingRecordBatch.Metric - Enum in org.apache.drill.exec.physical.impl.mergereceiver
 
MergingRecordBatch.Node - Class in org.apache.drill.exec.physical.impl.mergereceiver
A Node contains a reference to a single value in a specific incoming batch.
MESSAGE_LENGTH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
MESSAGE_OCTET_LENGTH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
MESSAGE_TEXT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
metadata - Variable in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer.ColumnSize
 
METADATA - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Metadata - Class in org.apache.drill.exec.store.parquet
 
Metadata.ColumnMetadata - Class in org.apache.drill.exec.store.parquet
 
Metadata.ColumnMetadata() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata
 
Metadata.ColumnMetadata_v1 - Class in org.apache.drill.exec.store.parquet
A struct that contains the metadata for a column in a parquet file
Metadata.ColumnMetadata_v1() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
Metadata.ColumnMetadata_v1(SchemaPath, PrimitiveType.PrimitiveTypeName, OriginalType, Object, Object, Long) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
Metadata.ColumnMetadata_v2 - Class in org.apache.drill.exec.store.parquet
A struct that contains the metadata for a column in a parquet file
Metadata.ColumnMetadata_v2() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2
 
Metadata.ColumnMetadata_v2(String[], PrimitiveType.PrimitiveTypeName, Object, Long) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2
 
Metadata.ColumnMetadata_v2.DeSerializer - Class in org.apache.drill.exec.store.parquet
 
Metadata.ColumnMetadata_v2.DeSerializer() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2.DeSerializer
 
Metadata.ColumnMetadata_v2.Serializer - Class in org.apache.drill.exec.store.parquet
 
Metadata.ColumnMetadata_v2.Serializer() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2.Serializer
 
Metadata.ColumnMetadata_v3 - Class in org.apache.drill.exec.store.parquet
A struct that contains the metadata for a column in a parquet file
Metadata.ColumnMetadata_v3() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3
 
Metadata.ColumnMetadata_v3(String[], PrimitiveType.PrimitiveTypeName, Object, Object, Long) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3
 
Metadata.ColumnMetadata_v3.DeSerializer - Class in org.apache.drill.exec.store.parquet
 
Metadata.ColumnMetadata_v3.DeSerializer() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3.DeSerializer
 
Metadata.ColumnMetadata_v3.Serializer - Class in org.apache.drill.exec.store.parquet
 
Metadata.ColumnMetadata_v3.Serializer() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3.Serializer
 
Metadata.ColumnTypeMetadata_v2 - Class in org.apache.drill.exec.store.parquet
 
Metadata.ColumnTypeMetadata_v2() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ColumnTypeMetadata_v2
 
Metadata.ColumnTypeMetadata_v2(String[], PrimitiveType.PrimitiveTypeName, OriginalType) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ColumnTypeMetadata_v2
 
Metadata.ColumnTypeMetadata_v3 - Class in org.apache.drill.exec.store.parquet
 
Metadata.ColumnTypeMetadata_v3() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ColumnTypeMetadata_v3
 
Metadata.ColumnTypeMetadata_v3(String[], PrimitiveType.PrimitiveTypeName, OriginalType, int, int, int, int) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ColumnTypeMetadata_v3
 
Metadata.ParquetFileMetadata - Class in org.apache.drill.exec.store.parquet
 
Metadata.ParquetFileMetadata() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata
 
Metadata.ParquetFileMetadata_v1 - Class in org.apache.drill.exec.store.parquet
Struct which contains the metadata for a single parquet file
Metadata.ParquetFileMetadata_v1() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v1
 
Metadata.ParquetFileMetadata_v1(String, Long, List<Metadata.RowGroupMetadata_v1>) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v1
 
Metadata.ParquetFileMetadata_v2 - Class in org.apache.drill.exec.store.parquet
Struct which contains the metadata for a single parquet file
Metadata.ParquetFileMetadata_v2() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v2
 
Metadata.ParquetFileMetadata_v2(String, Long, List<Metadata.RowGroupMetadata_v2>) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v2
 
Metadata.ParquetFileMetadata_v3 - Class in org.apache.drill.exec.store.parquet
Struct which contains the metadata for a single parquet file
Metadata.ParquetFileMetadata_v3() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v3
 
Metadata.ParquetFileMetadata_v3(String, Long, List<Metadata.RowGroupMetadata_v3>) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v3
 
Metadata.ParquetTableMetadata_v1 - Class in org.apache.drill.exec.store.parquet
 
Metadata.ParquetTableMetadata_v1() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v1
 
Metadata.ParquetTableMetadata_v1(String, List<Metadata.ParquetFileMetadata_v1>, List<String>) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v1
 
Metadata.ParquetTableMetadata_v2 - Class in org.apache.drill.exec.store.parquet
Struct which contains the metadata for an entire parquet directory structure
Metadata.ParquetTableMetadata_v2() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
Metadata.ParquetTableMetadata_v2(String, String) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
Metadata.ParquetTableMetadata_v2(String, Metadata.ParquetTableMetadataBase, List<Metadata.ParquetFileMetadata_v2>, List<String>, String) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
Metadata.ParquetTableMetadata_v2(String, List<Metadata.ParquetFileMetadata_v2>, List<String>, ConcurrentHashMap<Metadata.ColumnTypeMetadata_v2.Key, Metadata.ColumnTypeMetadata_v2>, String) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v2
 
Metadata.ParquetTableMetadata_v3 - Class in org.apache.drill.exec.store.parquet
 
Metadata.ParquetTableMetadata_v3() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
Default constructor needed for deserialization from Parquet Metadata Cache Files
Metadata.ParquetTableMetadata_v3(String, String) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
Used for creating the Parquet Metadata cache file
Metadata.ParquetTableMetadata_v3(String, Metadata.ParquetTableMetadataBase, List<Metadata.ParquetFileMetadata_v3>, List<String>, String) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
Metadata.ParquetTableMetadata_v3(String, List<Metadata.ParquetFileMetadata_v3>, List<String>, ConcurrentHashMap<Metadata.ColumnTypeMetadata_v3.Key, Metadata.ColumnTypeMetadata_v3>, String) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
 
Metadata.ParquetTableMetadataBase - Class in org.apache.drill.exec.store.parquet
Basic class for parquet metadata.
Metadata.ParquetTableMetadataBase() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataBase
 
Metadata.ParquetTableMetadataDirs - Class in org.apache.drill.exec.store.parquet
 
Metadata.ParquetTableMetadataDirs() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataDirs
 
Metadata.ParquetTableMetadataDirs(List<String>) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataDirs
 
Metadata.RowGroupMetadata - Class in org.apache.drill.exec.store.parquet
 
Metadata.RowGroupMetadata() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata
 
Metadata.RowGroupMetadata_v1 - Class in org.apache.drill.exec.store.parquet
A struct that contains the metadata for a parquet row group
Metadata.RowGroupMetadata_v1() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v1
 
Metadata.RowGroupMetadata_v1(Long, Long, Long, Map<String, Float>, List<Metadata.ColumnMetadata_v1>) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v1
 
Metadata.RowGroupMetadata_v2 - Class in org.apache.drill.exec.store.parquet
A struct that contains the metadata for a parquet row group
Metadata.RowGroupMetadata_v2() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v2
 
Metadata.RowGroupMetadata_v2(Long, Long, Long, Map<String, Float>, List<Metadata.ColumnMetadata_v2>) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v2
 
Metadata.RowGroupMetadata_v3 - Class in org.apache.drill.exec.store.parquet
A struct that contains the metadata for a parquet row group
Metadata.RowGroupMetadata_v3() - Constructor for class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v3
 
Metadata.RowGroupMetadata_v3(Long, Long, Long, Map<String, Float>, List<Metadata.ColumnMetadata_v3>) - Constructor for class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v3
 
METADATA_DIRECTORIES_FILENAME - Static variable in class org.apache.drill.exec.store.parquet.Metadata
 
METADATA_FILENAME - Static variable in class org.apache.drill.exec.store.parquet.Metadata
 
MetadataContext - Class in org.apache.drill.exec.store.dfs
A metadata context that holds state across multiple invocations of the Parquet metadata APIs.
MetadataContext() - Constructor for class org.apache.drill.exec.store.dfs.MetadataContext
 
MetadataContext.PruneStatus - Enum in org.apache.drill.exec.store.dfs
 
MetadataDirectGroupScan - Class in org.apache.drill.exec.store.direct
Represents direct scan based on metadata information.
MetadataDirectGroupScan(RecordReader, Collection<String>) - Constructor for class org.apache.drill.exec.store.direct.MetadataDirectGroupScan
 
MetadataDirectGroupScan(RecordReader, Collection<String>, ScanStats) - Constructor for class org.apache.drill.exec.store.direct.MetadataDirectGroupScan
 
MetadataProvider - Class in org.apache.drill.exec.work.metadata
Contains worker Runnable classes for providing the metadata and related helper methods.
MetadataProvider() - Constructor for class org.apache.drill.exec.work.metadata.MetadataProvider
 
MetadataVersion - Class in org.apache.drill.exec.store.parquet
 
MetadataVersion(int, int) - Constructor for class org.apache.drill.exec.store.parquet.MetadataVersion
 
MetadataVersion(String) - Constructor for class org.apache.drill.exec.store.parquet.MetadataVersion
 
MetadataVersion.Constants - Class in org.apache.drill.exec.store.parquet
Supported metadata versions.
MetadataVersion.Constants() - Constructor for class org.apache.drill.exec.store.parquet.MetadataVersion.Constants
 
meth(String) - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
meth(String, boolean) - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
METHOD - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
MethodAnalyzer<V extends org.objectweb.asm.tree.analysis.Value> - Class in org.apache.drill.exec.compile.bytecode
Analyzer that allows us to inject additional functionality into ASMs basic analysis.
MethodAnalyzer(Interpreter<V>) - Constructor for class org.apache.drill.exec.compile.bytecode.MethodAnalyzer
Constructor.
MethodGrabbingVisitor - Class in org.apache.drill.exec.expr.fn
 
MethodGrabbingVisitor.ClassFinder - Class in org.apache.drill.exec.expr.fn
 
MethodGrabbingVisitor.ClassFinder() - Constructor for class org.apache.drill.exec.expr.fn.MethodGrabbingVisitor.ClassFinder
 
MetricDef - Interface in org.apache.drill.exec.ops
Interface that defines a metric.
metricId() - Method in interface org.apache.drill.exec.ops.MetricDef
 
metricId() - Method in enum org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate.Metric
 
metricId() - Method in enum org.apache.drill.exec.physical.impl.broadcastsender.BroadcastSenderRootExec.Metric
 
metricId() - Method in enum org.apache.drill.exec.physical.impl.join.HashJoinBatch.Metric
 
metricId() - Method in enum org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch.Metric
 
metricId() - Method in enum org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec.Metric
 
metricId() - Method in enum org.apache.drill.exec.physical.impl.ScreenCreator.ScreenRoot.Metric
 
metricId() - Method in enum org.apache.drill.exec.physical.impl.SingleSenderCreator.SingleSenderRootExec.Metric
 
metricId() - Method in enum org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch.Metric
 
metricId() - Method in enum org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch.Metric
 
metricId() - Method in enum org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch.Metric
 
metricId() - Method in enum org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader.Metric
 
METRICS_CONTEXT_NAME - Static variable in class org.apache.drill.exec.ExecConstants
 
MetricsResources - Class in org.apache.drill.exec.server.rest
 
MetricsResources() - Constructor for class org.apache.drill.exec.server.rest.MetricsResources
 
MIN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
min - Variable in class org.apache.drill.exec.server.options.TypeValidators.RangeDoubleValidator
 
min - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
MIN_HASH_TABLE_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
MIN_HASH_TABLE_SIZE_KEY - Static variable in class org.apache.drill.exec.ExecConstants
HashTable runtime settings
MIN_MEMORY_PER_BUFFERED_OP - Static variable in class org.apache.drill.exec.ExecConstants
 
MIN_MEMORY_PER_BUFFERED_OP_KEY - Static variable in class org.apache.drill.exec.ExecConstants
Minimum memory allocated to each buffered operator instance.
MIN_MERGE_BATCH_SIZE - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
 
MIN_MERGE_LIMIT - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
 
MIN_MERGED_BATCH_SIZE - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
Smallest allowed output batch size.
MIN_ROWS_PER_SORT_BATCH - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
Desperate attempt to keep spill batches from being too small in low memory.
MIN_SPILL_BATCH_SIZE - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
 
MIN_SPILL_FILE_SIZE - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
In the bizarre case where the user gave us an unrealistically low spill file size, set a floor at some bare minimum size.
MinDateTypeFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinDateTypeFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions
 
MinDateTypeFunctions.DateMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinDateTypeFunctions.DateMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.DateMin
 
MinDateTypeFunctions.IntervalDayMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinDateTypeFunctions.IntervalDayMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.IntervalDayMin
 
MinDateTypeFunctions.IntervalMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinDateTypeFunctions.IntervalMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.IntervalMin
 
MinDateTypeFunctions.IntervalYearMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinDateTypeFunctions.IntervalYearMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.IntervalYearMin
 
MinDateTypeFunctions.NullableDateMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinDateTypeFunctions.NullableDateMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableDateMin
 
MinDateTypeFunctions.NullableIntervalDayMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinDateTypeFunctions.NullableIntervalDayMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableIntervalDayMin
 
MinDateTypeFunctions.NullableIntervalMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinDateTypeFunctions.NullableIntervalMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableIntervalMin
 
MinDateTypeFunctions.NullableIntervalYearMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinDateTypeFunctions.NullableIntervalYearMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableIntervalYearMin
 
MinDateTypeFunctions.NullableTimeMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinDateTypeFunctions.NullableTimeMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableTimeMin
 
MinDateTypeFunctions.NullableTimeStampMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinDateTypeFunctions.NullableTimeStampMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableTimeStampMin
 
MinDateTypeFunctions.TimeMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinDateTypeFunctions.TimeMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.TimeMin
 
MinDateTypeFunctions.TimeStampMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinDateTypeFunctions.TimeStampMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.TimeStampMin
 
MinFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions
 
MinFunctions.BigIntMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinFunctions.BigIntMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.BigIntMin
 
MinFunctions.BitMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinFunctions.BitMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.BitMin
 
MinFunctions.Float4Min - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinFunctions.Float4Min() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.Float4Min
 
MinFunctions.Float8Min - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinFunctions.Float8Min() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.Float8Min
 
MinFunctions.IntMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinFunctions.IntMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.IntMin
 
MinFunctions.NullableBigIntMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinFunctions.NullableBigIntMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableBigIntMin
 
MinFunctions.NullableBitMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinFunctions.NullableBitMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableBitMin
 
MinFunctions.NullableFloat4Min - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinFunctions.NullableFloat4Min() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableFloat4Min
 
MinFunctions.NullableFloat8Min - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinFunctions.NullableFloat8Min() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableFloat8Min
 
MinFunctions.NullableIntMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinFunctions.NullableIntMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableIntMin
 
minimumOperatorMemory() - Method in class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue
 
minimumOperatorMemory() - Method in class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue
 
minimumOperatorMemory() - Method in interface org.apache.drill.exec.work.foreman.rm.QueryQueue
Optional floor on the amount of memory assigned per operator.
minimumOperatorMemory() - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager
 
MinorFragmentEndpoint - Class in org.apache.drill.exec.physical
MinorFragmentEndpoint represents fragment's MinorFragmentId and Drillbit endpoint to which the fragment is assigned for execution.
MinorFragmentEndpoint(int, CoordinationProtos.DrillbitEndpoint) - Constructor for class org.apache.drill.exec.physical.MinorFragmentEndpoint
 
minorType - Variable in class org.apache.drill.exec.record.MajorTypeSerDe.MajorTypeHolder
 
minorType - Variable in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
Column type given as a Drill minor type (that is, a type without the extra information such as cardinality, width, etc.
minus(RelOptCost) - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
MINUS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
minusDirectories(DrillFileSystem) - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
MINUTE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
MINVALUE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
minValue - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3
 
MinVarBytesFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinVarBytesFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions
 
MinVarBytesFunctions.NullableVarBinaryMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinVarBytesFunctions.NullableVarBinaryMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.NullableVarBinaryMin
 
MinVarBytesFunctions.NullableVarCharMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinVarBytesFunctions.NullableVarCharMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.NullableVarCharMin
 
MinVarBytesFunctions.VarBinaryMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinVarBytesFunctions.VarBinaryMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.VarBinaryMin
 
MinVarBytesFunctions.VarCharMin - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
MinVarBytesFunctions.VarCharMin() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.VarCharMin
 
mkdirs(Path, FsPermission) - Method in class org.apache.drill.exec.store.ClassPathFileSystem
 
mkdirs(Path, FsPermission) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
mkdirs(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
mkdirs(Path, FsPermission) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem
 
MOBILITY_EXTENSION_V6 - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
MockBreakageStorage - Class in org.apache.drill.exec.store.mock
 
MockBreakageStorage(MockStorageEngineConfig, DrillbitContext, String) - Constructor for class org.apache.drill.exec.store.mock.MockBreakageStorage
 
mockCol - Variable in class org.apache.drill.exec.store.mock.ColumnDef
 
MockGroupScanPOP - Class in org.apache.drill.exec.store.mock
Describes a "group" scan of a (logical) mock table.
MockGroupScanPOP(String, List<MockTableDef.MockScanEntry>) - Constructor for class org.apache.drill.exec.store.mock.MockGroupScanPOP
 
MockRecordReader - Class in org.apache.drill.exec.store.mock
 
MockRecordReader(FragmentContext, MockTableDef.MockScanEntry) - Constructor for class org.apache.drill.exec.store.mock.MockRecordReader
 
MockScanBatchCreator - Class in org.apache.drill.exec.store.mock
 
MockScanBatchCreator() - Constructor for class org.apache.drill.exec.store.mock.MockScanBatchCreator
 
MockStorageEngine - Class in org.apache.drill.exec.store.mock
 
MockStorageEngine(MockStorageEngineConfig, DrillbitContext, String) - Constructor for class org.apache.drill.exec.store.mock.MockStorageEngine
 
MockStorageEngineConfig - Class in org.apache.drill.exec.store.mock
 
MockStorageEngineConfig(String) - Constructor for class org.apache.drill.exec.store.mock.MockStorageEngineConfig
 
MockStorePOP - Class in org.apache.drill.exec.store.mock
 
MockStorePOP(PhysicalOperator) - Constructor for class org.apache.drill.exec.store.mock.MockStorePOP
 
MockSubScanPOP - Class in org.apache.drill.exec.store.mock
Describes a physical scan operation for the mock data source.
MockSubScanPOP(String, Boolean, List<MockTableDef.MockScanEntry>) - Constructor for class org.apache.drill.exec.store.mock.MockSubScanPOP
This constructor is called from Jackson and is designed to support both older physical plans and the newer ("extended") plans.
MockTableDef - Class in org.apache.drill.exec.store.mock
Structure of a mock table definition file.
MockTableDef(String, List<MockTableDef.MockScanEntry>) - Constructor for class org.apache.drill.exec.store.mock.MockTableDef
 
MockTableDef.MockColumn - Class in org.apache.drill.exec.store.mock
Meta-data description of the columns we wish to create during a simulated scan.
MockTableDef.MockColumn(String, TypeProtos.MinorType, TypeProtos.DataMode, Integer, Integer, Integer, String, Integer, Map<String, Object>) - Constructor for class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
MockTableDef.MockScanEntry - Class in org.apache.drill.exec.store.mock
Describes one simulated file (or block) within the logical file scan described by this group scan.
MockTableDef.MockScanEntry(int, Boolean, Integer, Integer, MockTableDef.MockColumn[]) - Constructor for class org.apache.drill.exec.store.mock.MockTableDef.MockScanEntry
 
MOD - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
mode(DistributedCache.SerializationMode) - Method in class org.apache.drill.exec.cache.DistributedCache.CacheConfigBuilder
 
mode - Variable in class org.apache.drill.exec.record.MajorTypeSerDe.MajorTypeHolder
 
mode(SSLConfig.Mode) - Method in class org.apache.drill.exec.ssl.SSLConfigBuilder
 
mode - Variable in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
modificationTime - Variable in class org.apache.drill.exec.planner.sql.handlers.ShowFilesCommandResult
 
ModifiedUnparseVisitor - Class in org.apache.drill.exec.expr.fn
This is a modified version of UnparseVisitor so that we can avoid rendering few things.
ModifiedUnparseVisitor(Writer) - Constructor for class org.apache.drill.exec.expr.fn.ModifiedUnparseVisitor
 
MODIFIES - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
modifyAclEntries(Path, List<AclEntry>) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
modifyFileSelection(FileSelection) - Method in class org.apache.drill.exec.physical.base.AbstractFileGroupScan
 
modifyFileSelection(FileSelection) - Method in interface org.apache.drill.exec.physical.base.FileGroupScan
 
modifyFileSelection(FileSelection) - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
modifyFileSelection(FileSelection) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
MODULE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
MoneyGen - Class in org.apache.drill.exec.store.mock
Generates a mock money field as a double over the range 0 to 1 million.
MoneyGen() - Constructor for class org.apache.drill.exec.store.mock.MoneyGen
 
MONGO_ALL_TEXT_MODE - Static variable in class org.apache.drill.exec.ExecConstants
 
MONGO_BSON_RECORD_READER - Static variable in class org.apache.drill.exec.ExecConstants
 
MONGO_BSON_RECORD_READER_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
MONGO_READER_ALL_TEXT_MODE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
MONGO_READER_READ_NUMBERS_AS_DOUBLE - Static variable in class org.apache.drill.exec.ExecConstants
 
MONGO_READER_READ_NUMBERS_AS_DOUBLE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
MONTH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
MORE_KW - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
moveFromLocalFile(Path[], Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
moveFromLocalFile(Path, Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
moveToLocalFile(Path, Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
MSorter - Interface in org.apache.drill.exec.physical.impl.xsort.managed
In-memory sorter.
MSorter - Interface in org.apache.drill.exec.physical.impl.xsort
 
MSortTemplate - Class in org.apache.drill.exec.physical.impl.xsort.managed
 
MSortTemplate() - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.MSortTemplate
 
MSortTemplate - Class in org.apache.drill.exec.physical.impl.xsort
 
MSortTemplate() - Constructor for class org.apache.drill.exec.physical.impl.xsort.MSortTemplate
 
MULTI_CACHE_CONFIG - Static variable in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
 
MULTI_LINE_COMMENT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
MULTIPHASE - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
multiply(int, double) - Static method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
multiplyBy(double) - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
MultiplyFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
MultiplyFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions
 
MultiplyFunctions.BigIntBigIntMultiply - Class in org.apache.drill.exec.expr.fn.impl
 
MultiplyFunctions.BigIntBigIntMultiply() - Constructor for class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.BigIntBigIntMultiply
 
MultiplyFunctions.Float4Float4Multiply - Class in org.apache.drill.exec.expr.fn.impl
 
MultiplyFunctions.Float4Float4Multiply() - Constructor for class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.Float4Float4Multiply
 
MultiplyFunctions.Float8Float8Multiply - Class in org.apache.drill.exec.expr.fn.impl
 
MultiplyFunctions.Float8Float8Multiply() - Constructor for class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.Float8Float8Multiply
 
MultiplyFunctions.IntIntMultiply - Class in org.apache.drill.exec.expr.fn.impl
 
MultiplyFunctions.IntIntMultiply() - Constructor for class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.IntIntMultiply
 
MultiplyFunctions.SmallIntSmallIntMultiply - Class in org.apache.drill.exec.expr.fn.impl
 
MultiplyFunctions.SmallIntSmallIntMultiply() - Constructor for class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.SmallIntSmallIntMultiply
 
MultiplyFunctions.TinyIntTinyIntMultiply - Class in org.apache.drill.exec.expr.fn.impl
 
MultiplyFunctions.TinyIntTinyIntMultiply() - Constructor for class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.TinyIntTinyIntMultiply
 
MultiplyFunctions.UInt1UInt1Multiply - Class in org.apache.drill.exec.expr.fn.impl
 
MultiplyFunctions.UInt1UInt1Multiply() - Constructor for class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.UInt1UInt1Multiply
 
MultiplyFunctions.UInt2UInt2Multiply - Class in org.apache.drill.exec.expr.fn.impl
 
MultiplyFunctions.UInt2UInt2Multiply() - Constructor for class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.UInt2UInt2Multiply
 
MultiplyFunctions.UInt4UInt4Multiply - Class in org.apache.drill.exec.expr.fn.impl
 
MultiplyFunctions.UInt4UInt4Multiply() - Constructor for class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.UInt4UInt4Multiply
 
MultiplyFunctions.UInt8UInt8Multiply - Class in org.apache.drill.exec.expr.fn.impl
 
MultiplyFunctions.UInt8UInt8Multiply() - Constructor for class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.UInt8UInt8Multiply
 
MULTISET - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
MultisetConstructor() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a MULTISET constructor
MUMPS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Murmur128 - Class in org.apache.drill.exec.store.pcap.decoder
Simple port of MurmurHash with some state management.
Murmur128(long, long) - Constructor for class org.apache.drill.exec.store.pcap.decoder.Murmur128
 
murmur3_32(int, int, DrillBuf, int) - Static method in class org.apache.drill.exec.expr.fn.impl.MurmurHash3
 
murmur3_32(long, int) - Static method in class org.apache.drill.exec.expr.fn.impl.MurmurHash3
 
murmur3_64(long, long, DrillBuf, int) - Static method in class org.apache.drill.exec.expr.fn.impl.MurmurHash3
 
murmur3_64(long, int) - Static method in class org.apache.drill.exec.expr.fn.impl.MurmurHash3
 
MurmurHash3 - Class in org.apache.drill.exec.expr.fn.impl
MurmurHash3 was written by Austin Appleby, and is placed in the public domain.
MurmurHash3() - Constructor for class org.apache.drill.exec.expr.fn.impl.MurmurHash3
 
mutator - Variable in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.NullableVarCharColumn
 
mutator - Variable in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.VarCharColumn
 
MUX_EXCHANGE - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
mxValue - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2
 

N

name(String) - Method in class org.apache.drill.exec.cache.DistributedCache.CacheConfigBuilder
 
name() - Method in class org.apache.drill.exec.coord.store.TransientStoreConfigBuilder
 
name(String) - Method in class org.apache.drill.exec.coord.store.TransientStoreConfigBuilder
 
name() - Method in interface org.apache.drill.exec.ops.MetricDef
 
name - Variable in class org.apache.drill.exec.planner.physical.PrelUtil.DesiredField
 
name - Variable in class org.apache.drill.exec.planner.sql.handlers.ShowFilesCommandResult
 
NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
name - Variable in class org.apache.drill.exec.server.options.OptionValue
 
name - Variable in class org.apache.drill.exec.store.AbstractSchema
 
NAME - Static variable in class org.apache.drill.exec.store.dfs.FileSystemConfig
 
name - Variable in class org.apache.drill.exec.store.dfs.NamedFormatPluginConfig
 
NAME - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConfig
 
name - Variable in class org.apache.drill.exec.store.ischema.InfoSchemaTable.Field
 
name - Variable in class org.apache.drill.exec.store.mock.ColumnDef
 
NAME - Static variable in class org.apache.drill.exec.store.mock.MockStorageEngineConfig
 
name - Variable in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
name - Variable in class org.apache.drill.exec.store.NamedStoragePluginConfig
 
name - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
name - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2
 
name - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3
 
name - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnTypeMetadata_v2
 
name - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnTypeMetadata_v3
 
name - Variable in class org.apache.drill.exec.store.sys.ExtendedOptionIterator.ExtendedOptionValueWrapper
 
name - Variable in class org.apache.drill.exec.store.sys.OptionIterator.OptionValueWrapper
 
name(String) - Method in class org.apache.drill.exec.store.sys.PersistentStoreConfig.StoreConfigBuilder
 
NAME - Static variable in class org.apache.drill.exec.store.sys.SystemTablePluginConfig
 
NAMED_ARGUMENT_ASSIGNMENT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
NamedField - Class in org.apache.drill.exec.schema
 
NamedField(RecordSchema, String, String, TypeProtos.MajorType) - Constructor for class org.apache.drill.exec.schema.NamedField
 
NamedField(RecordSchema, String, String, TypeProtos.MajorType, TypeProtos.MajorType) - Constructor for class org.apache.drill.exec.schema.NamedField
 
NamedFormatPluginConfig - Class in org.apache.drill.exec.store.dfs
 
NamedFormatPluginConfig() - Constructor for class org.apache.drill.exec.store.dfs.NamedFormatPluginConfig
 
NamedFunctionCall() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a call to a named function (could be a builtin with regular syntax, or else a UDF).
NamedRoutineCall(SqlFunctionCategory, SqlAbstractParserImpl.ExprContext) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
NamedStoragePluginConfig - Class in org.apache.drill.exec.store
 
NamedStoragePluginConfig() - Constructor for class org.apache.drill.exec.store.NamedStoragePluginConfig
 
NAMES - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
NANOS_PER_MILLISECOND - Static variable in class org.apache.drill.exec.store.parquet.ParquetReaderUtility.NanoTimeUtils
 
naryOperation(AbstractInsnNode, List<? extends BasicValue>) - Method in class org.apache.drill.exec.compile.bytecode.ReplacingInterpreter
 
NATIONAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Natural() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
NATURAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
NCHAR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
NCLOB - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
NE - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
 
NE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
needsFinalColumnReordering() - Method in class org.apache.drill.exec.planner.physical.AggPrelBase
 
needsFinalColumnReordering() - Method in class org.apache.drill.exec.planner.physical.ComplexToJsonPrel
 
needsFinalColumnReordering() - Method in class org.apache.drill.exec.planner.physical.FilterPrel
 
needsFinalColumnReordering() - Method in class org.apache.drill.exec.planner.physical.JoinPrel
 
needsFinalColumnReordering() - Method in class org.apache.drill.exec.planner.physical.LimitPrel
 
needsFinalColumnReordering() - Method in interface org.apache.drill.exec.planner.physical.Prel
 
needsFinalColumnReordering() - Method in class org.apache.drill.exec.planner.physical.ProducerConsumerPrel
 
needsFinalColumnReordering() - Method in class org.apache.drill.exec.planner.physical.ProjectPrel
Whether this Project requires a final column re-ordering.
needsFinalColumnReordering() - Method in class org.apache.drill.exec.planner.physical.ScanPrel
 
needsFinalColumnReordering() - Method in class org.apache.drill.exec.planner.physical.ScreenPrel
 
needsFinalColumnReordering() - Method in class org.apache.drill.exec.planner.physical.SinglePrel
 
needsFinalColumnReordering() - Method in class org.apache.drill.exec.planner.physical.SortPrel
 
needsFinalColumnReordering() - Method in class org.apache.drill.exec.planner.physical.UnionPrel
 
needsFinalColumnReordering() - Method in class org.apache.drill.exec.planner.physical.ValuesPrel
 
needsFinalColumnReordering() - Method in class org.apache.drill.exec.planner.physical.WindowPrel
 
needsFinalColumnReordering() - Method in class org.apache.drill.exec.planner.physical.WriterPrel
 
NestedLoopJoin - Interface in org.apache.drill.exec.physical.impl.join
Interface for the nested loop join operator.
NESTEDLOOPJOIN - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
NESTEDLOOPJOIN_FACTOR - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
NestedLoopJoinBatch - Class in org.apache.drill.exec.physical.impl.join
 
NestedLoopJoinBatch(NestedLoopJoinPOP, FragmentContext, RecordBatch, RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch
 
NestedLoopJoinBatchCreator - Class in org.apache.drill.exec.physical.impl.join
 
NestedLoopJoinBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatchCreator
 
NestedLoopJoinPOP - Class in org.apache.drill.exec.physical.config
 
NestedLoopJoinPOP(PhysicalOperator, PhysicalOperator, JoinRelType, LogicalExpression) - Constructor for class org.apache.drill.exec.physical.config.NestedLoopJoinPOP
 
NestedLoopJoinPrel - Class in org.apache.drill.exec.planner.physical
 
NestedLoopJoinPrel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType) - Constructor for class org.apache.drill.exec.planner.physical.NestedLoopJoinPrel
 
NestedLoopJoinPrule - Class in org.apache.drill.exec.planner.physical
 
NestedLoopJoinTemplate - Class in org.apache.drill.exec.physical.impl.join
 
NestedLoopJoinTemplate() - Constructor for class org.apache.drill.exec.physical.impl.join.NestedLoopJoinTemplate
 
nestEvalBlock(JBlock) - Method in class org.apache.drill.exec.expr.ClassGenerator
 
NESTING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
netRowWidth() - Method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
 
netRowWidthCap50() - Method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
Compute the "real" width of the row, taking into account each varchar column size (historically capped at 50, and rounded up to power of 2 to match drill buf allocation) and null marking columns.
netSize() - Method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
 
nettySslContext - Variable in class org.apache.drill.exec.ssl.SSLConfig
 
NetworkFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
NetworkFunctions.AddressCountFunction - Class in org.apache.drill.exec.expr.fn.impl
This function retunrs the number of IP addresses in the input CIDR block.
NetworkFunctions.AddressCountFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.AddressCountFunction
 
NetworkFunctions.BroadcastAddressFunction - Class in org.apache.drill.exec.expr.fn.impl
This function returns the broadcast address of a given CIDR block.
NetworkFunctions.BroadcastAddressFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.BroadcastAddressFunction
 
NetworkFunctions.HighAddressFunction - Class in org.apache.drill.exec.expr.fn.impl
This function gets the numerically highest IP address in an input CIDR block.
NetworkFunctions.HighAddressFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.HighAddressFunction
 
NetworkFunctions.InetAtonFunction - Class in org.apache.drill.exec.expr.fn.impl
This function converts an IPv4 address into a BigInt.
NetworkFunctions.InetAtonFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.InetAtonFunction
 
NetworkFunctions.InetNtoaFunction - Class in org.apache.drill.exec.expr.fn.impl
This function converts a BigInt IPv4 into dotted decimal notation.
NetworkFunctions.InetNtoaFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.InetNtoaFunction
 
NetworkFunctions.InNetworkFunction - Class in org.apache.drill.exec.expr.fn.impl
This function takes two arguments, an input IPv4 and a CIDR, and returns true if the IP is in the given CIDR block
NetworkFunctions.InNetworkFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.InNetworkFunction
 
NetworkFunctions.IsPrivateIP - Class in org.apache.drill.exec.expr.fn.impl
This function returns true if a given IPv4 address is private, false if not.
NetworkFunctions.IsPrivateIP() - Constructor for class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.IsPrivateIP
 
NetworkFunctions.IsValidIPFunction - Class in org.apache.drill.exec.expr.fn.impl
Returns true if the input string is a valid IP address
NetworkFunctions.IsValidIPFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.IsValidIPFunction
 
NetworkFunctions.IsValidIPV4Function - Class in org.apache.drill.exec.expr.fn.impl
Returns true if the input string is a valid IPv4 address
NetworkFunctions.IsValidIPV4Function() - Constructor for class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.IsValidIPV4Function
 
NetworkFunctions.IsValidIPv6Function - Class in org.apache.drill.exec.expr.fn.impl
Returns true if the input string is a valid IP address
NetworkFunctions.IsValidIPv6Function() - Constructor for class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.IsValidIPv6Function
 
NetworkFunctions.LowAddressFunction - Class in org.apache.drill.exec.expr.fn.impl
This function gets the numerically lowest IP address in an input CIDR block.
NetworkFunctions.LowAddressFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.LowAddressFunction
 
NetworkFunctions.NetmaskFunction - Class in org.apache.drill.exec.expr.fn.impl
This function gets the netmask of the input CIDR block.
NetworkFunctions.NetmaskFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.NetmaskFunction
 
NetworkFunctions.urldecodeFunction - Class in org.apache.drill.exec.expr.fn.impl
This function decodes URL strings.
NetworkFunctions.urldecodeFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.urldecodeFunction
 
NetworkFunctions.urlencodeFunction - Class in org.apache.drill.exec.expr.fn.impl
This function encodes URL strings.
NetworkFunctions.urlencodeFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.urlencodeFunction
 
NEW - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
NEW_VIEW_DEFAULT_PERMS_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
NEW_VIEW_DEFAULT_PERMS_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
newAggregateRel(Aggregate, RelNode, List<AggregateCall>) - Method in class org.apache.drill.exec.planner.logical.DrillReduceAggregatesRule
Do a shallow clone of oldAggRel and update aggCalls.
newBatchHolder() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
 
newBatchHolder(int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
newBound(RexWindowBound) - Static method in class org.apache.drill.exec.physical.config.WindowPOP
 
newBuilder(Class<V>) - Static method in class org.apache.drill.exec.cache.DistributedCache.CacheConfig
 
newBuilder(Class<K>, Class<V>) - Static method in class org.apache.drill.exec.cache.DistributedCache.CacheConfig
 
newBuilder() - Static method in class org.apache.drill.exec.compile.ClassBodyBuilder
 
newBuilder() - Static method in class org.apache.drill.exec.coord.store.TransientStoreConfig
 
newBuilder() - Static method in class org.apache.drill.exec.planner.sql.parser.DrillCompoundIdentifier
 
newBuilder() - Static method in class org.apache.drill.exec.record.BatchSchema
 
newBuilder() - Static method in class org.apache.drill.exec.record.TypedFieldId
 
newBuilder() - Static method in class org.apache.drill.exec.rpc.user.UserSession.Builder
 
newBuilder(String, SchemaConfig.SchemaConfigInfoProvider) - Static method in class org.apache.drill.exec.store.SchemaConfig
Create new builder.
newDiscovery() - Method in class org.apache.drill.exec.coord.zk.ZKClusterCoordinator
 
newFileSystem(Configuration) - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
newFileSystem(Configuration) - Method in interface org.apache.drill.exec.ops.OperatorContext
 
newFormatCreator(FileSystemConfig, DrillbitContext, Configuration) - Method in class org.apache.drill.exec.store.dfs.FileSystemPlugin
Creates a new FormatCreator instance.
newFrame(int, int) - Method in class org.apache.drill.exec.compile.bytecode.MethodAnalyzer
 
newFrame(Frame<? extends V>) - Method in class org.apache.drill.exec.compile.bytecode.MethodAnalyzer
 
newFrame(long) - Method in class org.apache.drill.exec.physical.impl.window.Partition
 
newJacksonBuilder(ObjectMapper, Class<V>) - Static method in class org.apache.drill.exec.coord.store.TransientStoreConfig
 
newJacksonBuilder(ObjectMapper, Class<V>) - Static method in class org.apache.drill.exec.store.sys.PersistentStoreConfig
 
newNonTrackingFileSystem(Configuration) - Method in class org.apache.drill.exec.ops.BaseOperatorContext
Creates a DrillFileSystem that does not automatically track operator stats.
newNonTrackingFileSystem(Configuration) - Method in interface org.apache.drill.exec.ops.OperatorContext
 
newOperation(AbstractInsnNode) - Method in class org.apache.drill.exec.compile.bytecode.ReplacingInterpreter
 
newOperatorContext(PhysicalOperator, OperatorStats) - Method in class org.apache.drill.exec.ops.FragmentContext
 
newOperatorContext(PhysicalOperator) - Method in class org.apache.drill.exec.ops.FragmentContext
 
newOperatorStats(OpProfileDef, BufferAllocator) - Method in class org.apache.drill.exec.ops.FragmentStats
Creates a new holder for operator statistics within this holder for fragment statistics.
newOutgoingRecordBatch(OperatorStats, HashPartitionSender, AccountingDataTunnel, FragmentContext, BufferAllocator, int) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate
Shim method to be overridden in plain-old Java mode by the subclass to instantiate the generated inner class.
newPartition(int) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
newProtoBuilder(Schema<V>, Schema<B>) - Static method in class org.apache.drill.exec.coord.store.TransientStoreConfig
 
newProtoBuilder(Schema<V>, Schema<X>) - Static method in class org.apache.drill.exec.store.sys.PersistentStoreConfig
 
newPStoreProvider() - Method in class org.apache.drill.exec.store.sys.PersistentStoreRegistry
 
newQueryRM(Foreman) - Method in class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager
 
newQueryRM(Foreman) - Method in class org.apache.drill.exec.work.foreman.rm.DynamicResourceManager
 
newQueryRM(Foreman) - Method in interface org.apache.drill.exec.work.foreman.rm.ResourceManager
Create a resource manager to execute a query.
newQueryRM(Foreman) - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager
 
newRawFragmentBatch(BufferAllocator) - Method in class org.apache.drill.exec.rpc.data.IncomingDataBatch
Create a new RawFragmentBatch based on this incoming data batch that is transferred into the provided allocator.
newResourceAllocator(QueryContext) - Method in class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager
 
newResourceAllocator(QueryContext) - Method in class org.apache.drill.exec.work.foreman.rm.DynamicResourceManager
 
newResourceAllocator(QueryContext) - Method in interface org.apache.drill.exec.work.foreman.rm.ResourceManager
Create a resource manager to prepare or describe a query.
newResourceAllocator(QueryContext) - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager
 
newRoot(DrillConfig) - Static method in class org.apache.drill.exec.memory.RootAllocatorFactory
Create a new Root Allocator
newRoot(long) - Static method in class org.apache.drill.exec.memory.RootAllocatorFactory
 
newServiceInstance(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.coord.zk.ZKClusterCoordinator
 
NewSpecification() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a NEW UDT(...) expression.
newToken(int) - Static method in class org.apache.drill.exec.planner.sql.parser.impl.Token
Returns a new Token object, by default.
newTraitSet(RelTrait...) - Method in class org.apache.drill.exec.planner.physical.SubsetTransformer
 
newValue(Type) - Method in class org.apache.drill.exec.compile.bytecode.ReplacingInterpreter
 
next() - Method in interface org.apache.drill.exec.physical.impl.aggregate.BatchIterator
 
next() - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
Read the next batch from the spill file
next() - Method in class org.apache.drill.exec.physical.impl.BaseRootExec
 
next(RecordBatch) - Method in class org.apache.drill.exec.physical.impl.BaseRootExec
 
next() - Method in interface org.apache.drill.exec.physical.impl.RootExec
Do the next batch of work.
next() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
 
next() - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
 
next() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
next() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MergeSortWrapper
The SV4 provides a built-in iterator that returns a virtual set of record batches so that the downstream operator need not consume the entire set of accumulated batches in a single step.
next(int) - Method in interface org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopier
 
next(int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierTemplate
 
next() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierWrapper.BatchMerger
Read the next merged batch.
next() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.EmptyResults
 
next() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SingleBatchResults
 
next() - Method in interface org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SortResults
 
next(int) - Method in interface org.apache.drill.exec.physical.impl.xsort.PriorityQueueCopier
 
next(int) - Method in class org.apache.drill.exec.physical.impl.xsort.PriorityQueueCopierTemplate
 
next() - Method in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor.RelDataTypeReader
 
NEXT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
next - Variable in class org.apache.drill.exec.planner.sql.parser.impl.Token
A reference to the next regular (non-special) token from the input stream.
next(RecordBatch) - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
next(int, RecordBatch) - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
next() - Method in class org.apache.drill.exec.record.AbstractRecordBatch
 
next() - Method in interface org.apache.drill.exec.record.RecordBatch
Updates the data in each Field reading interface for the next range of records.
next() - Method in class org.apache.drill.exec.record.RecordIterator
Move iterator to next record.
next() - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
next() - Method in class org.apache.drill.exec.record.selection.SelectionVector4
 
next() - Method in class org.apache.drill.exec.record.SimpleRecordBatch
 
next() - Method in class org.apache.drill.exec.server.options.DrillConfigIterator.Iter
 
next() - Method in class org.apache.drill.exec.store.avro.AvroRecordReader
 
next() - Method in class org.apache.drill.exec.store.easy.json.JSONRecordReader
 
next() - Method in class org.apache.drill.exec.store.easy.sequencefile.SequenceFileRecordReader
 
next() - Method in class org.apache.drill.exec.store.easy.text.compliant.CompliantTextRecordReader
Generates the next record batch
next() - Method in class org.apache.drill.exec.store.mock.ExtendedMockRecordReader
 
next() - Method in class org.apache.drill.exec.store.mock.MockRecordReader
 
next() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
Read the next record batch from the file using the reader and read state created previously.
next() - Method in class org.apache.drill.exec.store.parquet2.DrillParquetReader
 
next() - Method in class org.apache.drill.exec.store.pcap.PcapRecordReader
 
next() - Method in class org.apache.drill.exec.store.pojo.AbstractPojoRecordReader
 
next() - Method in interface org.apache.drill.exec.store.RecordReader
Increments this record reader forward, writing via the provided output mutator into the output batch.
next() - Method in class org.apache.drill.exec.store.sys.DrillbitIterator
 
next() - Method in class org.apache.drill.exec.store.sys.ExtendedOptionIterator
 
next() - Method in class org.apache.drill.exec.store.sys.MemoryIterator
 
next() - Method in class org.apache.drill.exec.store.sys.OptionIterator
 
next() - Method in class org.apache.drill.exec.store.sys.ThreadsIterator
 
next() - Method in class org.apache.drill.exec.store.sys.VersionIterator
 
next() - Method in class org.apache.drill.exec.store.text.DrillTextRecordReader
 
nextPacket() - Method in class org.apache.drill.exec.store.pcap.decoder.PacketDecoder
 
nextUpdateTime - Variable in class org.apache.drill.exec.work.foreman.rm.DynamicResourceManager
 
nioBuffer() - Method in class org.apache.drill.exec.record.DeadBuf
 
nioBuffer(int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
nioBufferCount() - Method in class org.apache.drill.exec.record.DeadBuf
 
nioBuffers() - Method in class org.apache.drill.exec.record.DeadBuf
 
nioBuffers(int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
NLJOIN_FOR_SCALAR - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
NO - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
NO_COLUMN_STATS - Static variable in interface org.apache.drill.exec.physical.base.GroupScan
 
NO_NEXT_HEADER - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
NOFRAME_TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.window.WindowFramer
 
NoFrameSupportTemplate - Class in org.apache.drill.exec.physical.impl.window
WindowFramer implementation that doesn't support the FRAME clause (will assume the default frame).
NoFrameSupportTemplate() - Constructor for class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
 
NON_ADMIN_PRINCIPALS - Static variable in class org.apache.drill.exec.server.rest.auth.DrillUserPrincipal
 
NON_ADMIN_USER_ROLES - Static variable in class org.apache.drill.exec.server.rest.auth.DrillUserPrincipal
 
NON_BLOCKING_OPERATORS_MEMORY - Static variable in class org.apache.drill.exec.ExecConstants
 
NON_BLOCKING_OPERATORS_MEMORY_KEY - Static variable in class org.apache.drill.exec.ExecConstants
Extra query memory per node for non-blocking operators.
NON_REDUCIBLE_TYPES - Static variable in class org.apache.drill.exec.planner.logical.DrillConstExecutor
 
NONE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
NONE_AND_FOUR - Static variable in enum org.apache.drill.exec.record.BatchSchema.SelectionVectorMode
 
NONE_AND_TWO - Static variable in enum org.apache.drill.exec.record.BatchSchema.SelectionVectorMode
 
NonReservedJdbcFunctionName() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses the name of a JDBC function that is a token but is not reserved.
NonReservedKeyWord() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
NonRootFragmentManager - Class in org.apache.drill.exec.work.fragment
This managers determines when to run a non-root fragment node.
NonRootFragmentManager(BitControl.PlanFragment, FragmentExecutor, FragmentStatusReporter) - Constructor for class org.apache.drill.exec.work.fragment.NonRootFragmentManager
 
NoOpControlsInjector - Class in org.apache.drill.exec.testing
An injector that does not inject any controls, useful when not testing (i.e.
NoOpControlsInjector(Class<?>) - Constructor for class org.apache.drill.exec.testing.NoOpControlsInjector
Constructor.
normalize(String) - Static method in class org.apache.drill.exec.coord.zk.PathUtils
Normalizes the given path eliminating repeated forward slashes.
NORMALIZE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
NORMALIZED - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
normalizeException(Throwable) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
Not - Class in org.apache.drill.exec.expr.fn.impl
 
Not() - Constructor for class org.apache.drill.exec.expr.fn.impl.Not
 
NOT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Not.Required - Class in org.apache.drill.exec.expr.fn.impl
 
Not.Required() - Constructor for class org.apache.drill.exec.expr.fn.impl.Not.Required
 
NoWriteLocalStore<V> - Class in org.apache.drill.exec.testing.store
 
NoWriteLocalStore() - Constructor for class org.apache.drill.exec.testing.store.NoWriteLocalStore
 
ntile(int) - Method in class org.apache.drill.exec.physical.impl.window.Partition
 
NULL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
NULL_TYPE - Static variable in class org.apache.drill.exec.schema.json.jackson.JacksonHelper
 
NULLABLE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
NullableBigIntAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableBigIntAccessor(NullableBigIntVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableBigIntAccessor
 
NullableBitAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableBitAccessor(NullableBitVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableBitAccessor
 
nullableCount - Variable in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
Count the nullable columns; used for memory estimation
NullableDateAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableDateAccessor(NullableDateVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableDateAccessor
 
NullableDecimal18Accessor - Class in org.apache.drill.exec.vector.accessor
 
NullableDecimal18Accessor(NullableDecimal18Vector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableDecimal18Accessor
 
NullableDecimal28DenseAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableDecimal28DenseAccessor(NullableDecimal28DenseVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableDecimal28DenseAccessor
 
NullableDecimal28SparseAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableDecimal28SparseAccessor(NullableDecimal28SparseVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableDecimal28SparseAccessor
 
nullableDecimal28Vector - Variable in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.NullableDecimal28Column
 
NullableDecimal38DenseAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableDecimal38DenseAccessor(NullableDecimal38DenseVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableDecimal38DenseAccessor
 
NullableDecimal38SparseAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableDecimal38SparseAccessor(NullableDecimal38SparseVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableDecimal38SparseAccessor
 
NullableDecimal9Accessor - Class in org.apache.drill.exec.vector.accessor
 
NullableDecimal9Accessor(NullableDecimal9Vector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableDecimal9Accessor
 
NullableFixedByteAlignedReaders - Class in org.apache.drill.exec.store.parquet.columnreaders
 
NullableFixedByteAlignedReaders() - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.NullableFixedByteAlignedReaders
 
NullableFixedByteAlignedReaders.CorruptionDetectingNullableDateReader - Class in org.apache.drill.exec.store.parquet.columnreaders
Old versions of Drill were writing a non-standard format for date.
NullableFixedByteAlignedReaders.NullableCorruptDateReader - Class in org.apache.drill.exec.store.parquet.columnreaders
Old versions of Drill were writing a non-standard format for date.
NullableFixedByteAlignedReaders.NullableDateReader - Class in org.apache.drill.exec.store.parquet.columnreaders
 
NullableFixedByteAlignedReaders.NullableDecimal28Reader - Class in org.apache.drill.exec.store.parquet.columnreaders
 
NullableFixedByteAlignedReaders.NullableDecimal38Reader - Class in org.apache.drill.exec.store.parquet.columnreaders
 
NullableFixedByteAlignedReaders.NullableIntervalReader - Class in org.apache.drill.exec.store.parquet.columnreaders
 
NullableFloat4Accessor - Class in org.apache.drill.exec.vector.accessor
 
NullableFloat4Accessor(NullableFloat4Vector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableFloat4Accessor
 
NullableFloat8Accessor - Class in org.apache.drill.exec.vector.accessor
 
NullableFloat8Accessor(NullableFloat8Vector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableFloat8Accessor
 
NullableIntAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableIntAccessor(NullableIntVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableIntAccessor
 
NullableIntervalAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableIntervalAccessor(NullableIntervalVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableIntervalAccessor
 
NullableIntervalDayAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableIntervalDayAccessor(NullableIntervalDayVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableIntervalDayAccessor
 
NullableIntervalYearAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableIntervalYearAccessor(NullableIntervalYearVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableIntervalYearAccessor
 
NullableSmallIntAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableSmallIntAccessor(NullableSmallIntVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableSmallIntAccessor
 
NullableTimeAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableTimeAccessor(NullableTimeVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableTimeAccessor
 
NullableTimeStampAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableTimeStampAccessor(NullableTimeStampVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableTimeStampAccessor
 
NullableTinyIntAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableTinyIntAccessor(NullableTinyIntVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableTinyIntAccessor
 
NullableUInt1Accessor - Class in org.apache.drill.exec.vector.accessor
 
NullableUInt1Accessor(NullableUInt1Vector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableUInt1Accessor
 
NullableUInt2Accessor - Class in org.apache.drill.exec.vector.accessor
 
NullableUInt2Accessor(NullableUInt2Vector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableUInt2Accessor
 
NullableUInt4Accessor - Class in org.apache.drill.exec.vector.accessor
 
NullableUInt4Accessor(NullableUInt4Vector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableUInt4Accessor
 
NullableUInt8Accessor - Class in org.apache.drill.exec.vector.accessor
 
NullableUInt8Accessor(NullableUInt8Vector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableUInt8Accessor
 
NullableVar16CharAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableVar16CharAccessor(NullableVar16CharVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableVar16CharAccessor
 
NullableVarBinaryAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableVarBinaryAccessor(NullableVarBinaryVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableVarBinaryAccessor
 
NullableVarCharAccessor - Class in org.apache.drill.exec.vector.accessor
 
NullableVarCharAccessor(NullableVarCharVector) - Constructor for class org.apache.drill.exec.vector.accessor.NullableVarCharAccessor
 
NullableVarLengthValuesColumn<V extends ValueVector> - Class in org.apache.drill.exec.store.parquet.columnreaders
 
NULLIF - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
NULLS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
nulls - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
nulls - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2
 
nulls - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3
 
NUM_NULLABLE_ACTIVE_OVERVIEW_COLUMNS - Static variable in class org.apache.drill.exec.server.rest.profile.FragmentWrapper
 
NUM_NULLABLE_COMPLETED_OVERVIEW_COLUMNS - Static variable in class org.apache.drill.exec.server.rest.profile.FragmentWrapper
 
num_val - Variable in class org.apache.drill.exec.server.options.OptionValue
 
num_val - Variable in class org.apache.drill.exec.store.sys.OptionIterator.OptionValueWrapper
 
NUMBER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
numberPartitions - Variable in class org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec
 
numBuckets - Variable in class org.apache.drill.exec.physical.impl.common.HashTableStats
 
numBuckets() - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
numDataPageLoads - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
numDataPagesDecoded - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
numDataPagesDecompressed - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
numDictPageLoads - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
numDictPagesDecompressed - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
numEndPoints() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
numEntries - Variable in class org.apache.drill.exec.physical.impl.common.HashTableStats
 
NUMERIC - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
NUMERIC_PRECISION - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
NUMERIC_PRECISION_RADIX - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
NUMERIC_SCALE - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
NumericLiteral() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a numeric literal (can be signed)
numGroupedRecords() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
 
numResizing - Variable in class org.apache.drill.exec.physical.impl.common.HashTableStats
 
numResizing() - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 

O

OBJECT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ObjectSchema - Class in org.apache.drill.exec.schema
 
ObjectSchema() - Constructor for class org.apache.drill.exec.schema.ObjectSchema
 
oContext - Variable in class org.apache.drill.exec.physical.impl.BaseRootExec
 
oContext - Variable in class org.apache.drill.exec.record.AbstractRecordBatch
 
OCTET_LENGTH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
OCTETS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
of(TransientStoreFactory) - Static method in class org.apache.drill.exec.coord.store.CachingTransientStoreFactory
 
of(TransientStoreEventType, String, T) - Static method in class org.apache.drill.exec.coord.store.TransientStoreEvent
 
OF - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
offset - Variable in class org.apache.drill.exec.planner.common.DrillLimitRelBase
 
OFFSET - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ok - Variable in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
ok - Variable in class org.apache.drill.exec.planner.sql.handlers.SimpleCommandResult
 
OK - Static variable in class org.apache.drill.exec.rpc.control.ControlRpcConfig
 
OK - Static variable in class org.apache.drill.exec.rpc.data.DataRpcConfig
 
OLD - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
OLD_METADATA_FILENAMES - Static variable in class org.apache.drill.exec.store.parquet.Metadata
 
ON - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
onChange(TransientStoreEvent<?>) - Method in interface org.apache.drill.exec.coord.store.TransientStoreListener
transient store fires this method with event details upon an observed change.
ONLY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillAggregateRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillFilterRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillJoinRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillLimitRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillMergeFilterRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillProjectRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillPushFilterPastProjectRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillPushProjIntoScan
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillReduceAggregatesRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillScanRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillSortRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillUnionAllRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillValuesRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.logical.DrillWindowRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.ConvertCountToDirectScan
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.DirectScanPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.FilterPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.HashAggPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.HashJoinPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.LimitPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.LimitUnionExchangeTransposeRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.MergeJoinPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.NestedLoopJoinPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.ProjectPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.PushLimitToTopN
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.ScanPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.ScreenPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.SortPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.StreamAggPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.UnionAllPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.UnionDistinctPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.ValuesPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.WindowPrule
 
onMatch(RelOptRuleCall) - Method in class org.apache.drill.exec.planner.physical.WriterPrule
 
onMessage(REQUEST, DrillBuf) - Method in interface org.apache.drill.exec.rpc.control.Controller.CustomMessageHandler
Handle an incoming message.
OPEN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
open(Path, int) - Method in class org.apache.drill.exec.store.ClassPathFileSystem
 
open(Path, int) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
If OperatorStats are provided return a instrumented FSDataInputStream.
open(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
If OperatorStats are provided return a instrumented FSDataInputStream.
open(Path, int) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem
 
openBinary(JPackage, String) - Method in class org.apache.drill.exec.expr.SingleClassStringWriter
 
OpenFileTracker - Interface in org.apache.drill.exec.store.dfs
Interface to track opening and closing of files.
openForInput(String) - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet
 
openForOutput(String) - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet
 
openPossiblyCompressedStream(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
openSource(JPackage, String) - Method in class org.apache.drill.exec.expr.SingleClassStringWriter
 
operator - Variable in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
OPERATOR - Static variable in class org.apache.drill.exec.planner.sql.parser.SqlCreateFunction
 
OPERATOR - Static variable in class org.apache.drill.exec.planner.sql.parser.SqlCreateTable
 
OPERATOR - Static variable in class org.apache.drill.exec.planner.sql.parser.SqlCreateView
 
OPERATOR - Static variable in class org.apache.drill.exec.planner.sql.parser.SqlDescribeSchema
 
OPERATOR - Static variable in class org.apache.drill.exec.planner.sql.parser.SqlDescribeTable
 
OPERATOR - Static variable in class org.apache.drill.exec.planner.sql.parser.SqlDropFunction
 
OPERATOR - Static variable in class org.apache.drill.exec.planner.sql.parser.SqlDropTable
 
OPERATOR - Static variable in class org.apache.drill.exec.planner.sql.parser.SqlDropView
 
OPERATOR - Static variable in class org.apache.drill.exec.planner.sql.parser.SqlRefreshMetadata
 
OPERATOR - Static variable in class org.apache.drill.exec.planner.sql.parser.SqlShowFiles
 
OPERATOR - Static variable in class org.apache.drill.exec.planner.sql.parser.SqlShowSchemas
 
OPERATOR - Static variable in class org.apache.drill.exec.planner.sql.parser.SqlShowTables
 
OPERATOR - Static variable in class org.apache.drill.exec.planner.sql.parser.SqlUseSchema
 
OPERATOR_COLUMNS - Static variable in class org.apache.drill.exec.server.rest.profile.OperatorWrapper
 
OPERATOR_COLUMNS_TOOLTIP - Static variable in class org.apache.drill.exec.server.rest.profile.OperatorWrapper
 
OperatorContext - Interface in org.apache.drill.exec.ops
Per-operator services available for operator implementations.
OperatorCreatorRegistry - Class in org.apache.drill.exec.physical.impl
 
OperatorCreatorRegistry(ScanResult) - Constructor for class org.apache.drill.exec.physical.impl.OperatorCreatorRegistry
 
operatorId - Variable in class org.apache.drill.exec.ops.OperatorStats
 
operatorId - Variable in class org.apache.drill.exec.ops.OpProfileDef
 
OperatorIdVisitor - Class in org.apache.drill.exec.planner.fragment.contrib
Visitor to renumber operators - needed after materialization is done as some operators may be removed using @ExtendedMaterializerVisitor
OperatorMetricRegistry - Class in org.apache.drill.exec.ops
Registry of operator metrics.
OperatorPathBuilder - Class in org.apache.drill.exec.server.rest.profile
 
OperatorPathBuilder() - Constructor for class org.apache.drill.exec.server.rest.profile.OperatorPathBuilder
 
OPERATORS_OVERVIEW_COLUMNS - Static variable in class org.apache.drill.exec.server.rest.profile.OperatorWrapper
 
OPERATORS_OVERVIEW_COLUMNS_TOOLTIP - Static variable in class org.apache.drill.exec.server.rest.profile.OperatorWrapper
 
OperatorStatReceiver - Interface in org.apache.drill.exec.ops
Interface for updating a statistic.
OperatorStats - Class in org.apache.drill.exec.ops
 
OperatorStats(OpProfileDef, BufferAllocator) - Constructor for class org.apache.drill.exec.ops.OperatorStats
 
OperatorStats(OperatorStats, boolean) - Constructor for class org.apache.drill.exec.ops.OperatorStats
Copy constructor to be able to create a copy of existing stats object shell and use it independently this is useful if stats have to be updated in different threads, since it is not really possible to update such stats as waitNanos, setupNanos and processingNanos across threads
operatorType - Variable in class org.apache.drill.exec.ops.OperatorStats
 
operatorType - Variable in class org.apache.drill.exec.ops.OpProfileDef
 
OperatorUtilities - Class in org.apache.drill.exec.ops
Utility methods, formerly on the OperatorContext class, that work with operators.
OperatorWrapper - Class in org.apache.drill.exec.server.rest.profile
Wrapper class for profiles of ALL operator instances of the same operator type within a major fragment.
OperatorWrapper(int, List<ImmutablePair<ImmutablePair<UserBitShared.OperatorProfile, Integer>, String>>) - Constructor for class org.apache.drill.exec.server.rest.profile.OperatorWrapper
 
operPhase - Variable in class org.apache.drill.exec.planner.physical.AggPrelBase
 
oppositeMajorFragmentId - Variable in class org.apache.drill.exec.physical.base.AbstractSender
 
OpProfileDef - Class in org.apache.drill.exec.ops
 
OpProfileDef(int, int, int) - Constructor for class org.apache.drill.exec.ops.OpProfileDef
 
optimize(Optimizer.OptimizationContext, LogicalPlan) - Method in class org.apache.drill.exec.opt.BasicOptimizer
 
optimize(Optimizer.OptimizationContext, LogicalPlan) - Method in class org.apache.drill.exec.opt.IdentityOptimizer
 
optimize(Optimizer.OptimizationContext, LogicalPlan) - Method in class org.apache.drill.exec.opt.Optimizer
 
Optimizer - Class in org.apache.drill.exec.opt
 
Optimizer() - Constructor for class org.apache.drill.exec.opt.Optimizer
 
Optimizer.OptimizationContext - Interface in org.apache.drill.exec.opt
 
OPTIMIZER_IMPL_KEY - Static variable in class org.apache.drill.exec.opt.Optimizer
 
optimizerContext - Variable in class org.apache.drill.exec.store.parquet.ParquetPushDownFilter
 
OptimizerException - Exception in org.apache.drill.exec.exception
 
OptimizerException(String, Throwable) - Constructor for exception org.apache.drill.exec.exception.OptimizerException
 
OptimizerException(String) - Constructor for exception org.apache.drill.exec.exception.OptimizerException
 
OptimizerRulesContext - Interface in org.apache.drill.exec.ops
 
OPTION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
OPTION_DEFAULTS_ROOT - Static variable in class org.apache.drill.exec.ExecConstants
 
OptionDefinition - Class in org.apache.drill.exec.server.options
This holds all the information about an option.
OptionDefinition(OptionValidator) - Constructor for class org.apache.drill.exec.server.options.OptionDefinition
 
OptionDefinition(OptionValidator, OptionMetaData) - Constructor for class org.apache.drill.exec.server.options.OptionDefinition
 
OptionIterator - Class in org.apache.drill.exec.store.sys
 
OptionIterator(FragmentContext, OptionIterator.Mode) - Constructor for class org.apache.drill.exec.store.sys.OptionIterator
 
OptionIterator.OptionValueWrapper - Class in org.apache.drill.exec.store.sys
Wrapper class for OptionValue to add Status
OptionIterator.OptionValueWrapper(String, OptionValue.Kind, OptionValue.AccessibleScopes, OptionValue.OptionScope, Long, String, Boolean, Double, OptionIterator.Status) - Constructor for class org.apache.drill.exec.store.sys.OptionIterator.OptionValueWrapper
 
OptionIterator.Status - Enum in org.apache.drill.exec.store.sys
 
OptionList - Class in org.apache.drill.exec.server.options
 
OptionList() - Constructor for class org.apache.drill.exec.server.options.OptionList
 
OptionManager - Interface in org.apache.drill.exec.server.options
Manager for Drill options.
optionManager - Variable in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
 
OptionMetaData - Class in org.apache.drill.exec.server.options
Contains information about the scopes in which an option can be set, and an option's visibility.
OptionMetaData(OptionValue.AccessibleScopes, boolean, boolean) - Constructor for class org.apache.drill.exec.server.options.OptionMetaData
 
options - Variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
OPTIONS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
options - Variable in class org.apache.drill.exec.server.options.InMemoryOptionManager
 
options() - Method in class org.apache.drill.exec.work.QueryWorkUnit.MinorFragmentDefn
 
optionScope - Variable in class org.apache.drill.exec.store.sys.ExtendedOptionIterator.ExtendedOptionValueWrapper
 
optionScope - Variable in class org.apache.drill.exec.store.sys.OptionIterator.OptionValueWrapper
 
OptionSet - Interface in org.apache.drill.exec.server.options
Immutable set of options accessible by name or validator.
OptionValidator - Class in org.apache.drill.exec.server.options
Validates the values provided to Drill options.
OptionValidator(String) - Constructor for class org.apache.drill.exec.server.options.OptionValidator
By default, if admin option value is not specified, it would be set to false.
OptionValue - Class in org.apache.drill.exec.server.options
An option value is used internally by an OptionManager to store a run-time setting.
OptionValue.AccessibleScopes - Enum in org.apache.drill.exec.server.options
Defines where an option can be configured.
OptionValue.Kind - Enum in org.apache.drill.exec.server.options
 
OptionValue.OptionScope - Enum in org.apache.drill.exec.server.options
This defines where an option was actually configured.
OR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ORDER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
order() - Method in class org.apache.drill.exec.record.DeadBuf
 
order(ByteOrder) - Method in class org.apache.drill.exec.record.DeadBuf
 
OrderBy(boolean) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses an ORDER BY clause.
OrderedField - Class in org.apache.drill.exec.schema
 
OrderedField(RecordSchema, TypeProtos.MajorType, String, int) - Constructor for class org.apache.drill.exec.schema.OrderedField
 
OrderedPartitionExchange - Class in org.apache.drill.exec.physical.config
 
OrderedPartitionExchange(List<Order.Ordering>, FieldReference, PhysicalOperator, Integer, Integer, Float) - Constructor for class org.apache.drill.exec.physical.config.OrderedPartitionExchange
 
OrderedPartitionExchangePrel - Class in org.apache.drill.exec.planner.physical
 
OrderedPartitionExchangePrel(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.drill.exec.planner.physical.OrderedPartitionExchangePrel
 
OrderedPartitionProjector - Interface in org.apache.drill.exec.physical.impl.orderedpartitioner
 
OrderedPartitionProjectorTemplate - Class in org.apache.drill.exec.physical.impl.orderedpartitioner
 
OrderedPartitionProjectorTemplate() - Constructor for class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionProjectorTemplate
 
OrderedPartitionRecordBatch - Class in org.apache.drill.exec.physical.impl.orderedpartitioner
The purpose of this operator is to generate an ordered partition, rather than a random hash partition.
OrderedPartitionRecordBatch(OrderedPartitionSender, RecordBatch, FragmentContext) - Constructor for class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
 
OrderedPartitionSender - Class in org.apache.drill.exec.physical.config
 
OrderedPartitionSender(List<Order.Ordering>, FieldReference, PhysicalOperator, List<MinorFragmentEndpoint>, int, int, int, int, float) - Constructor for class org.apache.drill.exec.physical.config.OrderedPartitionSender
 
OrderedPartitionSenderCreator - Class in org.apache.drill.exec.physical.impl.orderedpartitioner
 
OrderedPartitionSenderCreator() - Constructor for class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionSenderCreator
 
OrderedQueryOrExpr(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses either a row expression or a query expression with an optional ORDER BY.
ORDERING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
orderings - Variable in class org.apache.drill.exec.physical.config.Sort
 
OrderItem() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses one list item in an ORDER BY clause.
ORDINAL_POSITION - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
ORDINALITY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
org.apache.drill.common.util - package org.apache.drill.common.util
 
org.apache.drill.exec - package org.apache.drill.exec
Drill execution engine, including: physical operators, runtime code generation, planning, RPC layer, Value Vector data structures.
org.apache.drill.exec.cache - package org.apache.drill.exec.cache
Distributed cache for syncing state and data between Drillbits.
org.apache.drill.exec.client - package org.apache.drill.exec.client
Java client API for submitting queries and accepting result sets from a Drill server.
org.apache.drill.exec.compile - package org.apache.drill.exec.compile
Runtime code-generation, compilation and bytecode-manipulation utilities.
org.apache.drill.exec.compile.bytecode - package org.apache.drill.exec.compile.bytecode
Bytecode manipulation utilities for stitching together runtime-generated code with prebuilt templates.
org.apache.drill.exec.compile.sig - package org.apache.drill.exec.compile.sig
TODO - write docs for this package
org.apache.drill.exec.coord - package org.apache.drill.exec.coord
Cluster coordination system based on Apache Zookeeper and Curator.
org.apache.drill.exec.coord.local - package org.apache.drill.exec.coord.local
A single-node "cluster coordinator" used when running Drill locally.
org.apache.drill.exec.coord.store - package org.apache.drill.exec.coord.store
 
org.apache.drill.exec.coord.zk - package org.apache.drill.exec.coord.zk
Zookeeper/Curator integration code.
org.apache.drill.exec.disk - package org.apache.drill.exec.disk
Interface for Drill's interaction with the local disk to persist data temporarily during an operation.
org.apache.drill.exec.dotdrill - package org.apache.drill.exec.dotdrill
Meta-data persistence format, used for views and other cluster-wide persistent state.
org.apache.drill.exec.exception - package org.apache.drill.exec.exception
Execution-time exceptions.
org.apache.drill.exec.expr - package org.apache.drill.exec.expr
Drill expression materialization and evaluation facilities.
org.apache.drill.exec.expr.annotations - package org.apache.drill.exec.expr.annotations
 
org.apache.drill.exec.expr.fn - package org.apache.drill.exec.expr.fn
 
org.apache.drill.exec.expr.fn.impl - package org.apache.drill.exec.expr.fn.impl
 
org.apache.drill.exec.expr.fn.impl.conv - package org.apache.drill.exec.expr.fn.impl.conv
 
org.apache.drill.exec.expr.fn.impl.gaggr - package org.apache.drill.exec.expr.fn.impl.gaggr
 
org.apache.drill.exec.expr.fn.impl.gcast - package org.apache.drill.exec.expr.fn.impl.gcast
 
org.apache.drill.exec.expr.fn.interpreter - package org.apache.drill.exec.expr.fn.interpreter
 
org.apache.drill.exec.expr.fn.output - package org.apache.drill.exec.expr.fn.output
 
org.apache.drill.exec.expr.fn.registry - package org.apache.drill.exec.expr.fn.registry
 
org.apache.drill.exec.expr.stat - package org.apache.drill.exec.expr.stat
 
org.apache.drill.exec.memory - package org.apache.drill.exec.memory
 
org.apache.drill.exec.ops - package org.apache.drill.exec.ops
 
org.apache.drill.exec.opt - package org.apache.drill.exec.opt
 
org.apache.drill.exec.physical - package org.apache.drill.exec.physical
 
org.apache.drill.exec.physical.base - package org.apache.drill.exec.physical.base
 
org.apache.drill.exec.physical.config - package org.apache.drill.exec.physical.config
 
org.apache.drill.exec.physical.impl - package org.apache.drill.exec.physical.impl
 
org.apache.drill.exec.physical.impl.aggregate - package org.apache.drill.exec.physical.impl.aggregate
 
org.apache.drill.exec.physical.impl.broadcastsender - package org.apache.drill.exec.physical.impl.broadcastsender
 
org.apache.drill.exec.physical.impl.common - package org.apache.drill.exec.physical.impl.common
 
org.apache.drill.exec.physical.impl.filter - package org.apache.drill.exec.physical.impl.filter
 
org.apache.drill.exec.physical.impl.flatten - package org.apache.drill.exec.physical.impl.flatten
 
org.apache.drill.exec.physical.impl.join - package org.apache.drill.exec.physical.impl.join
 
org.apache.drill.exec.physical.impl.limit - package org.apache.drill.exec.physical.impl.limit
 
org.apache.drill.exec.physical.impl.materialize - package org.apache.drill.exec.physical.impl.materialize
 
org.apache.drill.exec.physical.impl.mergereceiver - package org.apache.drill.exec.physical.impl.mergereceiver
 
org.apache.drill.exec.physical.impl.orderedpartitioner - package org.apache.drill.exec.physical.impl.orderedpartitioner
 
org.apache.drill.exec.physical.impl.partitionsender - package org.apache.drill.exec.physical.impl.partitionsender
 
org.apache.drill.exec.physical.impl.producer - package org.apache.drill.exec.physical.impl.producer
 
org.apache.drill.exec.physical.impl.project - package org.apache.drill.exec.physical.impl.project
 
org.apache.drill.exec.physical.impl.sort - package org.apache.drill.exec.physical.impl.sort
 
org.apache.drill.exec.physical.impl.spill - package org.apache.drill.exec.physical.impl.spill
Collection of classes shared by operators that implement spill-to-disk.
org.apache.drill.exec.physical.impl.svremover - package org.apache.drill.exec.physical.impl.svremover
 
org.apache.drill.exec.physical.impl.TopN - package org.apache.drill.exec.physical.impl.TopN
 
org.apache.drill.exec.physical.impl.trace - package org.apache.drill.exec.physical.impl.trace
 
org.apache.drill.exec.physical.impl.union - package org.apache.drill.exec.physical.impl.union
 
org.apache.drill.exec.physical.impl.unorderedreceiver - package org.apache.drill.exec.physical.impl.unorderedreceiver
 
org.apache.drill.exec.physical.impl.validate - package org.apache.drill.exec.physical.impl.validate
 
org.apache.drill.exec.physical.impl.values - package org.apache.drill.exec.physical.impl.values
 
org.apache.drill.exec.physical.impl.window - package org.apache.drill.exec.physical.impl.window
 
org.apache.drill.exec.physical.impl.xsort - package org.apache.drill.exec.physical.impl.xsort
 
org.apache.drill.exec.physical.impl.xsort.managed - package org.apache.drill.exec.physical.impl.xsort.managed
 
org.apache.drill.exec.planner - package org.apache.drill.exec.planner
 
org.apache.drill.exec.planner.common - package org.apache.drill.exec.planner.common
 
org.apache.drill.exec.planner.cost - package org.apache.drill.exec.planner.cost
 
org.apache.drill.exec.planner.fragment - package org.apache.drill.exec.planner.fragment
 
org.apache.drill.exec.planner.fragment.contrib - package org.apache.drill.exec.planner.fragment.contrib
 
org.apache.drill.exec.planner.logical - package org.apache.drill.exec.planner.logical
 
org.apache.drill.exec.planner.logical.partition - package org.apache.drill.exec.planner.logical.partition
 
org.apache.drill.exec.planner.physical - package org.apache.drill.exec.planner.physical
 
org.apache.drill.exec.planner.physical.explain - package org.apache.drill.exec.planner.physical.explain
 
org.apache.drill.exec.planner.physical.visitor - package org.apache.drill.exec.planner.physical.visitor
 
org.apache.drill.exec.planner.sql - package org.apache.drill.exec.planner.sql
 
org.apache.drill.exec.planner.sql.handlers - package org.apache.drill.exec.planner.sql.handlers
 
org.apache.drill.exec.planner.sql.parser - package org.apache.drill.exec.planner.sql.parser
 
org.apache.drill.exec.planner.sql.parser.impl - package org.apache.drill.exec.planner.sql.parser.impl
 
org.apache.drill.exec.planner.torel - package org.apache.drill.exec.planner.torel
 
org.apache.drill.exec.planner.types - package org.apache.drill.exec.planner.types
 
org.apache.drill.exec.proto.helper - package org.apache.drill.exec.proto.helper
 
org.apache.drill.exec.record - package org.apache.drill.exec.record
 
org.apache.drill.exec.record.selection - package org.apache.drill.exec.record.selection
 
org.apache.drill.exec.resolver - package org.apache.drill.exec.resolver
 
org.apache.drill.exec.rpc - package org.apache.drill.exec.rpc
 
org.apache.drill.exec.rpc.control - package org.apache.drill.exec.rpc.control
 
org.apache.drill.exec.rpc.data - package org.apache.drill.exec.rpc.data
 
org.apache.drill.exec.rpc.security - package org.apache.drill.exec.rpc.security
Communication security.
org.apache.drill.exec.rpc.security.kerberos - package org.apache.drill.exec.rpc.security.kerberos
 
org.apache.drill.exec.rpc.security.plain - package org.apache.drill.exec.rpc.security.plain
 
org.apache.drill.exec.rpc.user - package org.apache.drill.exec.rpc.user
 
org.apache.drill.exec.rpc.user.security - package org.apache.drill.exec.rpc.user.security
 
org.apache.drill.exec.schema - package org.apache.drill.exec.schema
 
org.apache.drill.exec.schema.json.jackson - package org.apache.drill.exec.schema.json.jackson
 
org.apache.drill.exec.serialization - package org.apache.drill.exec.serialization
 
org.apache.drill.exec.server - package org.apache.drill.exec.server
 
org.apache.drill.exec.server.options - package org.apache.drill.exec.server.options
 
org.apache.drill.exec.server.rest - package org.apache.drill.exec.server.rest
 
org.apache.drill.exec.server.rest.auth - package org.apache.drill.exec.server.rest.auth
 
org.apache.drill.exec.server.rest.profile - package org.apache.drill.exec.server.rest.profile
 
org.apache.drill.exec.service - package org.apache.drill.exec.service
 
org.apache.drill.exec.ssl - package org.apache.drill.exec.ssl
 
org.apache.drill.exec.store - package org.apache.drill.exec.store
 
org.apache.drill.exec.store.avro - package org.apache.drill.exec.store.avro
 
org.apache.drill.exec.store.bson - package org.apache.drill.exec.store.bson
 
org.apache.drill.exec.store.dfs - package org.apache.drill.exec.store.dfs
 
org.apache.drill.exec.store.dfs.easy - package org.apache.drill.exec.store.dfs.easy
 
org.apache.drill.exec.store.direct - package org.apache.drill.exec.store.direct
 
org.apache.drill.exec.store.easy.json - package org.apache.drill.exec.store.easy.json
 
org.apache.drill.exec.store.easy.json.reader - package org.apache.drill.exec.store.easy.json.reader
 
org.apache.drill.exec.store.easy.sequencefile - package org.apache.drill.exec.store.easy.sequencefile
 
org.apache.drill.exec.store.easy.text - package org.apache.drill.exec.store.easy.text
 
org.apache.drill.exec.store.easy.text.compliant - package org.apache.drill.exec.store.easy.text.compliant
 
org.apache.drill.exec.store.httpd - package org.apache.drill.exec.store.httpd
 
org.apache.drill.exec.store.ischema - package org.apache.drill.exec.store.ischema
 
org.apache.drill.exec.store.mock - package org.apache.drill.exec.store.mock
Defines a mock data source which generates dummy test data for use in testing.
org.apache.drill.exec.store.parquet - package org.apache.drill.exec.store.parquet
 
org.apache.drill.exec.store.parquet.columnreaders - package org.apache.drill.exec.store.parquet.columnreaders
 
org.apache.drill.exec.store.parquet.stat - package org.apache.drill.exec.store.parquet.stat
 
org.apache.drill.exec.store.parquet2 - package org.apache.drill.exec.store.parquet2
 
org.apache.drill.exec.store.pcap - package org.apache.drill.exec.store.pcap
For comments on realization of this format plugin look at :
org.apache.drill.exec.store.pcap.decoder - package org.apache.drill.exec.store.pcap.decoder
 
org.apache.drill.exec.store.pcap.dto - package org.apache.drill.exec.store.pcap.dto
 
org.apache.drill.exec.store.pcap.schema - package org.apache.drill.exec.store.pcap.schema
 
org.apache.drill.exec.store.pojo - package org.apache.drill.exec.store.pojo
 
org.apache.drill.exec.store.schedule - package org.apache.drill.exec.store.schedule
 
org.apache.drill.exec.store.sys - package org.apache.drill.exec.store.sys
 
org.apache.drill.exec.store.sys.local - package org.apache.drill.exec.store.sys.local
 
org.apache.drill.exec.store.sys.store - package org.apache.drill.exec.store.sys.store
 
org.apache.drill.exec.store.sys.store.provider - package org.apache.drill.exec.store.sys.store.provider
 
org.apache.drill.exec.store.sys.zk - package org.apache.drill.exec.store.sys.zk
 
org.apache.drill.exec.store.text - package org.apache.drill.exec.store.text
 
org.apache.drill.exec.testing - package org.apache.drill.exec.testing
 
org.apache.drill.exec.testing.store - package org.apache.drill.exec.testing.store
 
org.apache.drill.exec.util - package org.apache.drill.exec.util
 
org.apache.drill.exec.util.filereader - package org.apache.drill.exec.util.filereader
 
org.apache.drill.exec.vector - package org.apache.drill.exec.vector
 
org.apache.drill.exec.vector.accessor - package org.apache.drill.exec.vector.accessor
 
org.apache.drill.exec.vector.accessor.sql - package org.apache.drill.exec.vector.accessor.sql
 
org.apache.drill.exec.vector.complex - package org.apache.drill.exec.vector.complex
 
org.apache.drill.exec.vector.complex.fn - package org.apache.drill.exec.vector.complex.fn
 
org.apache.drill.exec.vector.complex.impl - package org.apache.drill.exec.vector.complex.impl
 
org.apache.drill.exec.work - package org.apache.drill.exec.work
 
org.apache.drill.exec.work.batch - package org.apache.drill.exec.work.batch
 
org.apache.drill.exec.work.foreman - package org.apache.drill.exec.work.foreman
 
org.apache.drill.exec.work.foreman.rm - package org.apache.drill.exec.work.foreman.rm
Provides resource management and queuing support for the Drill foreman.
org.apache.drill.exec.work.fragment - package org.apache.drill.exec.work.fragment
 
org.apache.drill.exec.work.metadata - package org.apache.drill.exec.work.metadata
 
org.apache.drill.exec.work.prepare - package org.apache.drill.exec.work.prepare
 
org.apache.drill.exec.work.user - package org.apache.drill.exec.work.user
 
org.apache.parquet.hadoop - package org.apache.parquet.hadoop
 
ORIGINAL_LENGTH_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
originalType - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
originalType - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnTypeMetadata_v2
 
originalType - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnTypeMetadata_v3
 
origIndex - Variable in class org.apache.drill.exec.planner.physical.PrelUtil.DesiredField
 
OTHERS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
OUT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
OUTER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
outOfMemory - Variable in class org.apache.drill.exec.record.AbstractSingleRecordBatch
 
outOfMemory - Variable in class org.apache.drill.exec.work.batch.BaseRawBatchBuffer
 
Output - Annotation Type in org.apache.drill.exec.expr.annotations
Describes the field will provide output from the given function.
output() - Method in interface org.apache.drill.exec.expr.DrillAggFunc
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.BitAggregateErrorFunctions
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.NullableBitAggregateErrorFunctions
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.NullableVarCharAggregateErrorFunctions
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.VarCharAggregateErrorFunctions
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.BitBooleanAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.BitBooleanOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.NullableBitBooleanAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.NullableBitBooleanOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.BigIntAvg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.Float4Avg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.Float8Avg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.IntAvg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableBigIntAvg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableFloat4Avg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableFloat8Avg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableIntAvg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.IntervalAvg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.IntervalDayAvg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.IntervalYearAvg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.NullableIntervalAvg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.NullableIntervalDayAvg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.NullableIntervalYearAvg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.BigIntBitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.IntBitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableBigIntBitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableIntBitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableSmallIntBitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableTinyIntBitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt1BitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt2BitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt4BitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt8BitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.SmallIntBitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.TinyIntBitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt1BitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt2BitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt4BitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt8BitwiseAnd
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.BigIntBitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.IntBitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableBigIntBitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableIntBitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableSmallIntBitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableTinyIntBitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt1BitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt2BitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt4BitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt8BitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.SmallIntBitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.TinyIntBitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt1BitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt2BitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt4BitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt8BitwiseOr
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.BigIntCorrelation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.Float4Correlation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.Float8Correlation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.IntCorrelation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableBigIntCorrelation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableFloat4Correlation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableFloat8Correlation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableIntCorrelation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableSmallIntCorrelation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableTinyIntCorrelation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt1Correlation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt2Correlation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt4Correlation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt8Correlation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.SmallIntCorrelation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.TinyIntCorrelation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt1Correlation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt2Correlation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt4Correlation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt8Correlation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.BigIntCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.BitCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.DateCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal18CountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal28SparseCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal38SparseCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal9CountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Float4CountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Float8CountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntervalCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntervalDayCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntervalYearCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.ListCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.MapCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableBigIntCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableBitCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDateCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal18CountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal28SparseCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal38SparseCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal9CountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableFloat4CountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableFloat8CountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntervalCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntervalDayCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntervalYearCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableTimeCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableTimeStampCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableVarBinaryCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableVarCharCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedBigIntCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedBitCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDateCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal18CountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal28SparseCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal38SparseCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal9CountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedFloat4CountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedFloat8CountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntervalCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntervalDayCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntervalYearCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedListCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedMapCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedTimeCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedTimeStampCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedVarBinaryCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedVarCharCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.TimeCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.TimeStampCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.VarBinaryCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.VarCharCountFunction
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.BigIntCoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.Float4CoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.Float8CoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.IntCoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableBigIntCoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableFloat4CoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableFloat8CoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableIntCoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableSmallIntCoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableTinyIntCoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt1CoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt2CoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt4CoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt8CoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.SmallIntCoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.TinyIntCoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt1CoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt2CoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt4CoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt8CoVariancePopulation
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.BigIntCoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.Float4CoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.Float8CoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.IntCoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableBigIntCoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableFloat4CoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableFloat8CoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableIntCoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableSmallIntCoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableTinyIntCoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt1CoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt2CoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt4CoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt8CoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.SmallIntCoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.TinyIntCoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt1CoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt2CoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt4CoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt8CoVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal18Avg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal28SparseAvg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal38SparseAvg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal9Avg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal18Avg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal28SparseAvg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal38SparseAvg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal9Avg
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal18Max
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal28SparseMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal38SparseMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal9Max
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal18Max
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal28SparseMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal38SparseMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal9Max
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal18Min
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal28SparseMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal38SparseMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal9Min
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal18Min
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal28SparseMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal38SparseMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal9Min
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal18Sum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal28SparseSum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal38SparseSum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal9Sum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal18Sum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal28SparseSum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal38SparseSum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal9Sum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.DateMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.IntervalDayMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.IntervalMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.IntervalYearMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableDateMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableIntervalDayMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableIntervalMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableIntervalYearMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableTimeMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableTimeStampMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.TimeMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.TimeStampMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.BigIntMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.Float4Max
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.Float8Max
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.IntMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableBigIntMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableFloat4Max
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableFloat8Max
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableIntMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.NullableVarBinaryMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.NullableVarCharMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.VarBinaryMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.VarCharMax
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.DateMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.IntervalDayMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.IntervalMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.IntervalYearMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableDateMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableIntervalDayMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableIntervalMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableIntervalYearMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableTimeMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableTimeStampMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.TimeMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.TimeStampMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.BigIntMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.BitMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.Float4Min
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.Float8Min
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.IntMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableBigIntMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableBitMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableFloat4Min
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableFloat8Min
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableIntMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.NullableVarBinaryMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.NullableVarCharMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.VarBinaryMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.VarCharMin
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.BigIntStdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.Float4StdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.Float8StdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.IntStdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableBigIntStdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableFloat4StdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableFloat8StdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableIntStdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableSmallIntStdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableTinyIntStdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt1StdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt2StdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt4StdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt8StdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.SmallIntStdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.TinyIntStdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt1StdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt2StdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt4StdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt8StdDevPop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.BigIntStdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.Float4StdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.Float8StdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.IntStdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableBigIntStdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableFloat4StdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableFloat8StdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableIntStdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableSmallIntStdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableTinyIntStdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt1StdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt2StdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt4StdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt8StdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.SmallIntStdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.TinyIntStdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt1StdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt2StdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt4StdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt8StdDevSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.IntervalDaySum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.IntervalSum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.IntervalYearSum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.NullableIntervalDaySum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.NullableIntervalSum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.NullableIntervalYearSum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.BigIntSum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.Float4Sum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.Float8Sum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.IntSum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableBigIntSum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableFloat4Sum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableFloat8Sum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableIntSum
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.BigIntSumZero
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.BitSumZero
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.Float4SumZero
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.Float8SumZero
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.IntSumZero
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableBigIntSumZero
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableBitSumZero
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableFloat4SumZero
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableFloat8SumZero
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableIntSumZero
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.BigIntVariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.Float4VariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.Float8VariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.IntVariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableBigIntVariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableFloat4VariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableFloat8VariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableIntVariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableSmallIntVariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableTinyIntVariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt1VariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt2VariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt4VariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt8VariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.SmallIntVariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.TinyIntVariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt1VariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt2VariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt4VariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt8VariancePop
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.BigIntVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.Float4VarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.Float8VarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.IntVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableBigIntVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableFloat4VarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableFloat8VarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableIntVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableSmallIntVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableTinyIntVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt1VarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt2VarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt4VarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt8VarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.SmallIntVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.TinyIntVarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt1VarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt2VarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt4VarianceSample
 
output() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt8VarianceSample
 
OUTPUT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
OUTPUT_FORMAT_OPTION - Static variable in class org.apache.drill.exec.ExecConstants
 
OUTPUT_FORMAT_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
outputBatch - Variable in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
outputCurrentBatch() - Method in interface org.apache.drill.exec.physical.impl.aggregate.HashAggregator
 
outputCurrentBatch() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
Output the next batch from partition "nextPartitionToReturn"
outputKeys(int, VectorContainer, int, int, int) - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
 
outputKeys(int, VectorContainer, int, int, int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
OutputMutator - Interface in org.apache.drill.exec.physical.impl
Interface that allows a record reader to modify the current schema.
outputRecordKeys(int, int) - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
 
outputRecordKeys(int, int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate.BatchHolder
 
outputRecordKeysPrev(InternalBatch, int, int) - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
 
outputRecords(JoinRelType) - Method in interface org.apache.drill.exec.physical.impl.join.NestedLoopJoin
 
outputRecords(JoinRelType) - Method in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinTemplate
Main entry point for producing the output records.
outputRecordValues(int, int) - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate.BatchHolder
 
outputRecordValues(int) - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
 
outputRow(int) - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
called once for each row after we evaluate all peer rows.
outputRow(int, Partition) - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
called once for each row after we evaluate all peer rows.
OVER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
OVERLAPS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
OVERLAY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
OVERRIDING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
owner - Variable in class org.apache.drill.exec.planner.sql.handlers.ShowFilesCommandResult
 

P

Packet - Class in org.apache.drill.exec.store.pcap.decoder
 
Packet() - Constructor for class org.apache.drill.exec.store.pcap.decoder.Packet
 
packet() - Method in class org.apache.drill.exec.store.pcap.decoder.PacketDecoder
 
PACKET_PROTOCOL_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
PacketConstants - Class in org.apache.drill.exec.store.pcap.decoder
 
PacketConstants() - Constructor for class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
PacketDecoder - Class in org.apache.drill.exec.store.pcap.decoder
 
PacketDecoder(InputStream) - Constructor for class org.apache.drill.exec.store.pcap.decoder.PacketDecoder
 
PAD - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PadReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
Return type calculation implementation for functions with return type set as FunctionTemplate.ReturnType.PAD.
PadReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.PadReturnTypeInference
 
Pam4jUserAuthenticator - Class in org.apache.drill.exec.rpc.user.security
Implement UserAuthenticator based on Pluggable Authentication Module (PAM) configuration.
Pam4jUserAuthenticator() - Constructor for class org.apache.drill.exec.rpc.user.security.Pam4jUserAuthenticator
 
PAM_AUTHENTICATOR_PROFILES - Static variable in class org.apache.drill.exec.ExecConstants
 
PamUserAuthenticator - Class in org.apache.drill.exec.rpc.user.security
Implement UserAuthenticator based on Pluggable Authentication Module (PAM) configuration.
PamUserAuthenticator() - Constructor for class org.apache.drill.exec.rpc.user.security.PamUserAuthenticator
 
ParallelizationInfo - Class in org.apache.drill.exec.planner.fragment
Captures parallelization parameters for a given operator/fragments.
ParallelizationInfo.ParallelizationInfoCollector - Class in org.apache.drill.exec.planner.fragment
Collects/merges one or more ParallelizationInfo instances.
ParallelizationInfo.ParallelizationInfoCollector() - Constructor for class org.apache.drill.exec.planner.fragment.ParallelizationInfo.ParallelizationInfoCollector
 
ParallelizationParameters - Interface in org.apache.drill.exec.planner.fragment
Interface to implement for passing parameters to FragmentParallelizer.
parallelizeFragment(Wrapper, ParallelizationParameters, Collection<CoordinationProtos.DrillbitEndpoint>) - Method in interface org.apache.drill.exec.planner.fragment.FragmentParallelizer
Parallelize the given fragment.
parallelizeFragment(Wrapper, ParallelizationParameters, Collection<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.planner.fragment.HardAffinityFragmentParallelizer
 
parallelizeFragment(Wrapper, ParallelizationParameters, Collection<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.planner.fragment.SoftAffinityFragmentParallelizer
 
Param - Annotation Type in org.apache.drill.exec.expr.annotations
Marker annotation to determine which fields should be included as parameters for the function.
PARAMETER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PARAMETER_MODE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PARAMETER_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PARAMETER_ORDINAL_POSITION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PARAMETER_SPECIFIC_CATALOG - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PARAMETER_SPECIFIC_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PARAMETER_SPECIFIC_SCHEMA - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
parent - Variable in class org.apache.drill.exec.compile.ClassTransformer.ClassSet
 
ParenthesizedExpression(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a parenthesized query or single row expression.
ParenthesizedQueryOrCommaList(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a parenthesized query or comma-list of row expressions.
ParenthesizedSimpleIdentifierList() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
List of simple identifiers in parentheses.
PARQUET_BLOCK_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_BLOCK_SIZE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_COLUMNREADER_ASYNC - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_COLUMNREADER_ASYNC_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_DICT_PAGE_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_DICT_PAGE_SIZE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_NEW_RECORD_READER - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_PAGE_MAX_SIZE - Static variable in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
PARQUET_PAGE_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_PAGE_SIZE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_PAGEREADER_ASYNC - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_PAGEREADER_ASYNC_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_PAGEREADER_BUFFER_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_PAGEREADER_BUFFER_SIZE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_PAGEREADER_ENFORCETOTALSIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_PAGEREADER_ENFORCETOTALSIZE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_PAGEREADER_QUEUE_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_PAGEREADER_QUEUE_SIZE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_PAGEREADER_USE_BUFFERED_READ - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_PAGEREADER_USE_BUFFERED_READ_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_PAGEREADER_USE_FADVISE - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_PAGEREADER_USE_FADVISE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_READER_INT96_AS_TIMESTAMP - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_READER_INT96_AS_TIMESTAMP_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_RECORD_READER_IMPLEMENTATION_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_ROWGROUP_FILTER_PUSHDOWN_PLANNING - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
PARQUET_ROWGROUP_FILTER_PUSHDOWN_PLANNING_KEY - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
PARQUET_ROWGROUP_FILTER_PUSHDOWN_PLANNING_THRESHOLD - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
PARQUET_ROWGROUP_FILTER_PUSHDOWN_PLANNING_THRESHOLD_KEY - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
PARQUET_VECTOR_FILL_CHECK_THRESHOLD - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_VECTOR_FILL_CHECK_THRESHOLD_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_VECTOR_FILL_THRESHOLD - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_VECTOR_FILL_THRESHOLD_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_WRITER_COMPRESSION_TYPE - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_WRITER_COMPRESSION_TYPE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_WRITER_ENABLE_DICTIONARY_ENCODING - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_WRITER_ENABLE_DICTIONARY_ENCODING_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_WRITER_USE_SINGLE_FS_BLOCK - Static variable in class org.apache.drill.exec.ExecConstants
 
PARQUET_WRITER_USE_SINGLE_FS_BLOCK_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
ParquetColumnChunkPageWriteStore - Class in org.apache.parquet.hadoop
This is a copy of ColumnChunkPageWriteStore from parquet library except of OutputStream that is used here.
ParquetColumnChunkPageWriteStore(CodecFactory.BytesCompressor, MessageType, int, int, ByteBufferAllocator) - Constructor for class org.apache.parquet.hadoop.ParquetColumnChunkPageWriteStore
 
ParquetColumnMetadata - Class in org.apache.drill.exec.store.parquet.columnreaders
Represents a single column read from the Parquet file by the record reader.
ParquetColumnMetadata(ColumnDescriptor) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.ParquetColumnMetadata
 
ParquetDirectByteBufferAllocator - Class in org.apache.drill.exec.store.parquet
ByteBufferAllocator implementation that uses Drill's BufferAllocator to allocate and release ByteBuffer objects.
To properly release an allocated ByteBuf, this class keeps track of it's corresponding ByteBuffer that was passed to the Parquet library.
ParquetDirectByteBufferAllocator(OperatorContext) - Constructor for class org.apache.drill.exec.store.parquet.ParquetDirectByteBufferAllocator
 
ParquetDirectByteBufferAllocator(BufferAllocator) - Constructor for class org.apache.drill.exec.store.parquet.ParquetDirectByteBufferAllocator
 
ParquetFilterBuilder - Class in org.apache.drill.exec.store.parquet
A visitor which visits a materialized logical expression, and build ParquetFilterPredicate If a visitXXX method returns null, that means the corresponding filter branch is not qualified for pushdown.
ParquetFilterPredicate - Interface in org.apache.drill.exec.expr.stat
 
ParquetFixedWidthDictionaryReaders - Class in org.apache.drill.exec.store.parquet.columnreaders
 
ParquetFixedWidthDictionaryReaders() - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.ParquetFixedWidthDictionaryReaders
 
ParquetFooterStatCollector - Class in org.apache.drill.exec.store.parquet.stat
 
ParquetFooterStatCollector(ParquetMetadata, int, Map<String, String>, boolean, OptionManager) - Constructor for class org.apache.drill.exec.store.parquet.stat.ParquetFooterStatCollector
 
ParquetFormatConfig - Class in org.apache.drill.exec.store.parquet
 
ParquetFormatConfig() - Constructor for class org.apache.drill.exec.store.parquet.ParquetFormatConfig
 
ParquetFormatPlugin - Class in org.apache.drill.exec.store.parquet
 
ParquetFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig) - Constructor for class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
ParquetFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig, ParquetFormatConfig) - Constructor for class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
ParquetGroupScan - Class in org.apache.drill.exec.store.parquet
 
ParquetGroupScan(String, List<ReadEntryWithPath>, StoragePluginConfig, FormatPluginConfig, StoragePluginRegistry, List<SchemaPath>, String, String, LogicalExpression) - Constructor for class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
ParquetGroupScan(String, FileSelection, ParquetFormatPlugin, List<SchemaPath>) - Constructor for class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
ParquetGroupScan(String, FileSelection, ParquetFormatPlugin, List<SchemaPath>, LogicalExpression) - Constructor for class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
ParquetGroupScan.RowGroupInfo - Class in org.apache.drill.exec.store.parquet
 
ParquetGroupScan.RowGroupInfo(String, long, long, int, long) - Constructor for class org.apache.drill.exec.store.parquet.ParquetGroupScan.RowGroupInfo
 
parquetMetadataConverter - Static variable in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
ParquetMetaStatCollector - Class in org.apache.drill.exec.store.parquet.stat
 
ParquetMetaStatCollector(Metadata.ParquetTableMetadataBase, List<? extends Metadata.ColumnMetadata>, Map<String, String>) - Constructor for class org.apache.drill.exec.store.parquet.stat.ParquetMetaStatCollector
 
ParquetOutputRecordWriter - Class in org.apache.drill.exec.store
Abstract implementation of RecordWriter interface which exposes interface: #writeHeader(List) #addField(int,String) to output the data in string format instead of implementing addField for each type holder.
ParquetOutputRecordWriter() - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
ParquetOutputRecordWriter.BigIntParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.BigIntParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.BigIntParquetConverter
 
ParquetOutputRecordWriter.BitParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.BitParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.BitParquetConverter
 
ParquetOutputRecordWriter.DateParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.DateParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.DateParquetConverter
 
ParquetOutputRecordWriter.Decimal18ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.Decimal18ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.Decimal18ParquetConverter
 
ParquetOutputRecordWriter.Decimal28DenseParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.Decimal28DenseParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.Decimal28DenseParquetConverter
 
ParquetOutputRecordWriter.Decimal28SparseParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.Decimal28SparseParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.Decimal28SparseParquetConverter
 
ParquetOutputRecordWriter.Decimal38DenseParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.Decimal38DenseParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.Decimal38DenseParquetConverter
 
ParquetOutputRecordWriter.Decimal38SparseParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.Decimal38SparseParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.Decimal38SparseParquetConverter
 
ParquetOutputRecordWriter.Decimal9ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.Decimal9ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.Decimal9ParquetConverter
 
ParquetOutputRecordWriter.Float4ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.Float4ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.Float4ParquetConverter
 
ParquetOutputRecordWriter.Float8ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.Float8ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.Float8ParquetConverter
 
ParquetOutputRecordWriter.IntervalDayParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.IntervalDayParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.IntervalDayParquetConverter
 
ParquetOutputRecordWriter.IntervalParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.IntervalParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.IntervalParquetConverter
 
ParquetOutputRecordWriter.IntervalYearParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.IntervalYearParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.IntervalYearParquetConverter
 
ParquetOutputRecordWriter.IntParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.IntParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.IntParquetConverter
 
ParquetOutputRecordWriter.NullableBigIntParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableBigIntParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableBigIntParquetConverter
 
ParquetOutputRecordWriter.NullableBitParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableBitParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableBitParquetConverter
 
ParquetOutputRecordWriter.NullableDateParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableDateParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableDateParquetConverter
 
ParquetOutputRecordWriter.NullableDecimal18ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableDecimal18ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableDecimal18ParquetConverter
 
ParquetOutputRecordWriter.NullableDecimal28DenseParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableDecimal28DenseParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableDecimal28DenseParquetConverter
 
ParquetOutputRecordWriter.NullableDecimal28SparseParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableDecimal28SparseParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableDecimal28SparseParquetConverter
 
ParquetOutputRecordWriter.NullableDecimal38DenseParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableDecimal38DenseParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableDecimal38DenseParquetConverter
 
ParquetOutputRecordWriter.NullableDecimal38SparseParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableDecimal38SparseParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableDecimal38SparseParquetConverter
 
ParquetOutputRecordWriter.NullableDecimal9ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableDecimal9ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableDecimal9ParquetConverter
 
ParquetOutputRecordWriter.NullableFloat4ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableFloat4ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableFloat4ParquetConverter
 
ParquetOutputRecordWriter.NullableFloat8ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableFloat8ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableFloat8ParquetConverter
 
ParquetOutputRecordWriter.NullableIntervalDayParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableIntervalDayParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableIntervalDayParquetConverter
 
ParquetOutputRecordWriter.NullableIntervalParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableIntervalParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableIntervalParquetConverter
 
ParquetOutputRecordWriter.NullableIntervalYearParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableIntervalYearParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableIntervalYearParquetConverter
 
ParquetOutputRecordWriter.NullableIntParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableIntParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableIntParquetConverter
 
ParquetOutputRecordWriter.NullableSmallIntParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableSmallIntParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableSmallIntParquetConverter
 
ParquetOutputRecordWriter.NullableTimeParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableTimeParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableTimeParquetConverter
 
ParquetOutputRecordWriter.NullableTimeStampParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableTimeStampParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableTimeStampParquetConverter
 
ParquetOutputRecordWriter.NullableTinyIntParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableTinyIntParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableTinyIntParquetConverter
 
ParquetOutputRecordWriter.NullableUInt1ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableUInt1ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableUInt1ParquetConverter
 
ParquetOutputRecordWriter.NullableUInt2ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableUInt2ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableUInt2ParquetConverter
 
ParquetOutputRecordWriter.NullableUInt4ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableUInt4ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableUInt4ParquetConverter
 
ParquetOutputRecordWriter.NullableUInt8ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableUInt8ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableUInt8ParquetConverter
 
ParquetOutputRecordWriter.NullableVar16CharParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableVar16CharParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableVar16CharParquetConverter
 
ParquetOutputRecordWriter.NullableVarBinaryParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableVarBinaryParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableVarBinaryParquetConverter
 
ParquetOutputRecordWriter.NullableVarCharParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.NullableVarCharParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableVarCharParquetConverter
 
ParquetOutputRecordWriter.RepeatedBigIntParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedBigIntParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedBigIntParquetConverter
 
ParquetOutputRecordWriter.RepeatedBitParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedBitParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedBitParquetConverter
 
ParquetOutputRecordWriter.RepeatedDateParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedDateParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedDateParquetConverter
 
ParquetOutputRecordWriter.RepeatedDecimal18ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedDecimal18ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedDecimal18ParquetConverter
 
ParquetOutputRecordWriter.RepeatedDecimal28DenseParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedDecimal28DenseParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedDecimal28DenseParquetConverter
 
ParquetOutputRecordWriter.RepeatedDecimal28SparseParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedDecimal28SparseParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedDecimal28SparseParquetConverter
 
ParquetOutputRecordWriter.RepeatedDecimal38DenseParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedDecimal38DenseParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedDecimal38DenseParquetConverter
 
ParquetOutputRecordWriter.RepeatedDecimal38SparseParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedDecimal38SparseParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedDecimal38SparseParquetConverter
 
ParquetOutputRecordWriter.RepeatedDecimal9ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedDecimal9ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedDecimal9ParquetConverter
 
ParquetOutputRecordWriter.RepeatedFloat4ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedFloat4ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedFloat4ParquetConverter
 
ParquetOutputRecordWriter.RepeatedFloat8ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedFloat8ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedFloat8ParquetConverter
 
ParquetOutputRecordWriter.RepeatedIntervalDayParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedIntervalDayParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedIntervalDayParquetConverter
 
ParquetOutputRecordWriter.RepeatedIntervalParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedIntervalParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedIntervalParquetConverter
 
ParquetOutputRecordWriter.RepeatedIntervalYearParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedIntervalYearParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedIntervalYearParquetConverter
 
ParquetOutputRecordWriter.RepeatedIntParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedIntParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedIntParquetConverter
 
ParquetOutputRecordWriter.RepeatedSmallIntParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedSmallIntParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedSmallIntParquetConverter
 
ParquetOutputRecordWriter.RepeatedTimeParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedTimeParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedTimeParquetConverter
 
ParquetOutputRecordWriter.RepeatedTimeStampParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedTimeStampParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedTimeStampParquetConverter
 
ParquetOutputRecordWriter.RepeatedTinyIntParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedTinyIntParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedTinyIntParquetConverter
 
ParquetOutputRecordWriter.RepeatedUInt1ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedUInt1ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedUInt1ParquetConverter
 
ParquetOutputRecordWriter.RepeatedUInt2ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedUInt2ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedUInt2ParquetConverter
 
ParquetOutputRecordWriter.RepeatedUInt4ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedUInt4ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedUInt4ParquetConverter
 
ParquetOutputRecordWriter.RepeatedUInt8ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedUInt8ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedUInt8ParquetConverter
 
ParquetOutputRecordWriter.RepeatedVar16CharParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedVar16CharParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedVar16CharParquetConverter
 
ParquetOutputRecordWriter.RepeatedVarBinaryParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedVarBinaryParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedVarBinaryParquetConverter
 
ParquetOutputRecordWriter.RepeatedVarCharParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.RepeatedVarCharParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedVarCharParquetConverter
 
ParquetOutputRecordWriter.SmallIntParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.SmallIntParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.SmallIntParquetConverter
 
ParquetOutputRecordWriter.TimeParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.TimeParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.TimeParquetConverter
 
ParquetOutputRecordWriter.TimeStampParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.TimeStampParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.TimeStampParquetConverter
 
ParquetOutputRecordWriter.TinyIntParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.TinyIntParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.TinyIntParquetConverter
 
ParquetOutputRecordWriter.UInt1ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.UInt1ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.UInt1ParquetConverter
 
ParquetOutputRecordWriter.UInt2ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.UInt2ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.UInt2ParquetConverter
 
ParquetOutputRecordWriter.UInt4ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.UInt4ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.UInt4ParquetConverter
 
ParquetOutputRecordWriter.UInt8ParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.UInt8ParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.UInt8ParquetConverter
 
ParquetOutputRecordWriter.Var16CharParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.Var16CharParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.Var16CharParquetConverter
 
ParquetOutputRecordWriter.VarBinaryParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.VarBinaryParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.VarBinaryParquetConverter
 
ParquetOutputRecordWriter.VarCharParquetConverter - Class in org.apache.drill.exec.store
 
ParquetOutputRecordWriter.VarCharParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.ParquetOutputRecordWriter.VarCharParquetConverter
 
ParquetPartitionDescriptor - Class in org.apache.drill.exec.planner
PartitionDescriptor that describes partitions based on column names instead of directory structure
ParquetPartitionDescriptor(PlannerSettings, DrillScanRel) - Constructor for class org.apache.drill.exec.planner.ParquetPartitionDescriptor
 
ParquetPartitionLocation - Class in org.apache.drill.exec.planner
 
ParquetPartitionLocation(String) - Constructor for class org.apache.drill.exec.planner.ParquetPartitionLocation
 
ParquetPredicates - Class in org.apache.drill.exec.expr.stat
 
ParquetPredicates() - Constructor for class org.apache.drill.exec.expr.stat.ParquetPredicates
 
ParquetPredicates.AndPredicate - Class in org.apache.drill.exec.expr.stat
 
ParquetPredicates.AndPredicate(String, List<LogicalExpression>, ExpressionPosition) - Constructor for class org.apache.drill.exec.expr.stat.ParquetPredicates.AndPredicate
 
ParquetPredicates.EqualPredicate - Class in org.apache.drill.exec.expr.stat
EQ (=) predicate
ParquetPredicates.EqualPredicate(LogicalExpression, LogicalExpression) - Constructor for class org.apache.drill.exec.expr.stat.ParquetPredicates.EqualPredicate
 
ParquetPredicates.GEPredicate - Class in org.apache.drill.exec.expr.stat
GE (>=) predicate.
ParquetPredicates.GEPredicate(LogicalExpression, LogicalExpression) - Constructor for class org.apache.drill.exec.expr.stat.ParquetPredicates.GEPredicate
 
ParquetPredicates.GTPredicate - Class in org.apache.drill.exec.expr.stat
GT (>) predicate.
ParquetPredicates.GTPredicate(LogicalExpression, LogicalExpression) - Constructor for class org.apache.drill.exec.expr.stat.ParquetPredicates.GTPredicate
 
ParquetPredicates.LEPredicate - Class in org.apache.drill.exec.expr.stat
LE (<=) predicate.
ParquetPredicates.LEPredicate(LogicalExpression, LogicalExpression) - Constructor for class org.apache.drill.exec.expr.stat.ParquetPredicates.LEPredicate
 
ParquetPredicates.LTPredicate - Class in org.apache.drill.exec.expr.stat
LT (<) predicate.
ParquetPredicates.LTPredicate(LogicalExpression, LogicalExpression) - Constructor for class org.apache.drill.exec.expr.stat.ParquetPredicates.LTPredicate
 
ParquetPredicates.NEPredicate - Class in org.apache.drill.exec.expr.stat
NE (!=) predicate.
ParquetPredicates.NEPredicate(LogicalExpression, LogicalExpression) - Constructor for class org.apache.drill.exec.expr.stat.ParquetPredicates.NEPredicate
 
ParquetPredicates.OrPredicate - Class in org.apache.drill.exec.expr.stat
 
ParquetPredicates.OrPredicate(String, List<LogicalExpression>, ExpressionPosition) - Constructor for class org.apache.drill.exec.expr.stat.ParquetPredicates.OrPredicate
 
ParquetPredicates.ParquetBooleanPredicate - Class in org.apache.drill.exec.expr.stat
 
ParquetPredicates.ParquetBooleanPredicate(String, List<LogicalExpression>, ExpressionPosition) - Constructor for class org.apache.drill.exec.expr.stat.ParquetPredicates.ParquetBooleanPredicate
 
ParquetPredicates.ParquetCompPredicate - Class in org.apache.drill.exec.expr.stat
 
ParquetPredicates.ParquetCompPredicate(LogicalExpression, LogicalExpression) - Constructor for class org.apache.drill.exec.expr.stat.ParquetPredicates.ParquetCompPredicate
 
ParquetPruneScanRule - Class in org.apache.drill.exec.planner.logical.partition
 
ParquetPruneScanRule() - Constructor for class org.apache.drill.exec.planner.logical.partition.ParquetPruneScanRule
 
ParquetPushDownFilter - Class in org.apache.drill.exec.store.parquet
 
parquetReaderStats - Variable in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
parquetReaderStats() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
 
ParquetReaderStats - Class in org.apache.drill.exec.store.parquet
 
ParquetReaderStats() - Constructor for class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
ParquetReaderUtility - Class in org.apache.drill.exec.store.parquet
Utility class where we can capture common logic between the two parquet readers
ParquetReaderUtility() - Constructor for class org.apache.drill.exec.store.parquet.ParquetReaderUtility
 
ParquetReaderUtility.DateCorruptionStatus - Enum in org.apache.drill.exec.store.parquet
For most recently created parquet files, we can determine if we have corrupted dates (see DRILL-4203) based on the file metadata.
ParquetReaderUtility.NanoTimeUtils - Class in org.apache.drill.exec.store.parquet
Utilities for converting from parquet INT96 binary (impala, hive timestamp) to date time value.
ParquetReaderUtility.NanoTimeUtils() - Constructor for class org.apache.drill.exec.store.parquet.ParquetReaderUtility.NanoTimeUtils
 
ParquetRecordReader - Class in org.apache.drill.exec.store.parquet.columnreaders
 
ParquetRecordReader(FragmentContext, String, int, long, FileSystem, CodecFactory, ParquetMetadata, List<SchemaPath>, ParquetReaderUtility.DateCorruptionStatus) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
ParquetRecordReader(FragmentContext, String, int, FileSystem, CodecFactory, ParquetMetadata, List<SchemaPath>, ParquetReaderUtility.DateCorruptionStatus) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
ParquetRecordReader(FragmentContext, long, long, String, int, FileSystem, CodecFactory, ParquetMetadata, List<SchemaPath>, ParquetReaderUtility.DateCorruptionStatus) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
ParquetRecordReader.Metric - Enum in org.apache.drill.exec.store.parquet.columnreaders
 
ParquetRecordWriter - Class in org.apache.drill.exec.store.parquet
 
ParquetRecordWriter(FragmentContext, ParquetWriter) - Constructor for class org.apache.drill.exec.store.parquet.ParquetRecordWriter
 
ParquetRecordWriter.MapParquetConverter - Class in org.apache.drill.exec.store.parquet
 
ParquetRecordWriter.MapParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.parquet.ParquetRecordWriter.MapParquetConverter
 
ParquetRecordWriter.RepeatedMapParquetConverter - Class in org.apache.drill.exec.store.parquet
 
ParquetRecordWriter.RepeatedMapParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.parquet.ParquetRecordWriter.RepeatedMapParquetConverter
 
ParquetRGFilterEvaluator - Class in org.apache.drill.exec.store.parquet
 
ParquetRGFilterEvaluator() - Constructor for class org.apache.drill.exec.store.parquet.ParquetRGFilterEvaluator
 
ParquetRGFilterEvaluator.FieldReferenceFinder - Class in org.apache.drill.exec.store.parquet
Search through a LogicalExpression, finding all internal schema path references and returning them in a set.
ParquetRGFilterEvaluator.FieldReferenceFinder() - Constructor for class org.apache.drill.exec.store.parquet.ParquetRGFilterEvaluator.FieldReferenceFinder
 
ParquetRowGroupScan - Class in org.apache.drill.exec.store.parquet
 
ParquetRowGroupScan(StoragePluginRegistry, String, StoragePluginConfig, FormatPluginConfig, LinkedList<RowGroupReadEntry>, List<SchemaPath>, String, LogicalExpression) - Constructor for class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
 
ParquetRowGroupScan(String, ParquetFormatPlugin, List<RowGroupReadEntry>, List<SchemaPath>, String, LogicalExpression) - Constructor for class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
 
ParquetScanBatchCreator - Class in org.apache.drill.exec.store.parquet
 
ParquetScanBatchCreator() - Constructor for class org.apache.drill.exec.store.parquet.ParquetScanBatchCreator
 
ParquetSchema - Class in org.apache.drill.exec.store.parquet.columnreaders
Mapping from the schema of the Parquet file to that of the record reader to the schema that Drill and the Parquet reader uses.
ParquetSchema(OptionManager, int, ParquetMetadata, Collection<SchemaPath>) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.ParquetSchema
Build the Parquet schema.
ParquetToDrillTypeConverter - Class in org.apache.drill.exec.store.parquet.columnreaders
 
ParquetToDrillTypeConverter() - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.ParquetToDrillTypeConverter
 
ParquetTypeHelper - Class in org.apache.drill.exec.store.parquet
 
ParquetTypeHelper() - Constructor for class org.apache.drill.exec.store.parquet.ParquetTypeHelper
 
ParquetWriter - Class in org.apache.drill.exec.store.parquet
 
ParquetWriter(PhysicalOperator, String, List<String>, StorageStrategy, StoragePluginConfig, StoragePluginRegistry) - Constructor for class org.apache.drill.exec.store.parquet.ParquetWriter
 
ParquetWriter(PhysicalOperator, String, List<String>, ParquetFormatPlugin) - Constructor for class org.apache.drill.exec.store.parquet.ParquetWriter
 
ParquetWriterBatchCreator - Class in org.apache.drill.exec.store.parquet
 
ParquetWriterBatchCreator() - Constructor for class org.apache.drill.exec.store.parquet.ParquetWriterBatchCreator
 
parse(ObjectReader, String) - Static method in class org.apache.drill.exec.physical.PhysicalPlan
Parses a physical plan.
parse(String) - Method in class org.apache.drill.exec.planner.sql.SqlConverter
 
parse(String[]) - Static method in class org.apache.drill.exec.server.StartupOptions
 
parse(String) - Method in class org.apache.drill.exec.store.httpd.HttpdParser
We do not expose the underlying parser or the record which is used to manage the writers.
parseBytesToASCII(byte[]) - Static method in class org.apache.drill.exec.store.pcap.PcapFormatUtils
 
ParseException - Exception in org.apache.drill.exec.planner.sql.parser.impl
This exception is thrown when parse errors are encountered.
ParseException(Token, int[][], String[]) - Constructor for exception org.apache.drill.exec.planner.sql.parser.impl.ParseException
This constructor is used by the method "generateParseException" in the generated parser.
ParseException() - Constructor for exception org.apache.drill.exec.planner.sql.parser.impl.ParseException
The following constructors are for use by you for whatever purpose you can think of.
ParseException(String) - Constructor for exception org.apache.drill.exec.planner.sql.parser.impl.ParseException
 
ParseOptionalFieldList(String) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses an optional field list and makes sure no field is a "*".
ParseQueryFunction - Class in org.apache.drill.exec.expr.fn.impl
 
ParseQueryFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.ParseQueryFunction
 
parser - Variable in class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
 
PARSER_WILDCARD - Static variable in class org.apache.drill.exec.store.httpd.HttpdParser
 
ParseRequiredFieldList(String) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a required field list and makes sure no field is a "*".
parserFactory() - Method in class org.apache.drill.exec.planner.sql.DrillParserConfig
 
parserFormattedFieldName(String) - Static method in class org.apache.drill.exec.store.httpd.HttpdParser
The parser deals with dots unlike Drill wanting underscores request_referer.
parseSqlExpressionEof() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
parseSqlExpressionEof() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserWithCompoundIdConverter
 
parseSqlStmtEof() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
parseSqlStmtEof() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserWithCompoundIdConverter
 
ParseUrlFunction - Class in org.apache.drill.exec.expr.fn.impl
 
ParseUrlFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.ParseUrlFunction
 
PARTIAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Partition - Class in org.apache.drill.exec.physical.impl.window
Used internally to keep track of partitions and frames.
A partition can be partial, which means we don't know "yet" the total number of records that are part of this partition.
Partition() - Constructor for class org.apache.drill.exec.physical.impl.window.Partition
 
PARTITION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PARTITION_BATCH_SIZE - Static variable in interface org.apache.drill.exec.planner.PartitionDescriptor
 
PARTITION_COMPARATOR_FIELD - Static variable in class org.apache.drill.exec.planner.physical.WriterPrel
 
PARTITION_COMPARATOR_FUNC - Static variable in class org.apache.drill.exec.planner.physical.WriterPrel
 
PARTITION_SENDER_MAX_THREADS - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
PARTITION_SENDER_SET_THREADS - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
PARTITION_SENDER_THREADS_FACTOR - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
partitionBatch(RecordBatch) - Method in interface org.apache.drill.exec.physical.impl.partitionsender.Partitioner
 
partitionBatch(RecordBatch) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerDecorator
partitionBatch - decorator method to call real Partitioner(s) to process incoming batch uses either threading or not threading approach based on number Partitioners
partitionBatch(RecordBatch) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate
 
PartitionDescriptor - Interface in org.apache.drill.exec.planner
 
PartitionedCollector - Class in org.apache.drill.exec.work.batch
 
PartitionedCollector(AtomicInteger, BitControl.Collector, FragmentContext) - Constructor for class org.apache.drill.exec.work.batch.PartitionedCollector
 
Partitioner - Interface in org.apache.drill.exec.physical.impl.partitionsender
 
PartitionerDecorator - Class in org.apache.drill.exec.physical.impl.partitionsender
Decorator class to hide multiple Partitioner existence from the caller since this class involves multithreaded processing of incoming batches as well as flushing it needs special handling of OperatorStats - stats since stats are not suitable for use in multithreaded environment The algorithm to figure out processing versus wait time is based on following formula: totalWaitTime = totalAllPartitionersProcessingTime - max(sum(processingTime) by partitioner)
PartitionerDecorator(List<Partitioner>, OperatorStats, FragmentContext) - Constructor for class org.apache.drill.exec.physical.impl.partitionsender.PartitionerDecorator
 
PartitionerDecorator.GeneralExecuteIface - Interface in org.apache.drill.exec.physical.impl.partitionsender
Helper interface to generalize functionality executed in the thread since it is absolutely the same for partitionBatch and flushOutgoingBatches protected is for testing purposes
PartitionerTemplate - Class in org.apache.drill.exec.physical.impl.partitionsender
 
PartitionerTemplate() - Constructor for class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate
 
PartitionerTemplate.OutgoingRecordBatch - Class in org.apache.drill.exec.physical.impl.partitionsender
 
PartitionerTemplate.OutgoingRecordBatch(OperatorStats, HashPartitionSender, AccountingDataTunnel, FragmentContext, BufferAllocator, int) - Constructor for class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
PartitionExplorer - Interface in org.apache.drill.exec.store
Exposes partition information to UDFs to allow queries to limit reading partitions dynamically.
PartitionExplorerImpl - Class in org.apache.drill.exec.store
 
PartitionExplorerImpl(SchemaPlus) - Constructor for class org.apache.drill.exec.store.PartitionExplorerImpl
 
partitionFilterPushdown() - Method in class org.apache.drill.exec.planner.logical.DrillScanRel
 
PartitionLocation - Interface in org.apache.drill.exec.planner
Interface to define a partition.
partitionMapping - Variable in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
 
PartitionNotFoundException - Exception in org.apache.drill.exec.store
 
PartitionNotFoundException() - Constructor for exception org.apache.drill.exec.store.PartitionNotFoundException
 
PartitionNotFoundException(String) - Constructor for exception org.apache.drill.exec.store.PartitionNotFoundException
 
PartitionNotFoundException(Exception) - Constructor for exception org.apache.drill.exec.store.PartitionNotFoundException
 
PartitionNotFoundException(String, Exception) - Constructor for exception org.apache.drill.exec.store.PartitionNotFoundException
 
PartitionOutgoingBatch - Interface in org.apache.drill.exec.physical.impl.partitionsender
 
PartitionRange - Class in org.apache.drill.exec.physical.config
 
PartitionRange(LogicalExpression, LogicalExpression) - Constructor for class org.apache.drill.exec.physical.config.PartitionRange
 
PartitionSenderCreator - Class in org.apache.drill.exec.physical.impl.partitionsender
 
PartitionSenderCreator() - Constructor for class org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderCreator
 
PartitionSenderRootExec - Class in org.apache.drill.exec.physical.impl.partitionsender
 
PartitionSenderRootExec(FragmentContext, RecordBatch, HashPartitionSender) - Constructor for class org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec
 
PartitionSenderRootExec.Metric - Enum in org.apache.drill.exec.physical.impl.partitionsender
 
PASCAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PASSTHROUGH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
patch() - Static method in class org.apache.drill.exec.util.GuavaPatcher
 
PATH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
path - Variable in class org.apache.drill.exec.store.dfs.ReadEntryWithPath
 
path - Variable in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v1
 
path - Variable in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v2
 
path - Variable in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v3
 
path - Variable in class org.apache.drill.exec.store.schedule.CompleteFileWork.FileWorkImpl
 
PATH_INTERNAL_OPTIONS - Static variable in class org.apache.drill.exec.server.rest.StatusResources
 
PATH_INTERNAL_OPTIONS_JSON - Static variable in class org.apache.drill.exec.server.rest.StatusResources
 
PATH_OPTIONS - Static variable in class org.apache.drill.exec.server.rest.StatusResources
 
PATH_OPTIONS_JSON - Static variable in class org.apache.drill.exec.server.rest.StatusResources
 
PATH_STATUS - Static variable in class org.apache.drill.exec.server.rest.StatusResources
 
PATH_STATUS_JSON - Static variable in class org.apache.drill.exec.server.rest.StatusResources
 
PathUtils - Class in org.apache.drill.exec.coord.zk
A convenience class used to expedite zookeeper paths manipulations.
PathUtils() - Constructor for class org.apache.drill.exec.coord.zk.PathUtils
 
patternByteBuffer - Variable in class org.apache.drill.exec.expr.fn.impl.AbstractSqlPatternMatcher
 
patternLength - Variable in class org.apache.drill.exec.expr.fn.impl.AbstractSqlPatternMatcher
 
patternString - Variable in class org.apache.drill.exec.expr.fn.impl.AbstractSqlPatternMatcher
 
pause() - Method in class org.apache.drill.exec.testing.PauseInjection
 
PauseInjection - Class in org.apache.drill.exec.testing
Injection for a single pause.
PAYLOAD_FROM_BUFFER - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
Given a buffer, this is the assumed amount of space available for data.
PCAP_HEADER_SIZE - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
PcapDrillTable - Class in org.apache.drill.exec.store.pcap
 
PcapDrillTable(String, FileSystemPlugin, String, FormatSelection) - Constructor for class org.apache.drill.exec.store.pcap.PcapDrillTable
 
PcapFormatConfig - Class in org.apache.drill.exec.store.pcap
 
PcapFormatConfig() - Constructor for class org.apache.drill.exec.store.pcap.PcapFormatConfig
 
PcapFormatPlugin - Class in org.apache.drill.exec.store.pcap
 
PcapFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig) - Constructor for class org.apache.drill.exec.store.pcap.PcapFormatPlugin
 
PcapFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig, PcapFormatConfig) - Constructor for class org.apache.drill.exec.store.pcap.PcapFormatPlugin
 
PcapFormatUtils - Class in org.apache.drill.exec.store.pcap
 
PcapFormatUtils() - Constructor for class org.apache.drill.exec.store.pcap.PcapFormatUtils
 
PcapRecordReader - Class in org.apache.drill.exec.store.pcap
 
PcapRecordReader(String, FileSystem, List<SchemaPath>) - Constructor for class org.apache.drill.exec.store.pcap.PcapRecordReader
 
PcapTypes - Enum in org.apache.drill.exec.store.pcap.schema
 
PERCENT_MEMORY_PER_QUERY - Static variable in class org.apache.drill.exec.ExecConstants
 
PERCENT_MEMORY_PER_QUERY_KEY - Static variable in class org.apache.drill.exec.ExecConstants
Alternative way to compute per-query-per-node memory as a percent of the total available system memory.
percent_rank - Variable in class org.apache.drill.exec.physical.impl.window.Partition
 
PERCENT_RANK - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PERCENTILE_CONT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PERCENTILE_DISC - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
permissions - Variable in class org.apache.drill.exec.planner.sql.handlers.ShowFilesCommandResult
 
persist() - Method in class org.apache.drill.exec.store.sys.PersistentStoreConfig.StoreConfigBuilder
 
PersistedOptionValue - Class in org.apache.drill.exec.server.options
This represents a persisted OptionValue.
PersistedOptionValue(String) - Constructor for class org.apache.drill.exec.server.options.PersistedOptionValue
 
PersistedOptionValue(OptionValue.Kind, String, Long, String, Boolean, Double) - Constructor for class org.apache.drill.exec.server.options.PersistedOptionValue
 
PersistedOptionValue.Deserializer - Class in org.apache.drill.exec.server.options
This deserializer only fetches the relevant information we care about from a store, which is the value of an option.
PersistedOptionValue.Deserializer(JavaType) - Constructor for class org.apache.drill.exec.server.options.PersistedOptionValue.Deserializer
 
PersistedOptionValue.Deserializer(StdDeserializer<?>) - Constructor for class org.apache.drill.exec.server.options.PersistedOptionValue.Deserializer
 
PERSISTENT_TABLE_UMASK - Static variable in class org.apache.drill.exec.ExecConstants
 
PERSISTENT_TABLE_UMASK_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
PersistentStore<V> - Interface in org.apache.drill.exec.store.sys
An abstraction used to store and retrieve instances of given value type.
PersistentStoreConfig<V> - Class in org.apache.drill.exec.store.sys
An abstraction for configurations that are used to create a store.
PersistentStoreConfig(String, InstanceSerializer<V>, PersistentStoreMode, int) - Constructor for class org.apache.drill.exec.store.sys.PersistentStoreConfig
 
PersistentStoreConfig.StoreConfigBuilder<V> - Class in org.apache.drill.exec.store.sys
 
PersistentStoreConfig.StoreConfigBuilder(InstanceSerializer<V>) - Constructor for class org.apache.drill.exec.store.sys.PersistentStoreConfig.StoreConfigBuilder
 
PersistentStoreMode - Enum in org.apache.drill.exec.store.sys
Defines operation mode of a PersistentStore instance.
PersistentStoreProvider - Interface in org.apache.drill.exec.store.sys
A factory used to create store instances.
PersistentStoreRegistry<C extends ClusterCoordinator> - Class in org.apache.drill.exec.store.sys
 
PersistentStoreRegistry(C, DrillConfig) - Constructor for class org.apache.drill.exec.store.sys.PersistentStoreRegistry
 
phase2AggCallList - Variable in class org.apache.drill.exec.planner.physical.AggPrelBase
 
PhysicalConfig - Annotation Type in org.apache.drill.exec.physical.impl
 
PhysicalOperator - Interface in org.apache.drill.exec.physical.base
 
PhysicalOperatorSetupException - Exception in org.apache.drill.exec.physical
 
PhysicalOperatorSetupException() - Constructor for exception org.apache.drill.exec.physical.PhysicalOperatorSetupException
 
PhysicalOperatorSetupException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.drill.exec.physical.PhysicalOperatorSetupException
 
PhysicalOperatorSetupException(String, Throwable) - Constructor for exception org.apache.drill.exec.physical.PhysicalOperatorSetupException
 
PhysicalOperatorSetupException(String) - Constructor for exception org.apache.drill.exec.physical.PhysicalOperatorSetupException
 
PhysicalOperatorSetupException(Throwable) - Constructor for exception org.apache.drill.exec.physical.PhysicalOperatorSetupException
 
PhysicalOperatorUtil - Class in org.apache.drill.exec.physical.base
 
PhysicalPlan - Class in org.apache.drill.exec.physical
 
PhysicalPlan(PlanProperties, List<PhysicalOperator>) - Constructor for class org.apache.drill.exec.physical.PhysicalPlan
 
PhysicalPlanCreator - Class in org.apache.drill.exec.planner.physical
 
PhysicalPlanCreator(QueryContext, Map<Prel, PrelSequencer.OpId>) - Constructor for class org.apache.drill.exec.planner.physical.PhysicalPlanCreator
 
PhysicalPlanReader - Class in org.apache.drill.exec.planner
 
PhysicalPlanReader(DrillConfig, ScanResult, LogicalPlanPersistence, CoordinationProtos.DrillbitEndpoint, StoragePluginRegistry) - Constructor for class org.apache.drill.exec.planner.PhysicalPlanReader
 
PhysicalVisitor<RETURN,EXTRA,EXCEP extends Throwable> - Interface in org.apache.drill.exec.physical.base
Visitor class designed to traversal of a operator tree.
PLACING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PlainFactory - Class in org.apache.drill.exec.rpc.security.plain
 
PlainFactory() - Constructor for class org.apache.drill.exec.rpc.security.plain.PlainFactory
 
PlainFactory(UserAuthenticator) - Constructor for class org.apache.drill.exec.rpc.security.plain.PlainFactory
 
plainJavaCapable(boolean) - Method in class org.apache.drill.exec.expr.CodeGenerator
Indicates that the code for this class can be generated using the "Plain Java" mechanism based on inheritance.
PLAN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
plan - Variable in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedResourceAllocator
 
planFragments(DrillbitContext, UserBitShared.QueryId, UserProtos.GetQueryPlanFragments, UserClientConnection) - Method in class org.apache.drill.exec.work.user.PlanSplitter
Method to plan the query and return list of fragments it will return query plan "as is" or split plans based on the req setting: split_plan
PLANNER_MEMORY_LIMIT - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
PlannerPhase - Enum in org.apache.drill.exec.planner
 
PlannerSettings - Class in org.apache.drill.exec.planner.physical
 
PlannerSettings(OptionManager, FunctionImplementationRegistry) - Constructor for class org.apache.drill.exec.planner.physical.PlannerSettings
 
PlannerType - Enum in org.apache.drill.exec.planner
 
PlanningSet - Class in org.apache.drill.exec.planner.fragment
 
PlanningSet() - Constructor for class org.apache.drill.exec.planner.fragment.PlanningSet
 
planQuery(UserBitShared.QueryType, String, boolean) - Method in class org.apache.drill.exec.client.DrillClient
API to just plan a query without execution
planQuery(UserProtos.GetQueryPlanFragments) - Method in class org.apache.drill.exec.rpc.user.UserClient
planQuery is an API to plan a query without query execution
PlanSplitter - Class in org.apache.drill.exec.work.user
Helper class to return PlanFragments based on the query plan or based on split query plan As of now it is only invoked once per query and therefore cheap to create PlanSplitter object on heap.
PlanSplitter() - Constructor for class org.apache.drill.exec.work.user.PlanSplitter
 
PLI - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PluggableFunctionRegistry - Interface in org.apache.drill.exec.expr.fn
 
plugin - Variable in class org.apache.drill.exec.store.dfs.BasicFormatMatcher
 
plugin - Variable in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory
 
PluginConfigWrapper - Class in org.apache.drill.exec.server.rest
 
PluginConfigWrapper(String, StoragePluginConfig) - Constructor for class org.apache.drill.exec.server.rest.PluginConfigWrapper
 
plus(RelOptCost) - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
plus() - Method in class org.apache.drill.exec.planner.sql.DynamicSchema
 
PLUS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
pointer - Variable in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
PojoDataType - Class in org.apache.drill.exec.store.pojo
This class uses reflection of a Java class to construct a RecordDataType.
PojoDataType(Class<?>) - Constructor for class org.apache.drill.exec.store.pojo.PojoDataType
 
PojoRecordReader<T> - Class in org.apache.drill.exec.store.pojo
Reads values from the given list of pojo instances.
PojoRecordReader(Class<T>, List<T>) - Constructor for class org.apache.drill.exec.store.pojo.PojoRecordReader
 
PojoWriter - Interface in org.apache.drill.exec.store.pojo
Pojo writer interface for writers based on types supported for pojo.
PojoWriters - Class in org.apache.drill.exec.store.pojo
 
PojoWriters() - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters
 
PojoWriters.BitWriter - Class in org.apache.drill.exec.store.pojo
Pojo writer for boolean.
PojoWriters.BitWriter(String) - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters.BitWriter
 
PojoWriters.DoubleWriter - Class in org.apache.drill.exec.store.pojo
Pojo writer for double.
PojoWriters.DoubleWriter(String) - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters.DoubleWriter
 
PojoWriters.EnumWriter - Class in org.apache.drill.exec.store.pojo
Pojo writer for Enum.
PojoWriters.EnumWriter(String, DrillBuf) - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters.EnumWriter
 
PojoWriters.IntWriter - Class in org.apache.drill.exec.store.pojo
Pojo writer for int.
PojoWriters.IntWriter(String) - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters.IntWriter
 
PojoWriters.LongWriter - Class in org.apache.drill.exec.store.pojo
Pojo writer for long.
PojoWriters.LongWriter(String) - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters.LongWriter
 
PojoWriters.NBigIntWriter - Class in org.apache.drill.exec.store.pojo
Pojo writer for Long.
PojoWriters.NBigIntWriter(String) - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters.NBigIntWriter
 
PojoWriters.NBooleanWriter - Class in org.apache.drill.exec.store.pojo
Pojo writer for Boolean.
PojoWriters.NBooleanWriter(String) - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters.NBooleanWriter
 
PojoWriters.NDoubleWriter - Class in org.apache.drill.exec.store.pojo
Pojo writer for Double.
PojoWriters.NDoubleWriter(String) - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters.NDoubleWriter
 
PojoWriters.NIntWriter - Class in org.apache.drill.exec.store.pojo
Pojo writer for Integer.
PojoWriters.NIntWriter(String) - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters.NIntWriter
 
PojoWriters.NTimeStampWriter - Class in org.apache.drill.exec.store.pojo
Pojo writer for Timestamp.
PojoWriters.NTimeStampWriter(String) - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters.NTimeStampWriter
 
PojoWriters.StringWriter - Class in org.apache.drill.exec.store.pojo
Pojo writer for String.
PojoWriters.StringWriter(String, DrillBuf) - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters.StringWriter
 
poll() - Method in interface org.apache.drill.exec.work.batch.BaseRawBatchBuffer.BufferQueue
 
pop() - Method in class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
 
pop() - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor.VisualizationState
 
popConfig - Variable in class org.apache.drill.exec.ops.BaseOperatorContext
 
popConfig - Variable in class org.apache.drill.exec.record.AbstractRecordBatch
 
populateDefaultValues(Map<String, OptionDefinition>, DrillConfig) - Static method in class org.apache.drill.exec.server.options.SystemOptionManager
 
populateImplicitColumns(FileWork, String) - Method in class org.apache.drill.exec.store.ColumnExplorer
Compares selection root and actual file path to determine partition columns values.
populateImplicitColumns(String, String) - Method in class org.apache.drill.exec.store.ColumnExplorer
Compares selection root and actual file path to determine partition columns values.
populatePartitionVectors(ValueVector[], List<PartitionLocation>, BitSet, Map<Integer, String>) - Method in class org.apache.drill.exec.planner.FileSystemPartitionDescriptor
 
populatePartitionVectors(ValueVector[], List<PartitionLocation>, BitSet, Map<Integer, String>) - Method in class org.apache.drill.exec.planner.ParquetPartitionDescriptor
 
populatePartitionVectors(ValueVector[], List<PartitionLocation>, BitSet, Map<Integer, String>) - Method in interface org.apache.drill.exec.planner.PartitionDescriptor
Method creates an in memory representation of all the partitions.
populatePruningVector(ValueVector, int, SchemaPath, String) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
port - Variable in class org.apache.drill.exec.testing.Injection
 
POSITION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PostfixRowOperator() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a postfix row operator like IS NOT NULL.
postPageRead() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
postPageRead() - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
 
postPageRead() - Method in class org.apache.drill.exec.store.parquet.columnreaders.NullableVarLengthValuesColumn
 
POWER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PPPoV6_IP_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
PPPoV6_TYPE - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
precedenceMap - Static variable in class org.apache.drill.exec.resolver.ResolverTypePrecedence
 
PRECEDING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PRECISION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
precision - Variable in class org.apache.drill.exec.record.MajorTypeSerDe.MajorTypeHolder
 
precision - Variable in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
precision - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnTypeMetadata_v3
 
precompiled - Variable in class org.apache.drill.exec.compile.ClassTransformer.ClassSet
 
PREFER_POJ_CONFIG - Static variable in class org.apache.drill.exec.compile.CodeCompiler
Prefer to generate code as plain Java when the code generator supports that mechanism.
preferPlainJava(boolean) - Method in class org.apache.drill.exec.expr.CodeGenerator
Identifies that this generated class should be generated via the plain Java mechanism.
prefetchFirstBatchFromBothSides() - Method in class org.apache.drill.exec.record.AbstractBinaryRecordBatch
Prefetch first batch from both inputs.
prefix - Variable in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer.ColumnSize
 
PREFIX_DELIMITER - Static variable in class org.apache.drill.exec.planner.StarColumnHelper
 
PREFIXED_STAR_COLUMN - Static variable in class org.apache.drill.exec.planner.StarColumnHelper
 
PREFIXED_STRING_LITERAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
prefixLineNumbers(String) - Method in class org.apache.drill.exec.compile.AbstractClassCompiler
 
PrefixRowOperator() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a prefix row operator like NOT.
Prel - Interface in org.apache.drill.exec.planner.physical
 
PrelFinalizable - Interface in org.apache.drill.exec.planner.sql.handlers
A marker interface that means that this node should be finalized before execution planning.
PrelSequencer - Class in org.apache.drill.exec.planner.physical.explain
 
PrelSequencer() - Constructor for class org.apache.drill.exec.planner.physical.explain.PrelSequencer
 
PrelSequencer.OpId - Class in org.apache.drill.exec.planner.physical.explain
 
PrelSequencer.OpId(int, int) - Constructor for class org.apache.drill.exec.planner.physical.explain.PrelSequencer.OpId
 
PrelUtil - Class in org.apache.drill.exec.planner.physical
 
PrelUtil() - Constructor for class org.apache.drill.exec.planner.physical.PrelUtil
 
PrelUtil.DesiredField - Class in org.apache.drill.exec.planner.physical
 
PrelUtil.DesiredField(int, String, RelDataTypeField) - Constructor for class org.apache.drill.exec.planner.physical.PrelUtil.DesiredField
 
PrelUtil.InputRefRemap - Class in org.apache.drill.exec.planner.physical
 
PrelUtil.InputRefRemap(int, int) - Constructor for class org.apache.drill.exec.planner.physical.PrelUtil.InputRefRemap
 
PrelUtil.InputRewriter - Class in org.apache.drill.exec.planner.physical
 
PrelUtil.InputRewriter(IntIntHashMap) - Constructor for class org.apache.drill.exec.planner.physical.PrelUtil.InputRewriter
 
PrelUtil.ProjectPushInfo - Class in org.apache.drill.exec.planner.physical
 
PrelUtil.ProjectPushInfo(List<SchemaPath>, ImmutableList<PrelUtil.DesiredField>) - Constructor for class org.apache.drill.exec.planner.physical.PrelUtil.ProjectPushInfo
 
PrelVisitor<RETURN,EXTRA,EXCEP extends Throwable> - Interface in org.apache.drill.exec.planner.physical.visitor
 
PrelVisualizerVisitor - Class in org.apache.drill.exec.planner.physical.visitor
Debug-time class that prints a PRel tree to the console for inspection.
PrelVisualizerVisitor() - Constructor for class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor
 
PrelVisualizerVisitor.VisualizationState - Class in org.apache.drill.exec.planner.physical.visitor
 
PrelVisualizerVisitor.VisualizationState() - Constructor for class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor.VisualizationState
 
prepare() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
PREPARE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
prepare() - Method in class org.apache.drill.exec.record.RecordIterator
buildSchema calls next() in order to read schema quikcly.
PreparedStatementProvider - Class in org.apache.drill.exec.work.prepare
Contains worker Runnable for creating a prepared statement and helper methods.
PreparedStatementProvider() - Constructor for class org.apache.drill.exec.work.prepare.PreparedStatementProvider
 
PreparedStatementProvider.PreparedStatementWorker - Class in org.apache.drill.exec.work.prepare
Runnable that creates a prepared statement for given UserProtos.CreatePreparedStatementReq and sends the response at the end.
PreparedStatementProvider.PreparedStatementWorker(UserClientConnection, UserWorker, ResponseSender, UserProtos.CreatePreparedStatementReq) - Constructor for class org.apache.drill.exec.work.prepare.PreparedStatementProvider.PreparedStatementWorker
 
preparePlainJava() - Method in class org.apache.drill.exec.expr.ClassGenerator
Prepare the generated class for use as a plain-old Java class (to be compiled by a compiler and directly loaded without a byte-code merge.
prepareSpill(long) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BufferedBatches
 
prepareSpillBatches(LinkedList<? extends BatchGroup>, int) - Static method in class org.apache.drill.exec.physical.impl.xsort.managed.SpilledRuns
 
PreProcessLogicalRel - Class in org.apache.drill.exec.planner.logical
This class rewrites all the project expression that contain convert_to/ convert_from to actual implementations.
PRESERVE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PRESERVE_ITEM - Static variable in class org.apache.drill.exec.planner.logical.DrillConditions
 
prevCharIsCR - Variable in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
prevCharIsLF - Variable in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
PRIMARY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
primitiveType - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
 
primitiveType - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnTypeMetadata_v2
 
primitiveType - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnTypeMetadata_v3
 
print(String, Prel) - Static method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor
 
printBatch(VectorAccessible) - Static method in class org.apache.drill.exec.util.BatchPrinter
 
printBatch(VectorAccessible, SelectionVector2) - Static method in class org.apache.drill.exec.util.BatchPrinter
 
printHyperBatch(VectorAccessible, SelectionVector4) - Static method in class org.apache.drill.exec.util.BatchPrinter
 
PrintingResultsListener - Class in org.apache.drill.exec.client
 
PrintingResultsListener(DrillConfig, QuerySubmitter.Format, int) - Constructor for class org.apache.drill.exec.client.PrintingResultsListener
 
printWithIds(Prel, SqlExplainLevel) - Static method in class org.apache.drill.exec.planner.physical.explain.PrelSequencer
 
PRIOR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
PriorityQueue - Interface in org.apache.drill.exec.physical.impl.TopN
 
PriorityQueueCopier - Interface in org.apache.drill.exec.physical.impl.xsort.managed
 
PriorityQueueCopier - Interface in org.apache.drill.exec.physical.impl.xsort
 
PriorityQueueCopierTemplate - Class in org.apache.drill.exec.physical.impl.xsort.managed
 
PriorityQueueCopierTemplate() - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierTemplate
 
PriorityQueueCopierTemplate - Class in org.apache.drill.exec.physical.impl.xsort
 
PriorityQueueCopierTemplate() - Constructor for class org.apache.drill.exec.physical.impl.xsort.PriorityQueueCopierTemplate
 
PriorityQueueCopierWrapper - Class in org.apache.drill.exec.physical.impl.xsort.managed
Manages a PriorityQueueCopier instance produced from code generation.
PriorityQueueCopierWrapper(OperatorContext) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierWrapper
 
PriorityQueueCopierWrapper.BatchMerger - Class in org.apache.drill.exec.physical.impl.xsort.managed
We've gathered a set of batches, each of which has been sorted.
PriorityQueueTemplate - Class in org.apache.drill.exec.physical.impl.TopN
 
PriorityQueueTemplate() - Constructor for class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
 
PRIVILEGES - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
probeAndProject() - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinProbe
 
probeAndProject() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinProbeTemplate
 
PROCEDURE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
processingNanos - Variable in class org.apache.drill.exec.ops.OperatorStats
 
processJSONException() - Method in class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
 
processPageData(int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
processPageData(int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumn
 
processPages(long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
processPagesAsync(long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
PRODUCER_CONSUMER - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
PRODUCER_CONSUMER_QUEUE_SIZE - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
ProducerConsumer - Class in org.apache.drill.exec.physical.config
 
ProducerConsumer(PhysicalOperator, int) - Constructor for class org.apache.drill.exec.physical.config.ProducerConsumer
 
ProducerConsumerBatch - Class in org.apache.drill.exec.physical.impl.producer
 
ProducerConsumerBatch(ProducerConsumer, FragmentContext, RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.producer.ProducerConsumerBatch
 
ProducerConsumerBatchCreator - Class in org.apache.drill.exec.physical.impl.producer
 
ProducerConsumerBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.producer.ProducerConsumerBatchCreator
 
ProducerConsumerPrel - Class in org.apache.drill.exec.planner.physical
 
ProducerConsumerPrel(RelNode, int) - Constructor for class org.apache.drill.exec.planner.physical.ProducerConsumerPrel
 
ProducerConsumerPrelVisitor - Class in org.apache.drill.exec.planner.physical.visitor
 
ProducerConsumerPrelVisitor(int) - Constructor for class org.apache.drill.exec.planner.physical.visitor.ProducerConsumerPrelVisitor
 
ProfileResources - Class in org.apache.drill.exec.server.rest.profile
 
ProfileResources() - Constructor for class org.apache.drill.exec.server.rest.profile.ProfileResources
 
ProfileResources.ProfileInfo - Class in org.apache.drill.exec.server.rest.profile
 
ProfileResources.ProfileInfo(DrillConfig, String, long, long, String, String, String, String, double, String) - Constructor for class org.apache.drill.exec.server.rest.profile.ProfileResources.ProfileInfo
 
ProfileResources.QProfiles - Class in org.apache.drill.exec.server.rest.profile
 
ProfileResources.QProfiles(List<ProfileResources.ProfileInfo>, List<ProfileResources.ProfileInfo>, List<String>) - Constructor for class org.apache.drill.exec.server.rest.profile.ProfileResources.QProfiles
 
PROFILES_STORE_CAPACITY - Static variable in class org.apache.drill.exec.ExecConstants
 
PROFILES_STORE_INMEMORY - Static variable in class org.apache.drill.exec.ExecConstants
 
ProfileUtil - Class in org.apache.drill.exec.server.rest.profile
 
ProfileUtil() - Constructor for class org.apache.drill.exec.server.rest.profile.ProfileUtil
 
ProfileWrapper - Class in org.apache.drill.exec.server.rest.profile
Wrapper class for a query profile, so it to be presented through web UI.
ProfileWrapper(UserBitShared.QueryProfile) - Constructor for class org.apache.drill.exec.server.rest.profile.ProfileWrapper
 
Project - Class in org.apache.drill.exec.physical.config
 
Project(List<NamedExpression>, PhysicalOperator, boolean) - Constructor for class org.apache.drill.exec.physical.config.Project
 
Project(List<NamedExpression>, PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.config.Project
 
PROJECT_CPU_COST - Static variable in class org.apache.drill.exec.planner.cost.DrillCostBase
 
ProjectAllowDupPrel - Class in org.apache.drill.exec.planner.physical
 
ProjectAllowDupPrel(RelOptCluster, RelTraitSet, RelNode, List<RexNode>, RelDataType) - Constructor for class org.apache.drill.exec.planner.physical.ProjectAllowDupPrel
 
ProjectBatchCreator - Class in org.apache.drill.exec.physical.impl.project
 
ProjectBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.project.ProjectBatchCreator
 
projectBuildRecord(int, int) - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinProbe
 
projectBuildRecord(int, int) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinProbeTemplate
 
projectedColumnName - Variable in class org.apache.drill.exec.store.parquet2.DrillParquetReader.ProjectedColumnType
 
Projector - Interface in org.apache.drill.exec.physical.impl.project
 
ProjectorTemplate - Class in org.apache.drill.exec.physical.impl.project
 
ProjectorTemplate() - Constructor for class org.apache.drill.exec.physical.impl.project.ProjectorTemplate
 
ProjectPrel - Class in org.apache.drill.exec.planner.physical
A physical Prel node for Project operator.
ProjectPrel(RelOptCluster, RelTraitSet, RelNode, List<RexNode>, RelDataType) - Constructor for class org.apache.drill.exec.planner.physical.ProjectPrel
 
ProjectPrel(RelOptCluster, RelTraitSet, RelNode, List<RexNode>, RelDataType, boolean) - Constructor for class org.apache.drill.exec.planner.physical.ProjectPrel
Constructor for ProjectPrel.
projectProbeRecord(int, int) - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinProbe
 
projectProbeRecord(int, int) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinProbeTemplate
 
ProjectPrule - Class in org.apache.drill.exec.planner.physical
 
ProjectRecordBatch - Class in org.apache.drill.exec.physical.impl.project
 
ProjectRecordBatch(Project, RecordBatch, FragmentContext) - Constructor for class org.apache.drill.exec.physical.impl.project.ProjectRecordBatch
 
projectRecords(int, int) - Method in interface org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionProjector
 
projectRecords(int, int) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionProjectorTemplate
 
projectRecords(int, int, int) - Method in interface org.apache.drill.exec.physical.impl.project.Projector
 
projectRecords(int, int, int) - Method in class org.apache.drill.exec.physical.impl.project.ProjectorTemplate
 
properties - Variable in class org.apache.drill.exec.planner.sql.handlers.DescribeSchemaHandler.DescribeSchemaResult
 
properties(Properties) - Method in class org.apache.drill.exec.ssl.SSLConfigBuilder
 
properties - Variable in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
proto() - Method in class org.apache.drill.exec.cache.DistributedCache.CacheConfigBuilder
 
ProtoSerializer<T,B extends com.google.protobuf.Message.Builder> - Class in org.apache.drill.exec.serialization
 
ProtoSerializer(Schema<B>, Schema<T>) - Constructor for class org.apache.drill.exec.serialization.ProtoSerializer
 
provide() - Method in class org.apache.drill.exec.server.rest.DrillRestServer.AnonDrillUserPrincipalProvider
 
provide() - Method in class org.apache.drill.exec.server.rest.DrillRestServer.AnonWebUserConnectionProvider
 
provide() - Method in class org.apache.drill.exec.server.rest.DrillRestServer.AuthWebUserConnectionProvider
 
provide() - Method in class org.apache.drill.exec.server.rest.DrillRestServer.DrillUserPrincipalProvider
 
Prule - Class in org.apache.drill.exec.planner.physical
 
Prule(RelOptRuleOperand, String) - Constructor for class org.apache.drill.exec.planner.physical.Prule
 
Prule(RelOptRuleOperand) - Constructor for class org.apache.drill.exec.planner.physical.Prule
 
PruneScanRule - Class in org.apache.drill.exec.planner.logical.partition
 
PruneScanRule(RelOptRuleOperand, String, OptimizerRulesContext) - Constructor for class org.apache.drill.exec.planner.logical.partition.PruneScanRule
 
PSTORE_NAME - Static variable in interface org.apache.drill.exec.store.StoragePluginRegistry
 
PUBLIC - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
purgeAndResetPriorityQueue() - Method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
Handle schema changes during execution.
push() - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor.VisualizationState
 
PushLimitToTopN - Class in org.apache.drill.exec.planner.physical
 
put(K, V) - Method in interface org.apache.drill.exec.cache.DistributedMap
 
put(K, V) - Method in interface org.apache.drill.exec.cache.DistributedMultiMap
 
put(String, V) - Method in class org.apache.drill.exec.coord.local.MapBackedStore
 
put(String, V) - Method in interface org.apache.drill.exec.coord.store.TransientStore
Stores the given (key, value) in this store overriding the existing value.
put(String, V) - Method in class org.apache.drill.exec.coord.zk.ZkEphemeralStore
 
put(String, byte[]) - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
Puts the given byte sequence into the given path.
put(String, byte[], DataChangeVersion) - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
Puts the given byte sequence into the given path.
put(int, IndexPointer, int) - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
 
put(int, IndexPointer, int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
put() uses the hash code (from gethashCode() above) to insert the key(s) from the incoming row into the hash table.
put(KEY, VALUE) - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
put(String, V, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.BasePersistentStore
By default put with version will behave the same way as without version.
put(String, V) - Method in interface org.apache.drill.exec.store.sys.PersistentStore
Stores the (key, value) tuple in the store.
put(String, V, DataChangeVersion) - Method in interface org.apache.drill.exec.store.sys.PersistentStore
Stores the (key, value) tuple in the store.
put(String, V) - Method in class org.apache.drill.exec.store.sys.store.InMemoryStore
 
put(String, V, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.store.InMemoryStore
 
put(String, V) - Method in class org.apache.drill.exec.store.sys.store.LocalPersistentStore
 
put(String, V, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.store.LocalPersistentStore
 
put(String, V) - Method in class org.apache.drill.exec.store.sys.store.ZookeeperPersistentStore
 
put(String, V, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.store.ZookeeperPersistentStore
 
put(String, V) - Method in class org.apache.drill.exec.testing.store.NoWriteLocalStore
 
put(String, V, DataChangeVersion) - Method in class org.apache.drill.exec.testing.store.NoWriteLocalStore
 
put(int, int) - Method in class org.apache.drill.exec.util.ArrayWrappedIntIntMap
 
putAll(Map<? extends KEY, ? extends VALUE>) - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
putIfAbsent(K, V) - Method in interface org.apache.drill.exec.cache.DistributedMap
 
putIfAbsent(K, V, long, TimeUnit) - Method in interface org.apache.drill.exec.cache.DistributedMap
 
putIfAbsent(String, V) - Method in class org.apache.drill.exec.coord.local.MapBackedStore
 
putIfAbsent(String, V) - Method in interface org.apache.drill.exec.coord.store.TransientStore
Stores the given (key, value) tuple in this store only if it does not exists.
putIfAbsent(String, V) - Method in class org.apache.drill.exec.coord.zk.ZkEphemeralStore
 
putIfAbsent(String, byte[]) - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
Puts the given byte sequence into the given path if path is does not exist.
putIfAbsent(KEY, VALUE) - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
putIfAbsent(String, V) - Method in interface org.apache.drill.exec.store.sys.PersistentStore
Stores the (key, value) tuple in the store only if it does not exists.
putIfAbsent(String, V) - Method in class org.apache.drill.exec.store.sys.store.InMemoryStore
 
putIfAbsent(String, V) - Method in class org.apache.drill.exec.store.sys.store.LocalPersistentStore
 
putIfAbsent(String, V) - Method in class org.apache.drill.exec.store.sys.store.ZookeeperPersistentStore
 
putIfAbsent(String, V) - Method in class org.apache.drill.exec.testing.store.NoWriteLocalStore
 

Q

qualifyPartitionCol(RelNode, List<String>) - Static method in class org.apache.drill.exec.planner.sql.handlers.SqlHandlerUtil
Resolve the partition columns specified in "PARTITION BY" clause of CTAS statement.
QUERY_PROFILE_DEBUG_OPTION - Static variable in class org.apache.drill.exec.ExecConstants
Profiles are normally written after the last client message to reduce latency.
QUERY_PROFILE_DEBUG_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
QUERY_TRANSIENT_STATE_UPDATE - Static variable in class org.apache.drill.exec.ExecConstants
 
QUERY_TRANSIENT_STATE_UPDATE_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
QueryClassLoader - Class in org.apache.drill.exec.compile
Per-compilation unit class loader that holds both caching and compilation steps.
QueryClassLoader(DrillConfig, OptionSet) - Constructor for class org.apache.drill.exec.compile.QueryClassLoader
 
queryCompleted(UserBitShared.QueryResult.QueryState) - Method in class org.apache.drill.exec.client.PrintingResultsListener
 
queryCompleted(UserBitShared.QueryResult.QueryState) - Method in class org.apache.drill.exec.rpc.user.AwaitableUserResultsListener
 
queryCompleted(UserBitShared.QueryResult.QueryState) - Method in interface org.apache.drill.exec.rpc.user.UserResultsListener
The query has completed (successsful completion or cancellation).
QueryContext - Class in org.apache.drill.exec.ops
 
QueryContext(UserSession, DrillbitContext, UserBitShared.QueryId) - Constructor for class org.apache.drill.exec.ops.QueryContext
 
queryContext - Variable in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedResourceAllocator
 
queryCost - Variable in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedResourceAllocator
 
QueryDataBatch - Class in org.apache.drill.exec.rpc.user
 
QueryDataBatch(UserBitShared.QueryData, DrillBuf) - Constructor for class org.apache.drill.exec.rpc.user.QueryDataBatch
 
queryId() - Method in exception org.apache.drill.exec.work.foreman.rm.QueryQueue.QueueTimeoutException
 
queryIdArrived(UserBitShared.QueryId) - Method in class org.apache.drill.exec.client.PrintingResultsListener
 
queryIdArrived(UserBitShared.QueryId) - Method in class org.apache.drill.exec.rpc.user.AwaitableUserResultsListener
 
queryIdArrived(UserBitShared.QueryId) - Method in interface org.apache.drill.exec.rpc.user.UserResultsListener
QueryId is available.
QueryIdHelper - Class in org.apache.drill.exec.proto.helper
 
QueryIdHelper() - Constructor for class org.apache.drill.exec.proto.helper.QueryIdHelper
 
QueryInputException - Exception in org.apache.drill.exec.planner.sql
 
QueryInputException() - Constructor for exception org.apache.drill.exec.planner.sql.QueryInputException
 
QueryInputException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.drill.exec.planner.sql.QueryInputException
 
QueryInputException(String, Throwable) - Constructor for exception org.apache.drill.exec.planner.sql.QueryInputException
 
QueryInputException(String) - Constructor for exception org.apache.drill.exec.planner.sql.QueryInputException
 
QueryInputException(Throwable) - Constructor for exception org.apache.drill.exec.planner.sql.QueryInputException
 
QueryManager - Class in org.apache.drill.exec.work.foreman
Each Foreman holds its own QueryManager.
QueryManager(UserBitShared.QueryId, UserProtos.RunQuery, PersistentStoreProvider, ClusterCoordinator, Foreman) - Constructor for class org.apache.drill.exec.work.foreman.QueryManager
 
queryMemoryPerNode() - Method in class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue.EmbeddedQueueLease
 
queryMemoryPerNode() - Method in interface org.apache.drill.exec.work.foreman.rm.QueryQueue.QueueLease
 
queryMemoryPerNode() - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedQueryResourceManager
 
queryMemoryPerNode() - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedResourceAllocator
 
QueryOptionManager - Class in org.apache.drill.exec.server.options
OptionManager that holds options within QueryContext.
QueryOptionManager(OptionManager) - Constructor for class org.apache.drill.exec.server.options.QueryOptionManager
 
QueryOrExpr(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses either a row expression or a query expression without ORDER BY.
QueryProfileStoreContext - Class in org.apache.drill.exec.server
 
QueryProfileStoreContext(DrillConfig, PersistentStoreProvider, ClusterCoordinator) - Constructor for class org.apache.drill.exec.server.QueryProfileStoreContext
 
QueryQueue - Interface in org.apache.drill.exec.work.foreman.rm
Interface which defines a queue implementation for query queues.
QueryQueue.QueryQueueException - Exception in org.apache.drill.exec.work.foreman.rm
Exception thrown for all non-timeout error conditions.
QueryQueue.QueueLease - Interface in org.apache.drill.exec.work.foreman.rm
The opaque lease returned once a query is admitted for execution.
QueryQueue.QueueTimeoutException - Exception in org.apache.drill.exec.work.foreman.rm
Exception thrown if a query exceeds the configured wait time in the query queue.
QueryQueue.QueueTimeoutException(UserBitShared.QueryId, String, int) - Constructor for exception org.apache.drill.exec.work.foreman.rm.QueryQueue.QueueTimeoutException
 
QueryResourceAllocator - Interface in org.apache.drill.exec.work.foreman.rm
Manages resources for an individual query in conjunction with the global ResourceManager.
QueryResourceManager - Interface in org.apache.drill.exec.work.foreman.rm
Extends a QueryResourceAllocator to provide queueing support.
QueryResources - Class in org.apache.drill.exec.server.rest
 
QueryResources() - Constructor for class org.apache.drill.exec.server.rest.QueryResources
 
QueryResources.TabularResult - Class in org.apache.drill.exec.server.rest
 
QueryResources.TabularResult(QueryWrapper.QueryResult) - Constructor for class org.apache.drill.exec.server.rest.QueryResources.TabularResult
 
QueryResultHandler - Class in org.apache.drill.exec.rpc.user
Encapsulates the future management of query submissions.
QueryResultHandler() - Constructor for class org.apache.drill.exec.rpc.user.QueryResultHandler
 
QuerySubmitter - Class in org.apache.drill.exec.client
 
QuerySubmitter() - Constructor for class org.apache.drill.exec.client.QuerySubmitter
 
QuerySubmitter.Format - Enum in org.apache.drill.exec.client
 
QueryWorkUnit - Class in org.apache.drill.exec.work
 
QueryWorkUnit(FragmentRoot, QueryWorkUnit.MinorFragmentDefn, List<QueryWorkUnit.MinorFragmentDefn>) - Constructor for class org.apache.drill.exec.work.QueryWorkUnit
 
QueryWorkUnit.MinorFragmentDefn - Class in org.apache.drill.exec.work
Definition of a minor fragment that contains the (unserialized) fragment operator tree and the (partially built) fragment.
QueryWorkUnit.MinorFragmentDefn(BitControl.PlanFragment, FragmentRoot, OptionList) - Constructor for class org.apache.drill.exec.work.QueryWorkUnit.MinorFragmentDefn
 
QueryWrapper - Class in org.apache.drill.exec.server.rest
 
QueryWrapper(String, String) - Constructor for class org.apache.drill.exec.server.rest.QueryWrapper
 
QueryWrapper.QueryResult - Class in org.apache.drill.exec.server.rest
 
QueryWrapper.QueryResult(Collection<String>, List<Map<String, String>>) - Constructor for class org.apache.drill.exec.server.rest.QueryWrapper.QueryResult
 
QueryWritableBatch - Class in org.apache.drill.exec.physical.impl.materialize
 
QueryWritableBatch(UserBitShared.QueryData, ByteBuf...) - Constructor for class org.apache.drill.exec.physical.impl.materialize.QueryWritableBatch
 
queue() - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager
 
QUEUE_MEMORY_RATIO - Static variable in class org.apache.drill.exec.ExecConstants
 
QUEUE_MEMORY_RESERVE - Static variable in class org.apache.drill.exec.ExecConstants
 
QUEUE_SIZE - Static variable in class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue
 
QUEUE_THRESHOLD_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
QUEUE_TIMEOUT - Static variable in class org.apache.drill.exec.ExecConstants
 
queueInfo() - Method in class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
 
queueName() - Method in class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager.DefaultQueryResourceManager
 
queueName() - Method in class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue.EmbeddedQueueLease
 
queueName() - Method in interface org.apache.drill.exec.work.foreman.rm.QueryQueue.QueueLease
 
queueName() - Method in exception org.apache.drill.exec.work.foreman.rm.QueryQueue.QueueTimeoutException
 
queueName() - Method in interface org.apache.drill.exec.work.foreman.rm.QueryResourceManager
Returns the name of the queue (if any) on which the query was placed.
queueName() - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedQueryResourceManager
 
queueThreshold - Variable in class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue.ZKQueueInfo
 
QUOTE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
quote - Variable in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
QUOTED_IDENTIFIER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
QUOTED_STRING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
quotedCasing() - Method in class org.apache.drill.exec.planner.sql.DrillParserConfig
 
quoting() - Method in class org.apache.drill.exec.planner.sql.DrillParserConfig
 
QUOTING_IDENTIFIERS - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
QUOTING_IDENTIFIERS_KEY - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 

R

RANDOM_DISTRIBUTED - Static variable in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
 
RANGE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
RANGE_PARTITION_CPU_COST - Static variable in class org.apache.drill.exec.planner.cost.DrillCostBase
 
RangeExprEvaluator - Class in org.apache.drill.exec.expr.stat
 
RangeExprEvaluator(Map<SchemaPath, ColumnStatistics>, long) - Constructor for class org.apache.drill.exec.expr.stat.RangeExprEvaluator
 
RangeSender - Class in org.apache.drill.exec.physical.config
 
RangeSender(int, PhysicalOperator, List<RangeSender.EndpointPartition>) - Constructor for class org.apache.drill.exec.physical.config.RangeSender
 
RangeSender.EndpointPartition - Class in org.apache.drill.exec.physical.config
 
RangeSender.EndpointPartition(PartitionRange, CoordinationProtos.DrillbitEndpoint) - Constructor for class org.apache.drill.exec.physical.config.RangeSender.EndpointPartition
 
rank - Variable in class org.apache.drill.exec.physical.impl.window.Partition
 
RANK - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
RawBatchBuffer - Interface in org.apache.drill.exec.work.batch
A batch buffer is responsible for queuing incoming batches until a consumer is ready to receive them.
RawFragmentBatch - Class in org.apache.drill.exec.record
 
RawFragmentBatch(BitData.FragmentRecordBatch, DrillBuf, AckSender) - Constructor for class org.apache.drill.exec.record.RawFragmentBatch
 
RawFragmentBatchProvider - Interface in org.apache.drill.exec.record
 
RBRACE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
RBRACKET - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
read(DataInput) - Method in class org.apache.drill.exec.cache.CachedVectorContainer
 
read(DataInput) - Method in interface org.apache.drill.exec.cache.DrillSerializable
 
read() - Method in class org.apache.drill.exec.cache.VectorSerializer.Reader
 
read(RecordBatch) - Method in interface org.apache.drill.exec.disk.Spool
 
read(TypeProtos.MajorType, JExpression, JBlock, ClassGenerator.HoldingContainer, JCodeModel, JExpression) - Static method in class org.apache.drill.exec.expr.GetSetVectorHelper
 
read() - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingInputStream
 
read(byte[]) - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingInputStream
 
read(byte[], int, int) - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingInputStream
 
READ - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
read(long, byte[], int, int) - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
read(ByteBuffer) - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
read(ByteBufferPool, int, EnumSet<ReadOption>) - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
read() - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
read(long, byte[], int, int) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalInputStream
 
read(ByteBuffer) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalInputStream
 
read(byte[]) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalInputStream
 
read(byte[], int, int) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalInputStream
 
read() - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalInputStream
 
read(long, byte[], int, int) - Method in class org.apache.drill.exec.store.ResourceInputStream
 
read(byte[]) - Method in class org.apache.drill.exec.store.ResourceInputStream
 
read() - Method in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
Implements the read method of InputStream.
read(DrillBuf, int, int) - Method in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
Has the same contract as InputStream.read(byte[], int, int) Except with DrillBuf
read(byte[]) - Method in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
 
read(byte[], int, int) - Method in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
 
read() - Method in class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
read(DrillBuf, int, int) - Method in class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
readableBytes() - Method in class org.apache.drill.exec.record.DeadBuf
 
readAllFixedFields(long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.BatchReader
 
readAllFixedFieldsParallel(long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.BatchReader
 
readAllFixedFieldsSerial(long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.BatchReader
 
readAndStoreValueSizeInformation() - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
 
readAndStoreValueSizeInformation() - Method in class org.apache.drill.exec.store.parquet.columnreaders.NullableVarLengthValuesColumn
 
readAndStoreValueSizeInformation() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumn
 
readAndStoreValueSizeInformation() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthValuesColumn
 
readBatch() - Method in class org.apache.drill.exec.store.parquet.columnreaders.BatchReader
 
readBlockMeta(FileSystem, Path, MetadataContext, ParquetFormatConfig) - Static method in class org.apache.drill.exec.store.parquet.Metadata
Get the parquet metadata for the table by reading the metadata file
readBoolean() - Method in class org.apache.drill.exec.record.DeadBuf
 
readByte() - Method in class org.apache.drill.exec.record.DeadBuf
 
readBytes(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
readBytes(ByteBuf) - Method in class org.apache.drill.exec.record.DeadBuf
 
readBytes(ByteBuf, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
readBytes(ByteBuf, int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
readBytes(byte[]) - Method in class org.apache.drill.exec.record.DeadBuf
 
readBytes(byte[], int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
readBytes(ByteBuffer) - Method in class org.apache.drill.exec.record.DeadBuf
 
readBytes(OutputStream, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
readBytes(GatheringByteChannel, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
readChar() - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
readChar() - Method in class org.apache.drill.exec.record.DeadBuf
 
readDictionaryPage() - Method in class org.apache.parquet.hadoop.ColumnChunkIncReadStore.ColumnChunkIncPageReader
 
readDouble() - Method in class org.apache.drill.exec.record.DeadBuf
 
readEntries - Variable in class org.apache.drill.exec.store.mock.MockGroupScanPOP
The set of simulated files to scan.
readEntries - Variable in class org.apache.drill.exec.store.mock.MockSubScanPOP
 
ReadEntryFromHDFS - Class in org.apache.drill.exec.store.dfs
 
ReadEntryFromHDFS(String, long, long) - Constructor for class org.apache.drill.exec.store.dfs.ReadEntryFromHDFS
 
ReadEntryWithPath - Class in org.apache.drill.exec.store.dfs
 
ReadEntryWithPath(String) - Constructor for class org.apache.drill.exec.store.dfs.ReadEntryWithPath
 
ReadEntryWithPath() - Constructor for class org.apache.drill.exec.store.dfs.ReadEntryWithPath
 
reader(BufferAllocator, InputStream) - Static method in class org.apache.drill.exec.cache.VectorSerializer
 
reader - Variable in class org.apache.drill.exec.store.direct.DirectGroupScan
 
reader - Variable in class org.apache.drill.exec.store.EventBasedRecordWriter.FieldConverter
 
readerIndex() - Method in class org.apache.drill.exec.record.DeadBuf
 
readerIndex(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
readField(long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
readField(long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
 
readField(long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.NullableVarLengthValuesColumn
 
readField(long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthValuesColumn
 
readFields(long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLenBinaryReader
Reads as many variable length values as possible.
readFloat() - Method in class org.apache.drill.exec.record.DeadBuf
 
readFooter(Configuration, FileStatus) - Static method in class org.apache.drill.exec.store.parquet.FooterGatherer
An updated footer reader that tries to read the entire footer without knowing the length.
readFragmentLeaf(String) - Method in class org.apache.drill.exec.planner.PhysicalPlanReader
 
readFragmentRoot(String) - Method in class org.apache.drill.exec.planner.PhysicalPlanReader
 
readFromStream(InputStream) - Method in class org.apache.drill.exec.cache.AbstractStreamSerializable
 
readFromStream(InputStream) - Method in interface org.apache.drill.exec.cache.DrillSerializable
 
readFromStream(InputStream) - Method in class org.apache.drill.exec.cache.VectorAccessibleSerializable
Reads from an InputStream and parses a RecordBatchDef.
readFromStreamWithContainer(VectorContainer, InputStream) - Method in class org.apache.drill.exec.cache.VectorAccessibleSerializable
 
readFully(long, byte[], int, int) - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
readFully(long, byte[]) - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
readFully(long, byte[], int, int) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalInputStream
 
readFully(long, byte[]) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalInputStream
 
readFully(long, byte[]) - Method in class org.apache.drill.exec.store.ResourceInputStream
 
readFully(long, byte[], int, int) - Method in class org.apache.drill.exec.store.ResourceInputStream
 
readInt() - Method in class org.apache.drill.exec.record.DeadBuf
 
readIntLittleEndian(DrillBuf, int) - Static method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
readLogicalPlan(String) - Method in class org.apache.drill.exec.planner.PhysicalPlanReader
 
readLong() - Method in class org.apache.drill.exec.record.DeadBuf
 
readMedium() - Method in class org.apache.drill.exec.record.DeadBuf
 
readMetadataDirs(FileSystem, Path, MetadataContext, ParquetFormatConfig) - Static method in class org.apache.drill.exec.store.parquet.Metadata
Get the parquet metadata for all subdirectories by reading the metadata file
readPage() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
readPage() - Method in class org.apache.parquet.hadoop.ColumnChunkIncReadStore.ColumnChunkIncPageReader
 
readPageAsync() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
readPageHeader() - Method in class org.apache.drill.exec.store.parquet.ColumnDataReader
 
readPcap(InputStream, boolean, int) - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
 
readPhysicalPlan(String) - Method in class org.apache.drill.exec.planner.PhysicalPlanReader
 
readQueueSize - Variable in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
readRecords(ColumnReader<?>, long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.BatchReader.FixedWidthReader
 
readRecords(ColumnReader<?>, long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.BatchReader.MockBatchReader
 
readRecords(ColumnReader<?>, long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.BatchReader
 
readRecords(ColumnReader<?>, long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.BatchReader.VariableWidthReader
 
readRecords(int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
readRecords(int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
 
readRecordsAsync(int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
READS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
readShort() - Method in class org.apache.drill.exec.record.DeadBuf
 
readSlice(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
readState - Variable in class org.apache.drill.exec.store.parquet.columnreaders.BatchReader
 
ReadState - Class in org.apache.drill.exec.store.parquet.columnreaders
Internal state for reading from a Parquet file.
ReadState(ParquetSchema, ParquetReaderStats, long, boolean) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.ReadState
 
readUnsignedByte() - Method in class org.apache.drill.exec.record.DeadBuf
 
readUnsignedInt() - Method in class org.apache.drill.exec.record.DeadBuf
 
readUnsignedMedium() - Method in class org.apache.drill.exec.record.DeadBuf
 
readUnsignedShort() - Method in class org.apache.drill.exec.record.DeadBuf
 
readValues(long) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
readVInt(DrillBuf, int, int) - Static method in class org.apache.drill.exec.util.ByteBufUtil.HadoopWritables
Reads a zero-compressed encoded integer from input stream and returns it.
readVLong(DrillBuf, int, int) - Static method in class org.apache.drill.exec.util.ByteBufUtil.HadoopWritables
Reads a zero-compressed encoded long from input stream and returns it.
REAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Receiver - Interface in org.apache.drill.exec.physical.base
A receiver is one half of an exchange operator.
receiverLocations - Variable in class org.apache.drill.exec.physical.base.AbstractExchange
 
receiverMajorFragmentId - Variable in class org.apache.drill.exec.physical.base.AbstractExchange
 
receiverToSenderMapping - Variable in class org.apache.drill.exec.physical.config.AbstractDeMuxExchange
 
receiverToSenderMapping - Variable in class org.apache.drill.exec.physical.config.AbstractMuxExchange
 
receivingFragmentFinished(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.physical.impl.BaseRootExec
 
receivingFragmentFinished(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec
 
receivingFragmentFinished(ExecProtos.FragmentHandle) - Method in interface org.apache.drill.exec.physical.impl.RootExec
Inform sender that receiving fragment is finished and doesn't need any more data
receivingFragmentFinished(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.physical.impl.SingleSenderCreator.SingleSenderRootExec
 
receivingFragmentFinished(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
receivingFragmentFinished(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.work.fragment.FragmentExecutor
Inform this fragment that one of its downstream partners no longer needs additional records.
receivingFragmentFinished(ExecProtos.FragmentHandle) - Method in interface org.apache.drill.exec.work.fragment.FragmentManager
 
receivingFragmentFinished(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.work.fragment.NonRootFragmentManager
 
receivingFragmentFinished(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.work.fragment.RootFragmentManager
 
recheckDelayMs - Variable in class org.apache.drill.exec.work.foreman.rm.DynamicResourceManager
 
reconnect() - Method in class org.apache.drill.exec.client.DrillClient
 
reconstructContainer(BufferAllocator, VectorContainer) - Method in class org.apache.drill.exec.record.WritableBatch
 
Record - Interface in org.apache.drill.exec.schema
 
RECORD_SIZE - Static variable in class org.apache.drill.exec.record.selection.SelectionVector2
 
RecordBatch - Interface in org.apache.drill.exec.record
A record batch contains a set of field values for a particular range of records.
RecordBatch.IterOutcome - Enum in org.apache.drill.exec.record
Describes the outcome of incrementing RecordBatch forward by a call to RecordBatch.next().
RecordBatchData - Class in org.apache.drill.exec.physical.impl.sort
Holds the data for a particular record batch for later manipulation.
RecordBatchData(VectorAccessible, BufferAllocator) - Constructor for class org.apache.drill.exec.physical.impl.sort.RecordBatchData
 
RecordBatchLoader - Class in org.apache.drill.exec.record
Holds record batch loaded from record batch message.
RecordBatchLoader(BufferAllocator) - Constructor for class org.apache.drill.exec.record.RecordBatchLoader
Constructs a loader using the given allocator for vector buffer allocation.
RecordBatchSizer - Class in org.apache.drill.exec.physical.impl.spill
Given a record batch or vector container, determines the actual memory consumed by each column, the average row, and the entire record batch.
RecordBatchSizer(RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
 
RecordBatchSizer(VectorAccessible) - Constructor for class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
Create empirical metadata for a record batch given a vector accessible (basically, an iterator over the vectors in the batch.)
RecordBatchSizer(VectorAccessible, SelectionVector2) - Constructor for class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
Create empirical metadata for a record batch given a vector accessible (basically, an iterator over the vectors in the batch) along with a selection vector for those records.
RecordBatchSizer.ColumnSize - Class in org.apache.drill.exec.physical.impl.spill
Column size information.
RecordBatchSizer.ColumnSize(ValueVector, String) - Constructor for class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer.ColumnSize
 
RecordDataType - Class in org.apache.drill.exec.store
RecordDataType defines names and data types of columns in a static drill table.
RecordDataType() - Constructor for class org.apache.drill.exec.store.RecordDataType
 
RecordIterator - Class in org.apache.drill.exec.record
RecordIterator iterates over incoming record batches one record at a time.
RecordIterator(RecordBatch, AbstractRecordBatch<?>, OperatorContext, int) - Constructor for class org.apache.drill.exec.record.RecordIterator
 
RecordIterator(RecordBatch, AbstractRecordBatch<?>, OperatorContext, int, boolean) - Constructor for class org.apache.drill.exec.record.RecordIterator
 
RecordMaterializer - Interface in org.apache.drill.exec.physical.impl.materialize
 
recordNewField(Field) - Method in class org.apache.drill.exec.schema.DiffSchema
 
RecordReader - Interface in org.apache.drill.exec.store
 
Records - Class in org.apache.drill.exec.store.ischema
 
Records() - Constructor for class org.apache.drill.exec.store.ischema.Records
 
records - Variable in class org.apache.drill.exec.store.pojo.AbstractPojoRecordReader
 
Records.Catalog - Class in org.apache.drill.exec.store.ischema
Pojo object for a record in INFORMATION_SCHEMA.CATALOGS
Records.Catalog(String, String, String) - Constructor for class org.apache.drill.exec.store.ischema.Records.Catalog
 
Records.Column - Class in org.apache.drill.exec.store.ischema
Pojo object for a record in INFORMATION_SCHEMA.COLUMNS
Records.Column(String, String, String, RelDataTypeField) - Constructor for class org.apache.drill.exec.store.ischema.Records.Column
 
Records.Schema - Class in org.apache.drill.exec.store.ischema
Pojo object for a record in INFORMATION_SCHEMA.SCHEMATA
Records.Schema(String, String, String, String, boolean) - Constructor for class org.apache.drill.exec.store.ischema.Records.Schema
 
Records.Table - Class in org.apache.drill.exec.store.ischema
Pojo object for a record in INFORMATION_SCHEMA.TABLES
Records.Table(String, String, String, String) - Constructor for class org.apache.drill.exec.store.ischema.Records.Table
 
Records.View - Class in org.apache.drill.exec.store.ischema
Pojo object for a record in INFORMATION_SCHEMA.VIEWS
Records.View(String, String, String, String) - Constructor for class org.apache.drill.exec.store.ischema.Records.View
 
RecordSchema - Interface in org.apache.drill.exec.schema
 
recordsRead() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
 
recordsReceivedByInput - Variable in class org.apache.drill.exec.ops.OperatorStats
 
RecordValueAccessor - Class in org.apache.drill.exec.record
Wrapper around VectorAccessible to iterate over the records and fetch fields within a record.
RecordValueAccessor(VectorAccessible) - Constructor for class org.apache.drill.exec.record.RecordValueAccessor
 
RecordWriter - Interface in org.apache.drill.exec.store
RecordWriter interface.
RECURSIVE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
REDIRECT_QUERY_PARM - Static variable in class org.apache.drill.exec.server.rest.LogInLogOutResources
 
reduce(RexBuilder, List<RexNode>, List<RexNode>) - Method in class org.apache.drill.exec.planner.logical.DrillConstExecutor
 
REF - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
refCnt() - Method in class org.apache.drill.exec.record.DeadBuf
 
REFERENCES - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
REFERENCING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
REFRESH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
RefreshMetadataHandler - Class in org.apache.drill.exec.planner.sql.handlers
 
RefreshMetadataHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.RefreshMetadataHandler
 
RegexpUtil - Class in org.apache.drill.exec.expr.fn.impl
Utilities for converting SQL LIKE and SIMILAR operators to regular expressions.
RegexpUtil() - Constructor for class org.apache.drill.exec.expr.fn.impl.RegexpUtil
 
RegexpUtil.SqlPatternInfo - Class in org.apache.drill.exec.expr.fn.impl
 
RegexpUtil.SqlPatternInfo(RegexpUtil.SqlPatternType, String, String) - Constructor for class org.apache.drill.exec.expr.fn.impl.RegexpUtil.SqlPatternInfo
 
RegexpUtil.SqlPatternType - Enum in org.apache.drill.exec.expr.fn.impl
 
register(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.coord.ClusterCoordinator
 
register(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.coord.local.LocalClusterCoordinator
 
register(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.coord.zk.ZKClusterCoordinator
 
register(DrillOperatorTable) - Method in class org.apache.drill.exec.expr.fn.FunctionImplementationRegistry
Register functions in given operator table.
register(DrillOperatorTable) - Method in interface org.apache.drill.exec.expr.fn.PluggableFunctionRegistry
Register functions in given operator table.
register(List<JarScan>, long) - Method in class org.apache.drill.exec.expr.fn.registry.LocalFunctionRegistry
Registers all functions present in jar and updates registry version.
register(DrillOperatorTable) - Method in class org.apache.drill.exec.expr.fn.registry.LocalFunctionRegistry
Registers all functions present in DrillOperatorTable, also sets sync registry version used at the moment of function registration.
register(RelOptPlanner) - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
 
registerAllocatorMetrics(BufferAllocator, String) - Method in class org.apache.drill.exec.rpc.AbstractRpcMetrics
 
registerCustomHandler(int, Controller.CustomMessageHandler<REQUEST, RESPONSE>, Parser<REQUEST>) - Method in interface org.apache.drill.exec.rpc.control.Controller
Register a new handler for custom message types.
registerCustomHandler(int, Controller.CustomMessageHandler<REQUEST, RESPONSE>, Controller.CustomSerDe<REQUEST>, Controller.CustomSerDe<RESPONSE>) - Method in interface org.apache.drill.exec.rpc.control.Controller
Register a new handler for custom message types.
registerCustomHandler(int, Controller.CustomMessageHandler<REQUEST, RESPONSE>, Parser<REQUEST>) - Method in class org.apache.drill.exec.rpc.control.ControllerImpl
 
registerCustomHandler(int, Controller.CustomMessageHandler<REQUEST, RESPONSE>, Controller.CustomSerDe<REQUEST>, Controller.CustomSerDe<RESPONSE>) - Method in class org.apache.drill.exec.rpc.control.ControllerImpl
 
registerCustomHandler(int, Controller.CustomMessageHandler<REQUEST, RESPONSE>, Controller.CustomSerDe<REQUEST>, Controller.CustomSerDe<RESPONSE>) - Method in class org.apache.drill.exec.rpc.control.CustomHandlerRegistry
 
registerSchemas(SchemaConfig, SchemaPlus) - Method in class org.apache.drill.exec.store.dfs.FileSystemPlugin
 
registerSchemas(SchemaConfig, SchemaPlus) - Method in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory
 
registerSchemas(SchemaConfig, SchemaPlus) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaStoragePlugin
 
registerSchemas(SchemaConfig, SchemaPlus) - Method in class org.apache.drill.exec.store.mock.MockBreakageStorage
 
registerSchemas(SchemaConfig, SchemaPlus) - Method in class org.apache.drill.exec.store.mock.MockStorageEngine
 
registerSchemas(SchemaConfig, SchemaPlus) - Method in interface org.apache.drill.exec.store.SchemaFactory
Register the schemas provided by this SchemaFactory implementation under the given parent schema.
registerSchemas(SchemaConfig, SchemaPlus) - Method in class org.apache.drill.exec.store.StoragePluginRegistryImpl.DrillSchemaFactory
 
registerSchemas(SchemaConfig, SchemaPlus) - Method in class org.apache.drill.exec.store.sys.SystemTablePlugin
 
registerSource(DrillTable) - Method in class org.apache.drill.exec.planner.logical.DrillImplementor
 
registerTemporaryTable(AbstractSchema, String, DrillConfig) - Method in class org.apache.drill.exec.rpc.user.UserSession
Creates and adds session temporary location if absent using schema configuration.
REGR_AVGX - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
REGR_AVGY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
REGR_COUNT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
REGR_INTERCEPT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
REGR_R2 - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
REGR_SLOPE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
REGR_SXX - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
REGR_SXY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
REGR_SYY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
reinit(RecordBatch) - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
 
reinit(RecordBatch) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
ReInit(InputStream) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
ReInit(InputStream, String) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
ReInit(Reader) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
ReInit(DrillParserImplTokenManager) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
ReInit(SimpleCharStream) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplTokenManager
 
ReInit(SimpleCharStream, int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplTokenManager
 
ReInit(Reader, int, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
ReInit(Reader, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
ReInit(Reader) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
ReInit(InputStream, String, int, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
ReInit(InputStream, int, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
ReInit(InputStream, String) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
ReInit(InputStream) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
ReInit(InputStream, String, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
ReInit(InputStream, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
RELATIVE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
RelDataTypeDrillImpl - Class in org.apache.drill.exec.planner.types
 
RelDataTypeDrillImpl(RelDataTypeHolder, RelDataTypeFactory) - Constructor for class org.apache.drill.exec.planner.types.RelDataTypeDrillImpl
 
RelDataTypeHolder - Class in org.apache.drill.exec.planner.types
 
RelDataTypeHolder() - Constructor for class org.apache.drill.exec.planner.types.RelDataTypeHolder
 
release() - Method in class org.apache.drill.exec.ops.ViewExpansionContext.ViewExpansionToken
Release the token.
RELEASE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
release() - Method in class org.apache.drill.exec.record.DeadBuf
 
release(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
release() - Method in class org.apache.drill.exec.record.RawFragmentBatch
 
release() - Method in class org.apache.drill.exec.rpc.user.QueryDataBatch
 
release(ByteBuffer) - Method in class org.apache.drill.exec.store.parquet.ParquetDirectByteBufferAllocator
 
release() - Method in class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue.EmbeddedQueueLease
 
release() - Method in interface org.apache.drill.exec.work.foreman.rm.QueryQueue.QueueLease
Release a query lease obtained from #queue(QueryId, double)).
releaseBatches(RecordBatch) - Static method in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
 
releaseBuffer(ByteBuffer) - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
reloadDrillOperatorTable() - Method in class org.apache.drill.exec.ops.QueryContext
Re-creates drill operator table to refresh functions list from local function registry.
RelOptHelper - Class in org.apache.drill.exec.planner.logical
 
RelOptHelper() - Constructor for class org.apache.drill.exec.planner.logical.RelOptHelper
 
RelUniqifier - Class in org.apache.drill.exec.planner.physical.visitor
 
RelUniqifier() - Constructor for class org.apache.drill.exec.planner.physical.visitor.RelUniqifier
 
remainder(PathSegment) - Method in class org.apache.drill.exec.record.TypedFieldId.Builder
 
REMAPPING_FLAG - Static variable in class org.apache.drill.exec.store.httpd.HttpdParser
 
RemoteFunctionRegistry - Class in org.apache.drill.exec.expr.fn.registry
Is responsible for remote function registry management.
RemoteFunctionRegistry(TransientStoreListener) - Constructor for class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
 
RemoteFunctionRegistry.Action - Enum in org.apache.drill.exec.expr.fn.registry
 
RemoteServiceSet - Class in org.apache.drill.exec.server
 
RemoteServiceSet(ClusterCoordinator) - Constructor for class org.apache.drill.exec.server.RemoteServiceSet
 
remove(String) - Method in class org.apache.drill.exec.coord.local.MapBackedStore
 
remove(String) - Method in interface org.apache.drill.exec.coord.store.TransientStore
Removes the (key, value) tuple from this store if the key exists.
remove(String) - Method in class org.apache.drill.exec.coord.zk.ZkEphemeralStore
 
remove(Object) - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
remove(Object, Object) - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
remove(ValueVector) - Method in class org.apache.drill.exec.record.VectorContainer
 
remove() - Method in class org.apache.drill.exec.server.options.DrillConfigIterator.Iter
 
remove() - Method in class org.apache.drill.exec.store.sys.DrillbitIterator
 
remove() - Method in class org.apache.drill.exec.store.sys.ExtendedOptionIterator
 
remove() - Method in class org.apache.drill.exec.store.sys.MemoryIterator
 
remove() - Method in class org.apache.drill.exec.store.sys.OptionIterator
 
remove() - Method in class org.apache.drill.exec.store.sys.ThreadsIterator
 
remove() - Method in class org.apache.drill.exec.store.sys.VersionIterator
 
removeAcl(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
removeAclEntries(Path, List<AclEntry>) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
removeAll() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BufferedBatches
 
removeDefaultAcl(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
removeDrillbitStatusListener(DrillbitStatusListener) - Method in class org.apache.drill.exec.coord.ClusterCoordinator
Unregister a DrillbitStatusListener.
removeExcessiveEchanges(Prel, long) - Static method in class org.apache.drill.exec.planner.physical.visitor.ExcessiveExchangeIdentifier
 
removeField(MaterializedField) - Method in class org.apache.drill.exec.record.SchemaBuilder
 
removeField(Field, int) - Method in class org.apache.drill.exec.schema.ListSchema
 
removeField(Field, int) - Method in class org.apache.drill.exec.schema.ObjectSchema
 
removeField(Field, int) - Method in interface org.apache.drill.exec.schema.RecordSchema
 
removeFragmentManager(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.rpc.control.WorkEventBus
Removes fragment manager (for the corresponding the handle) from the work event bus.
removeFragmentStatusListener(UserBitShared.QueryId) - Method in class org.apache.drill.exec.rpc.control.WorkEventBus
 
removeFromJars(String) - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
 
removeJar(String) - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
Removes jar from FunctionRegistryHolder.jars and all associated with jar functions from FunctionRegistryHolder.functions This is write operation, so one user at a time can call perform such action, others will wait till first user completes his action.
removeLeadingSlash(String) - Static method in class org.apache.drill.exec.store.dfs.FileSelection
 
removeListener(TransientStoreListener) - Method in class org.apache.drill.exec.coord.store.BaseTransientStore
 
removeListener(TransientStoreListener) - Method in interface org.apache.drill.exec.coord.store.TransientStore
Removes the given listener from this store if exists, has no effect otherwise.
removeSvIfRequired(Prel, BatchSchema.SelectionVectorMode...) - Static method in class org.apache.drill.exec.planner.physical.PrelUtil
 
removeTemporaryTable(AbstractSchema, String, DrillConfig) - Method in class org.apache.drill.exec.rpc.user.UserSession
Removes temporary table name from the list of session temporary tables.
removeUnreadFields() - Method in class org.apache.drill.exec.schema.ListSchema
 
removeUnreadFields() - Method in class org.apache.drill.exec.schema.ObjectSchema
 
removeUnreadFields() - Method in interface org.apache.drill.exec.schema.RecordSchema
 
removeXAttr(Path, String) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
RemovingRecordBatch - Class in org.apache.drill.exec.physical.impl.svremover
 
RemovingRecordBatch(SelectionVectorRemover, FragmentContext, RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.svremover.RemovingRecordBatch
 
rename(Path, Path) - Method in class org.apache.drill.exec.store.ClassPathFileSystem
 
rename(Path, Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
rename(Path, Path) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem
 
renameSnapshot(Path, String, String) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
renderEnd(ClassGenerator<?>, ClassGenerator.HoldingContainer[], JVar[], FieldReference) - Method in class org.apache.drill.exec.expr.fn.AbstractFuncHolder
Generate methods body and complete the code generation.
renderEnd(ClassGenerator<?>, ClassGenerator.HoldingContainer[], JVar[], FieldReference) - Method in class org.apache.drill.exec.expr.fn.DrillSimpleFuncHolder
 
renderMiddle(ClassGenerator<?>, ClassGenerator.HoldingContainer[], JVar[]) - Method in class org.apache.drill.exec.expr.fn.AbstractFuncHolder
 
renderStart(ClassGenerator<?>, ClassGenerator.HoldingContainer[]) - Method in class org.apache.drill.exec.expr.fn.AbstractFuncHolder
 
renderStart(ClassGenerator<?>, ClassGenerator.HoldingContainer[]) - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
repeat - Variable in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
Some tests want to create a very wide row with many columns.
REPEATABLE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
REPEATED_BOOLEAN_TYPE - Static variable in class org.apache.drill.exec.schema.json.jackson.JacksonHelper
 
REPEATED_FLOAT_TYPE - Static variable in class org.apache.drill.exec.schema.json.jackson.JacksonHelper
 
REPEATED_INT_TYPE - Static variable in class org.apache.drill.exec.schema.json.jackson.JacksonHelper
 
REPEATED_STRING_TYPE - Static variable in class org.apache.drill.exec.schema.json.jackson.JacksonHelper
 
repetitionLevel - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnTypeMetadata_v3
 
replace(DrillBuf, int) - Method in class org.apache.drill.exec.ops.BaseFragmentContext
 
replace(DrillBuf, int) - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
replace(DrillBuf, int) - Method in class org.apache.drill.exec.ops.BufferManagerImpl
 
replace(DrillBuf, int) - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
 
replace(DrillBuf, int) - Method in interface org.apache.drill.exec.ops.OperatorContext
 
replace(KEY, VALUE, VALUE) - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
replace(KEY, VALUE) - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
REPLACE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
replaceUserCredentials(InboundImpersonationManager, UserBitShared.UserCredentials) - Method in class org.apache.drill.exec.rpc.user.UserSession
Replace current user credentials with the given user's credentials.
replaceUserOnSession(String, UserSession) - Method in class org.apache.drill.exec.rpc.user.InboundImpersonationManager
Check if the current session user, as a proxy user, is authorized to impersonate the given target user based on the system's impersonation policies.
ReplacingBasicValue - Class in org.apache.drill.exec.compile.bytecode
BasicValue with additional tracking information used to determine the replaceability of the value (a holder, or boxed value) for scalar replacement purposes.
ReplacingInterpreter - Class in org.apache.drill.exec.compile.bytecode
 
ReplacingInterpreter(String, List<ReplacingBasicValue>) - Constructor for class org.apache.drill.exec.compile.bytecode.ReplacingInterpreter
 
requestCancelQuery(UserBitShared.QueryId) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel
 
requestQueryProfile(UserBitShared.QueryId) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel
 
requiresDecimalExpansion() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
requiresDecimalExpansion() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
requiresDecimalExpansion() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
requiresFullPartition(WindowPOP) - Method in class org.apache.drill.exec.physical.impl.window.WindowFunction
 
ReservedFunctionName() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a reserved word which is used as the name of a function.
reserveViewExpansionToken(String) - Method in class org.apache.drill.exec.ops.ViewExpansionContext
Reserve a token for expansion of view owned by given user name.
reset() - Method in class org.apache.drill.exec.compile.FsmCursor
Resets the state machine, setting it back to the start state.
reset() - Method in interface org.apache.drill.exec.expr.DrillAggFunc
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.BitAggregateErrorFunctions
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.NullableBitAggregateErrorFunctions
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.NullableVarCharAggregateErrorFunctions
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.VarCharAggregateErrorFunctions
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.BitBooleanAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.BitBooleanOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.NullableBitBooleanAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.NullableBitBooleanOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.BigIntAvg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.Float4Avg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.Float8Avg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.IntAvg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableBigIntAvg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableFloat4Avg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableFloat8Avg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableIntAvg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.IntervalAvg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.IntervalDayAvg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.IntervalYearAvg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.NullableIntervalAvg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.NullableIntervalDayAvg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.NullableIntervalYearAvg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.BigIntBitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.IntBitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableBigIntBitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableIntBitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableSmallIntBitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableTinyIntBitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt1BitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt2BitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt4BitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt8BitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.SmallIntBitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.TinyIntBitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt1BitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt2BitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt4BitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt8BitwiseAnd
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.BigIntBitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.IntBitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableBigIntBitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableIntBitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableSmallIntBitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableTinyIntBitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt1BitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt2BitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt4BitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt8BitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.SmallIntBitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.TinyIntBitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt1BitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt2BitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt4BitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt8BitwiseOr
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.BigIntCorrelation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.Float4Correlation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.Float8Correlation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.IntCorrelation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableBigIntCorrelation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableFloat4Correlation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableFloat8Correlation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableIntCorrelation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableSmallIntCorrelation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableTinyIntCorrelation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt1Correlation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt2Correlation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt4Correlation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt8Correlation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.SmallIntCorrelation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.TinyIntCorrelation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt1Correlation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt2Correlation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt4Correlation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt8Correlation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.BigIntCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.BitCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.DateCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal18CountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal28SparseCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal38SparseCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal9CountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Float4CountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Float8CountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntervalCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntervalDayCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntervalYearCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.ListCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.MapCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableBigIntCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableBitCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDateCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal18CountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal28SparseCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal38SparseCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal9CountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableFloat4CountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableFloat8CountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntervalCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntervalDayCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntervalYearCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableTimeCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableTimeStampCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableVarBinaryCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableVarCharCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedBigIntCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedBitCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDateCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal18CountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal28SparseCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal38SparseCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal9CountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedFloat4CountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedFloat8CountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntervalCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntervalDayCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntervalYearCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedListCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedMapCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedTimeCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedTimeStampCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedVarBinaryCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedVarCharCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.TimeCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.TimeStampCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.VarBinaryCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.VarCharCountFunction
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.BigIntCoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.Float4CoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.Float8CoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.IntCoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableBigIntCoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableFloat4CoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableFloat8CoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableIntCoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableSmallIntCoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableTinyIntCoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt1CoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt2CoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt4CoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt8CoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.SmallIntCoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.TinyIntCoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt1CoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt2CoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt4CoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt8CoVariancePopulation
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.BigIntCoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.Float4CoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.Float8CoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.IntCoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableBigIntCoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableFloat4CoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableFloat8CoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableIntCoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableSmallIntCoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableTinyIntCoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt1CoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt2CoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt4CoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt8CoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.SmallIntCoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.TinyIntCoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt1CoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt2CoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt4CoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt8CoVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal18Avg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal28SparseAvg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal38SparseAvg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal9Avg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal18Avg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal28SparseAvg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal38SparseAvg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal9Avg
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal18Max
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal28SparseMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal38SparseMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal9Max
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal18Max
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal28SparseMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal38SparseMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal9Max
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal18Min
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal28SparseMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal38SparseMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal9Min
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal18Min
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal28SparseMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal38SparseMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal9Min
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal18Sum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal28SparseSum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal38SparseSum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal9Sum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal18Sum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal28SparseSum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal38SparseSum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal9Sum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.DateMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.IntervalDayMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.IntervalMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.IntervalYearMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableDateMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableIntervalDayMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableIntervalMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableIntervalYearMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableTimeMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableTimeStampMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.TimeMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.TimeStampMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.BigIntMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.Float4Max
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.Float8Max
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.IntMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableBigIntMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableFloat4Max
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableFloat8Max
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableIntMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.NullableVarBinaryMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.NullableVarCharMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.VarBinaryMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.VarCharMax
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.DateMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.IntervalDayMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.IntervalMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.IntervalYearMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableDateMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableIntervalDayMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableIntervalMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableIntervalYearMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableTimeMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableTimeStampMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.TimeMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.TimeStampMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.BigIntMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.BitMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.Float4Min
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.Float8Min
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.IntMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableBigIntMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableBitMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableFloat4Min
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableFloat8Min
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableIntMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.NullableVarBinaryMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.NullableVarCharMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.VarBinaryMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.VarCharMin
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.BigIntStdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.Float4StdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.Float8StdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.IntStdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableBigIntStdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableFloat4StdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableFloat8StdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableIntStdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableSmallIntStdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableTinyIntStdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt1StdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt2StdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt4StdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt8StdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.SmallIntStdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.TinyIntStdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt1StdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt2StdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt4StdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt8StdDevPop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.BigIntStdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.Float4StdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.Float8StdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.IntStdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableBigIntStdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableFloat4StdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableFloat8StdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableIntStdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableSmallIntStdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableTinyIntStdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt1StdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt2StdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt4StdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt8StdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.SmallIntStdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.TinyIntStdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt1StdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt2StdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt4StdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt8StdDevSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.IntervalDaySum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.IntervalSum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.IntervalYearSum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.NullableIntervalDaySum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.NullableIntervalSum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.NullableIntervalYearSum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.BigIntSum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.Float4Sum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.Float8Sum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.IntSum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableBigIntSum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableFloat4Sum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableFloat8Sum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableIntSum
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.BigIntSumZero
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.BitSumZero
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.Float4SumZero
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.Float8SumZero
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.IntSumZero
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableBigIntSumZero
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableBitSumZero
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableFloat4SumZero
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableFloat8SumZero
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableIntSumZero
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.BigIntVariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.Float4VariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.Float8VariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.IntVariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableBigIntVariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableFloat4VariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableFloat8VariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableIntVariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableSmallIntVariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableTinyIntVariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt1VariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt2VariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt4VariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt8VariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.SmallIntVariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.TinyIntVariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt1VariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt2VariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt4VariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt8VariancePop
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.BigIntVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.Float4VarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.Float8VarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.IntVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableBigIntVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableFloat4VarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableFloat8VarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableIntVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableSmallIntVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableTinyIntVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt1VarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt2VarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt4VarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt8VarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.SmallIntVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.TinyIntVarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt1VarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt2VarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt4VarianceSample
 
reset() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt8VarianceSample
 
reset() - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
 
reset() - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
Reinit the hash table to its original size, and clear up all its prior batch holder
RESET - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
reset() - Method in class org.apache.drill.exec.record.RecordIterator
 
reset() - Method in class org.apache.drill.exec.schema.DiffSchema
 
reset() - Method in interface org.apache.drill.exec.schema.IdGenerator
 
reset() - Method in class org.apache.drill.exec.schema.SchemaIdGenerator
 
reset() - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
reset() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
reset() - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
 
reset() - Method in class org.apache.drill.exec.store.parquet.columnreaders.NullableVarLengthValuesColumn
 
reset() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumn
 
reset() - Method in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
 
reset() - Method in class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
 
resetAllocation() - Method in class org.apache.drill.exec.planner.fragment.Wrapper
 
resetBatch() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
resetBatch() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
 
resetGroupIndex() - Method in interface org.apache.drill.exec.physical.impl.flatten.Flattener
 
resetGroupIndex() - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenTemplate
 
resetIterator() - Method in class org.apache.drill.exec.record.RecordValueAccessor
 
resetMarkedFields() - Method in class org.apache.drill.exec.schema.ListSchema
 
resetMarkedFields() - Method in class org.apache.drill.exec.schema.ObjectSchema
 
resetMarkedFields() - Method in interface org.apache.drill.exec.schema.RecordSchema
 
resetOutputPos() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
resetQueue(VectorContainer, SelectionVector4) - Method in interface org.apache.drill.exec.physical.impl.TopN.PriorityQueue
 
resetQueue(VectorContainer, SelectionVector4) - Method in class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
 
resetReaderIndex() - Method in class org.apache.drill.exec.record.DeadBuf
 
resetRecordCount() - Method in class org.apache.drill.exec.record.RecordBatchLoader
 
resetValues() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
 
resetValues() - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
 
resetValues() - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
reset all window functions
resetValues() - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
reset all window functions
resetWriterIndex() - Method in class org.apache.drill.exec.record.DeadBuf
 
resizingTime - Variable in class org.apache.drill.exec.physical.impl.common.HashTableStats
 
resolveDrillType(Map<String, SchemaElement>, OptionManager) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetColumnMetadata
 
resolveNewTableRel(boolean, List<String>, RelDataType, RelNode) - Static method in class org.apache.drill.exec.planner.sql.handlers.SqlHandlerUtil
Resolve final RelNode of the new table (or view) for given table field list and new table definition.
resolvePath(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
ResolverTypePrecedence - Class in org.apache.drill.exec.resolver
 
ResolverTypePrecedence() - Constructor for class org.apache.drill.exec.resolver.ResolverTypePrecedence
 
resolveTemporaryTableName(String) - Method in class org.apache.drill.exec.rpc.user.UserSession
Returns generated temporary table name from the list of session temporary tables, null otherwise.
resolveToMutableDrillSchema(SchemaPlus, List<String>) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
Given reference to default schema in schema tree, search for schema with given schemaPath.
resolveToValidTemporaryWorkspace(AbstractSchema, DrillConfig) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
Makes sure that passed workspace exists, is default temporary workspace, mutable and file-based (instance of WorkspaceSchemaFactory.WorkspaceSchema).
resolveUserName(String) - Static method in class org.apache.drill.exec.util.ImpersonationUtil
If the given user name is empty, return the current process user name.
ResourceInputStream - Class in org.apache.drill.exec.store
 
ResourceInputStream(byte[]) - Constructor for class org.apache.drill.exec.store.ResourceInputStream
 
ResourceManager - Interface in org.apache.drill.exec.work.foreman.rm
Drillbit-wide resource manager shared by all queries.
ResourceManagerBuilder - Class in org.apache.drill.exec.work.foreman.rm
Builds the proper resource manager and queue implementation for the configured system options.
ResourceManagerBuilder(DrillbitContext) - Constructor for class org.apache.drill.exec.work.foreman.rm.ResourceManagerBuilder
 
ResponseSenderQueue - Class in org.apache.drill.exec.work.batch
 
ResponseSenderQueue() - Constructor for class org.apache.drill.exec.work.batch.ResponseSenderQueue
 
REST_API_SUFFIX - Static variable in class org.apache.drill.exec.server.rest.StatusResources
 
RESTART - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
RESTRICT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
RESULT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
resultArrived(ByteBuf) - Method in class org.apache.drill.exec.rpc.user.QueryResultHandler
Maps internal low-level API protocol to UserResultsListener-level API protocol.
results - Variable in class org.apache.drill.exec.server.rest.WebUserConnection
 
resume() - Method in class org.apache.drill.exec.work.foreman.Foreman
Resume the query.
resumeQuery(UserBitShared.QueryId) - Method in class org.apache.drill.exec.client.DrillClient
 
resumeQuery(UserBitShared.QueryId) - Method in class org.apache.drill.exec.work.user.UserWorker
 
retain() - Method in class org.apache.drill.exec.cache.VectorSerializer.Writer
 
retain(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
retain() - Method in class org.apache.drill.exec.record.DeadBuf
 
retainBuffers(int) - Method in class org.apache.drill.exec.record.WritableBatch
 
retainSv4OnNone(RecordBatch) - Static method in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
Workaround for DRILL-5656.
RetargetableClassVisitor - Class in org.apache.drill.exec.compile
An ASM ClassVisitor that allows for a late-bound delegate.
RetargetableClassVisitor(int) - Constructor for class org.apache.drill.exec.compile.RetargetableClassVisitor
See ClassVisitor.ClassVisitor(int).
RetargetableClassVisitor(int, ClassVisitor) - Constructor for class org.apache.drill.exec.compile.RetargetableClassVisitor
See ClassVisitor.ClassVisitor(int, ClassVisitor).
retireForeman(Foreman) - Method in class org.apache.drill.exec.work.WorkManager.WorkerBee
Remove the given Foreman from the running query list.
RETURN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
RETURN_ERROR_FOR_FAILURE_IN_CANCELLED_FRAGMENTS - Static variable in class org.apache.drill.exec.ExecConstants
Currently if a query is cancelled, but one of the fragments reports the status as FAILED instead of CANCELLED or FINISHED we report the query result as CANCELLED by swallowing the failures occurred in fragments.
RETURNED_CARDINALITY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
RETURNED_LENGTH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
RETURNED_OCTET_LENGTH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
RETURNED_SQLSTATE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
RETURNS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ReturnTypeInference - Interface in org.apache.drill.exec.expr.fn.output
Return type calculation interface for functions that have return type set as with enum FunctionTemplate.ReturnType.
ReturnValueExpression - Class in org.apache.drill.exec.physical.impl.filter
 
ReturnValueExpression(LogicalExpression) - Constructor for class org.apache.drill.exec.physical.impl.filter.ReturnValueExpression
 
ReturnValueExpression(LogicalExpression, boolean) - Constructor for class org.apache.drill.exec.physical.impl.filter.ReturnValueExpression
 
reverse - Variable in class org.apache.drill.exec.physical.config.Sort
 
REVOKE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
rewrite(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
Rewrite the parse tree.
rewrite(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.DescribeTableHandler
Rewrite the parse tree as SELECT ...
rewrite(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.ExplainHandler
 
rewrite(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.ShowSchemasHandler
Rewrite the parse tree as SELECT ...
rewrite(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.ShowTablesHandler
Rewrite the parse tree as SELECT ...
RewriteAsBinaryOperators - Class in org.apache.drill.exec.planner.logical.partition
Rewrites an expression tree, replacing OR and AND operators with more than 2 operands with a chained operators each with only 2 operands.
RewriteAsBinaryOperators(boolean, RexBuilder) - Constructor for class org.apache.drill.exec.planner.logical.partition.RewriteAsBinaryOperators
 
rewriteCall(SqlValidator, SqlCall) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
RewriteCombineBinaryOperators - Class in org.apache.drill.exec.planner.logical.partition
Rewrites an expression tree, replacing chained OR and AND operators with a single N-ary operator e.g.
RewriteCombineBinaryOperators(boolean, RexBuilder) - Constructor for class org.apache.drill.exec.planner.logical.partition.RewriteCombineBinaryOperators
 
rewritePlanWithIteratorValidator(FragmentContext, FragmentRoot) - Static method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorInjector
 
RewriteProjectToFlatten - Class in org.apache.drill.exec.planner.physical.visitor
 
RewriteProjectToFlatten(RelDataTypeFactory, DrillOperatorTable) - Constructor for class org.apache.drill.exec.planner.physical.visitor.RewriteProjectToFlatten
 
rewriter - Variable in class org.apache.drill.exec.planner.physical.PrelUtil.ProjectPushInfo
 
RexVisitorComplexExprSplitter - Class in org.apache.drill.exec.planner.physical.visitor
 
RexVisitorComplexExprSplitter(RelDataTypeFactory, FunctionImplementationRegistry, int) - Constructor for class org.apache.drill.exec.planner.physical.visitor.RexVisitorComplexExprSplitter
 
right - Variable in class org.apache.drill.exec.expr.stat.ParquetPredicates.ParquetCompPredicate
 
right - Variable in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
RIGHT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
right - Variable in class org.apache.drill.exec.record.AbstractBinaryRecordBatch
 
RIGHT_INPUT - Static variable in class org.apache.drill.exec.physical.impl.join.HashJoinHelper
 
RIGHT_INPUT - Static variable in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch
 
RIGHT_MAPPING - Variable in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
 
RIGHT_MAPPING - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.BaseSortWrapper
 
rightKeys - Variable in class org.apache.drill.exec.planner.common.DrillJoinRelBase
 
rightMapping - Variable in class org.apache.drill.exec.physical.impl.sort.SortBatch
 
rightMapping - Variable in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
rightUpstream - Variable in class org.apache.drill.exec.record.AbstractBinaryRecordBatch
 
rm - Variable in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedResourceAllocator
 
ROLE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ROLLBACK - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ROLLUP - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Root - Interface in org.apache.drill.exec.physical.base
Marker interface describe the root of a query plan.
root - Variable in class org.apache.drill.exec.store.parquet2.DrillParquetRecordMaterializer
 
root() - Method in class org.apache.drill.exec.work.QueryWorkUnit.MinorFragmentDefn
 
ROOT_SCHEMA - Static variable in class org.apache.drill.exec.util.StoragePluginTestUtils
 
RootAllocatorFactory - Class in org.apache.drill.exec.memory
 
rootAsList() - Method in class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
 
rootAsMap() - Method in class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
 
RootCreator<T extends PhysicalOperator> - Interface in org.apache.drill.exec.physical.impl
 
RootExec - Interface in org.apache.drill.exec.physical.impl
A FragmentRoot is a node which is the last processing node in a query plan.
RootFragmentManager - Class in org.apache.drill.exec.work.fragment
This managers determines when to run a root fragment node.
RootFragmentManager(BitControl.PlanFragment, FragmentExecutor, FragmentStatusReporter) - Constructor for class org.apache.drill.exec.work.fragment.RootFragmentManager
 
rotateBlock() - Method in class org.apache.drill.exec.expr.ClassGenerator
 
RoundFunctions - Class in org.apache.drill.exec.expr.fn.impl.conv
 
RoundFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions
 
RoundFunctions.RoundBigInt - Class in org.apache.drill.exec.expr.fn.impl.conv
 
RoundFunctions.RoundBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundBigInt
 
RoundFunctions.RoundFloat4 - Class in org.apache.drill.exec.expr.fn.impl.conv
 
RoundFunctions.RoundFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundFloat4
 
RoundFunctions.RoundFloat8 - Class in org.apache.drill.exec.expr.fn.impl.conv
 
RoundFunctions.RoundFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundFloat8
 
RoundFunctions.RoundInt - Class in org.apache.drill.exec.expr.fn.impl.conv
 
RoundFunctions.RoundInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundInt
 
RoundFunctions.RoundSmallInt - Class in org.apache.drill.exec.expr.fn.impl.conv
 
RoundFunctions.RoundSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundSmallInt
 
RoundFunctions.RoundTinyInt - Class in org.apache.drill.exec.expr.fn.impl.conv
 
RoundFunctions.RoundTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundTinyInt
 
RoundFunctions.RoundUInt1 - Class in org.apache.drill.exec.expr.fn.impl.conv
 
RoundFunctions.RoundUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt1
 
RoundFunctions.RoundUInt2 - Class in org.apache.drill.exec.expr.fn.impl.conv
 
RoundFunctions.RoundUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt2
 
RoundFunctions.RoundUInt4 - Class in org.apache.drill.exec.expr.fn.impl.conv
 
RoundFunctions.RoundUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt4
 
RoundFunctions.RoundUInt8 - Class in org.apache.drill.exec.expr.fn.impl.conv
 
RoundFunctions.RoundUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt8
 
ROUTINE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ROUTINE_CATALOG - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ROUTINE_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ROUTINE_SCHEMA - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ROUTING_V6 - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
ROW - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ROW_COUNT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
row_number - Variable in class org.apache.drill.exec.physical.impl.window.Partition
 
ROW_NUMBER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
rowAggregated() - Method in class org.apache.drill.exec.physical.impl.window.Partition
 
RowConstructor() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a row constructor in the context of a VALUES expression.
RowConstructorList(SqlParserPos) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses one or more rows in a VALUES expression.
rowCount() - Method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
 
rowCount - Variable in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v1
 
rowCount - Variable in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v2
 
rowCount - Variable in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v3
 
RowGroupReadEntry - Class in org.apache.drill.exec.store.parquet
 
RowGroupReadEntry(String, long, long, int, long) - Constructor for class org.apache.drill.exec.store.parquet.RowGroupReadEntry
 
rowGroups - Variable in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v1
 
rowGroups - Variable in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v2
 
rowGroups - Variable in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v3
 
rowHasData() - Method in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
 
ROWS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
rows - Variable in class org.apache.drill.exec.server.rest.QueryWrapper.QueryResult
 
RPAREN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
RPC_VERSION - Static variable in class org.apache.drill.exec.rpc.control.ControlRpcConfig
 
RPC_VERSION - Static variable in class org.apache.drill.exec.rpc.data.DataRpcConfig
 
RPC_VERSION - Static variable in class org.apache.drill.exec.rpc.user.UserRpcConfig
 
run() - Method in interface org.apache.drill.exec.cache.DistributedCache
 
run() - Method in class org.apache.drill.exec.server.Drillbit
 
run(WorkManager, WebUserConnection) - Method in class org.apache.drill.exec.server.rest.QueryWrapper
 
run() - Method in class org.apache.drill.exec.store.TimedRunnable
 
run(String, Logger, List<TimedRunnable<V>>, int) - Static method in class org.apache.drill.exec.store.TimedRunnable
Execute the list of runnables with the given parallelization.
run() - Method in class org.apache.drill.exec.work.foreman.Foreman
Called by execution pool to do query setup, and kick off remote execution.
run() - Method in class org.apache.drill.exec.work.fragment.FragmentExecutor
 
run() - Method in class org.apache.drill.exec.work.metadata.ServerMetaProvider.ServerMetaWorker
 
run() - Method in class org.apache.drill.exec.work.prepare.PreparedStatementProvider.PreparedStatementWorker
 
runCallableAs(UserGroupInformation, Callable<RESULT>) - Method in interface org.apache.drill.exec.ops.OperatorContext
Run the callable as the given proxy user.
runInner() - Method in class org.apache.drill.exec.store.TimedRunnable
 
runQuery(UserBitShared.QueryType, String) - Method in class org.apache.drill.exec.client.DrillClient
Submits a string based query plan for execution and returns the result batches.
runQuery(UserBitShared.QueryType, List<BitControl.PlanFragment>, UserResultsListener) - Method in class org.apache.drill.exec.client.DrillClient
Run query based on list of fragments that were supposedly produced during query planning phase.
runQuery(UserBitShared.QueryType, String, UserResultsListener) - Method in class org.apache.drill.exec.client.DrillClient
Submits a Logical plan for direct execution (bypasses parsing)
RuntimeOverridden - Annotation Type in org.apache.drill.exec.compile.sig
Describes the field will provide output from the given function.

S

SAFE_SEPARATOR - Static variable in class org.apache.drill.exec.store.httpd.HttpdParser
 
SAFE_WILDCARD - Static variable in class org.apache.drill.exec.store.httpd.HttpdParser
 
safeDivide(long, long) - Static method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
 
SameInOutLengthReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
Return type calculation implementation for functions with return type set as FunctionTemplate.ReturnType.SAME_IN_OUT_LENGTH.
SameInOutLengthReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.SameInOutLengthReturnTypeInference
 
SampleCopier - Interface in org.apache.drill.exec.physical.impl.orderedpartitioner
 
SampleCopierTemplate - Class in org.apache.drill.exec.physical.impl.orderedpartitioner
 
SampleCopierTemplate() - Constructor for class org.apache.drill.exec.physical.impl.orderedpartitioner.SampleCopierTemplate
 
SampleSorter - Interface in org.apache.drill.exec.physical.impl.orderedpartitioner
 
SampleSortTemplate - Class in org.apache.drill.exec.physical.impl.orderedpartitioner
 
SampleSortTemplate() - Constructor for class org.apache.drill.exec.physical.impl.orderedpartitioner.SampleSortTemplate
 
SaslProperties - Class in org.apache.drill.exec.rpc.security
 
satisfies(RelTrait) - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
 
saveCodeForDebugging(boolean) - Method in class org.apache.drill.exec.expr.CodeGenerator
Debug-time option to persist the code for the generated class to permit debugging.
saveFirstValue(int) - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
 
SAVEPOINT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SCALAR_REPLACEMENT_OPTION - Static variable in class org.apache.drill.exec.compile.ClassTransformer
 
SCALAR_REPLACEMENT_VALIDATOR - Static variable in class org.apache.drill.exec.compile.ClassTransformer
 
ScalarReplacementNode - Class in org.apache.drill.exec.compile.bytecode
 
ScalarReplacementNode(String, int, String, String, String, String[], MethodVisitor, boolean) - Constructor for class org.apache.drill.exec.compile.bytecode.ScalarReplacementNode
 
ScalarReplacementTypes - Class in org.apache.drill.exec.compile.bytecode
Reference list of classes we will perform scalar replacement on.
SCALE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
scale - Variable in class org.apache.drill.exec.record.MajorTypeSerDe.MajorTypeHolder
 
scale - Variable in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
scale - Variable in class org.apache.drill.exec.store.parquet.Metadata.ColumnTypeMetadata_v3
 
Scan - Interface in org.apache.drill.exec.physical.base
 
SCAN_DECODE_THREADPOOL_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
SCAN_THREADPOOL_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
ScanBatch - Class in org.apache.drill.exec.physical.impl
Record batch used for a particular scan.
ScanBatch(PhysicalOperator, FragmentContext, OperatorContext, List<RecordReader>, List<Map<String, String>>) - Constructor for class org.apache.drill.exec.physical.impl.ScanBatch
 
ScanBatch(PhysicalOperator, FragmentContext, List<RecordReader>) - Constructor for class org.apache.drill.exec.physical.impl.ScanBatch
 
ScanBatch.Mutator - Class in org.apache.drill.exec.physical.impl
Row set mutator implementation provided to record readers created by this scan batch.
ScanBatch.Mutator(OperatorContext, BufferAllocator, VectorContainer) - Constructor for class org.apache.drill.exec.physical.impl.ScanBatch.Mutator
 
ScanFieldDeterminer - Class in org.apache.drill.exec.planner.logical
This visitor will walk a logical plan and record in a map the list of field references associated to each scan.
ScanFieldDeterminer.FieldList - Class in org.apache.drill.exec.planner.logical
 
ScanFieldDeterminer.FieldList() - Constructor for class org.apache.drill.exec.planner.logical.ScanFieldDeterminer.FieldList
 
ScanPrel - Class in org.apache.drill.exec.planner.physical
 
ScanPrel(RelOptCluster, RelTraitSet, GroupScan, RelDataType) - Constructor for class org.apache.drill.exec.planner.physical.ScanPrel
 
ScanPrule - Class in org.apache.drill.exec.planner.physical
 
ScanPrule() - Constructor for class org.apache.drill.exec.planner.physical.ScanPrule
 
scanSchema(SchemaPlus) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
 
ScanStats - Class in org.apache.drill.exec.physical.base
 
ScanStats(ScanStats.GroupScanProperty, long, float, float) - Constructor for class org.apache.drill.exec.physical.base.ScanStats
 
ScanStats.GroupScanProperty - Enum in org.apache.drill.exec.physical.base
 
schema - Variable in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
 
schema - Variable in class org.apache.drill.exec.planner.sql.handlers.DescribeSchemaHandler.DescribeSchemaResult
 
SCHEMA - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
schema() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
 
Schema - Class in org.apache.drill.exec.store.pcap.schema
 
Schema() - Constructor for class org.apache.drill.exec.store.pcap.schema.Schema
 
SCHEMA_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SCHEMA_NAME - Variable in class org.apache.drill.exec.store.ischema.Records.Schema
 
SCHEMA_OWNER - Variable in class org.apache.drill.exec.store.ischema.Records.Schema
 
SCHEMA_PATH_JOINER - Static variable in class org.apache.drill.exec.planner.sql.SchemaUtilites
 
SchemaBuilder - Class in org.apache.drill.exec.record
A reusable builder that supports the creation of BatchSchemas.
schemaChanged(String, BatchSchema, BatchSchema) - Static method in exception org.apache.drill.exec.exception.SchemaChangeException
 
SchemaChangeException - Exception in org.apache.drill.exec.exception
 
SchemaChangeException() - Constructor for exception org.apache.drill.exec.exception.SchemaChangeException
 
SchemaChangeException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.drill.exec.exception.SchemaChangeException
 
SchemaChangeException(String, Throwable) - Constructor for exception org.apache.drill.exec.exception.SchemaChangeException
 
SchemaChangeException(String) - Constructor for exception org.apache.drill.exec.exception.SchemaChangeException
 
SchemaChangeException(Throwable) - Constructor for exception org.apache.drill.exec.exception.SchemaChangeException
 
SchemaChangeException(String, Object...) - Constructor for exception org.apache.drill.exec.exception.SchemaChangeException
 
SchemaChangeException(String, Throwable, Object...) - Constructor for exception org.apache.drill.exec.exception.SchemaChangeException
 
schemaConfig - Variable in class org.apache.drill.exec.planner.sql.DynamicRootSchema
 
SchemaConfig - Class in org.apache.drill.exec.store
Contains information needed by AbstractSchema implementations.
SchemaConfig.Builder - Class in org.apache.drill.exec.store
 
SchemaConfig.SchemaConfigInfoProvider - Interface in org.apache.drill.exec.store
Interface to implement to provide required info for SchemaConfig
SchemaFactory - Interface in org.apache.drill.exec.store
StoragePlugins implements this interface to register the schemas they provide.
SchemaIdGenerator - Class in org.apache.drill.exec.schema
 
SchemaIdGenerator() - Constructor for class org.apache.drill.exec.schema.SchemaIdGenerator
 
SchemaPartitionExplorer - Interface in org.apache.drill.exec.store
Exposes partition information for a particular schema.
schemaPath - Variable in class org.apache.drill.exec.store.AbstractSchema
 
SCHEMAS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
schemas(UserSession, DrillbitContext, UserProtos.GetSchemasReq, ResponseSender) - Static method in class org.apache.drill.exec.work.metadata.MetadataProvider
 
SchemaTreeProvider - Class in org.apache.drill.exec.store
Class which creates new schema trees.
SchemaTreeProvider(DrillbitContext) - Constructor for class org.apache.drill.exec.store.SchemaTreeProvider
 
SchemaUtil - Class in org.apache.drill.exec.record
Utility class for dealing with changing schemas
SchemaUtil() - Constructor for class org.apache.drill.exec.record.SchemaUtil
 
SchemaUtilites - Class in org.apache.drill.exec.planner.sql
 
SchemaUtilites() - Constructor for class org.apache.drill.exec.planner.sql.SchemaUtilites
 
SCHS_COL_CATALOG_NAME - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
SCHS_COL_IS_MUTABLE - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
SCHS_COL_SCHEMA_NAME - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
SCHS_COL_SCHEMA_OWNER - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
SCHS_COL_TYPE - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
Scope() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
SCOPE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
scope - Variable in class org.apache.drill.exec.server.options.OptionValue
 
SCOPE_CATALOGS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SCOPE_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SCOPE_SCHEMA - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Screen - Class in org.apache.drill.exec.physical.config
 
Screen(PhysicalOperator, CoordinationProtos.DrillbitEndpoint) - Constructor for class org.apache.drill.exec.physical.config.Screen
 
ScreenCreator - Class in org.apache.drill.exec.physical.impl
 
ScreenCreator() - Constructor for class org.apache.drill.exec.physical.impl.ScreenCreator
 
ScreenCreator.ScreenRoot - Class in org.apache.drill.exec.physical.impl
 
ScreenCreator.ScreenRoot(FragmentContext, RecordBatch, Screen) - Constructor for class org.apache.drill.exec.physical.impl.ScreenCreator.ScreenRoot
 
ScreenCreator.ScreenRoot.Metric - Enum in org.apache.drill.exec.physical.impl
 
ScreenPrel - Class in org.apache.drill.exec.planner.physical
 
ScreenPrel(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.drill.exec.planner.physical.ScreenPrel
 
ScreenPrule - Class in org.apache.drill.exec.planner.physical
 
ScreenPrule() - Constructor for class org.apache.drill.exec.planner.physical.ScreenPrule
 
SCROLL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SEARCH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SECOND - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
secondaryFinal(TypeProtos.MajorType) - Method in class org.apache.drill.exec.record.TypedFieldId.Builder
 
secondaryImplicitCastRules - Static variable in class org.apache.drill.exec.resolver.ResolverTypePrecedence
 
SECTION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SECURITY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SecurityConfiguration - Class in org.apache.drill.exec.rpc.security
 
SecurityConfiguration() - Constructor for class org.apache.drill.exec.rpc.security.SecurityConfiguration
 
seek(long) - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
seek(long) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalInputStream
 
seek(long) - Method in class org.apache.drill.exec.store.ResourceInputStream
 
seek(long) - Method in class org.apache.drill.exec.vector.complex.fn.DrillBufInputStream
 
seek(long) - Method in class org.apache.drill.exec.vector.complex.fn.SeekableBAIS
 
SeekableBAIS - Class in org.apache.drill.exec.vector.complex.fn
A ByteArrayInputStream that supports the HDFS Seekable API.
SeekableBAIS(byte[], int, int) - Constructor for class org.apache.drill.exec.vector.complex.fn.SeekableBAIS
 
SeekableBAIS(byte[]) - Constructor for class org.apache.drill.exec.vector.complex.fn.SeekableBAIS
 
seekToNewSource(long) - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
seekToNewSource(long) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalInputStream
 
seekToNewSource(long) - Method in class org.apache.drill.exec.store.ResourceInputStream
 
seekToNewSource(long) - Method in class org.apache.drill.exec.vector.complex.fn.DrillBufInputStream
 
seekToNewSource(long) - Method in class org.apache.drill.exec.vector.complex.fn.SeekableBAIS
 
SELECT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SelectExpression() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses one unaliased expression in a select list.
selectionRoot - Variable in class org.apache.drill.exec.store.dfs.FileSelection
root path for the selections
SelectionVector2 - Class in org.apache.drill.exec.record.selection
A selection vector that fronts, at most, a
SelectionVector2(BufferAllocator) - Constructor for class org.apache.drill.exec.record.selection.SelectionVector2
 
SelectionVector2(BufferAllocator, DrillBuf, int) - Constructor for class org.apache.drill.exec.record.selection.SelectionVector2
 
SelectionVector4 - Class in org.apache.drill.exec.record.selection
 
SelectionVector4(ByteBuf, int, int) - Constructor for class org.apache.drill.exec.record.selection.SelectionVector4
 
SelectionVector4Builder - Class in org.apache.drill.exec.record.selection
 
SelectionVector4Builder() - Constructor for class org.apache.drill.exec.record.selection.SelectionVector4Builder
 
SelectionVectorPrelVisitor - Class in org.apache.drill.exec.planner.physical.visitor
 
SelectionVectorPrelVisitor() - Constructor for class org.apache.drill.exec.planner.physical.visitor.SelectionVectorPrelVisitor
 
SelectionVectorRemover - Class in org.apache.drill.exec.physical.config
 
SelectionVectorRemover(PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.config.SelectionVectorRemover
 
SelectionVectorRemoverPrel - Class in org.apache.drill.exec.planner.physical
 
SelectionVectorRemoverPrel(Prel) - Constructor for class org.apache.drill.exec.planner.physical.SelectionVectorRemoverPrel
 
SelectionVectorRemoverPrel(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.drill.exec.planner.physical.SelectionVectorRemoverPrel
 
SelectItem() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses one item in a select list.
SelectList() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses the select list of a SELECT statement.
SELF - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SEMICOLON - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
send(RpcOutcomeListener<RECEIVE>, BitControl.RpcType, SEND, Class<RECEIVE>, ByteBuf...) - Method in class org.apache.drill.exec.rpc.control.ControlConnection
 
send(SEND, ByteBuf...) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.CustomTunnel
Send a message and receive a future for monitoring the outcome.
send(RpcOutcomeListener<RECEIVE>, SEND, ByteBuf...) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.CustomTunnel
Send a message using a custom listener.
send(RpcOutcomeListener<RECEIVE>, BitData.RpcType, SEND, Class<RECEIVE>, ByteBuf...) - Method in class org.apache.drill.exec.rpc.data.DataClientConnection
 
send(RpcOutcomeListener<RECEIVE>, UserProtos.RpcType, SEND, Class<RECEIVE>, boolean, ByteBuf...) - Method in class org.apache.drill.exec.rpc.user.UserClient
 
sendData(QueryWritableBatch) - Method in class org.apache.drill.exec.ops.AccountingUserConnection
 
sendData(RpcOutcomeListener<GeneralRPCProtos.Ack>, QueryWritableBatch) - Method in class org.apache.drill.exec.rpc.user.UserServer.BitToUserConnection
 
sendData(RpcOutcomeListener<GeneralRPCProtos.Ack>, QueryWritableBatch) - Method in interface org.apache.drill.exec.rpc.UserClientConnection
Send query data to client.
sendData(RpcOutcomeListener<GeneralRPCProtos.Ack>, QueryWritableBatch) - Method in class org.apache.drill.exec.server.rest.WebUserConnection
 
sendEmptyBatch(boolean) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec
 
Sender - Interface in org.apache.drill.exec.physical.base
A sender is one half of an exchange node operations.
senderLocations - Variable in class org.apache.drill.exec.physical.base.AbstractExchange
 
senderMajorFragmentId - Variable in class org.apache.drill.exec.physical.base.AbstractExchange
 
senderToReceiverMapping - Variable in class org.apache.drill.exec.physical.config.AbstractMuxExchange
 
senderToReceiversMapping - Variable in class org.apache.drill.exec.physical.config.AbstractDeMuxExchange
 
sendFragments(RpcOutcomeListener<GeneralRPCProtos.Ack>, BitControl.InitializeFragments) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel
 
sendFragmentStatus(BitControl.FragmentStatus) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel
 
sendOk() - Method in class org.apache.drill.exec.record.RawFragmentBatch
 
sendOk() - Method in class org.apache.drill.exec.rpc.data.AckSender
Decrement the number of references still holding on to this response.
sendRecordBatch(FragmentWritableBatch) - Method in class org.apache.drill.exec.ops.AccountingDataTunnel
 
sendRecordBatch(RpcOutcomeListener<GeneralRPCProtos.Ack>, FragmentWritableBatch) - Method in class org.apache.drill.exec.rpc.data.DataTunnel
 
sendRecordBatch(FragmentContext, FragmentWritableBatch) - Method in class org.apache.drill.exec.rpc.data.DataTunnel
 
sendResult(RpcOutcomeListener<GeneralRPCProtos.Ack>, UserBitShared.QueryResult) - Method in class org.apache.drill.exec.rpc.AbstractDisposableUserClientConnection
 
sendResult(RpcOutcomeListener<GeneralRPCProtos.Ack>, UserBitShared.QueryResult) - Method in class org.apache.drill.exec.rpc.user.UserServer.BitToUserConnection
 
sendResult(RpcOutcomeListener<GeneralRPCProtos.Ack>, UserBitShared.QueryResult) - Method in interface org.apache.drill.exec.rpc.UserClientConnection
Send query result outcome to client.
sendUnsafe(RpcOutcomeListener<RECEIVE>, BitControl.RpcType, SEND, Class<RECEIVE>, ByteBuf...) - Method in class org.apache.drill.exec.rpc.control.ControlConnection
 
SENSITIVE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SEQUENCE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SequenceExpression() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
SequenceFileFormatConfig - Class in org.apache.drill.exec.store.easy.sequencefile
 
SequenceFileFormatConfig() - Constructor for class org.apache.drill.exec.store.easy.sequencefile.SequenceFileFormatConfig
 
SequenceFileFormatPlugin - Class in org.apache.drill.exec.store.easy.sequencefile
 
SequenceFileFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig) - Constructor for class org.apache.drill.exec.store.easy.sequencefile.SequenceFileFormatPlugin
 
SequenceFileFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig, SequenceFileFormatConfig) - Constructor for class org.apache.drill.exec.store.easy.sequencefile.SequenceFileFormatPlugin
 
SequenceFileRecordReader - Class in org.apache.drill.exec.store.easy.sequencefile
 
SequenceFileRecordReader(FileSplit, DrillFileSystem, String, String) - Constructor for class org.apache.drill.exec.store.easy.sequencefile.SequenceFileRecordReader
 
SERIALIZABLE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SerializationDefinition - Enum in org.apache.drill.exec.cache
 
serialize(CoordinationProtos.DrillbitEndpoint, JsonGenerator, SerializerProvider) - Method in class org.apache.drill.exec.coord.DrillbitEndpointSerDe.Se
 
serialize(TypeProtos.MajorType, JsonGenerator, SerializerProvider) - Method in class org.apache.drill.exec.record.MajorTypeSerDe.Se
 
serialize(T) - Method in interface org.apache.drill.exec.serialization.InstanceSerializer
 
serialize(T) - Method in class org.apache.drill.exec.serialization.JacksonSerializer
 
serialize(T) - Method in class org.apache.drill.exec.serialization.ProtoSerializer
 
serialize(Metadata.ColumnMetadata_v2, JsonGenerator, SerializerProvider) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2.Serializer
 
serialize(Metadata.ColumnMetadata_v3, JsonGenerator, SerializerProvider) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3.Serializer
 
serialized - Variable in enum org.apache.drill.exec.vector.complex.fn.ExtendedType
 
SERIALIZER - Static variable in class org.apache.drill.exec.coord.DrillServiceInstanceHelper
 
serializer() - Method in class org.apache.drill.exec.coord.store.TransientStoreConfigBuilder
 
serializer(InstanceSerializer<T>) - Method in class org.apache.drill.exec.coord.store.TransientStoreConfigBuilder
 
serializeToSend(MSG) - Method in interface org.apache.drill.exec.rpc.control.Controller.CustomSerDe
 
serializeToSend(MSG) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.JacksonSerDe
 
serializeToSend(MSG) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.ProtoSerDe
 
SERVER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SERVER_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ServerAuthenticationHandler<S extends ServerConnection<S>,T extends com.google.protobuf.Internal.EnumLite> - Class in org.apache.drill.exec.rpc.security
Handles SASL exchange, on the server-side.
ServerAuthenticationHandler(RequestHandler<S>, int, T) - Constructor for class org.apache.drill.exec.rpc.security.ServerAuthenticationHandler
 
ServerMetaProvider - Class in org.apache.drill.exec.work.metadata
Contains worker Runnable for returning server meta information
ServerMetaProvider() - Constructor for class org.apache.drill.exec.work.metadata.ServerMetaProvider
 
ServerMetaProvider.ServerMetaWorker - Class in org.apache.drill.exec.work.metadata
Runnable that creates server meta information for given ServerMetaReq and sends the response at the end.
ServerMetaProvider.ServerMetaWorker(UserSession, DrillbitContext, UserProtos.GetServerMetaReq, ResponseSender) - Constructor for class org.apache.drill.exec.work.metadata.ServerMetaProvider.ServerMetaWorker
 
ServerMethod - Enum in org.apache.drill.exec.client
A enumeration of server methods, and the version they were introduced it allows to introduce new methods without changing the protocol, with client being able to gracefully handle cases were method is not handled by the server.
SERVICE_KEYTAB_LOCATION - Static variable in class org.apache.drill.exec.server.BootStrapContext
 
SERVICE_NAME - Static variable in class org.apache.drill.exec.ExecConstants
 
SERVICE_PRINCIPAL - Static variable in class org.apache.drill.exec.server.BootStrapContext
 
ServiceEngine - Class in org.apache.drill.exec.service
 
ServiceEngine(WorkManager, BootStrapContext, boolean, boolean) - Constructor for class org.apache.drill.exec.service.ServiceEngine
 
SESSION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SESSION_USER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SessionOptionManager - Class in org.apache.drill.exec.server.options
OptionManager that holds options within UserSession context.
SessionOptionManager(OptionManager, UserSession) - Constructor for class org.apache.drill.exec.server.options.SessionOptionManager
 
SET - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
set(int, int) - Method in class org.apache.drill.exec.record.selection.SelectionVector4
 
set(int, int, int) - Method in class org.apache.drill.exec.record.selection.SelectionVector4
 
set(TextFormatPlugin.TextFormatConfig) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
set(String, String) - Method in class org.apache.drill.exec.store.httpd.HttpdLogRecord
This method is referenced and called via reflection.
set(String, Long) - Method in class org.apache.drill.exec.store.httpd.HttpdLogRecord
This method is referenced and called via reflection.
set(String, Double) - Method in class org.apache.drill.exec.store.httpd.HttpdLogRecord
This method is referenced and called via reflection.
setAcl(Path, List<AclEntry>) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
setArgumentCount(int, int) - Method in class org.apache.drill.exec.planner.sql.DrillSqlAggOperator.DrillSqlAggOperatorBuilder
 
setArgumentCount(int, int) - Method in class org.apache.drill.exec.planner.sql.DrillSqlOperator.DrillSqlOperatorBuilder
 
setAssignedToMember() - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
Mark this value as being assigned to a class member variable.
setAssignmentRequired() - Method in class org.apache.drill.exec.physical.EndpointAffinity
Set the endpoint requires at least one assignment.
setAutoRead(boolean) - Method in class org.apache.drill.exec.client.DrillClient
 
setAutoRead(boolean) - Method in class org.apache.drill.exec.server.rest.WebUserConnection
 
setBackend(DiffSchema, DataRecord) - Method in class org.apache.drill.exec.schema.BackedRecord
 
setBatchSize(long) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.SpilledRun
 
setBody(String) - Method in class org.apache.drill.exec.compile.ClassBodyBuilder
 
setBoolean(int, boolean) - Method in class org.apache.drill.exec.record.DeadBuf
 
setBreakRegister(boolean) - Method in class org.apache.drill.exec.store.mock.MockBreakageStorage
 
setBuffer(int, int, DrillBuf) - Method in class org.apache.drill.exec.expr.fn.impl.CharSequenceWrapper
Set the DrillBuf to adapt to a CharSequence.
setBuffer(DrillBuf) - Method in class org.apache.drill.exec.record.selection.SelectionVector2
 
setBuffers(IncomingBuffers) - Method in class org.apache.drill.exec.ops.FragmentContext
 
setByte(int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
setBytes(byte[]) - Method in class org.apache.drill.exec.expr.fn.impl.DrillByteArray
 
setBytes(byte[], int) - Method in class org.apache.drill.exec.expr.fn.impl.DrillByteArray
 
setBytes(int, ByteBuf) - Method in class org.apache.drill.exec.record.DeadBuf
 
setBytes(int, ByteBuf, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
setBytes(int, ByteBuf, int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
setBytes(int, byte[]) - Method in class org.apache.drill.exec.record.DeadBuf
 
setBytes(int, byte[], int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
setBytes(int, ByteBuffer) - Method in class org.apache.drill.exec.record.DeadBuf
 
setBytes(int, InputStream, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
setBytes(int, ScatteringByteChannel, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
setCapacity(int) - Method in class org.apache.drill.exec.store.sys.PersistentStoreConfig.StoreConfigBuilder
 
setChar(int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
setClassName(String) - Method in class org.apache.drill.exec.compile.ClassBodyBuilder
 
setClientName(String) - Method in class org.apache.drill.exec.client.DrillClient
Sets the client name.
setColumns(Collection<SchemaPath>) - Method in class org.apache.drill.exec.store.AbstractRecordReader
 
setColumns(List<? extends Metadata.ColumnMetadata>) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan.RowGroupInfo
 
setComment(byte) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
setConf(Configuration) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
setConstant(boolean) - Method in class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
 
setConstant(boolean) - Method in class org.apache.drill.exec.expr.fn.ValueReference
 
setCost(double) - Method in class org.apache.drill.exec.physical.base.AbstractBase
 
setCost(double) - Method in interface org.apache.drill.exec.physical.base.PhysicalOperator
 
setCost(double) - Method in class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager.DefaultQueryResourceManager
 
setCost(double) - Method in interface org.apache.drill.exec.work.foreman.rm.QueryResourceManager
For some cases the foreman does not have a full plan, just a cost.
setCost(double) - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedQueryResourceManager
 
setCount(int) - Method in class org.apache.drill.exec.record.selection.SelectionVector4
 
setCurrentIndex(int, int, int) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelper
 
setDebugStream(PrintStream) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplTokenManager
 
setDefaultImports(String...) - Method in class org.apache.drill.exec.compile.ClassBodyBuilder
 
setDefaultSchemaPath(String, SchemaPlus) - Method in class org.apache.drill.exec.rpc.user.UserSession
Update the schema path for the session.
setDelegate(ClassVisitor) - Method in class org.apache.drill.exec.compile.RetargetableClassVisitor
Set the delegate for this ClassVisitor.
setDelimiter(byte) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Defines the field delimiter character.
setDeterministic(boolean) - Method in class org.apache.drill.exec.planner.sql.DrillSqlOperator.DrillSqlOperatorBuilder
 
setDistributionAffinity(DistributionAffinity) - Method in class org.apache.drill.exec.planner.fragment.Stats
 
setDouble(int, double) - Method in class org.apache.drill.exec.record.DeadBuf
 
setDoubleStat(MetricDef, double) - Method in interface org.apache.drill.exec.ops.OperatorStatReceiver
Set a stat to the specified double value.
setDoubleStat(MetricDef, double) - Method in class org.apache.drill.exec.ops.OperatorStats
 
setDropBehind(Boolean) - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
setEmptyValue(String) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Sets the String representation of an empty value (defaults to null)
setEnabledInStorage(StoragePluginRegistry, boolean) - Method in class org.apache.drill.exec.server.rest.PluginConfigWrapper
 
setEncryption(boolean) - Method in class org.apache.drill.exec.rpc.AbstractServerConnection
 
setEndPoint(CoordinationProtos.DrillbitEndpoint) - Method in interface org.apache.drill.exec.coord.ClusterCoordinator.RegistrationHandle
 
setEndPoint(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.coord.zk.ZKRegistrationHandle
 
setEndpoint(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.rpc.control.CustomHandlerRegistry
 
setEndpointByteMap(EndpointByteMap) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan.RowGroupInfo
 
setException(SqlUnsupportedException.ExceptionType, String) - Method in class org.apache.drill.exec.exception.UnsupportedOperatorCollector
 
setException(SqlUnsupportedException.ExceptionType) - Method in class org.apache.drill.exec.exception.UnsupportedOperatorCollector
 
setExecutorState(FragmentContext.ExecutorState) - Method in class org.apache.drill.exec.ops.FragmentContext
 
setExpandedFully() - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
setExpandedPartial() - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
setExtendedClass(Class<?>) - Method in class org.apache.drill.exec.compile.ClassBodyBuilder
 
setFieldDelimiter(char) - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
Deprecated.
setFieldType(TypeProtos.MajorType) - Method in class org.apache.drill.exec.schema.Field
 
setFilter(LogicalExpression) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
setFilterPushedDown(boolean) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaGroupScan
 
setFlattenField(RepeatedValueVector) - Method in interface org.apache.drill.exec.physical.impl.flatten.Flattener
 
setFlattenField(RepeatedValueVector) - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenTemplate
 
setFloat(int, float) - Method in class org.apache.drill.exec.record.DeadBuf
 
setForcefulShutdown(boolean) - Method in class org.apache.drill.exec.server.Drillbit
 
setFragmentLimit(long) - Method in class org.apache.drill.exec.ops.FragmentContext
 
setFrameSlot(int) - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
 
setFromBuffer(int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager.BatchSizeEstimate
 
setFromData(int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager.BatchSizeEstimate
 
setFromWorstCaseBuffer(int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager.BatchSizeEstimate
 
setFunctionArgument() - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
Mark this value as being used as a function argument.
setFunctionRegistryVersion(long) - Method in class org.apache.drill.exec.planner.sql.DrillOperatorTable
Set function registry version based on which operator table was loaded.
setHadWildcard(boolean) - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
setHasMoreData(boolean) - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
setHeaderExtractionEnabled(boolean) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Defines whether or not the first valid record parsed from the input should be considered as the row containing the names of each column
setIdentifierMaxLength(int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
setIdentityService(IdentityService) - Method in class org.apache.drill.exec.server.rest.auth.DrillRestLoginService
 
setIgnoreAuthErrors(boolean) - Method in class org.apache.drill.exec.store.SchemaConfig.Builder
 
setIgnoreJSONParseErrors(boolean) - Method in interface org.apache.drill.exec.store.easy.json.JsonProcessor
 
setIgnoreJSONParseErrors(boolean) - Method in class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
 
setIgnoreLeadingWhitespaces(boolean) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
setIgnoreTrailingWhitespaces(boolean) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
setImplementedInterfaces(Class<?>...) - Method in class org.apache.drill.exec.compile.ClassBodyBuilder
 
setImports(String[]) - Method in class org.apache.drill.exec.compile.ClassBodyBuilder
 
setIndex(int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
setIndex(int, char) - Method in class org.apache.drill.exec.record.selection.SelectionVector2
 
setIndex(int, int) - Method in class org.apache.drill.exec.record.selection.SelectionVector2
 
setInfoSchemaFilter(InfoSchemaFilter) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
 
setInjector(ControlsInjector) - Method in class org.apache.drill.exec.ops.BaseOperatorContext
 
setInjector(ControlsInjector) - Method in interface org.apache.drill.exec.ops.OperatorContext
 
setInt(int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
setInterpreter(DrillSimpleFunc) - Method in class org.apache.drill.exec.expr.DrillFuncHolderExpr
 
setIsLast() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
setLength(int) - Method in class org.apache.drill.exec.expr.fn.impl.DrillByteArray
 
setLocalOption(String, boolean) - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
setLocalOption(String, long) - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
setLocalOption(String, double) - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
setLocalOption(String, String) - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
setLocalOption(String, Object) - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
setLocalOption(OptionValue.Kind, String, String) - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
setLocalOption(String, boolean) - Method in interface org.apache.drill.exec.server.options.OptionManager
Sets a boolean option on the OptionManager.
setLocalOption(String, long) - Method in interface org.apache.drill.exec.server.options.OptionManager
Sets a long option on the OptionManager.
setLocalOption(String, double) - Method in interface org.apache.drill.exec.server.options.OptionManager
Sets a double option on the OptionManager.
setLocalOption(String, String) - Method in interface org.apache.drill.exec.server.options.OptionManager
Sets a String option on the OptionManager.
setLocalOption(String, Object) - Method in interface org.apache.drill.exec.server.options.OptionManager
Sets an option on the OptionManager.
setLocalOption(OptionValue.Kind, String, String) - Method in interface org.apache.drill.exec.server.options.OptionManager
Sets an option of the specified OptionValue.Kind on the OptionManager.
setLocalOptionHelper(OptionValue) - Method in class org.apache.drill.exec.server.options.BaseOptionManager
 
setLocalOptionHelper(OptionValue) - Method in class org.apache.drill.exec.server.options.FragmentOptionManager
 
setLocalOptionHelper(OptionValue) - Method in class org.apache.drill.exec.server.options.InMemoryOptionManager
 
setLocalOptionHelper(OptionValue) - Method in class org.apache.drill.exec.server.options.SessionOptionManager
 
setLocalOptionHelper(OptionValue) - Method in class org.apache.drill.exec.server.options.SystemOptionManager
 
setLong(int, long) - Method in class org.apache.drill.exec.record.DeadBuf
 
setLongStat(MetricDef, long) - Method in interface org.apache.drill.exec.ops.OperatorStatReceiver
Set a stat to the specified long value.
setLongStat(MetricDef, long) - Method in class org.apache.drill.exec.ops.OperatorStats
 
setMajor(UserBitShared.MajorFragmentProfile) - Method in class org.apache.drill.exec.server.rest.profile.OperatorPathBuilder
 
setMajor(int) - Method in class org.apache.drill.exec.server.rest.profile.OperatorPathBuilder
 
setMappingSet(MappingSet) - Method in class org.apache.drill.exec.expr.ClassGenerator
 
setMax(Object) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata
Set the max value recorded in the parquet metadata statistics.
setMax(Object) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
setter used during deserialization of the 'max' field of the metadata cache file.
setMax(Object) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2
 
setMax(Object) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3
 
setMaxAllocation(long) - Method in class org.apache.drill.exec.physical.base.AbstractBase
Any operator that supports spilling should override this method
setMaxAllocation(long) - Method in interface org.apache.drill.exec.physical.base.PhysicalOperator
 
setMaxAllocation(long) - Method in class org.apache.drill.exec.physical.config.ExternalSort
 
setMaxAllocation(long) - Method in class org.apache.drill.exec.physical.config.HashAggregate
 
setMaxCharsPerColumn(long) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
setMaxVarcharSize(int) - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
 
setMaxVarcharSize(int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
setMaxWidth(int) - Method in class org.apache.drill.exec.physical.EndpointAffinity
Set the new max width as the minimum of the the given value and current max width.
setMaxWrappedSize(int) - Method in class org.apache.drill.exec.rpc.AbstractServerConnection
 
setMedium(int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
setMemoryPerNode(long) - Method in class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue
 
setMemoryPerNode(long) - Method in class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue
 
setMemoryPerNode(long) - Method in interface org.apache.drill.exec.work.foreman.rm.QueryQueue
 
setMetaContext(MetadataContext) - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
setMetadataCacheCorrupted(boolean) - Method in class org.apache.drill.exec.store.dfs.MetadataContext
Setting this as true allows to avoid double reading of corrupted, unsupported or missing metadata files
setMin(Object) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata
Set the min value recorded in the parquet metadata statistics.
setMin(Object) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v1
setter used during deserialization of the 'min' field of the metadata cache file.
setMin(Object) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v2
 
setMin(Object) - Method in class org.apache.drill.exec.store.parquet.Metadata.ColumnMetadata_v3
 
setMinor(UserBitShared.MinorFragmentProfile) - Method in class org.apache.drill.exec.server.rest.profile.OperatorPathBuilder
 
setMinor(int) - Method in class org.apache.drill.exec.server.rest.profile.OperatorPathBuilder
 
setName(String) - Method in class org.apache.drill.exec.planner.sql.DrillSqlAggOperator.DrillSqlAggOperatorBuilder
 
setName(String) - Method in class org.apache.drill.exec.planner.sql.DrillSqlOperator.DrillSqlOperatorBuilder
 
setNiladic(boolean) - Method in class org.apache.drill.exec.planner.sql.DrillSqlOperator.DrillSqlOperatorBuilder
 
setNormalizedNewLine(byte) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
setNumberOfRecordsToRead(int) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Defines the number of valid records to be parsed before the process is stopped.
setNumEndPoints(int) - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
setNumRecordsToRead(long) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan.RowGroupInfo
 
setOperator(UserBitShared.OperatorProfile) - Method in class org.apache.drill.exec.server.rest.profile.OperatorPathBuilder
 
setOperator(int) - Method in class org.apache.drill.exec.server.rest.profile.OperatorPathBuilder
 
setOperatorId(int) - Method in class org.apache.drill.exec.physical.base.AbstractBase
 
setOperatorId(int) - Method in interface org.apache.drill.exec.physical.base.PhysicalOperator
 
SetOptionHandler - Class in org.apache.drill.exec.planner.sql.handlers
Converts a SqlNode representing "ALTER ..
SetOptionHandler(QueryContext) - Constructor for class org.apache.drill.exec.planner.sql.handlers.SetOptionHandler
 
setOwner(Path, String, String) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
setParseUnescapedQuotes(boolean) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Configures how to handle unescaped quotes inside quoted values.
setPartitionVector(BitVector) - Method in class org.apache.drill.exec.store.AbstractRecordWriter
 
setPermission(Path, FsPermission) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
setPosition(int) - Method in class org.apache.drill.exec.store.EventBasedRecordWriter.FieldConverter
 
setPosition(int) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetRecordMaterializer
 
setPosition(int) - Method in class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
 
setPruneStatus(MetadataContext.PruneStatus) - Method in class org.apache.drill.exec.store.dfs.MetadataContext
 
setQueueName(String) - Method in class org.apache.drill.exec.work.foreman.QueryManager
 
setQuiescentMode(boolean) - Method in class org.apache.drill.exec.server.Drillbit
 
setQuote(byte) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Defines the character used for escaping values where the field delimiter is part of the value.
setQuotedCasing(Casing) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
setQuoteEscape(byte) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
Defines the character used for escaping quotes inside an already quoted value.
setRead(boolean) - Method in class org.apache.drill.exec.schema.Field
 
setReadahead(Long) - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
setRecordCount(int) - Method in class org.apache.drill.exec.record.selection.SelectionVector2
 
setRecordCount(int) - Method in class org.apache.drill.exec.record.VectorContainer
 
setRecordMatched(int) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelper
 
setRelDataTypeFactory(RelDataTypeFactory) - Method in class org.apache.drill.exec.planner.types.RelDataTypeHolder
 
setReplication(Path, short) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
setRowType() - Method in class org.apache.drill.exec.planner.common.DrillWriterRelBase
 
SETS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.NullableVarLengthValuesColumn
 
setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.Decimal28Column
 
setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.Decimal38Column
 
setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.NullableDecimal28Column
 
setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.NullableDecimal38Column
 
setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.NullableVarBinaryColumn
 
setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.NullableVarCharColumn
 
setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.VarBinaryColumn
 
setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.VarCharColumn
 
setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthValuesColumn
 
setSaslClient(SaslClient) - Method in class org.apache.drill.exec.rpc.AbstractClientConnection
 
setSaslClient(SaslClient) - Method in class org.apache.drill.exec.rpc.control.ControlConnection
 
setSchema(BatchSchema) - Method in class org.apache.drill.exec.physical.impl.xsort.BatchGroup
Updates the schema for this batch group.
setSchema(BatchSchema) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
Updates the schema for this batch group.
setSchema(BatchSchema) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BufferedBatches
 
setSchema(BatchSchema) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl
 
setSchema(BatchSchema) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SpilledRuns
 
setSelectionVectorMode(BatchSchema.SelectionVectorMode) - Method in class org.apache.drill.exec.record.SchemaBuilder
 
setSessionOption(String, String) - Method in class org.apache.drill.exec.rpc.user.UserSession
Set the option of a session level.
setShort(int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
setSkipFirstLine(boolean) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
setSource(InputStream) - Method in interface org.apache.drill.exec.store.easy.json.JsonProcessor
 
setSource(JsonNode) - Method in interface org.apache.drill.exec.store.easy.json.JsonProcessor
 
setSource(InputStream) - Method in class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
 
setSource(JsonNode) - Method in class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
 
setSource(int, int, DrillBuf) - Method in class org.apache.drill.exec.vector.complex.fn.JsonReader
 
setSource(InputStream) - Method in class org.apache.drill.exec.vector.complex.fn.JsonReader
 
setSource(JsonNode) - Method in class org.apache.drill.exec.vector.complex.fn.JsonReader
 
setSource(String) - Method in class org.apache.drill.exec.vector.complex.fn.JsonReader
 
setSource(byte[]) - Method in class org.apache.drill.exec.vector.complex.fn.JsonReader
 
setSql(String) - Method in class org.apache.drill.exec.dotdrill.View
 
setSslChannel(Channel) - Method in class org.apache.drill.exec.rpc.user.UserServer
 
setState(DrillbitStateManager.DrillbitState) - Method in class org.apache.drill.exec.server.DrillbitStateManager
 
setStatus(String) - Method in class org.apache.drill.exec.store.dfs.MetadataContext
 
setStatus(BitControl.FragmentStatus) - Method in class org.apache.drill.exec.work.foreman.FragmentData
Update the status for this fragment.
setStorageStrategy(StorageStrategy) - Method in class org.apache.drill.exec.physical.base.AbstractWriter
 
setSupportComplexTypes(boolean) - Method in class org.apache.drill.exec.client.DrillClient
Sets whether the application is willing to accept complex types (Map, Arrays) in the returned result set.
setSupportComplexTypes(boolean) - Method in class org.apache.drill.exec.rpc.user.UserSession.Builder
 
setSv2(SelectionVector2) - Method in class org.apache.drill.exec.physical.impl.sort.RecordBatchData
 
setSwapped(boolean) - Method in class org.apache.drill.exec.planner.physical.HashJoinPrel
 
setTabSize(int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
setTabSize(int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
setTestInjectionControls(ControlsInjector, ExecutionControls, Logger) - Method in class org.apache.drill.exec.ops.AccountingDataTunnel
setTestInjectionControls(ControlsInjector, ExecutionControls, Logger) - Method in class org.apache.drill.exec.rpc.data.DataTunnel
Once a DataTunnel is created, clients of DataTunnel can pass injection controls to enable setting injections at pre-defined places.
setThis() - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
Mark this value as a "this" reference.
setTimes(Path, long, long) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
setTotalCost(double) - Method in class org.apache.drill.exec.work.foreman.QueryManager
 
setUnquotedCasing(Casing) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
setup() - Method in interface org.apache.drill.exec.expr.DrillAggFunc
Initialization for the beginning of the aggregation.
setup() - Method in interface org.apache.drill.exec.expr.DrillSimpleFunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.ExceptionFunction.ThrowException
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.BigIntBigIntAdd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.Float4Float4Add
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.Float8Float8Add
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.IntIntAdd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.SmallIntSmallIntAdd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.TinyIntTinyIntAdd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.UInt1UInt1Add
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.UInt2UInt2Add
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.UInt4UInt4Add
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.AddFunctions.UInt8UInt8Add
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.BitAggregateErrorFunctions
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.NullableBitAggregateErrorFunctions
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.NullableVarCharAggregateErrorFunctions
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.VarCharAggregateErrorFunctions
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Alternator.Alternate2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Alternator.Alternate3
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.BitFunctions.BitAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.BitFunctions.BitOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.BitFunctions.IntXor
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.BitBooleanAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.BitBooleanOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.NullableBitBooleanAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.BooleanAggrFunctions.NullableBitBooleanOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ByteSubstring
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.CastBigIntDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.CastBigIntTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.CastIntTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.CastVarCharVar16Char
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.CharSubstring
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ContextFunctions.CurrentSchema
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ContextFunctions.SessionId
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ContextFunctions.User
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BigIntBEConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BigIntBEConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BigIntConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BigIntConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BigIntVLongConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BigIntVLongConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BooleanByteConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.BooleanByteConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.ConvertFromImpalaTimestamp.ImpalaTimestampConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DateEpochBEConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DateEpochBEConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DateEpochConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DateEpochConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DoubleBEConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DoubleBEConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DoubleConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DoubleConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DummyConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DummyConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.DummyFlatten
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.FloatBEConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.FloatBEConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.FloatConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.FloatConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.IntBEConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.IntBEConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.IntConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.IntConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.IntVIntConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.IntVIntConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertFrom.ConvertFromJson
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertFrom.ConvertFromJsonVarchar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertTo.ConvertToExtendedJson
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertTo.ConvertToJson
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.SmallIntBEConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.SmallIntBEConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.SmallIntConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.SmallIntConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeEpochBEConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeEpochBEConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeEpochConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeEpochConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeStampEpochBEConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeStampEpochBEConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeStampEpochConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TimeStampEpochConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TinyIntConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.TinyIntConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UInt4BEConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UInt4BEConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UInt4ConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UInt4ConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UInt8ConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UInt8ConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UTF16ConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UTF16ConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UTF8ConvertFrom
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.conv.UTF8ConvertTo
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.AESDecryptFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.AESEncryptFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.MD2Function
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.MD5Function
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.SHA1Function
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.SHA256Function
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.SHA384Function
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.CryptoFunctions.SHA512Function
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateBigIntFunctions.BigIntDateAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateBigIntFunctions.DateBigIntAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateBigIntFunctions.DateBigIntSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalDayFunctions.DateIntervalDayAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalDayFunctions.DateIntervalDaySubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalDayFunctions.IntervalDayDateAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalFunctions.DateIntervalAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalFunctions.DateIntervalSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalFunctions.IntervalDateAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalYearFunctions.DateIntervalYearAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalYearFunctions.DateIntervalYearSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntervalYearFunctions.IntervalYearDateAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntFunctions.DateIntAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntFunctions.DateIntSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateIntFunctions.IntDateAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.AgeDate2Function
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.AgeDateFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.AgeTimeStamp2Function
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.AgeTimeStampFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.CastTimeStampToTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.CurrentDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.CurrentTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.DatePartFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.DateTimeAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.DateType
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IntervalDayType
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IntervalType
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IntervalYearType
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IsDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IsDateRequiredInput
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.LocalTimeStampNiladic
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.LocalTimeStampNonNiladic
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeDateAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeOfDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeStampType
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeType
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.UnixTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.UnixTimeStampForDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.UnixTimeStampForDateWithPattern
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18AbsFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18AddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18CeilFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18DivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18Equal
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18FloorFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18GreaterThan
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18GreaterThanEq
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18LessThan
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18LessThanEq
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18ModFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18MultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18NotEqual
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18RoundFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18RoundScaleFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18SignFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18SubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18TruncateScaleFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.Decimal18TruncFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareDecimal18VsDecimal18NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareDecimal18VsDecimal18NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareDecimal18VsNullableDecimal18NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareDecimal18VsNullableDecimal18NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareNullableDecimal18VsDecimal18NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareNullableDecimal18VsDecimal18NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareNullableDecimal18VsNullableDecimal18NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal18Functions.GCompareNullableDecimal18VsNullableDecimal18NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseEqual
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseGreaterThan
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseGreaterThanEq
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseLessThan
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseLessThanEq
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.Decimal28DenseNotEqual
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareDecimal28DenseVsDecimal28DenseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareDecimal28DenseVsDecimal28DenseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareDecimal28DenseVsNullableDecimal28DenseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareDecimal28DenseVsNullableDecimal28DenseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsDecimal28DenseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsDecimal28DenseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsNullableDecimal28DenseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28DenseFunctions.GCompareNullableDecimal28DenseVsNullableDecimal28DenseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseAbsFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseCeilFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseDivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseEqual
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseFloorFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseGreaterThan
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseGreaterThanEq
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseLessThan
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseLessThanEq
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseModFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseNotEqual
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseRoundFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseRoundScaleFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseSignFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseTruncateFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.Decimal28SparseTruncateScaleFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareDecimal28SparseVsDecimal28SparseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareDecimal28SparseVsDecimal28SparseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareDecimal28SparseVsNullableDecimal28SparseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareDecimal28SparseVsNullableDecimal28SparseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsDecimal28SparseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsDecimal28SparseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsNullableDecimal28SparseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal28SparseFunctions.GCompareNullableDecimal28SparseVsNullableDecimal28SparseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseEqual
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseGreaterThan
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseGreaterThanEq
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseLessThan
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseLessThanEq
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.Decimal38DenseNotEqual
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareDecimal38DenseVsDecimal38DenseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareDecimal38DenseVsDecimal38DenseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareDecimal38DenseVsNullableDecimal38DenseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareDecimal38DenseVsNullableDecimal38DenseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsDecimal38DenseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsDecimal38DenseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsNullableDecimal38DenseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38DenseFunctions.GCompareNullableDecimal38DenseVsNullableDecimal38DenseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseAbsFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseCeilFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseDivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseEqual
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseFloorFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseGreaterThan
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseGreaterThanEq
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseLessThan
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseLessThanEq
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseModFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseNotEqual
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseRoundFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseRoundScaleFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseSignFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseTruncateFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.Decimal38SparseTruncateScaleFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareDecimal38SparseVsDecimal38SparseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareDecimal38SparseVsDecimal38SparseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareDecimal38SparseVsNullableDecimal38SparseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareDecimal38SparseVsNullableDecimal38SparseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsDecimal38SparseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsDecimal38SparseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsNullableDecimal38SparseNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal38SparseFunctions.GCompareNullableDecimal38SparseVsNullableDecimal38SparseNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9AbsFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9AddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9CeilFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9DivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9Equal
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9FloorFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9GreaterThan
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9GreaterThanEq
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9LessThan
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9LessThanEq
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9ModFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9MultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9NotEqual
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9RoundFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9RoundScaleFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9SignFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9SubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9TruncateScaleFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.Decimal9TruncFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareDecimal9VsDecimal9NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareDecimal9VsDecimal9NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareDecimal9VsNullableDecimal9NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareDecimal9VsNullableDecimal9NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareNullableDecimal9VsDecimal9NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareNullableDecimal9VsDecimal9NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareNullableDecimal9VsNullableDecimal9NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Decimal9Functions.GCompareNullableDecimal9VsNullableDecimal9NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.IMaxDir
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.IMaxDirTwoArg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.IMinDir
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.IMinDirTwoArg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.MaxDir
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.MaxDirTwoArg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.MinDir
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DirectoryExplorers.MinDirTwoArg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.BigIntBigIntDivide
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.Float4Float4Divide
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.Float8Float8Divide
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.IntIntDivide
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.SmallIntSmallIntDivide
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.TinyIntTinyIntDivide
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.UInt1UInt1Divide
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.UInt2UInt2Divide
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.UInt4UInt4Divide
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.DivideFunctions.UInt8UInt8Divide
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.CbrtUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.DegreesUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.ExpUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBaseUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.LogUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ExtendedMathFunctions.RadiansUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.BigIntAvg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.Float4Avg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.Float8Avg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.IntAvg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableBigIntAvg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableFloat4Avg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableFloat8Avg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgFunctions.NullableIntAvg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.IntervalAvg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.IntervalDayAvg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.IntervalYearAvg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.NullableIntervalAvg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.NullableIntervalDayAvg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.AvgIntervalTypeFunctions.NullableIntervalYearAvg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.BigIntBitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.IntBitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableBigIntBitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableIntBitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableSmallIntBitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableTinyIntBitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt1BitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt2BitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt4BitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.NullableUInt8BitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.SmallIntBitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.TinyIntBitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt1BitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt2BitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt4BitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseAndFunctions.UInt8BitwiseAnd
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.BigIntBitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.IntBitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableBigIntBitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableIntBitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableSmallIntBitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableTinyIntBitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt1BitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt2BitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt4BitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.NullableUInt8BitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.SmallIntBitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.TinyIntBitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt1BitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt2BitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt4BitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.BitwiseOrFunctions.UInt8BitwiseOr
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.BigIntCorrelation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.Float4Correlation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.Float8Correlation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.IntCorrelation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableBigIntCorrelation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableFloat4Correlation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableFloat8Correlation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableIntCorrelation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableSmallIntCorrelation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableTinyIntCorrelation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt1Correlation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt2Correlation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt4Correlation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.NullableUInt8Correlation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.SmallIntCorrelation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.TinyIntCorrelation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt1Correlation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt2Correlation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt4Correlation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CorrelationFunctions.UInt8Correlation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.BigIntCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.BitCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.DateCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal18CountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal28SparseCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal38SparseCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Decimal9CountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Float4CountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.Float8CountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntervalCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntervalDayCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.IntervalYearCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.ListCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.MapCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableBigIntCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableBitCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDateCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal18CountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal28SparseCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal38SparseCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableDecimal9CountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableFloat4CountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableFloat8CountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntervalCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntervalDayCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableIntervalYearCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableTimeCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableTimeStampCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableVarBinaryCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.NullableVarCharCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedBigIntCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedBitCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDateCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal18CountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal28SparseCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal38SparseCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedDecimal9CountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedFloat4CountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedFloat8CountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntervalCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntervalDayCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedIntervalYearCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedListCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedMapCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedTimeCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedTimeStampCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedVarBinaryCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.RepeatedVarCharCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.TimeCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.TimeStampCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.VarBinaryCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CountFunctions.VarCharCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.BigIntCoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.Float4CoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.Float8CoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.IntCoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableBigIntCoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableFloat4CoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableFloat8CoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableIntCoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableSmallIntCoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableTinyIntCoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt1CoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt2CoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt4CoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.NullableUInt8CoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.SmallIntCoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.TinyIntCoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt1CoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt2CoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt4CoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVariancePopulationFunctions.UInt8CoVariancePopulation
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.BigIntCoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.Float4CoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.Float8CoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.IntCoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableBigIntCoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableFloat4CoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableFloat8CoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableIntCoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableSmallIntCoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableTinyIntCoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt1CoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt2CoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt4CoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.NullableUInt8CoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.SmallIntCoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.TinyIntCoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt1CoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt2CoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt4CoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.CoVarianceSampleFunctions.UInt8CoVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal18Avg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal28SparseAvg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal38SparseAvg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.Decimal9Avg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal18Avg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal28SparseAvg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal38SparseAvg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalAvgFunctions.NullableDecimal9Avg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal18Max
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal28SparseMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal38SparseMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.Decimal9Max
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal18Max
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal28SparseMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal38SparseMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMaxFunctions.NullableDecimal9Max
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal18Min
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal28SparseMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal38SparseMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.Decimal9Min
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal18Min
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal28SparseMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal38SparseMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalMinFunctions.NullableDecimal9Min
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal18Sum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal28SparseSum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal38SparseSum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.Decimal9Sum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal18Sum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal28SparseSum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal38SparseSum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.DecimalSumFunctions.NullableDecimal9Sum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.DateMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.IntervalDayMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.IntervalMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.IntervalYearMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableDateMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableIntervalDayMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableIntervalMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableIntervalYearMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableTimeMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.NullableTimeStampMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.TimeMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxDateTypeFunctions.TimeStampMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.BigIntMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.Float4Max
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.Float8Max
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.IntMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableBigIntMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableFloat4Max
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableFloat8Max
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxFunctions.NullableIntMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.NullableVarBinaryMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.NullableVarCharMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.VarBinaryMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MaxVarBytesFunctions.VarCharMax
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.DateMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.IntervalDayMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.IntervalMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.IntervalYearMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableDateMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableIntervalDayMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableIntervalMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableIntervalYearMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableTimeMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.NullableTimeStampMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.TimeMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinDateTypeFunctions.TimeStampMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.BigIntMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.BitMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.Float4Min
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.Float8Min
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.IntMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableBigIntMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableBitMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableFloat4Min
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableFloat8Min
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinFunctions.NullableIntMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.NullableVarBinaryMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.NullableVarCharMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.VarBinaryMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.MinVarBytesFunctions.VarCharMin
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.BigIntStdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.Float4StdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.Float8StdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.IntStdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableBigIntStdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableFloat4StdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableFloat8StdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableIntStdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableSmallIntStdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableTinyIntStdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt1StdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt2StdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt4StdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt8StdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.SmallIntStdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.TinyIntStdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt1StdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt2StdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt4StdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt8StdDevPop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.BigIntStdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.Float4StdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.Float8StdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.IntStdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableBigIntStdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableFloat4StdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableFloat8StdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableIntStdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableSmallIntStdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableTinyIntStdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt1StdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt2StdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt4StdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt8StdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.SmallIntStdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.TinyIntStdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt1StdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt2StdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt4StdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt8StdDevSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.IntervalDaySum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.IntervalSum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.IntervalYearSum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.NullableIntervalDaySum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.NullableIntervalSum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.NullableIntervalYearSum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.BigIntSum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.Float4Sum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.Float8Sum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.IntSum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableBigIntSum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableFloat4Sum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableFloat8Sum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableIntSum
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.BigIntSumZero
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.BitSumZero
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.Float4SumZero
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.Float8SumZero
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.IntSumZero
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableBigIntSumZero
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableBitSumZero
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableFloat4SumZero
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableFloat8SumZero
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableIntSumZero
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.BigIntVariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.Float4VariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.Float8VariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.IntVariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableBigIntVariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableFloat4VariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableFloat8VariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableIntVariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableSmallIntVariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableTinyIntVariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt1VariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt2VariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt4VariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt8VariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.SmallIntVariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.TinyIntVariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt1VariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt2VariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt4VariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt8VariancePop
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.BigIntVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.Float4VarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.Float8VarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.IntVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableBigIntVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableFloat4VarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableFloat8VarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableIntVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableSmallIntVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableTinyIntVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt1VarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt2VarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt4VarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt8VarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.SmallIntVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.TinyIntVarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt1VarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt2VarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt4VarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt8VarianceSample
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GBigIntToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GBigIntToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntDecimal28Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntDecimal38Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBigIntVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastBitTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDateToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDateToVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18BigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Decimal28Dense
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Decimal28Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Decimal38Dense
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Decimal38Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Decimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Float4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Float8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18Int
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal18VarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28DenseDecimal28Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28DenseDecimal38Dense
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28DenseDecimal38Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28DenseFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28DenseFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseDecimal28Dense
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseDecimal38Dense
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseDecimal38Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal28SparseVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38DenseDecimal38Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38DenseFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38DenseFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseDecimal28Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseDecimal38Dense
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal38SparseVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9BigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Decimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Decimal28Dense
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Decimal28Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Decimal38Dense
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Decimal38Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Float4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Float8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9Int
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastDecimal9VarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableDecimal28Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableDecimal38Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVar16CharToNullableInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableDecimal28Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableDecimal38Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarBinaryToNullableInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableDecimal28Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableDecimal38Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringNullableVarCharToNullableInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableDecimal28Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableDecimal38Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastEmptyStringVarCharToNullableInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4BigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Decimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Decimal28Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Decimal38Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Decimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Float8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4Int
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4VarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat4VarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8BigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Decimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Decimal28Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Decimal38Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Decimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Float4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8Int
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8VarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastFloat8VarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighDecimal28Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighDecimal38Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastHighFunctions.CastHighInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntDecimal28Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntDecimal38Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalDayToInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalDayToVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalToIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalToIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalToVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalYearToInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntervalYearToVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastIntVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastTimeStampToDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastTimeStampToVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastTimeToVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastTinyIntBit
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryToDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryToTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarBinaryVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharDecimal28Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharDecimal38Sparse
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.gcast.CastVarCharVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.EqualsBigIntVsBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareBigIntVsBigIntNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareBigIntVsBigIntNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareBigIntVsNullableBigIntNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareBigIntVsNullableBigIntNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareNullableBigIntVsBigIntNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareNullableBigIntVsBigIntNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareNullableBigIntVsNullableBigIntNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GCompareNullableBigIntVsNullableBigIntNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GreaterThanBigIntVsBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.GreaterThanEqBigIntVsBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.LessThanBigIntVsBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.LessThanEqBigIntVsBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBigIntVsBigInt.NotEqualsBigIntVsBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.EqualsBitVsBit
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareBitVsBitNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareBitVsBitNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareBitVsNullableBitNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareBitVsNullableBitNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareNullableBitVsBitNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareNullableBitVsBitNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareNullableBitVsNullableBitNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GCompareNullableBitVsNullableBitNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GreaterThanBitVsBit
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.GreaterThanEqBitVsBit
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.LessThanBitVsBit
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.LessThanEqBitVsBit
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareBitVsBit.NotEqualsBitVsBit
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.EqualsDateVsDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareDateVsDateNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareDateVsDateNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareDateVsNullableDateNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareDateVsNullableDateNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareNullableDateVsDateNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareNullableDateVsDateNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareNullableDateVsNullableDateNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GCompareNullableDateVsNullableDateNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GreaterThanDateVsDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.GreaterThanEqDateVsDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.LessThanDateVsDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.LessThanEqDateVsDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareDateVsDate.NotEqualsDateVsDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.EqualsFloat4VsFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareFloat4VsFloat4NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareFloat4VsFloat4NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareFloat4VsNullableFloat4NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareFloat4VsNullableFloat4NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareNullableFloat4VsFloat4NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareNullableFloat4VsFloat4NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareNullableFloat4VsNullableFloat4NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GCompareNullableFloat4VsNullableFloat4NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GreaterThanEqFloat4VsFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.GreaterThanFloat4VsFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.LessThanEqFloat4VsFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.LessThanFloat4VsFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat4VsFloat4.NotEqualsFloat4VsFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.EqualsFloat8VsFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareFloat8VsFloat8NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareFloat8VsFloat8NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareFloat8VsNullableFloat8NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareFloat8VsNullableFloat8NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareNullableFloat8VsFloat8NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareNullableFloat8VsFloat8NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareNullableFloat8VsNullableFloat8NullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GCompareNullableFloat8VsNullableFloat8NullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GreaterThanEqFloat8VsFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.GreaterThanFloat8VsFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.LessThanEqFloat8VsFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.LessThanFloat8VsFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareFloat8VsFloat8.NotEqualsFloat8VsFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.EqualsIntervalDayVsIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsIntervalDayNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsIntervalDayNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsNullableIntervalDayNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareIntervalDayVsNullableIntervalDayNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsIntervalDayNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsIntervalDayNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsNullableIntervalDayNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GCompareNullableIntervalDayVsNullableIntervalDayNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GreaterThanEqIntervalDayVsIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.GreaterThanIntervalDayVsIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.LessThanEqIntervalDayVsIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.LessThanIntervalDayVsIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalDayVsIntervalDay.NotEqualsIntervalDayVsIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.EqualsIntervalVsInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareIntervalVsIntervalNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareIntervalVsIntervalNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareIntervalVsNullableIntervalNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareIntervalVsNullableIntervalNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareNullableIntervalVsIntervalNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareNullableIntervalVsIntervalNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareNullableIntervalVsNullableIntervalNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GCompareNullableIntervalVsNullableIntervalNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GreaterThanEqIntervalVsInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.GreaterThanIntervalVsInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.LessThanEqIntervalVsInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.LessThanIntervalVsInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalVsInterval.NotEqualsIntervalVsInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.EqualsIntervalYearVsIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsIntervalYearNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsIntervalYearNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsNullableIntervalYearNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareIntervalYearVsNullableIntervalYearNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsIntervalYearNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsIntervalYearNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsNullableIntervalYearNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GCompareNullableIntervalYearVsNullableIntervalYearNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GreaterThanEqIntervalYearVsIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.GreaterThanIntervalYearVsIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.LessThanEqIntervalYearVsIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.LessThanIntervalYearVsIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntervalYearVsIntervalYear.NotEqualsIntervalYearVsIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.EqualsIntVsInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareIntVsIntNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareIntVsIntNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareIntVsNullableIntNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareIntVsNullableIntNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareNullableIntVsIntNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareNullableIntVsIntNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareNullableIntVsNullableIntNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GCompareNullableIntVsNullableIntNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GreaterThanEqIntVsInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.GreaterThanIntVsInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.LessThanEqIntVsInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.LessThanIntVsInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareIntVsInt.NotEqualsIntVsInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.EqualsTimeStampVsTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsNullableTimeStampNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsNullableTimeStampNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsTimeStampNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareNullableTimeStampVsTimeStampNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareTimeStampVsNullableTimeStampNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareTimeStampVsNullableTimeStampNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareTimeStampVsTimeStampNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GCompareTimeStampVsTimeStampNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GreaterThanEqTimeStampVsTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.GreaterThanTimeStampVsTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.LessThanEqTimeStampVsTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.LessThanTimeStampVsTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeStampVsTimeStamp.NotEqualsTimeStampVsTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.EqualsTimeVsTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareNullableTimeVsNullableTimeNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareNullableTimeVsNullableTimeNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareNullableTimeVsTimeNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareNullableTimeVsTimeNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareTimeVsNullableTimeNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareTimeVsNullableTimeNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareTimeVsTimeNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GCompareTimeVsTimeNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GreaterThanEqTimeVsTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.GreaterThanTimeVsTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.LessThanEqTimeVsTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.LessThanTimeVsTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareTimeVsTime.NotEqualsTimeVsTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.EqualsVarBinaryVsVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsNullableVarBinaryNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsNullableVarBinaryNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsVarBinaryNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareNullableVarBinaryVsVarBinaryNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsNullableVarBinaryNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsNullableVarBinaryNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsVarBinaryNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GCompareVarBinaryVsVarBinaryNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GreaterThanEqVarBinaryVsVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.GreaterThanVarBinaryVsVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.LessThanEqVarBinaryVsVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.LessThanVarBinaryVsVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarBinary.NotEqualsVarBinaryVsVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.EqualsVarBinaryVsVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsNullableVarCharNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsNullableVarCharNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsVarCharNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareNullableVarBinaryVsVarCharNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareVarBinaryVsNullableVarCharNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareVarBinaryVsNullableVarCharNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareVarBinaryVsVarCharNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GCompareVarBinaryVsVarCharNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GreaterThanEqVarBinaryVsVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.GreaterThanVarBinaryVsVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.LessThanEqVarBinaryVsVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.LessThanVarBinaryVsVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarBinaryVsVarChar.NotEqualsVarBinaryVsVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.EqualsVarCharVsVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareNullableVarCharVsNullableVarBinaryNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareNullableVarCharVsNullableVarBinaryNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareNullableVarCharVsVarBinaryNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareNullableVarCharVsVarBinaryNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareVarCharVsNullableVarBinaryNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareVarCharVsNullableVarBinaryNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareVarCharVsVarBinaryNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GCompareVarCharVsVarBinaryNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GreaterThanEqVarCharVsVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.GreaterThanVarCharVsVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.LessThanEqVarCharVsVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.LessThanVarCharVsVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarBinary.NotEqualsVarCharVsVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.EqualsVarCharVsVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareNullableVarCharVsNullableVarCharNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareNullableVarCharVsNullableVarCharNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareNullableVarCharVsVarCharNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareNullableVarCharVsVarCharNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareVarCharVsNullableVarCharNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareVarCharVsNullableVarCharNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareVarCharVsVarCharNullHigh
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GCompareVarCharVsVarCharNullLow
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GreaterThanEqVarCharVsVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.GreaterThanVarCharVsVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.LessThanEqVarCharVsVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.LessThanVarCharVsVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GCompareVarCharVsVarChar.NotEqualsVarCharVsVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableBigIntHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableBitHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDateHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal18Holder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal28DenseHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal28SparseHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal38DenseHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal38SparseHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableDecimal9Holder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableFloat4Holder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableFloat8Holder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableIntervalDayHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableIntervalHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableIntervalYearHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableIntHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableSmallIntHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableTimeHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableTimeStampHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableTinyIntHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableUInt1Holder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableUInt2Holder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableUInt4Holder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableUInt8Holder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableVar16CharHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableVarBinaryHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GConvertToNullableVarCharHolder
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateArithmetic.GDateDifference
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateCenturyDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateDayDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateDecadeDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateDummyDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateHourDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateMillenniumDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateMinuteDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateMonthDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateQuarterDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateSecondDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateWeekDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GDateYearDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalCenturyDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayCenturyDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayDayDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayDecadeDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayDummyDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayHourDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayMillenniumDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayMinuteDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayMonthDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayQuarterDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDaySecondDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDayYearDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDecadeDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalDummyDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalHourDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalMillenniumDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalMinuteDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalMonthDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalQuarterDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalSecondDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearCenturyDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearDayDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearDecadeDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearDummyDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearHourDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearMillenniumDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearMinuteDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearMonthDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearQuarterDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearSecondDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GIntervalYearYearDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeCenturyDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeDayDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeDecadeDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeDummyDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeHourDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeMillenniumDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeMinuteDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeMonthDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeQuarterDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeSecondDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampCenturyDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampDayDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampDecadeDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampDummyDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampHourDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampMillenniumDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampMinuteDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampMonthDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampQuarterDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampSecondDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampWeekDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeStampYearDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateTimeTruncateFunctions.GTimeYearDateTrunc
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDateToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal18ToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal18ToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal28DenseToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal28DenseToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal28SparseToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal28SparseToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal38DenseToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal38DenseToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal38SparseToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal38SparseToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal9ToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GDecimal9ToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.DayFromDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.DayFromInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.DayFromIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.DayFromIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.DayFromTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.HourFromTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MinuteFromTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MonthFromDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MonthFromInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MonthFromIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MonthFromIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.MonthFromTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.SecondFromTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.YearFromDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.YearFromInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.YearFromIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.YearFromIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GExtract.YearFromTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GFloat4ToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GFloat4ToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GFloat8ToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GFloat8ToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GIntToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GIntToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.AbsUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.CeilUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.DivUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.FloorUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.LeftShiftUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.ModUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.NegativeUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RightShiftUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.RounddUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SignUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.SqrtUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncateUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GMathFunctions.TruncUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueBigIntNullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueBit
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueBitNullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDateNullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDecimal18
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDecimal18Nullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDecimal9
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueDecimal9Nullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueFloat4Nullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueFloat8Nullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueIntNullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueSmallIntNullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTimeNullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTimeStampNullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueTinyIntNullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt1Nullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt2Nullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt4Nullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueUInt8Nullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVar16Char
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVar16CharNullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVarBinaryNullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNewValueFunctions.NewValueVarCharNullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpBigIntHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpBigIntHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpBitHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpBitHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDateHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDateHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal18Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal18Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal28DenseHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal28DenseHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal28SparseHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal28SparseHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal38DenseHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal38DenseHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal38SparseHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal38SparseHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal9Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpDecimal9Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpFloat4Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpFloat4Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpFloat8Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpFloat8Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalDayHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalDayHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalYearHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntervalYearHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpIntHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableBigIntHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableBigIntHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableBitHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableBitHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDateHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDateHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal18Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal18Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal28DenseHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal28DenseHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal28SparseHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal28SparseHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal38DenseHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal38DenseHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal38SparseHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal38SparseHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal9Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableDecimal9Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableFloat4Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableFloat4Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableFloat8Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableFloat8Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalDayHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalDayHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalYearHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntervalYearHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableIntHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableSmallIntHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableSmallIntHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTimeHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTimeHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTimeStampHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTimeStampHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTinyIntHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableTinyIntHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt1Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt1Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt2Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt2Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt4Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt4Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt8Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableUInt8Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVar16CharHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVar16CharHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVarBinaryHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVarBinaryHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVarCharHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpNullableVarCharHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedBigIntHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedBigIntHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedBitHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedBitHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDateHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDateHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal18Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal18Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal28DenseHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal28DenseHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal28SparseHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal28SparseHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal38DenseHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal38DenseHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal38SparseHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal38SparseHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal9Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedDecimal9Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedFloat4Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedFloat4Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedFloat8Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedFloat8Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalDayHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalDayHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalYearHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntervalYearHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedIntHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedSmallIntHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedSmallIntHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTimeHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTimeHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTimeStampHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTimeStampHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTinyIntHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedTinyIntHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt1Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt1Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt2Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt2Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt4Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt4Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt8Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedUInt8Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVar16CharHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVar16CharHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVarBinaryHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVarBinaryHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVarCharHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpRepeatedVarCharHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpSmallIntHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpSmallIntHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpTimeHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpTimeHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpTimeStampHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpTimeStampHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpTinyIntHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpTinyIntHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt1Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt1Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt2Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt2Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt4Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt4Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt8Holder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpUInt8Holder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpVar16CharHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpVar16CharHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpVarBinaryHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpVarBinaryHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpVarCharHolder.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GNullOpVarCharHolder.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GSmallIntToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GSmallIntToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GTimeArithmetic.GTimeDifference
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GTimeStampArithmetic.GTimeStampDifference
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GTimeStampToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GTimeToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GTinyIntToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GTinyIntToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GToDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GToTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt1ToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt1ToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt2ToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt2ToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt4ToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt4ToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt8ToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUInt8ToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionBit
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionVar16Char
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.CastUnionVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsBit
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsInterval
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsIntervalDay
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsIntervalYear
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsVar16Char
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsVarBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.GUnionFunctions.UnionIsVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.BigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.Decimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.Decimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.Decimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.Decimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.DoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.FloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.IntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableBigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableDecimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableDecimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableDecimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableDecimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableDoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableFloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.NullableIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.BigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.BitHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.DateHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Decimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Decimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Decimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Decimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.DoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.FloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.IntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableBigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableBitHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDateHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDecimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDecimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDecimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDecimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableDoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableFloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableTimeHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableTimeStampHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableVar16CharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableVarBinaryHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.NullableVarCharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.TimeHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.TimeStampHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Var16CharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.VarBinaryHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32Functions.VarCharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.BigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.BitHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.DateHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Decimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Decimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Decimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Decimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.DoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.FloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.IntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableBigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableBitHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDateHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDecimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDecimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDecimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDecimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableDoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableFloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableTimeHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableTimeStampHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableVar16CharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableVarBinaryHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.NullableVarCharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.TimeHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.TimeStampHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Var16CharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.VarBinaryHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.VarCharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.BigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.Decimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.Decimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.Decimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.Decimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.DoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.FloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.IntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableBigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableDecimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableDecimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableDecimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableDecimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableDoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableFloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.NullableIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.BigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.Decimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.Decimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.Decimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.Decimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.DoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.FloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.IntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableBigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableDecimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableDecimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableDecimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableDecimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableDoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableFloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.NullableIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.BigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.BitHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.DateHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Decimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Decimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Decimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Decimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.DoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.FloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.IntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableBigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableBitHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDateHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDecimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDecimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDecimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDecimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableDoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableFloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableTimeHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableTimeStampHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableVar16CharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableVarBinaryHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.NullableVarCharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.TimeHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.TimeStampHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Var16CharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.VarBinaryHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64Functions.VarCharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.BigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.BitHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.DateHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Decimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Decimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Decimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Decimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.DoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.FloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.IntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableBigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableBitHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDateHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDecimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDecimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDecimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDecimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableDoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableFloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableTimeHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableTimeStampHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableVar16CharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableVarBinaryHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.NullableVarCharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.TimeHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.TimeStampHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Var16CharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.VarBinaryHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.VarCharHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.BigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.Decimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.Decimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.Decimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.Decimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.DoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.FloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.IntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableBigIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableDecimal18Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableDecimal28Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableDecimal38Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableDecimal9Hash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableDoubleHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableFloatHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.NullableIntHash
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalBigIntFunctions.BigIntIntervalMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalBigIntFunctions.IntervalBigIntDivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalBigIntFunctions.IntervalBigIntMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayBigIntFunctions.BigIntIntervalDayMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayBigIntFunctions.IntervalDayBigIntDivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayBigIntFunctions.IntervalDayBigIntMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat4Functions.Float4IntervalDayMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat4Functions.IntervalDayFloat4DivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat4Functions.IntervalDayFloat4MultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat8Functions.Float8IntervalDayMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat8Functions.IntervalDayFloat8DivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFloat8Functions.IntervalDayFloat8MultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFunctions.IntervalDayAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFunctions.IntervalDayNegateFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayFunctions.IntervalDaySubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayIntFunctions.IntervalDayIntDivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayIntFunctions.IntervalDayIntMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalDayIntFunctions.IntIntervalDayMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFloat4Functions.Float4IntervalMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFloat4Functions.IntervalFloat4DivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFloat4Functions.IntervalFloat4MultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFloat8Functions.Float8IntervalMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFloat8Functions.IntervalFloat8DivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFloat8Functions.IntervalFloat8MultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFunctions.IntervalAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFunctions.IntervalNegateFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalFunctions.IntervalSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalIntFunctions.IntervalIntDivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalIntFunctions.IntervalIntMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalIntFunctions.IntIntervalMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearBigIntFunctions.BigIntIntervalYearMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearBigIntFunctions.IntervalYearBigIntDivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearBigIntFunctions.IntervalYearBigIntMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat4Functions.Float4IntervalYearMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat4Functions.IntervalYearFloat4DivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat4Functions.IntervalYearFloat4MultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat8Functions.Float8IntervalYearMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat8Functions.IntervalYearFloat8DivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFloat8Functions.IntervalYearFloat8MultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFunctions.IntervalYearAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFunctions.IntervalYearNegateFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearFunctions.IntervalYearSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearIntFunctions.IntervalYearIntDivideFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearIntFunctions.IntervalYearIntMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IntervalYearIntFunctions.IntIntervalYearMultiplyFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsFalse.Optional
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsFalse.Required
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNotFalse.Optional
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNotFalse.Required
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNotTrue.Optional
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNotTrue.Required
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.BigIntIsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.IntIsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableBigIntIsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableIntIsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableSmallIntIsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableTinyIntIsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableUInt1IsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableUInt2IsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableUInt4IsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableUInt8IsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.NullableVarCharIsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.SmallIntIsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.TinyIntIsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.UInt1IsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.UInt2IsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.UInt4IsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.UInt8IsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsNumericFunctions.VarCharIsNumeric
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsTrue.Optional
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.IsTrue.Required
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Mappify.ConvertMapToKeyValuePairs
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.MathFunctions.Pi
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.MathFunctions.Power
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.MathFunctions.Random
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.MathFunctions.ToNumber
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.BigIntBigIntMultiply
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.Float4Float4Multiply
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.Float8Float8Multiply
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.IntIntMultiply
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.SmallIntSmallIntMultiply
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.TinyIntTinyIntMultiply
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.UInt1UInt1Multiply
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.UInt2UInt2Multiply
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.UInt4UInt4Multiply
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.MultiplyFunctions.UInt8UInt8Multiply
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.AddressCountFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.BroadcastAddressFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.HighAddressFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.InetAtonFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.InetNtoaFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.InNetworkFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.IsPrivateIP
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.IsValidIPFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.IsValidIPV4Function
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.IsValidIPv6Function
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.LowAddressFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.NetmaskFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.urldecodeFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.NetworkFunctions.urlencodeFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.Not.Required
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ParseQueryFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.ParseUrlFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleCastFunctions.CastBooleanVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleCastFunctions.CastVarCharBoolean
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsBit
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthBit
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthVarChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SqlToDate
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SqlToTime
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SqlToTimeStamp
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.AsciiEndode
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.AsciiString
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.AsciiToChar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.BinaryString
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.BitLength
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Btrim
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.BtrimOneArg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ByteLength
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.CharLength
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Concat
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatBothNullInput
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatLeftNullInput
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatOperator
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatRightNullInput
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ILike
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ILikeWithEscape
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.InitCap
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Left
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Like
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.LikeWithEscape
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.LowerCase
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Lpad
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.LpadTwoArg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Ltrim
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.LtrimOneArg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.OctetLength
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Position
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.RegexpMatches
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.RegexpReplace
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.RepeatString
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Replace
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.ReverseString
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Right
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Rpad
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.RpadTwoArg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Rtrim
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.RtrimOneArg
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Similar
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.SimilarWithEscape
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Split
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.SplitPart
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.StringBinary
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Strpos
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.Substring
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.SubstringOffset
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.SubstringRegex
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.SubstringRegexNullable
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.StringFunctions.UpperCase
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.BigIntBigIntSubtract
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.Float4Float4Subtract
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.Float8Float8Subtract
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.IntIntSubtract
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.SmallIntSmallIntSubtract
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.TinyIntTinyIntSubtract
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.UInt1UInt1Subtract
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.UInt2UInt2Subtract
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.UInt4UInt4Subtract
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.UInt8UInt8Subtract
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeBigIntFunctions.BigIntTimeAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeBigIntFunctions.TimeBigIntAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeBigIntFunctions.TimeBigIntSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalDayFunctions.IntervalDayTimeAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalDayFunctions.TimeIntervalDayAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalDayFunctions.TimeIntervalDaySubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalFunctions.IntervalTimeAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalFunctions.TimeIntervalAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalFunctions.TimeIntervalSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalYearFunctions.IntervalYearTimeAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalYearFunctions.TimeIntervalYearAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntervalYearFunctions.TimeIntervalYearSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntFunctions.IntTimeAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntFunctions.TimeIntAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeIntFunctions.TimeIntSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampBigIntFunctions.BigIntTimeStampAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampBigIntFunctions.TimeStampBigIntAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampBigIntFunctions.TimeStampBigIntSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalDayFunctions.IntervalDayTimeStampAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalDayFunctions.TimeStampIntervalDayAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalDayFunctions.TimeStampIntervalDaySubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalFunctions.IntervalTimeStampAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalFunctions.TimeStampIntervalAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalFunctions.TimeStampIntervalSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalYearFunctions.IntervalYearTimeStampAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalYearFunctions.TimeStampIntervalYearAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalYearFunctions.TimeStampIntervalYearSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntFunctions.IntTimeStampAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntFunctions.TimeStampIntAddFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TimeStampIntFunctions.TimeStampIntSubtractFunction
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhBigInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhFloat4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhFloat8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanSmallInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanTinyInt
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanUInt1
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanUInt2
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanUInt4
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanUInt8
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CastUnionList
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CastUnionMap
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CastUnionToUnion
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CompareType
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.GetType
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.IsNotNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.IsNull
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.UnionIsList
 
setup() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.UnionIsMap
 
setup(HashAggregate, HashTableConfig, FragmentContext, OperatorContext, RecordBatch, HashAggBatch, LogicalExpression[], List<TypedFieldId>, TypedFieldId[], VectorContainer, int) - Method in interface org.apache.drill.exec.physical.impl.aggregate.HashAggregator
 
setup(HashAggregate, HashTableConfig, FragmentContext, OperatorContext, RecordBatch, HashAggBatch, LogicalExpression[], List<TypedFieldId>, TypedFieldId[], VectorContainer, int) - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
 
setup(OperatorContext, RecordBatch, StreamingAggBatch) - Method in interface org.apache.drill.exec.physical.impl.aggregate.StreamingAggregator
 
setup(OperatorContext, RecordBatch, StreamingAggBatch) - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
 
setup(HashTableConfig, FragmentContext, BufferAllocator, RecordBatch, RecordBatch, RecordBatch, VectorContainer) - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
 
setup() - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate.BatchHolder
 
setup(HashTableConfig, FragmentContext, BufferAllocator, RecordBatch, RecordBatch, RecordBatch, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
setup(FragmentContext, RecordBatch, RecordBatch, TransferPair[]) - Method in interface org.apache.drill.exec.physical.impl.filter.Filterer
 
setup(FragmentContext, RecordBatch, RecordBatch, TransferPair[]) - Method in class org.apache.drill.exec.physical.impl.filter.FilterTemplate2
 
setup(FragmentContext, RecordBatch, RecordBatch, TransferPair[]) - Method in class org.apache.drill.exec.physical.impl.filter.FilterTemplate4
 
setup(FragmentContext, RecordBatch, RecordBatch, List<TransferPair>) - Method in interface org.apache.drill.exec.physical.impl.flatten.Flattener
 
setup(FragmentContext, RecordBatch, RecordBatch, List<TransferPair>) - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenTemplate
 
setup(FragmentContext, VectorAccessible, RecordBatch, List<TransferPair>, VectorContainer, int, SchemaPath) - Method in interface org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionProjector
 
setup(FragmentContext, VectorAccessible, RecordBatch, List<TransferPair>, VectorContainer, int, SchemaPath) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionProjectorTemplate
 
setup(FragmentContext, RecordBatch) - Method in interface org.apache.drill.exec.physical.impl.orderedpartitioner.SampleSorter
 
setup(FragmentContext, VectorContainer, SelectionVector2) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.SampleSortTemplate
 
setup(FragmentContext, RecordBatch, HashPartitionSender, OperatorStats, OperatorContext, int, int) - Method in interface org.apache.drill.exec.physical.impl.partitionsender.Partitioner
 
setup(FragmentContext, RecordBatch, HashPartitionSender, OperatorStats, OperatorContext, int, int) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate
 
setup(FragmentContext, RecordBatch, RecordBatch, List<TransferPair>) - Method in interface org.apache.drill.exec.physical.impl.project.Projector
 
setup(FragmentContext, RecordBatch, RecordBatch, List<TransferPair>) - Method in class org.apache.drill.exec.physical.impl.project.ProjectorTemplate
 
setup(FragmentContext, SelectionVector4, VectorContainer) - Method in interface org.apache.drill.exec.physical.impl.sort.Sorter
 
setup(FragmentContext, SelectionVector4, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.sort.SortTemplate
 
setup(FragmentContext, RecordBatch, RecordBatch, List<TransferPair>) - Method in interface org.apache.drill.exec.physical.impl.union.UnionAller
 
setup(FragmentContext, RecordBatch, RecordBatch, List<TransferPair>) - Method in class org.apache.drill.exec.physical.impl.union.UnionAllerTemplate
 
setup(List<WindowDataBatch>, VectorContainer, OperatorContext, boolean, WindowPOP) - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
 
setup(List<WindowDataBatch>, VectorContainer, OperatorContext, boolean, WindowPOP) - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
 
setup(List<WindowDataBatch>, VectorContainer, OperatorContext, boolean, WindowPOP) - Method in interface org.apache.drill.exec.physical.impl.window.WindowFramer
 
setup(FragmentContextInterface, BufferAllocator, SelectionVector4, VectorContainer, int, int) - Method in interface org.apache.drill.exec.physical.impl.xsort.managed.MSorter
 
setup(FragmentContextInterface, BufferAllocator, SelectionVector4, VectorContainer, int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MSortTemplate
 
setup(BufferAllocator, VectorAccessible, List<BatchGroup>, VectorAccessible) - Method in interface org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopier
 
setup(BufferAllocator, VectorAccessible, List<BatchGroup>, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierTemplate
 
setup(FragmentContext, BufferAllocator, SelectionVector4, VectorContainer) - Method in interface org.apache.drill.exec.physical.impl.xsort.MSorter
 
setup(FragmentContext, BufferAllocator, SelectionVector4, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.xsort.MSortTemplate
 
setup(FragmentContext, BufferAllocator, VectorAccessible, List<BatchGroup>, VectorAccessible) - Method in interface org.apache.drill.exec.physical.impl.xsort.PriorityQueueCopier
 
setup(FragmentContext, BufferAllocator, VectorAccessible, List<BatchGroup>, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.xsort.PriorityQueueCopierTemplate
 
setup(FragmentContextInterface, SelectionVector2, VectorAccessible) - Method in interface org.apache.drill.exec.physical.impl.xsort.SingleBatchSorter
 
setup(FragmentContextInterface, SelectionVector2, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.xsort.SingleBatchSorterTemplate
 
setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor.RelDataTypeReader
 
setup(DrillConfig) - Method in class org.apache.drill.exec.rpc.user.security.Pam4jUserAuthenticator
 
setup(DrillConfig) - Method in class org.apache.drill.exec.rpc.user.security.PamUserAuthenticator
 
setup(DrillConfig) - Method in interface org.apache.drill.exec.rpc.user.security.UserAuthenticator
Setup for authenticating user credentials.
setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.avro.AvroRecordReader
 
setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.easy.json.JSONRecordReader
 
setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.easy.sequencefile.SequenceFileRecordReader
 
setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.easy.text.compliant.CompliantTextRecordReader
Performs the initial setup required for the record reader.
setup(ColumnDef) - Method in class org.apache.drill.exec.store.mock.BooleanGen
 
setup(ColumnDef) - Method in class org.apache.drill.exec.store.mock.DateGen
 
setup(ColumnDef) - Method in class org.apache.drill.exec.store.mock.DoubleGen
 
setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.mock.ExtendedMockRecordReader
 
setup(ColumnDef) - Method in interface org.apache.drill.exec.store.mock.FieldGen
 
setup(ColumnDef) - Method in class org.apache.drill.exec.store.mock.IntGen
 
setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.mock.MockRecordReader
 
setup(ColumnDef) - Method in class org.apache.drill.exec.store.mock.MoneyGen
 
setup(ColumnDef) - Method in class org.apache.drill.exec.store.mock.StringGen
 
setup(ColumnDef) - Method in class org.apache.drill.exec.store.mock.VaryingStringGen
 
setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
Prepare the Parquet reader.
setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetReader
 
setUp(MessageType, RecordConsumer) - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter
 
setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.pcap.PcapRecordReader
 
setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.pojo.AbstractPojoRecordReader
 
setup(OperatorContext, OutputMutator) - Method in interface org.apache.drill.exec.store.RecordReader
Configure the RecordReader with the provided schema and the record batch that should be written to.
setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.text.DrillTextRecordReader
 
setupBufferedOpsMemoryAllocations(PhysicalPlan, QueryContext) - Static method in class org.apache.drill.exec.util.MemoryAllocationUtilities
Helper method to setup Memory Allocations
setupCopier(FragmentContext, SelectionVector4, VectorAccessible, VectorAccessible) - Method in interface org.apache.drill.exec.physical.impl.orderedpartitioner.SampleCopier
 
setupCopier(FragmentContext, SelectionVector4, VectorAccessible, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.SampleCopierTemplate
 
setupCopyFromInternal(VectorAccessible, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
 
setupCopyNext(VectorAccessible, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
 
setupCopyPrev(VectorAccessible, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
 
setupEvaluatePeer(VectorAccessible, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
 
SetupException - Exception in org.apache.drill.exec.exception
 
SetupException() - Constructor for exception org.apache.drill.exec.exception.SetupException
 
SetupException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.drill.exec.exception.SetupException
 
SetupException(String, Throwable) - Constructor for exception org.apache.drill.exec.exception.SetupException
 
SetupException(String) - Constructor for exception org.apache.drill.exec.exception.SetupException
 
SetupException(Throwable) - Constructor for exception org.apache.drill.exec.exception.SetupException
 
setupHashJoinProbe() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
 
setupHashJoinProbe(FragmentContext, VectorContainer, RecordBatch, int, HashJoinBatch, HashTable, HashJoinHelper, JoinRelType) - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinProbe
 
setupHashJoinProbe(FragmentContext, VectorContainer, RecordBatch, int, HashJoinBatch, HashTable, HashJoinHelper, JoinRelType) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinProbeTemplate
 
setupHashTable() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
 
setupInterior(RecordBatch, RecordBatch, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate.BatchHolder
 
setupInterior(RecordBatch, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
 
setupInterior(RecordBatch, RecordBatch, RecordBatch, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate.BatchHolder
 
setupJoin(FragmentContext, JoinStatus, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.join.JoinTemplate
 
setupJoin(FragmentContext, JoinStatus, VectorContainer) - Method in interface org.apache.drill.exec.physical.impl.join.JoinWorker
 
setupMapping - Variable in class org.apache.drill.exec.physical.impl.join.MergeJoinBatch
 
setupNanos - Variable in class org.apache.drill.exec.ops.OperatorStats
 
setupNestedLoopJoin(FragmentContext, RecordBatch, ExpandableHyperContainer, LinkedList<Integer>, NestedLoopJoinBatch) - Method in interface org.apache.drill.exec.physical.impl.join.NestedLoopJoin
 
setupNestedLoopJoin(FragmentContext, RecordBatch, ExpandableHyperContainer, LinkedList<Integer>, NestedLoopJoinBatch) - Method in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinTemplate
Method initializes necessary state and invokes the doSetup() to set the input and output value vector references.
setupNewSchema() - Method in class org.apache.drill.exec.physical.impl.filter.FilterRecordBatch
 
setupNewSchema() - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenRecordBatch
 
setupNewSchema() - Method in class org.apache.drill.exec.physical.impl.limit.LimitRecordBatch
 
setupNewSchema(VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
Sets up projection that will transfer all of the columns in batch, and also populate the partition column based on which partition a record falls into in the partition table
setupNewSchema() - Method in class org.apache.drill.exec.physical.impl.project.ProjectRecordBatch
 
setupNewSchema() - Method in class org.apache.drill.exec.physical.impl.svremover.RemovingRecordBatch
 
setupNewSchema() - Method in class org.apache.drill.exec.physical.impl.trace.TraceRecordBatch
 
setupNewSchema() - Method in class org.apache.drill.exec.physical.impl.WriterRecordBatch
 
setupNewSchema() - Method in class org.apache.drill.exec.record.AbstractSingleRecordBatch
 
setupPartition(WindowDataBatch, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
Called once per partition, before processing the partition.
setupPartition(WindowDataBatch, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
Called once per partition, before processing the partition.
setupReadLastValue(VectorAccessible, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
 
setupReceivers(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.physical.base.AbstractExchange
 
setupReceivers(int, List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.physical.base.AbstractExchange
 
setupReceivers(int, List<CoordinationProtos.DrillbitEndpoint>) - Method in interface org.apache.drill.exec.physical.base.Exchange
Inform this Exchange node about its receiver locations.
setupReceivers(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.physical.config.SingleMergeExchange
 
setupReceivers(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.physical.config.UnionExchange
 
setupRemover(FragmentContext, RecordBatch, RecordBatch) - Method in interface org.apache.drill.exec.physical.impl.svremover.Copier
 
setupRemover(FragmentContext, RecordBatch, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.svremover.CopierTemplate2
 
setupRemover(FragmentContext, RecordBatch, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.svremover.CopierTemplate4
 
setupSaveFirstValue(VectorAccessible, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
 
setupSenders(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.physical.base.AbstractExchange
 
setupSenders(int, List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.physical.base.AbstractExchange
 
setupSenders(int, List<CoordinationProtos.DrillbitEndpoint>) - Method in interface org.apache.drill.exec.physical.base.Exchange
Inform this Exchange node about its sender locations.
setupSenders(List<CoordinationProtos.DrillbitEndpoint>) - Method in class org.apache.drill.exec.physical.config.UnionExchange
 
setupSSL(ChannelPipeline, ConnectionMultiListener.SSLHandshakeListener) - Method in class org.apache.drill.exec.rpc.user.UserClient
 
setupSSL(ChannelPipeline) - Method in class org.apache.drill.exec.rpc.user.UserServer
 
setupWriteFirstValue(VectorAccessible, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
 
setupWriters(OutputMutator) - Method in class org.apache.drill.exec.store.pojo.AbstractPojoRecordReader
Setups writers for each field in the row.
setupWriters(OutputMutator) - Method in class org.apache.drill.exec.store.pojo.DynamicPojoRecordReader
Initiates writers based on given schema which contains field name and its type.
setupWriters(OutputMutator) - Method in class org.apache.drill.exec.store.pojo.PojoRecordReader
Creates writers based on pojo field class types.
setUseDefaultCosting(boolean) - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
setUseRepeatedVarChar(boolean) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
setValue(int, int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate.BatchHolder
 
setValue(ValueVector, int) - Method in class org.apache.drill.exec.store.mock.BooleanGen
 
setValue(ValueVector, int) - Method in class org.apache.drill.exec.store.mock.DateGen
 
setValue(ValueVector, int) - Method in class org.apache.drill.exec.store.mock.DoubleGen
 
setValue(ValueVector, int) - Method in interface org.apache.drill.exec.store.mock.FieldGen
 
setValue(ValueVector, int) - Method in class org.apache.drill.exec.store.mock.IntGen
 
setValue(ValueVector, int) - Method in class org.apache.drill.exec.store.mock.MoneyGen
 
setValue(ValueVector, int) - Method in class org.apache.drill.exec.store.mock.StringGen
 
setValue(ValueVector, int) - Method in class org.apache.drill.exec.store.mock.VaryingStringGen
 
setValueCount(VectorAccessible, int) - Static method in class org.apache.drill.exec.record.VectorAccessibleUtilities
 
setValueCount(int) - Method in class org.apache.drill.exec.store.pojo.AbstractPojoWriter
 
setValueCount(int) - Method in interface org.apache.drill.exec.store.pojo.PojoWriter
Sets number of written records.
setValueCount(Iterable<ValueVector>, int) - Static method in class org.apache.drill.exec.util.VectorUtil
 
setValueCount(int) - Method in class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
 
setVerifyChecksum(boolean) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
setVersion(int) - Method in class org.apache.drill.exec.store.sys.store.DataChangeVersion
 
setWidth(int) - Method in class org.apache.drill.exec.planner.fragment.Wrapper
 
setWildcard(String, String) - Method in class org.apache.drill.exec.store.httpd.HttpdLogRecord
This method is referenced and called via reflection.
setWildcard(String, Long) - Method in class org.apache.drill.exec.store.httpd.HttpdLogRecord
This method is referenced and called via reflection.
setWildcard(String, Double) - Method in class org.apache.drill.exec.store.httpd.HttpdLogRecord
This method is referenced and called via reflection.
setWorkingDirectory(Path) - Method in class org.apache.drill.exec.store.ClassPathFileSystem
 
setWorkingDirectory(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
setWorkingDirectory(Path) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem
 
setWriteChecksum(boolean) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
setXAttr(Path, String, byte[]) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
setXAttr(Path, String, byte[], EnumSet<XAttrSetFlag>) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
setZero(int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
shouldContinue() - Method in interface org.apache.drill.exec.ops.FragmentContext.ExecutorState
Whether execution should continue.
shouldContinue() - Method in class org.apache.drill.exec.ops.FragmentContext
Tells individual operations whether they should continue.
shouldContinue() - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
Determine if fragment execution has been interrupted.
shouldMark() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
shouldShowAdminInfo() - Method in class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
 
shouldVisitCatalog() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
 
shouldVisitColumn(String, String, String) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
 
shouldVisitSchema(String, SchemaPlus) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
 
shouldVisitTable(String, String, Schema.TableType) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
 
SHOW - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ShowFileHandler - Class in org.apache.drill.exec.planner.sql.handlers
 
ShowFileHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ShowFileHandler
 
ShowFilesCommandResult - Class in org.apache.drill.exec.planner.sql.handlers
 
ShowFilesCommandResult(String, boolean, boolean, long, String, String, String, long, long) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ShowFilesCommandResult
 
showInInformationSchema() - Method in class org.apache.drill.exec.store.AbstractSchema
Reports whether to show items from this schema in INFORMATION_SCHEMA tables.
showInInformationSchema() - Method in class org.apache.drill.exec.store.dfs.FileSystemSchemaFactory.FileSystemSchema
 
showInInformationSchema() - Method in class org.apache.drill.exec.store.SubSchemaWrapper
 
ShowSchemasHandler - Class in org.apache.drill.exec.planner.sql.handlers
 
ShowSchemasHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ShowSchemasHandler
 
ShowTablesHandler - Class in org.apache.drill.exec.planner.sql.handlers
 
ShowTablesHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ShowTablesHandler
 
showVectorAccessibleContent(VectorAccessible, String) - Static method in class org.apache.drill.exec.util.VectorUtil
 
showVectorAccessibleContent(VectorAccessible) - Static method in class org.apache.drill.exec.util.VectorUtil
 
showVectorAccessibleContent(VectorAccessible, int) - Static method in class org.apache.drill.exec.util.VectorUtil
 
showVectorAccessibleContent(VectorAccessible, int[]) - Static method in class org.apache.drill.exec.util.VectorUtil
 
SHRD_COL_TABLE_CATALOG - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
SHRD_COL_TABLE_NAME - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
SHRD_COL_TABLE_SCHEMA - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
shutdown() - Method in class org.apache.drill.exec.server.Drillbit
 
shutdownDrillbit() - Method in class org.apache.drill.exec.server.rest.DrillRoot
 
shutdownForcefully() - Method in class org.apache.drill.exec.server.rest.DrillRoot
 
Signature - Annotation Type in org.apache.drill.exec.compile.sig
Describes the field will provide output from the given function.
SignatureHolder - Class in org.apache.drill.exec.compile.sig
 
SIMILAR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SIMPLE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SIMPLE_NAME - Static variable in class org.apache.drill.exec.rpc.security.plain.PlainFactory
 
SimpleCastFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleCastFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleCastFunctions
 
SimpleCastFunctions.CastBooleanVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleCastFunctions.CastBooleanVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleCastFunctions.CastBooleanVarChar
 
SimpleCastFunctions.CastVarCharBoolean - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleCastFunctions.CastVarCharBoolean() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleCastFunctions.CastVarCharBoolean
 
SimpleCharStream - Class in org.apache.drill.exec.planner.sql.parser.impl
An implementation of interface CharStream, where the stream is assumed to contain only ASCII characters (without unicode processing).
SimpleCharStream(Reader, int, int, int) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
SimpleCharStream(Reader, int, int) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
SimpleCharStream(Reader) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
SimpleCharStream(InputStream, String, int, int, int) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
SimpleCharStream(InputStream, int, int, int) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
SimpleCharStream(InputStream, String, int, int) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
SimpleCharStream(InputStream, int, int) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
SimpleCharStream(InputStream, String) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
SimpleCharStream(InputStream) - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
SimpleCommandResult - Class in org.apache.drill.exec.planner.sql.handlers
 
SimpleCommandResult(boolean, String) - Constructor for class org.apache.drill.exec.planner.sql.handlers.SimpleCommandResult
 
SimpleDurationFormat - Class in org.apache.drill.exec.server.rest.profile
Representation of a millisecond duration in a human-readable format
SimpleDurationFormat(long, long) - Constructor for class org.apache.drill.exec.server.rest.profile.SimpleDurationFormat
If end time is less than the start time, current epoch time is assumed as the end time.
SimpleIdentifier() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a simple identifier as an SqlIdentifier.
SimpleIdentifierCommaList() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a comma-separated list of simple identifiers.
SimpleParallelizer - Class in org.apache.drill.exec.planner.fragment
The simple parallelizer determines the level of parallelization of a plan based on the cost of the underlying operations.
SimpleParallelizer(QueryContext) - Constructor for class org.apache.drill.exec.planner.fragment.SimpleParallelizer
 
SimpleParallelizer(long, int, int, double) - Constructor for class org.apache.drill.exec.planner.fragment.SimpleParallelizer
 
SimpleParallelizer.CountRequiredFragments - Class in org.apache.drill.exec.planner.fragment
Designed to setup initial values for arriving fragment accounting.
SimpleParallelizer.CountRequiredFragments() - Constructor for class org.apache.drill.exec.planner.fragment.SimpleParallelizer.CountRequiredFragments
 
SimplePartitionLocation - Class in org.apache.drill.exec.planner
Abstract class for simple partition.
SimplePartitionLocation() - Constructor for class org.apache.drill.exec.planner.SimplePartitionLocation
 
SimpleRecordBatch - Class in org.apache.drill.exec.record
Wrap a VectorContainer into a record batch.
SimpleRecordBatch(VectorContainer, FragmentContext) - Constructor for class org.apache.drill.exec.record.SimpleRecordBatch
 
SimpleRepeatedFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleRepeatedFunctions.ContainsBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleRepeatedFunctions.ContainsBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsBigInt
 
SimpleRepeatedFunctions.ContainsBit - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleRepeatedFunctions.ContainsBit() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsBit
 
SimpleRepeatedFunctions.ContainsFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleRepeatedFunctions.ContainsFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsFloat4
 
SimpleRepeatedFunctions.ContainsFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleRepeatedFunctions.ContainsFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsFloat8
 
SimpleRepeatedFunctions.ContainsInt - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleRepeatedFunctions.ContainsInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsInt
 
SimpleRepeatedFunctions.ContainsTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleRepeatedFunctions.ContainsTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsTinyInt
 
SimpleRepeatedFunctions.ContainsVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleRepeatedFunctions.ContainsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsVarChar
 
SimpleRepeatedFunctions.RepeatedLengthBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleRepeatedFunctions.RepeatedLengthBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthBigInt
 
SimpleRepeatedFunctions.RepeatedLengthBit - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleRepeatedFunctions.RepeatedLengthBit() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthBit
 
SimpleRepeatedFunctions.RepeatedLengthFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleRepeatedFunctions.RepeatedLengthFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthFloat4
 
SimpleRepeatedFunctions.RepeatedLengthFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleRepeatedFunctions.RepeatedLengthFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthFloat8
 
SimpleRepeatedFunctions.RepeatedLengthInt - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleRepeatedFunctions.RepeatedLengthInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthInt
 
SimpleRepeatedFunctions.RepeatedLengthTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleRepeatedFunctions.RepeatedLengthTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthTinyInt
 
SimpleRepeatedFunctions.RepeatedLengthVarChar - Class in org.apache.drill.exec.expr.fn.impl
 
SimpleRepeatedFunctions.RepeatedLengthVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthVarChar
 
SimpleVectorWrapper<T extends ValueVector> - Class in org.apache.drill.exec.record
 
SimpleVectorWrapper(T) - Constructor for class org.apache.drill.exec.record.SimpleVectorWrapper
 
SINGLE_CACHE_CONFIG - Static variable in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
 
SINGLE_LINE_COMMENT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SingleBatchSorter - Interface in org.apache.drill.exec.physical.impl.xsort
 
SingleBatchSorterTemplate - Class in org.apache.drill.exec.physical.impl.xsort
 
SingleBatchSorterTemplate() - Constructor for class org.apache.drill.exec.physical.impl.xsort.SingleBatchSorterTemplate
 
SingleClassStringWriter - Class in org.apache.drill.exec.expr
 
SingleClassStringWriter() - Constructor for class org.apache.drill.exec.expr.SingleClassStringWriter
 
SingleMergeExchange - Class in org.apache.drill.exec.physical.config
 
SingleMergeExchange(PhysicalOperator, List<Order.Ordering>) - Constructor for class org.apache.drill.exec.physical.config.SingleMergeExchange
 
SingleMergeExchangePrel - Class in org.apache.drill.exec.planner.physical
 
SingleMergeExchangePrel(RelOptCluster, RelTraitSet, RelNode, RelCollation) - Constructor for class org.apache.drill.exec.planner.physical.SingleMergeExchangePrel
 
SinglePrel - Class in org.apache.drill.exec.planner.physical
 
SinglePrel(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.drill.exec.planner.physical.SinglePrel
 
SingleSender - Class in org.apache.drill.exec.physical.config
Sender that pushes all data to a single destination node.
SingleSender(int, int, PhysicalOperator, CoordinationProtos.DrillbitEndpoint) - Constructor for class org.apache.drill.exec.physical.config.SingleSender
Create a SingleSender which sends data to fragment identified by given MajorFragmentId and MinorFragmentId, and running at given endpoint
SingleSender(int, PhysicalOperator, CoordinationProtos.DrillbitEndpoint) - Constructor for class org.apache.drill.exec.physical.config.SingleSender
Create a SingleSender which sends data to fragment with MinorFragmentId as 0 in given opposite major fragment.
SingleSenderCreator - Class in org.apache.drill.exec.physical.impl
 
SingleSenderCreator() - Constructor for class org.apache.drill.exec.physical.impl.SingleSenderCreator
 
SingleSenderCreator.SingleSenderRootExec - Class in org.apache.drill.exec.physical.impl
 
SingleSenderCreator.SingleSenderRootExec(FragmentContext, RecordBatch, SingleSender) - Constructor for class org.apache.drill.exec.physical.impl.SingleSenderCreator.SingleSenderRootExec
 
SingleSenderCreator.SingleSenderRootExec.Metric - Enum in org.apache.drill.exec.physical.impl
 
SINGLETON - Static variable in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
 
siteClass - Variable in class org.apache.drill.exec.testing.Injection
 
size() - Method in class org.apache.drill.exec.compile.bytecode.TrackingInstructionList
 
size() - Method in class org.apache.drill.exec.compile.sig.SignatureHolder
 
size() - Method in class org.apache.drill.exec.coord.local.MapBackedStore
 
size() - Method in interface org.apache.drill.exec.coord.store.TransientStore
Returns number of entries.
size() - Method in class org.apache.drill.exec.coord.zk.ZkEphemeralStore
 
size() - Method in class org.apache.drill.exec.expr.fn.registry.LocalFunctionRegistry
 
size() - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
 
size() - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
size() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BufferedBatches
 
size() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SpilledRuns
 
size() - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
SIZE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
size - Variable in enum org.apache.drill.exec.record.BatchSchema.SelectionVectorMode
 
size() - Method in class org.apache.drill.exec.store.parquet.ColumnDataReader.HadoopBytesInput
 
size() - Method in interface org.apache.drill.exec.work.batch.BaseRawBatchBuffer.BufferQueue
 
SizedJBlock - Class in org.apache.drill.exec.expr
Uses this class to keep track # of Drill Logical Expressions that are put to JBlock.
SizedJBlock(JBlock) - Constructor for class org.apache.drill.exec.expr.SizedJBlock
 
skip(long) - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingInputStream
 
skip(long) - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
skip(long) - Method in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
Has the same contract as InputStream.skip(long) Skips upto the next n bytes.
skipBytes(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
skipFirstLine - Variable in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
skipNullFields - Variable in class org.apache.drill.exec.store.JSONOutputRecordWriter
 
skipReadyToReadPositionUpdate() - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
 
skipReadyToReadPositionUpdate() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumn
 
skipReadyToReadPositionUpdate() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthValuesColumn
 
slash - Variable in class org.apache.drill.exec.compile.ClassTransformer.ClassNames
 
SLASH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
slice() - Method in class org.apache.drill.exec.record.DeadBuf
 
slice(int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
SLICE_TARGET - Static variable in class org.apache.drill.exec.ExecConstants
 
SLICE_TARGET_DEFAULT - Static variable in class org.apache.drill.exec.ExecConstants
 
SLICE_TARGET_OPTION - Static variable in class org.apache.drill.exec.ExecConstants
 
SMALL_QUEUE_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
SMALLINT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SmallIntAccessor - Class in org.apache.drill.exec.vector.accessor
 
SmallIntAccessor(SmallIntVector) - Constructor for class org.apache.drill.exec.vector.accessor.SmallIntAccessor
 
SmallIntBEConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
SmallIntBEConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.SmallIntBEConvertFrom
 
SmallIntBEConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
SmallIntBEConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.SmallIntBEConvertTo
 
SmallIntConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
SmallIntConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.SmallIntConvertFrom
 
SmallIntConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
SmallIntConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.SmallIntConvertTo
 
smallQueueMemory() - Method in class org.apache.drill.exec.server.rest.DrillRoot.QueueInfo
 
smallQueueSize() - Method in class org.apache.drill.exec.server.rest.DrillRoot.QueueInfo
 
smallQueueSize - Variable in class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue.ZKQueueInfo
 
SoftAffinityFragmentParallelizer - Class in org.apache.drill.exec.planner.fragment
Implementation of FragmentParallelizer where fragment has zero or more endpoints with affinities.
SoftAffinityFragmentParallelizer() - Constructor for class org.apache.drill.exec.planner.fragment.SoftAffinityFragmentParallelizer
 
some(Class<? extends RelNode>, RelOptRuleOperand, RelOptRuleOperand...) - Static method in class org.apache.drill.exec.planner.logical.RelOptHelper
 
some(Class<? extends RelNode>, RelTrait, RelOptRuleOperand, RelOptRuleOperand...) - Static method in class org.apache.drill.exec.planner.logical.RelOptHelper
 
SOME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
Sort - Class in org.apache.drill.exec.physical.config
 
Sort(PhysicalOperator, List<Order.Ordering>, boolean) - Constructor for class org.apache.drill.exec.physical.config.Sort
 
sort(SelectionVector2, VectorContainer) - Method in interface org.apache.drill.exec.physical.impl.orderedpartitioner.SampleSorter
 
sort(SelectionVector2, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.SampleSortTemplate
 
sort(SelectionVector4, VectorContainer) - Method in interface org.apache.drill.exec.physical.impl.sort.Sorter
 
sort(SelectionVector4, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.sort.SortTemplate
 
sort() - Method in interface org.apache.drill.exec.physical.impl.xsort.managed.MSorter
 
sort() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MSortTemplate
Merge a set of pre-sorted runs to produce a combined result set.
sort(VectorContainer) - Method in interface org.apache.drill.exec.physical.impl.xsort.MSorter
 
sort(VectorContainer) - Method in class org.apache.drill.exec.physical.impl.xsort.MSortTemplate
 
sort(SelectionVector2) - Method in interface org.apache.drill.exec.physical.impl.xsort.SingleBatchSorter
 
sort(SelectionVector2) - Method in class org.apache.drill.exec.physical.impl.xsort.SingleBatchSorterTemplate
 
SortBatch - Class in org.apache.drill.exec.physical.impl.sort
 
SortBatch(Sort, FragmentContext, RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.sort.SortBatch
 
sortBatch(VectorContainer, SelectionVector2) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SorterWrapper
 
SortBatchCreator - Class in org.apache.drill.exec.physical.impl.sort
 
SortBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.sort.SortBatchCreator
 
SortConfig - Class in org.apache.drill.exec.physical.impl.xsort.managed
 
SortConfig(DrillConfig) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
 
SortConvertPrule - Class in org.apache.drill.exec.planner.physical
Rule that converts an Sort to a physical SortPrel, implemented by a Drill "order" operation.
Sorter - Interface in org.apache.drill.exec.physical.impl.sort
 
SorterWrapper - Class in org.apache.drill.exec.physical.impl.xsort.managed
Single-batch sorter using a generated implementation based on the schema and sort specification.
SorterWrapper(OperatorContext) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.SorterWrapper
 
SortImpl - Class in org.apache.drill.exec.physical.impl.xsort.managed
Implementation of the external sort which is wrapped into the Drill "next" protocol by the ExternalSortBatch class.
SortImpl(OperatorContext, SortConfig, SpilledRuns, VectorContainer) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl
 
SortImpl.EmptyResults - Class in org.apache.drill.exec.physical.impl.xsort.managed
 
SortImpl.EmptyResults(VectorContainer) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.EmptyResults
 
SortImpl.SingleBatchResults - Class in org.apache.drill.exec.physical.impl.xsort.managed
Return results for a single input batch.
SortImpl.SingleBatchResults(BatchGroup.InputBatch, VectorContainer) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SingleBatchResults
 
SortImpl.SortResults - Interface in org.apache.drill.exec.physical.impl.xsort.managed
Iterates over the final sorted results.
SortMemoryManager - Class in org.apache.drill.exec.physical.impl.xsort.managed
Computes the memory needs for input batches, spill batches and merge batches.
SortMemoryManager(SortConfig, long) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
 
SortMemoryManager.BatchSizeEstimate - Class in org.apache.drill.exec.physical.impl.xsort.managed
 
SortMemoryManager.BatchSizeEstimate() - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager.BatchSizeEstimate
 
SortMemoryManager.MergeAction - Enum in org.apache.drill.exec.physical.impl.xsort.managed
 
SortMemoryManager.MergeTask - Class in org.apache.drill.exec.physical.impl.xsort.managed
 
SortMemoryManager.MergeTask(SortMemoryManager.MergeAction, int) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager.MergeTask
 
SortMetrics - Class in org.apache.drill.exec.physical.impl.xsort.managed
 
SortMetrics(OperatorStatReceiver) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
 
sortOptions(Iterator<OptionValue>) - Method in class org.apache.drill.exec.store.sys.ExtendedOptionIterator
 
SortPrel - Class in org.apache.drill.exec.planner.physical
 
SortPrel(RelOptCluster, RelTraitSet, RelNode, RelCollation) - Constructor for class org.apache.drill.exec.planner.physical.SortPrel
Creates a DrillSortRel.
SortPrel(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.drill.exec.planner.physical.SortPrel
Creates a DrillSortRel with offset and fetch.
SortPrule - Class in org.apache.drill.exec.planner.physical
Rule that converts a logical DrillSortRel to a physical sort.
SortRecordBatchBuilder - Class in org.apache.drill.exec.physical.impl.sort
 
SortRecordBatchBuilder(BufferAllocator) - Constructor for class org.apache.drill.exec.physical.impl.sort.SortRecordBatchBuilder
 
SortTemplate - Class in org.apache.drill.exec.physical.impl.sort
 
SortTemplate() - Constructor for class org.apache.drill.exec.physical.impl.sort.SortTemplate
 
SOURCE - Static variable in class org.apache.drill.exec.planner.cost.DrillRelMdDistinctRowCount
 
SOURCE - Static variable in class org.apache.drill.exec.planner.cost.DrillRelMdRowCount
 
SOURCE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SPACE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
specialConstructor - Variable in exception org.apache.drill.exec.planner.sql.parser.impl.ParseException
This variable determines which constructor was used to create this object and thereby affects the semantics of the "getMessage" method (see below).
SpecialLiteral() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parse a special literal keyword
specialToken - Variable in class org.apache.drill.exec.planner.sql.parser.impl.Token
This field is used to access special tokens that occur prior to this token, but after the immediately preceding regular (non-special) token.
SPECIFIC - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SPECIFIC_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SPECIFICTYPE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SPILL_DIRS - Static variable in class org.apache.drill.exec.ExecConstants
 
SPILL_FILESYSTEM - Static variable in class org.apache.drill.exec.ExecConstants
 
spillBatchSize() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
 
SpilledRecordbatch - Class in org.apache.drill.exec.physical.impl.aggregate
A class to replace "incoming" - instead scanning a spilled partition file
SpilledRecordbatch(String, int, FragmentContext, BatchSchema, OperatorContext, SpillSet) - Constructor for class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
 
SpilledRuns - Class in org.apache.drill.exec.physical.impl.xsort.managed
Represents the set of spilled batches, including methods to spill and/or merge a set of batches to produce a new spill file.
SpilledRuns(OperatorContext, SpillSet, PriorityQueueCopierWrapper) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.SpilledRuns
 
spillFileSize() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
 
SpillSet - Class in org.apache.drill.exec.physical.impl.spill
Generates the set of spill files for this sort session.
SpillSet(FragmentContext, PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.impl.spill.SpillSet
 
SpillSet(DrillConfig, ExecProtos.FragmentHandle, PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.impl.spill.SpillSet
 
SpillSet.CountingInputStream - Class in org.apache.drill.exec.physical.impl.spill
Wrapper around an input stream to collect the total bytes read through the stream for use in reporting performance metrics.
SpillSet.CountingInputStream(InputStream) - Constructor for class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingInputStream
 
SpillSet.CountingOutputStream - Class in org.apache.drill.exec.physical.impl.spill
Wrapper around an output stream to collect the total bytes written through the stream for use in reporting performance metrics.
SpillSet.CountingOutputStream(OutputStream) - Constructor for class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingOutputStream
 
SplittingParallelizer - Class in org.apache.drill.exec.planner.fragment.contrib
SimpleParallelizerMultiPlans class is an extension to SimpleParallelizer to help with getting PlanFragments for split plan.
SplittingParallelizer(QueryContext) - Constructor for class org.apache.drill.exec.planner.fragment.contrib.SplittingParallelizer
 
SplitUpComplexExpressions - Class in org.apache.drill.exec.planner.physical.visitor
 
SplitUpComplexExpressions(RelDataTypeFactory, DrillOperatorTable, FunctionImplementationRegistry) - Constructor for class org.apache.drill.exec.planner.physical.visitor.SplitUpComplexExpressions
 
Spool - Interface in org.apache.drill.exec.disk
 
SPOOLING_BUFFER_DELETE - Static variable in class org.apache.drill.exec.ExecConstants
 
SPOOLING_BUFFER_MEMORY - Static variable in class org.apache.drill.exec.ExecConstants
 
SpoolingRawBatchBuffer - Class in org.apache.drill.exec.work.batch
This implementation of RawBatchBuffer starts writing incoming batches to disk once the buffer size reaches a threshold.
SpoolingRawBatchBuffer(FragmentContext, int, int, int) - Constructor for class org.apache.drill.exec.work.batch.SpoolingRawBatchBuffer
 
SQL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SqlAccessor - Interface in org.apache.drill.exec.vector.accessor
Column-data accessor that implements JDBC's Java-null--when--SQL-NULL mapping.
SqlConverter - Class in org.apache.drill.exec.planner.sql
Class responsible for managing parsing, validation and toRel conversion for sql statements.
SqlConverter(QueryContext) - Constructor for class org.apache.drill.exec.planner.sql.SqlConverter
 
SqlCreateFunction() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parse create UDF statement CREATE FUNCTION USING JAR 'jar_name'
SqlCreateFunction - Class in org.apache.drill.exec.planner.sql.parser
 
SqlCreateFunction(SqlParserPos, SqlNode) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlCreateFunction
 
SqlCreateOrReplaceView() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a create view or replace existing view statement.
SqlCreateTable() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a CTAS or CTTAS statement.
SqlCreateTable - Class in org.apache.drill.exec.planner.sql.parser
 
SqlCreateTable(SqlParserPos, SqlIdentifier, SqlNodeList, SqlNodeList, SqlNode, SqlLiteral, SqlLiteral) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlCreateTable
 
SqlCreateView - Class in org.apache.drill.exec.planner.sql.parser
 
SqlCreateView(SqlParserPos, SqlIdentifier, SqlNodeList, SqlNode, SqlLiteral) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlCreateView
 
SqlCreateView.SqlCreateViewType - Enum in org.apache.drill.exec.planner.sql.parser
 
SqlDelete() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a DELETE statement.
SqlDescribeSchema() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses statement DESCRIBE { SCHEMA | DATABASE } name
SqlDescribeSchema - Class in org.apache.drill.exec.planner.sql.parser
Sql parse tree node to represent statement: DESCRIBE {SCHEMA | DATABASE} schema_name
SqlDescribeSchema(SqlParserPos, SqlIdentifier) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlDescribeSchema
 
SqlDescribeTable() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses statement { DESCRIBE | DESC } tblname [col_name | wildcard ]
SqlDescribeTable - Class in org.apache.drill.exec.planner.sql.parser
Sql parser tree node to represent statement: { DESCRIBE | DESC } tblname [col_name | wildcard ]
SqlDescribeTable(SqlParserPos, SqlIdentifier, SqlIdentifier, SqlNode) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlDescribeTable
 
SqlDropFunction() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parse drop UDF statement DROP FUNCTION USING JAR 'jar_name'
SqlDropFunction - Class in org.apache.drill.exec.planner.sql.parser
 
SqlDropFunction(SqlParserPos, SqlNode) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlDropFunction
 
SqlDropTable() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a drop table or drop table if exists statement.
SqlDropTable - Class in org.apache.drill.exec.planner.sql.parser
 
SqlDropTable(SqlParserPos, SqlIdentifier, SqlLiteral) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlDropTable
 
SqlDropTable(SqlParserPos, SqlIdentifier, boolean) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlDropTable
 
SqlDropView() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a drop view or drop view if exists statement.
SqlDropView - Class in org.apache.drill.exec.planner.sql.parser
 
SqlDropView(SqlParserPos, SqlIdentifier, SqlLiteral) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlDropView
 
SqlDropView(SqlParserPos, SqlIdentifier, boolean) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlDropView
 
SQLEXCEPTION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SqlExplain() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses an EXPLAIN PLAN statement.
SqlExpressionEof() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a SQL expression (such as might occur in a WHERE clause) followed by the end-of-file symbol.
SqlHandlerConfig - Class in org.apache.drill.exec.planner.sql.handlers
 
SqlHandlerConfig(QueryContext, SqlConverter) - Constructor for class org.apache.drill.exec.planner.sql.handlers.SqlHandlerConfig
 
SqlHandlerUtil - Class in org.apache.drill.exec.planner.sql.handlers
 
SqlHandlerUtil() - Constructor for class org.apache.drill.exec.planner.sql.handlers.SqlHandlerUtil
 
SqlInsert() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses an INSERT statement.
SqlInsertKeywords(List<SqlLiteral>) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
SqlMerge() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a MERGE statement.
SqlPatternComplexMatcher - Class in org.apache.drill.exec.expr.fn.impl
 
SqlPatternComplexMatcher(String) - Constructor for class org.apache.drill.exec.expr.fn.impl.SqlPatternComplexMatcher
 
SqlPatternConstantMatcher - Class in org.apache.drill.exec.expr.fn.impl
 
SqlPatternConstantMatcher(String) - Constructor for class org.apache.drill.exec.expr.fn.impl.SqlPatternConstantMatcher
 
SqlPatternContainsMatcher - Class in org.apache.drill.exec.expr.fn.impl
 
SqlPatternContainsMatcher(String) - Constructor for class org.apache.drill.exec.expr.fn.impl.SqlPatternContainsMatcher
 
SqlPatternEndsWithMatcher - Class in org.apache.drill.exec.expr.fn.impl
 
SqlPatternEndsWithMatcher(String) - Constructor for class org.apache.drill.exec.expr.fn.impl.SqlPatternEndsWithMatcher
 
SqlPatternFactory - Class in org.apache.drill.exec.expr.fn.impl
 
SqlPatternFactory() - Constructor for class org.apache.drill.exec.expr.fn.impl.SqlPatternFactory
 
SqlPatternMatcher - Interface in org.apache.drill.exec.expr.fn.impl
 
SqlPatternStartsWithMatcher - Class in org.apache.drill.exec.expr.fn.impl
 
SqlPatternStartsWithMatcher(String) - Constructor for class org.apache.drill.exec.expr.fn.impl.SqlPatternStartsWithMatcher
 
SqlProcedureCall() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a CALL statement.
SqlQueryEof() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a query (SELECT, UNION, INTERSECT, EXCEPT, VALUES, TABLE) followed by the end-of-file symbol.
SqlRefreshMetadata() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parse refresh table metadata statement.
SqlRefreshMetadata - Class in org.apache.drill.exec.planner.sql.parser
Sql parse tree node to represent statement: REFRESH TABLE METADATA tblname
SqlRefreshMetadata(SqlParserPos, SqlIdentifier) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlRefreshMetadata
 
SqlSelect() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a leaf SELECT expression without ORDER BY.
SqlSelectKeywords(List<SqlLiteral>) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
SqlSetOption() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses an expression for setting or resetting an option in SQL, such as QUOTED_IDENTIFIERS, or explain plan level (physical/logical).
SqlShowFiles() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses statement SHOW FILES [{FROM | IN} schema]
SqlShowFiles - Class in org.apache.drill.exec.planner.sql.parser
Sql parse tree node to represent statement: SHOW FILES [{FROM | IN} db_name] [LIKE 'pattern' | WHERE expr]
SqlShowFiles(SqlParserPos, SqlIdentifier) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlShowFiles
 
SqlShowSchemas() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses statement SHOW {DATABASES | SCHEMAS} [LIKE 'pattern' | WHERE expr]
SqlShowSchemas - Class in org.apache.drill.exec.planner.sql.parser
Sql parse tree node to represent statement: SHOW {DATABASES | SCHEMAS} [LIKE 'pattern' | WHERE expr]
SqlShowSchemas(SqlParserPos, SqlNode, SqlNode) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlShowSchemas
 
SqlShowTables() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses statement SHOW TABLES [{FROM | IN} db_name] [LIKE 'pattern' | WHERE expr]
SqlShowTables - Class in org.apache.drill.exec.planner.sql.parser
Sql parse tree node to represent statement: SHOW TABLES [{FROM | IN} db_name] [LIKE 'pattern' | WHERE expr]
SqlShowTables(SqlParserPos, SqlIdentifier, SqlNode, SqlNode) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlShowTables
 
SQLSTATE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SqlStmt() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses an SQL statement.
SqlStmtEof() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses an SQL statement followed by the end-of-file symbol.
SqlToDate - Class in org.apache.drill.exec.expr.fn.impl
 
SqlToDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.SqlToDate
 
sqlToRegexLike(String) - Static method in class org.apache.drill.exec.expr.fn.impl.RegexpUtil
Translates a SQL LIKE pattern to Java regex pattern.
sqlToRegexLike(String, CharSequence) - Static method in class org.apache.drill.exec.expr.fn.impl.RegexpUtil
Translates a SQL LIKE pattern to Java regex pattern, with optional escape string.
sqlToRegexLike(String, char) - Static method in class org.apache.drill.exec.expr.fn.impl.RegexpUtil
Translates a SQL LIKE pattern to Java regex pattern.
sqlToRegexSimilar(String) - Static method in class org.apache.drill.exec.expr.fn.impl.RegexpUtil
Translates a SQL SIMILAR pattern to Java regex pattern.
sqlToRegexSimilar(String, CharSequence) - Static method in class org.apache.drill.exec.expr.fn.impl.RegexpUtil
Translates a SQL SIMILAR pattern to Java regex pattern, with optional escape string.
sqlToRegexSimilar(String, char) - Static method in class org.apache.drill.exec.expr.fn.impl.RegexpUtil
Translates SQL SIMILAR pattern to Java regex pattern.
SqlToTime - Class in org.apache.drill.exec.expr.fn.impl
 
SqlToTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.SqlToTime
 
SqlToTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
 
SqlToTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.SqlToTimeStamp
 
SqlUnsupportedException - Exception in org.apache.drill.exec.work.foreman
 
SqlUnsupportedException(String, String) - Constructor for exception org.apache.drill.exec.work.foreman.SqlUnsupportedException
 
SqlUnsupportedException(String) - Constructor for exception org.apache.drill.exec.work.foreman.SqlUnsupportedException
 
SqlUnsupportedException.ExceptionType - Enum in org.apache.drill.exec.work.foreman
 
SqlUpdate() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses an UPDATE statement.
SqlUseSchema() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
SqlUseSchema - Class in org.apache.drill.exec.planner.sql.parser
Sql parser tree node to represent USE SCHEMA statement.
SqlUseSchema(SqlParserPos, SqlIdentifier) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlUseSchema
 
SQLWARNING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SQRT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SSL_HANDSHAKE_TIMEOUT - Static variable in class org.apache.drill.exec.ExecConstants
 
SSL_KEY_PASSWORD - Static variable in class org.apache.drill.exec.ExecConstants
 
SSL_KEYSTORE_PASSWORD - Static variable in class org.apache.drill.exec.ExecConstants
 
SSL_KEYSTORE_PATH - Static variable in class org.apache.drill.exec.ExecConstants
 
SSL_KEYSTORE_TYPE - Static variable in class org.apache.drill.exec.ExecConstants
 
SSL_PROTOCOL - Static variable in class org.apache.drill.exec.ExecConstants
 
SSL_PROVIDER - Static variable in class org.apache.drill.exec.ExecConstants
 
SSL_TRUSTSTORE_PASSWORD - Static variable in class org.apache.drill.exec.ExecConstants
 
SSL_TRUSTSTORE_PATH - Static variable in class org.apache.drill.exec.ExecConstants
 
SSL_TRUSTSTORE_TYPE - Static variable in class org.apache.drill.exec.ExecConstants
 
SSL_USE_HADOOP_CONF - Static variable in class org.apache.drill.exec.ExecConstants
 
SSLConfig - Class in org.apache.drill.exec.ssl
 
SSLConfig() - Constructor for class org.apache.drill.exec.ssl.SSLConfig
 
SSLConfig.Mode - Enum in org.apache.drill.exec.ssl
 
SSLConfigBuilder - Class in org.apache.drill.exec.ssl
 
SSLConfigBuilder() - Constructor for class org.apache.drill.exec.ssl.SSLConfigBuilder
 
SSLConfigClient - Class in org.apache.drill.exec.ssl
 
SSLConfigClient(Properties) - Constructor for class org.apache.drill.exec.ssl.SSLConfigClient
 
SSLConfigServer - Class in org.apache.drill.exec.ssl
 
SSLConfigServer(DrillConfig, Configuration) - Constructor for class org.apache.drill.exec.ssl.SSLConfigServer
 
StandardFloorCeilOptions(SqlParserPos, boolean) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
STAR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
STAR_COLUMN - Static variable in class org.apache.drill.exec.planner.StarColumnHelper
 
STAR_COLUMN - Static variable in class org.apache.drill.exec.util.Utilities
 
StarColumnConverter - Class in org.apache.drill.exec.planner.physical.visitor
 
StarColumnHelper - Class in org.apache.drill.exec.planner
 
StarColumnHelper() - Constructor for class org.apache.drill.exec.planner.StarColumnHelper
 
start(long) - Method in class org.apache.drill.exec.coord.ClusterCoordinator
Start the cluster coordinator.
start(long) - Method in class org.apache.drill.exec.coord.local.LocalClusterCoordinator
 
start(long) - Method in class org.apache.drill.exec.coord.zk.ZKClusterCoordinator
 
start() - Method in class org.apache.drill.exec.coord.zk.ZkEphemeralStore
 
start() - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
Starts the client.
START - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
start(CoordinationProtos.DrillbitEndpoint, boolean) - Method in interface org.apache.drill.exec.rpc.control.Controller
 
start(CoordinationProtos.DrillbitEndpoint, boolean) - Method in class org.apache.drill.exec.rpc.control.ControllerImpl
 
start(CoordinationProtos.DrillbitEndpoint, boolean) - Method in class org.apache.drill.exec.rpc.data.DataConnectionCreator
 
start(StartupOptions) - Static method in class org.apache.drill.exec.server.Drillbit
 
start(DrillConfig) - Static method in class org.apache.drill.exec.server.Drillbit
 
start(DrillConfig, RemoteServiceSet) - Static method in class org.apache.drill.exec.server.Drillbit
 
start(DrillConfig, CaseInsensitiveMap<OptionDefinition>, RemoteServiceSet) - Static method in class org.apache.drill.exec.server.Drillbit
 
start() - Method in class org.apache.drill.exec.server.rest.WebServer
Start the web server including setup.
start() - Method in class org.apache.drill.exec.service.ServiceEngine
 
start() - Method in class org.apache.drill.exec.store.AbstractStoragePlugin
 
start - Variable in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v1
 
start - Variable in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v2
 
start - Variable in class org.apache.drill.exec.store.parquet.Metadata.RowGroupMetadata_v3
 
start() - Method in class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter
 
start - Variable in class org.apache.drill.exec.store.schedule.CompleteFileWork.FileWorkImpl
 
start() - Method in interface org.apache.drill.exec.store.StoragePlugin
Initialize the storage plugin.
start() - Method in interface org.apache.drill.exec.store.sys.PersistentStoreProvider
Sets up the provider.
start() - Method in class org.apache.drill.exec.store.sys.store.provider.BasePersistentStoreProvider
 
start() - Method in class org.apache.drill.exec.store.sys.store.provider.CachingPersistentStoreProvider
 
start() - Method in class org.apache.drill.exec.store.sys.store.provider.InMemoryStoreProvider
 
start() - Method in class org.apache.drill.exec.store.sys.store.ZookeeperPersistentStore
 
start(CoordinationProtos.DrillbitEndpoint, Controller, DataConnectionCreator, ClusterCoordinator, PersistentStoreProvider, PersistentStoreProvider) - Method in class org.apache.drill.exec.work.WorkManager
 
startBatch() - Method in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
 
startBitMasks - Static variable in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
startField() - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter.MapJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter.RepeatedListJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter.RepeatedMapJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter.UnionJsonConverter
 
startField(int) - Method in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
 
startField() - Method in class org.apache.drill.exec.store.EventBasedRecordWriter.FieldConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.BigIntJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.BitJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.DateJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal18JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal28DenseJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal28SparseJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal38DenseJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal38SparseJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal9JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Float4JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Float8JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.IntervalDayJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.IntervalJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.IntervalYearJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.IntJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableBigIntJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableBitJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDateJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal18JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal28DenseJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal28SparseJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal38DenseJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal38SparseJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal9JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableFloat4JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableFloat8JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableIntervalDayJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableIntervalJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableIntervalYearJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableIntJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableSmallIntJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableTimeJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableTimeStampJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableTinyIntJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableUInt1JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableUInt2JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableUInt4JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableUInt8JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableVar16CharJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableVarBinaryJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableVarCharJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedBigIntJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedBitJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDateJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal18JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal28DenseJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal28SparseJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal38DenseJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal38SparseJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal9JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedFloat4JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedFloat8JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedIntervalDayJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedIntervalJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedIntervalYearJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedIntJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedSmallIntJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedTimeJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedTimeStampJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedTinyIntJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedUInt1JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedUInt2JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedUInt4JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedUInt8JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedVar16CharJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedVarBinaryJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedVarCharJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.SmallIntJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.TimeJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.TimeStampJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.TinyIntJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.UInt1JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.UInt2JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.UInt4JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.UInt8JsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Var16CharJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.VarBinaryJsonConverter
 
startField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.VarCharJsonConverter
 
startFragmentPendingRemote(FragmentManager) - Method in class org.apache.drill.exec.work.WorkManager.WorkerBee
Currently used to start a root fragment that is blocked on data, and intermediate fragments.
startLocalOutput(Path, Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
startMerge(BatchSchema, List<? extends BatchGroup>, VectorContainer, int, VectorInitializer) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierWrapper
Start a merge operation using the specified vector container.
startMerge() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl
 
startNewSchema(List<String>) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
startNewSchema(List<String>) - Method in class org.apache.drill.exec.store.text.DrillTextRecordWriter
 
startNode(Prel) - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor.VisualizationState
 
startOffset - Variable in class org.apache.drill.exec.util.filereader.DirectBufInputStream
The offset in the underlying stream to start reading from
startProcessing() - Method in class org.apache.drill.exec.ops.OperatorStats
 
startRecord() - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter
 
startRecord() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
 
startRecord() - Method in interface org.apache.drill.exec.store.RecordWriter
Called before starting writing fields in a record.
startRecord() - Method in class org.apache.drill.exec.store.text.DrillTextRecordWriter
 
startRM() - Method in class org.apache.drill.exec.server.DrillbitContext
Starts the resource manager.
startSetup() - Method in class org.apache.drill.exec.ops.OperatorStats
 
StartupOptions - Class in org.apache.drill.exec.server
 
StartupOptions() - Constructor for class org.apache.drill.exec.server.StartupOptions
 
startWait() - Method in interface org.apache.drill.exec.ops.OperatorStatReceiver
 
startWait() - Method in class org.apache.drill.exec.ops.OperatorStats
 
STATE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
state - Variable in class org.apache.drill.exec.record.AbstractRecordBatch
 
state - Variable in class org.apache.drill.exec.store.sys.DrillbitIterator.DrillbitInstance
 
STATEMENT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
StateTransitionException - Exception in org.apache.drill.exec.work.fragment
 
StateTransitionException() - Constructor for exception org.apache.drill.exec.work.fragment.StateTransitionException
 
StateTransitionException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.drill.exec.work.fragment.StateTransitionException
 
StateTransitionException(String, Throwable) - Constructor for exception org.apache.drill.exec.work.fragment.StateTransitionException
 
StateTransitionException(String) - Constructor for exception org.apache.drill.exec.work.fragment.StateTransitionException
 
StateTransitionException(Throwable) - Constructor for exception org.apache.drill.exec.work.fragment.StateTransitionException
 
STATIC - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
StaticDrillTable - Class in org.apache.drill.exec.store.sys
A DrillTable with a defined schema Currently, this is a wrapper class for SystemTable.
StaticDrillTable(String, StoragePlugin, Schema.TableType, Object, RecordDataType) - Constructor for class org.apache.drill.exec.store.sys.StaticDrillTable
 
staticFlag - Static variable in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
stats - Variable in class org.apache.drill.exec.physical.impl.BaseRootExec
 
Stats - Class in org.apache.drill.exec.planner.fragment
 
Stats() - Constructor for class org.apache.drill.exec.planner.fragment.Stats
 
stats - Variable in class org.apache.drill.exec.record.AbstractRecordBatch
 
stats - Variable in class org.apache.drill.exec.store.direct.DirectGroupScan
 
StatsCollector - Class in org.apache.drill.exec.planner.fragment
Visitor to collect stats such as cost and parallelization info of operators within a fragment.
StatsCollector(PlanningSet) - Constructor for class org.apache.drill.exec.planner.fragment.StatsCollector
 
status - Variable in class org.apache.drill.exec.store.sys.OptionIterator.OptionValueWrapper
 
StatusHandler - Class in org.apache.drill.exec.ops
Listener that keeps track of the status of batches sent, and updates the SendingAccountor when status is received for each batch
StatusHandler(Consumer<RpcException>, SendingAccountor) - Constructor for class org.apache.drill.exec.ops.StatusHandler
 
StatusResources - Class in org.apache.drill.exec.server.rest
 
StatusResources() - Constructor for class org.apache.drill.exec.server.rest.StatusResources
 
StatusResources.OptionWrapper - Class in org.apache.drill.exec.server.rest
 
StatusResources.OptionWrapper(String, Object, OptionValue.AccessibleScopes, OptionValue.Kind, OptionValue.OptionScope) - Constructor for class org.apache.drill.exec.server.rest.StatusResources.OptionWrapper
 
statusUpdate(BitControl.FragmentStatus) - Method in class org.apache.drill.exec.rpc.control.WorkEventBus
 
statusUpdate(BitControl.FragmentStatus) - Method in interface org.apache.drill.exec.work.foreman.FragmentStatusListener
 
STDDEV_POP - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
STDDEV_SAMP - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
StdDevPopFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions
 
StdDevPopFunctions.BigIntStdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.BigIntStdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.BigIntStdDevPop
 
StdDevPopFunctions.Float4StdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.Float4StdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.Float4StdDevPop
 
StdDevPopFunctions.Float8StdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.Float8StdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.Float8StdDevPop
 
StdDevPopFunctions.IntStdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.IntStdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.IntStdDevPop
 
StdDevPopFunctions.NullableBigIntStdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.NullableBigIntStdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableBigIntStdDevPop
 
StdDevPopFunctions.NullableFloat4StdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.NullableFloat4StdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableFloat4StdDevPop
 
StdDevPopFunctions.NullableFloat8StdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.NullableFloat8StdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableFloat8StdDevPop
 
StdDevPopFunctions.NullableIntStdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.NullableIntStdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableIntStdDevPop
 
StdDevPopFunctions.NullableSmallIntStdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.NullableSmallIntStdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableSmallIntStdDevPop
 
StdDevPopFunctions.NullableTinyIntStdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.NullableTinyIntStdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableTinyIntStdDevPop
 
StdDevPopFunctions.NullableUInt1StdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.NullableUInt1StdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt1StdDevPop
 
StdDevPopFunctions.NullableUInt2StdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.NullableUInt2StdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt2StdDevPop
 
StdDevPopFunctions.NullableUInt4StdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.NullableUInt4StdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt4StdDevPop
 
StdDevPopFunctions.NullableUInt8StdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.NullableUInt8StdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.NullableUInt8StdDevPop
 
StdDevPopFunctions.SmallIntStdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.SmallIntStdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.SmallIntStdDevPop
 
StdDevPopFunctions.TinyIntStdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.TinyIntStdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.TinyIntStdDevPop
 
StdDevPopFunctions.UInt1StdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.UInt1StdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt1StdDevPop
 
StdDevPopFunctions.UInt2StdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.UInt2StdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt2StdDevPop
 
StdDevPopFunctions.UInt4StdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.UInt4StdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt4StdDevPop
 
StdDevPopFunctions.UInt8StdDevPop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevPopFunctions.UInt8StdDevPop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevPopFunctions.UInt8StdDevPop
 
StdDevSampleFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions
 
StdDevSampleFunctions.BigIntStdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.BigIntStdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.BigIntStdDevSample
 
StdDevSampleFunctions.Float4StdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.Float4StdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.Float4StdDevSample
 
StdDevSampleFunctions.Float8StdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.Float8StdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.Float8StdDevSample
 
StdDevSampleFunctions.IntStdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.IntStdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.IntStdDevSample
 
StdDevSampleFunctions.NullableBigIntStdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.NullableBigIntStdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableBigIntStdDevSample
 
StdDevSampleFunctions.NullableFloat4StdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.NullableFloat4StdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableFloat4StdDevSample
 
StdDevSampleFunctions.NullableFloat8StdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.NullableFloat8StdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableFloat8StdDevSample
 
StdDevSampleFunctions.NullableIntStdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.NullableIntStdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableIntStdDevSample
 
StdDevSampleFunctions.NullableSmallIntStdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.NullableSmallIntStdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableSmallIntStdDevSample
 
StdDevSampleFunctions.NullableTinyIntStdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.NullableTinyIntStdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableTinyIntStdDevSample
 
StdDevSampleFunctions.NullableUInt1StdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.NullableUInt1StdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt1StdDevSample
 
StdDevSampleFunctions.NullableUInt2StdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.NullableUInt2StdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt2StdDevSample
 
StdDevSampleFunctions.NullableUInt4StdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.NullableUInt4StdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt4StdDevSample
 
StdDevSampleFunctions.NullableUInt8StdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.NullableUInt8StdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.NullableUInt8StdDevSample
 
StdDevSampleFunctions.SmallIntStdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.SmallIntStdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.SmallIntStdDevSample
 
StdDevSampleFunctions.TinyIntStdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.TinyIntStdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.TinyIntStdDevSample
 
StdDevSampleFunctions.UInt1StdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.UInt1StdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt1StdDevSample
 
StdDevSampleFunctions.UInt2StdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.UInt2StdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt2StdDevSample
 
StdDevSampleFunctions.UInt4StdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.UInt4StdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt4StdDevSample
 
StdDevSampleFunctions.UInt8StdDevSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
StdDevSampleFunctions.UInt8StdDevSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.StdDevSampleFunctions.UInt8StdDevSample
 
stdRowWidth() - Method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
 
stdSize - Variable in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer.ColumnSize
Assumed size from Drill metadata.
stopProcessing() - Method in class org.apache.drill.exec.ops.OperatorStats
 
stopSetup() - Method in class org.apache.drill.exec.ops.OperatorStats
 
stopWait() - Method in interface org.apache.drill.exec.ops.OperatorStatReceiver
 
stopWait() - Method in class org.apache.drill.exec.ops.OperatorStats
 
STORAGE_PLUGIN_REGISTRY_IMPL - Static variable in interface org.apache.drill.exec.store.StoragePluginRegistry
 
StoragePlugin - Interface in org.apache.drill.exec.store
Interface for all implementations of the storage plugins.
StoragePluginOptimizerRule - Class in org.apache.drill.exec.store
 
StoragePluginOptimizerRule(RelOptRuleOperand, String) - Constructor for class org.apache.drill.exec.store.StoragePluginOptimizerRule
 
StoragePluginRegistry - Interface in org.apache.drill.exec.store
 
StoragePluginRegistryImpl - Class in org.apache.drill.exec.store
 
StoragePluginRegistryImpl(DrillbitContext) - Constructor for class org.apache.drill.exec.store.StoragePluginRegistryImpl
 
StoragePluginRegistryImpl.DrillSchemaFactory - Class in org.apache.drill.exec.store
 
StoragePluginRegistryImpl.DrillSchemaFactory() - Constructor for class org.apache.drill.exec.store.StoragePluginRegistryImpl.DrillSchemaFactory
 
StoragePlugins - Class in org.apache.drill.exec.planner.logical
 
StoragePlugins(Map<String, StoragePluginConfig>) - Constructor for class org.apache.drill.exec.planner.logical.StoragePlugins
 
StoragePluginTestUtils - Class in org.apache.drill.exec.util
This class contains utility methods to speed up tests.
StoragePluginTestUtils() - Constructor for class org.apache.drill.exec.util.StoragePluginTestUtils
 
StorageResources - Class in org.apache.drill.exec.server.rest
 
StorageResources() - Constructor for class org.apache.drill.exec.server.rest.StorageResources
 
StorageResources.JsonResult - Class in org.apache.drill.exec.server.rest
 
StorageResources.JsonResult(String) - Constructor for class org.apache.drill.exec.server.rest.StorageResources.JsonResult
 
storages - Variable in class org.apache.drill.exec.planner.sql.DynamicRootSchema
 
StorageStrategy - Class in org.apache.drill.exec.store
Contains list of parameters that will be used to store path / files on file system.
StorageStrategy(String, boolean) - Constructor for class org.apache.drill.exec.store.StorageStrategy
 
Store - Interface in org.apache.drill.exec.physical.base
An interface which supports storing a record stream.
StoreException - Exception in org.apache.drill.exec.exception
 
StoreException() - Constructor for exception org.apache.drill.exec.exception.StoreException
 
StoreException(Throwable) - Constructor for exception org.apache.drill.exec.exception.StoreException
 
StoreException(String) - Constructor for exception org.apache.drill.exec.exception.StoreException
 
StoreException(String, Throwable) - Constructor for exception org.apache.drill.exec.exception.StoreException
 
StoreException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.drill.exec.exception.StoreException
 
STREAM - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
STREAMAGG - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
StreamAggPrel - Class in org.apache.drill.exec.planner.physical
 
StreamAggPrel(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>, AggPrelBase.OperatorPhase) - Constructor for class org.apache.drill.exec.planner.physical.StreamAggPrel
 
StreamAggPrule - Class in org.apache.drill.exec.planner.physical
 
streamId - Variable in class org.apache.drill.exec.util.filereader.DirectBufInputStream
 
StreamingAggBatch - Class in org.apache.drill.exec.physical.impl.aggregate
 
StreamingAggBatch(StreamingAggregate, RecordBatch, FragmentContext) - Constructor for class org.apache.drill.exec.physical.impl.aggregate.StreamingAggBatch
 
StreamingAggBatchCreator - Class in org.apache.drill.exec.physical.impl.aggregate
 
StreamingAggBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.aggregate.StreamingAggBatchCreator
 
StreamingAggregate - Class in org.apache.drill.exec.physical.config
 
StreamingAggregate(PhysicalOperator, List<NamedExpression>, List<NamedExpression>, float) - Constructor for class org.apache.drill.exec.physical.config.StreamingAggregate
 
StreamingAggregator - Interface in org.apache.drill.exec.physical.impl.aggregate
 
StreamingAggregator.AggOutcome - Enum in org.apache.drill.exec.physical.impl.aggregate
 
StreamingAggTemplate - Class in org.apache.drill.exec.physical.impl.aggregate
 
StreamingAggTemplate() - Constructor for class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
 
STRING_TYPE - Static variable in class org.apache.drill.exec.schema.json.jackson.JacksonHelper
 
string_val - Variable in class org.apache.drill.exec.server.options.OptionValue
 
string_val - Variable in class org.apache.drill.exec.store.sys.OptionIterator.OptionValueWrapper
 
StringCastReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
Return type calculation implementation for functions with return type set as FunctionTemplate.ReturnType.STRING_CAST.
StringCastReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.StringCastReturnTypeInference
 
StringFunctionHelpers - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctionHelpers() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctionHelpers
 
StringFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.AsciiEndode - Class in org.apache.drill.exec.expr.fn.impl
Convert string to ASCII from another encoding input.
StringFunctions.AsciiEndode() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.AsciiEndode
 
StringFunctions.AsciiString - Class in org.apache.drill.exec.expr.fn.impl
Returns the ASCII code of the first character of input string
StringFunctions.AsciiString() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.AsciiString
 
StringFunctions.AsciiToChar - Class in org.apache.drill.exec.expr.fn.impl
Returns the char corresponding to ASCII code input.
StringFunctions.AsciiToChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.AsciiToChar
 
StringFunctions.BinaryString - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.BinaryString() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.BinaryString
 
StringFunctions.BitLength - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.BitLength() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.BitLength
 
StringFunctions.Btrim - Class in org.apache.drill.exec.expr.fn.impl
Remove the longest string containing only characters from "from" from the start of "text"
StringFunctions.Btrim() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Btrim
 
StringFunctions.BtrimOneArg - Class in org.apache.drill.exec.expr.fn.impl
Remove the longest string containing only character " " from the start of "text"
StringFunctions.BtrimOneArg() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.BtrimOneArg
 
StringFunctions.ByteLength - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.ByteLength() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.ByteLength
 
StringFunctions.CharLength - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.CharLength() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.CharLength
 
StringFunctions.Concat - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.Concat() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Concat
 
StringFunctions.ConcatBothNullInput - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.ConcatBothNullInput() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatBothNullInput
 
StringFunctions.ConcatLeftNullInput - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.ConcatLeftNullInput() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatLeftNullInput
 
StringFunctions.ConcatOperator - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.ConcatOperator() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatOperator
 
StringFunctions.ConcatRightNullInput - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.ConcatRightNullInput() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatRightNullInput
 
StringFunctions.ILike - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.ILike() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.ILike
 
StringFunctions.ILikeWithEscape - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.ILikeWithEscape() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.ILikeWithEscape
 
StringFunctions.InitCap - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.InitCap() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.InitCap
 
StringFunctions.Left - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.Left() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Left
 
StringFunctions.Like - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.Like() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Like
 
StringFunctions.LikeWithEscape - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.LikeWithEscape() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.LikeWithEscape
 
StringFunctions.LowerCase - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.LowerCase() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.LowerCase
 
StringFunctions.Lpad - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.Lpad() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Lpad
 
StringFunctions.LpadTwoArg - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.LpadTwoArg() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.LpadTwoArg
 
StringFunctions.Ltrim - Class in org.apache.drill.exec.expr.fn.impl
Remove the longest string containing only characters from "from" from the start of "text"
StringFunctions.Ltrim() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Ltrim
 
StringFunctions.LtrimOneArg - Class in org.apache.drill.exec.expr.fn.impl
Remove the longest string containing only character " " from the start of "text"
StringFunctions.LtrimOneArg() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.LtrimOneArg
 
StringFunctions.OctetLength - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.OctetLength() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.OctetLength
 
StringFunctions.Position - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.Position() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Position
 
StringFunctions.RegexpMatches - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.RegexpMatches() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.RegexpMatches
 
StringFunctions.RegexpReplace - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.RegexpReplace() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.RegexpReplace
 
StringFunctions.RepeatString - Class in org.apache.drill.exec.expr.fn.impl
Returns the input char sequences repeated nTimes.
StringFunctions.RepeatString() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.RepeatString
 
StringFunctions.Replace - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.Replace() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Replace
 
StringFunctions.ReverseString - Class in org.apache.drill.exec.expr.fn.impl
Returns the reverse string for given input.
StringFunctions.ReverseString() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.ReverseString
 
StringFunctions.Right - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.Right() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Right
 
StringFunctions.Rpad - Class in org.apache.drill.exec.expr.fn.impl
Fill up the string to length "length" by appending the characters 'fill' at the end of 'text' If the string is already longer than length then it is truncated.
StringFunctions.Rpad() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Rpad
 
StringFunctions.RpadTwoArg - Class in org.apache.drill.exec.expr.fn.impl
Fill up the string to length "length" by appending the characters ' ' at the end of 'text' If the string is already longer than length then it is truncated.
StringFunctions.RpadTwoArg() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.RpadTwoArg
 
StringFunctions.Rtrim - Class in org.apache.drill.exec.expr.fn.impl
Remove the longest string containing only characters from "from" from the end of "text"
StringFunctions.Rtrim() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Rtrim
 
StringFunctions.RtrimOneArg - Class in org.apache.drill.exec.expr.fn.impl
Remove the longest string containing only character " " from the end of "text"
StringFunctions.RtrimOneArg() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.RtrimOneArg
 
StringFunctions.Similar - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.Similar() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Similar
 
StringFunctions.SimilarWithEscape - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.SimilarWithEscape() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.SimilarWithEscape
 
StringFunctions.Split - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.Split() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Split
 
StringFunctions.SplitPart - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.SplitPart() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.SplitPart
 
StringFunctions.StringBinary - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.StringBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.StringBinary
 
StringFunctions.Strpos - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.Strpos() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Strpos
 
StringFunctions.Substring - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.Substring() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Substring
 
StringFunctions.SubstringOffset - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.SubstringOffset() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.SubstringOffset
 
StringFunctions.SubstringRegex - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.SubstringRegex() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.SubstringRegex
 
StringFunctions.SubstringRegexNullable - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.SubstringRegexNullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.SubstringRegexNullable
 
StringFunctions.UpperCase - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctions.UpperCase() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.UpperCase
 
StringFunctionUtil - Class in org.apache.drill.exec.expr.fn.impl
 
StringFunctionUtil() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctionUtil
 
StringGen - Class in org.apache.drill.exec.store.mock
Generates a mock string field of the given length.
StringGen() - Constructor for class org.apache.drill.exec.store.mock.StringGen
 
stringLeftMatchUTF8(ByteBuf, int, int, ByteBuf, int, int) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionUtil
 
StringLiteral() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a string literal.
StringOutputRecordWriter - Class in org.apache.drill.exec.store
Abstract implementation of RecordWriter interface which exposes interface: #writeHeader(List) StringOutputRecordWriter.addField(int,String) to output the data in string format instead of implementing addField for each type holder.
StringOutputRecordWriter(BufferAllocator) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter
 
StringOutputRecordWriter.BigIntStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.BigIntStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.BigIntStringFieldConverter
 
StringOutputRecordWriter.BitStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.BitStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.BitStringFieldConverter
 
StringOutputRecordWriter.DateStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.DateStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.DateStringFieldConverter
 
StringOutputRecordWriter.Decimal18StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.Decimal18StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.Decimal18StringFieldConverter
 
StringOutputRecordWriter.Decimal28DenseStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.Decimal28DenseStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.Decimal28DenseStringFieldConverter
 
StringOutputRecordWriter.Decimal28SparseStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.Decimal28SparseStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.Decimal28SparseStringFieldConverter
 
StringOutputRecordWriter.Decimal38DenseStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.Decimal38DenseStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.Decimal38DenseStringFieldConverter
 
StringOutputRecordWriter.Decimal38SparseStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.Decimal38SparseStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.Decimal38SparseStringFieldConverter
 
StringOutputRecordWriter.Decimal9StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.Decimal9StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.Decimal9StringFieldConverter
 
StringOutputRecordWriter.Float4StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.Float4StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.Float4StringFieldConverter
 
StringOutputRecordWriter.Float8StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.Float8StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.Float8StringFieldConverter
 
StringOutputRecordWriter.IntervalDayStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.IntervalDayStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.IntervalDayStringFieldConverter
 
StringOutputRecordWriter.IntervalStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.IntervalStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.IntervalStringFieldConverter
 
StringOutputRecordWriter.IntervalYearStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.IntervalYearStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.IntervalYearStringFieldConverter
 
StringOutputRecordWriter.IntStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.IntStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.IntStringFieldConverter
 
StringOutputRecordWriter.NullableBigIntStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableBigIntStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableBigIntStringFieldConverter
 
StringOutputRecordWriter.NullableBitStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableBitStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableBitStringFieldConverter
 
StringOutputRecordWriter.NullableDateStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableDateStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableDateStringFieldConverter
 
StringOutputRecordWriter.NullableDecimal18StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableDecimal18StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableDecimal18StringFieldConverter
 
StringOutputRecordWriter.NullableDecimal28DenseStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableDecimal28DenseStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableDecimal28DenseStringFieldConverter
 
StringOutputRecordWriter.NullableDecimal28SparseStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableDecimal28SparseStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableDecimal28SparseStringFieldConverter
 
StringOutputRecordWriter.NullableDecimal38DenseStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableDecimal38DenseStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableDecimal38DenseStringFieldConverter
 
StringOutputRecordWriter.NullableDecimal38SparseStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableDecimal38SparseStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableDecimal38SparseStringFieldConverter
 
StringOutputRecordWriter.NullableDecimal9StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableDecimal9StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableDecimal9StringFieldConverter
 
StringOutputRecordWriter.NullableFloat4StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableFloat4StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableFloat4StringFieldConverter
 
StringOutputRecordWriter.NullableFloat8StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableFloat8StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableFloat8StringFieldConverter
 
StringOutputRecordWriter.NullableIntervalDayStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableIntervalDayStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableIntervalDayStringFieldConverter
 
StringOutputRecordWriter.NullableIntervalStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableIntervalStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableIntervalStringFieldConverter
 
StringOutputRecordWriter.NullableIntervalYearStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableIntervalYearStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableIntervalYearStringFieldConverter
 
StringOutputRecordWriter.NullableIntStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableIntStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableIntStringFieldConverter
 
StringOutputRecordWriter.NullableSmallIntStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableSmallIntStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableSmallIntStringFieldConverter
 
StringOutputRecordWriter.NullableTimeStampStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableTimeStampStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableTimeStampStringFieldConverter
 
StringOutputRecordWriter.NullableTimeStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableTimeStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableTimeStringFieldConverter
 
StringOutputRecordWriter.NullableTinyIntStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableTinyIntStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableTinyIntStringFieldConverter
 
StringOutputRecordWriter.NullableUInt1StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableUInt1StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableUInt1StringFieldConverter
 
StringOutputRecordWriter.NullableUInt2StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableUInt2StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableUInt2StringFieldConverter
 
StringOutputRecordWriter.NullableUInt4StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableUInt4StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableUInt4StringFieldConverter
 
StringOutputRecordWriter.NullableUInt8StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableUInt8StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableUInt8StringFieldConverter
 
StringOutputRecordWriter.NullableVar16CharStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableVar16CharStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableVar16CharStringFieldConverter
 
StringOutputRecordWriter.NullableVarBinaryStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableVarBinaryStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableVarBinaryStringFieldConverter
 
StringOutputRecordWriter.NullableVarCharStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.NullableVarCharStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.NullableVarCharStringFieldConverter
 
StringOutputRecordWriter.RepeatedBigIntStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedBigIntStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedBigIntStringFieldConverter
 
StringOutputRecordWriter.RepeatedBitStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedBitStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedBitStringFieldConverter
 
StringOutputRecordWriter.RepeatedDateStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedDateStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedDateStringFieldConverter
 
StringOutputRecordWriter.RepeatedDecimal18StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedDecimal18StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedDecimal18StringFieldConverter
 
StringOutputRecordWriter.RepeatedDecimal28DenseStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedDecimal28DenseStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedDecimal28DenseStringFieldConverter
 
StringOutputRecordWriter.RepeatedDecimal28SparseStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedDecimal28SparseStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedDecimal28SparseStringFieldConverter
 
StringOutputRecordWriter.RepeatedDecimal38DenseStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedDecimal38DenseStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedDecimal38DenseStringFieldConverter
 
StringOutputRecordWriter.RepeatedDecimal38SparseStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedDecimal38SparseStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedDecimal38SparseStringFieldConverter
 
StringOutputRecordWriter.RepeatedDecimal9StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedDecimal9StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedDecimal9StringFieldConverter
 
StringOutputRecordWriter.RepeatedFloat4StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedFloat4StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedFloat4StringFieldConverter
 
StringOutputRecordWriter.RepeatedFloat8StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedFloat8StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedFloat8StringFieldConverter
 
StringOutputRecordWriter.RepeatedIntervalDayStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedIntervalDayStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedIntervalDayStringFieldConverter
 
StringOutputRecordWriter.RepeatedIntervalStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedIntervalStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedIntervalStringFieldConverter
 
StringOutputRecordWriter.RepeatedIntervalYearStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedIntervalYearStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedIntervalYearStringFieldConverter
 
StringOutputRecordWriter.RepeatedIntStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedIntStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedIntStringFieldConverter
 
StringOutputRecordWriter.RepeatedSmallIntStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedSmallIntStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedSmallIntStringFieldConverter
 
StringOutputRecordWriter.RepeatedTimeStampStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedTimeStampStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedTimeStampStringFieldConverter
 
StringOutputRecordWriter.RepeatedTimeStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedTimeStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedTimeStringFieldConverter
 
StringOutputRecordWriter.RepeatedTinyIntStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedTinyIntStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedTinyIntStringFieldConverter
 
StringOutputRecordWriter.RepeatedUInt1StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedUInt1StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedUInt1StringFieldConverter
 
StringOutputRecordWriter.RepeatedUInt2StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedUInt2StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedUInt2StringFieldConverter
 
StringOutputRecordWriter.RepeatedUInt4StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedUInt4StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedUInt4StringFieldConverter
 
StringOutputRecordWriter.RepeatedUInt8StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedUInt8StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedUInt8StringFieldConverter
 
StringOutputRecordWriter.RepeatedVar16CharStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedVar16CharStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedVar16CharStringFieldConverter
 
StringOutputRecordWriter.RepeatedVarBinaryStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedVarBinaryStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedVarBinaryStringFieldConverter
 
StringOutputRecordWriter.RepeatedVarCharStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.RepeatedVarCharStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedVarCharStringFieldConverter
 
StringOutputRecordWriter.SmallIntStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.SmallIntStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.SmallIntStringFieldConverter
 
StringOutputRecordWriter.TimeStampStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.TimeStampStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.TimeStampStringFieldConverter
 
StringOutputRecordWriter.TimeStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.TimeStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.TimeStringFieldConverter
 
StringOutputRecordWriter.TinyIntStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.TinyIntStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.TinyIntStringFieldConverter
 
StringOutputRecordWriter.UInt1StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.UInt1StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.UInt1StringFieldConverter
 
StringOutputRecordWriter.UInt2StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.UInt2StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.UInt2StringFieldConverter
 
StringOutputRecordWriter.UInt4StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.UInt4StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.UInt4StringFieldConverter
 
StringOutputRecordWriter.UInt8StringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.UInt8StringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.UInt8StringFieldConverter
 
StringOutputRecordWriter.Var16CharStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.Var16CharStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.Var16CharStringFieldConverter
 
StringOutputRecordWriter.VarBinaryStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.VarBinaryStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.VarBinaryStringFieldConverter
 
StringOutputRecordWriter.VarCharStringFieldConverter - Class in org.apache.drill.exec.store
 
StringOutputRecordWriter.VarCharStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.StringOutputRecordWriter.VarCharStringFieldConverter
 
STRUCTURE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
STYLE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SUBCLASS_ORIGIN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SubDirectoryList - Class in org.apache.drill.exec.store.dfs
 
sublistsCreated - Variable in class org.apache.drill.exec.planner.AbstractPartitionDescriptor
Flag to indicate if the sublists of the partition locations has been created
submissionFailed(UserException) - Method in class org.apache.drill.exec.client.PrintingResultsListener
 
submissionFailed(UserException) - Method in class org.apache.drill.exec.rpc.user.AwaitableUserResultsListener
 
submissionFailed(UserException) - Method in interface org.apache.drill.exec.rpc.user.UserResultsListener
The query has failed.
submitCatalogMetadataWork(UserSession, UserProtos.GetCatalogsReq, ResponseSender) - Method in class org.apache.drill.exec.work.user.UserWorker
 
submitColumnsMetadataWork(UserSession, UserProtos.GetColumnsReq, ResponseSender) - Method in class org.apache.drill.exec.work.user.UserWorker
 
submitForUnregistration(String) - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
 
submitPreparedStatementWork(UserClientConnection, UserProtos.CreatePreparedStatementReq, ResponseSender) - Method in class org.apache.drill.exec.work.user.UserWorker
 
submitQuery(String, String, String, String, boolean, int, String) - Method in class org.apache.drill.exec.client.QuerySubmitter
 
submitQuery(String, String, String, String, boolean, int, String, int) - Method in class org.apache.drill.exec.client.QuerySubmitter
 
submitQuery(DrillClient, String, String, String, int) - Method in class org.apache.drill.exec.client.QuerySubmitter
 
submitQuery(UserResultsListener, UserProtos.RunQuery) - Method in class org.apache.drill.exec.rpc.user.UserClient
 
submitQuery(String, String) - Method in class org.apache.drill.exec.server.rest.QueryResources
 
submitQueryJSON(QueryWrapper) - Method in class org.apache.drill.exec.server.rest.QueryResources
 
submitSchemasMetadataWork(UserSession, UserProtos.GetSchemasReq, ResponseSender) - Method in class org.apache.drill.exec.work.user.UserWorker
 
submitServerMetadataWork(UserSession, UserProtos.GetServerMetaReq, ResponseSender) - Method in class org.apache.drill.exec.work.user.UserWorker
 
submitTablesMetadataWork(UserSession, UserProtos.GetTablesReq, ResponseSender) - Method in class org.apache.drill.exec.work.user.UserWorker
 
submitWork(UserClientConnection, UserProtos.RunQuery) - Method in class org.apache.drill.exec.work.user.UserWorker
 
SUBMULTISET - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SubScan - Interface in org.apache.drill.exec.physical.base
A SubScan operator represents the data scanned by a particular major/minor fragment.
SubSchemaWrapper - Class in org.apache.drill.exec.store
 
SubSchemaWrapper(AbstractSchema) - Constructor for class org.apache.drill.exec.store.SubSchemaWrapper
 
subSequence(int, int) - Method in class org.apache.drill.exec.expr.fn.impl.CharSequenceWrapper
When using the Java regex Matcher the subSequence is only called when capturing groups.
SubsetTransformer<T extends org.apache.calcite.rel.RelNode,E extends Exception> - Class in org.apache.drill.exec.planner.physical
 
SubsetTransformer(RelOptRuleCall) - Constructor for class org.apache.drill.exec.planner.physical.SubsetTransformer
 
SUBSTITUTE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SUBSTRING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
subsumeColumn(Map<String, String>, String) - Static method in class org.apache.drill.exec.planner.StarColumnHelper
 
SubtractFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
SubtractFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.SubtractFunctions
 
SubtractFunctions.BigIntBigIntSubtract - Class in org.apache.drill.exec.expr.fn.impl
 
SubtractFunctions.BigIntBigIntSubtract() - Constructor for class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.BigIntBigIntSubtract
 
SubtractFunctions.Float4Float4Subtract - Class in org.apache.drill.exec.expr.fn.impl
 
SubtractFunctions.Float4Float4Subtract() - Constructor for class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.Float4Float4Subtract
 
SubtractFunctions.Float8Float8Subtract - Class in org.apache.drill.exec.expr.fn.impl
 
SubtractFunctions.Float8Float8Subtract() - Constructor for class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.Float8Float8Subtract
 
SubtractFunctions.IntIntSubtract - Class in org.apache.drill.exec.expr.fn.impl
 
SubtractFunctions.IntIntSubtract() - Constructor for class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.IntIntSubtract
 
SubtractFunctions.SmallIntSmallIntSubtract - Class in org.apache.drill.exec.expr.fn.impl
 
SubtractFunctions.SmallIntSmallIntSubtract() - Constructor for class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.SmallIntSmallIntSubtract
 
SubtractFunctions.TinyIntTinyIntSubtract - Class in org.apache.drill.exec.expr.fn.impl
 
SubtractFunctions.TinyIntTinyIntSubtract() - Constructor for class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.TinyIntTinyIntSubtract
 
SubtractFunctions.UInt1UInt1Subtract - Class in org.apache.drill.exec.expr.fn.impl
 
SubtractFunctions.UInt1UInt1Subtract() - Constructor for class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.UInt1UInt1Subtract
 
SubtractFunctions.UInt2UInt2Subtract - Class in org.apache.drill.exec.expr.fn.impl
 
SubtractFunctions.UInt2UInt2Subtract() - Constructor for class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.UInt2UInt2Subtract
 
SubtractFunctions.UInt4UInt4Subtract - Class in org.apache.drill.exec.expr.fn.impl
 
SubtractFunctions.UInt4UInt4Subtract() - Constructor for class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.UInt4UInt4Subtract
 
SubtractFunctions.UInt8UInt8Subtract - Class in org.apache.drill.exec.expr.fn.impl
 
SubtractFunctions.UInt8UInt8Subtract() - Constructor for class org.apache.drill.exec.expr.fn.impl.SubtractFunctions.UInt8UInt8Subtract
 
success(GeneralRPCProtos.Ack, ByteBuf) - Method in class org.apache.drill.exec.ops.StatusHandler
 
success(UserBitShared.SaslMessage, ByteBuf) - Method in class org.apache.drill.exec.rpc.security.AuthenticationOutcomeListener
 
SUM - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SumDateTypeFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumDateTypeFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions
 
SumDateTypeFunctions.IntervalDaySum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumDateTypeFunctions.IntervalDaySum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.IntervalDaySum
 
SumDateTypeFunctions.IntervalSum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumDateTypeFunctions.IntervalSum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.IntervalSum
 
SumDateTypeFunctions.IntervalYearSum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumDateTypeFunctions.IntervalYearSum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.IntervalYearSum
 
SumDateTypeFunctions.NullableIntervalDaySum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumDateTypeFunctions.NullableIntervalDaySum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.NullableIntervalDaySum
 
SumDateTypeFunctions.NullableIntervalSum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumDateTypeFunctions.NullableIntervalSum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.NullableIntervalSum
 
SumDateTypeFunctions.NullableIntervalYearSum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumDateTypeFunctions.NullableIntervalYearSum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumDateTypeFunctions.NullableIntervalYearSum
 
SumFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions
 
SumFunctions.BigIntSum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumFunctions.BigIntSum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.BigIntSum
 
SumFunctions.Float4Sum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumFunctions.Float4Sum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.Float4Sum
 
SumFunctions.Float8Sum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumFunctions.Float8Sum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.Float8Sum
 
SumFunctions.IntSum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumFunctions.IntSum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.IntSum
 
SumFunctions.NullableBigIntSum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumFunctions.NullableBigIntSum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableBigIntSum
 
SumFunctions.NullableFloat4Sum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumFunctions.NullableFloat4Sum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableFloat4Sum
 
SumFunctions.NullableFloat8Sum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumFunctions.NullableFloat8Sum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableFloat8Sum
 
SumFunctions.NullableIntSum - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumFunctions.NullableIntSum() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumFunctions.NullableIntSum
 
summary - Variable in class org.apache.drill.exec.planner.sql.handlers.SimpleCommandResult
 
SumVarBytesFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumVarBytesFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumVarBytesFunctions
 
SumZeroFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumZeroFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions
 
SumZeroFunctions.BigIntSumZero - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumZeroFunctions.BigIntSumZero() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.BigIntSumZero
 
SumZeroFunctions.BitSumZero - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumZeroFunctions.BitSumZero() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.BitSumZero
 
SumZeroFunctions.Float4SumZero - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumZeroFunctions.Float4SumZero() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.Float4SumZero
 
SumZeroFunctions.Float8SumZero - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumZeroFunctions.Float8SumZero() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.Float8SumZero
 
SumZeroFunctions.IntSumZero - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumZeroFunctions.IntSumZero() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.IntSumZero
 
SumZeroFunctions.NullableBigIntSumZero - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumZeroFunctions.NullableBigIntSumZero() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableBigIntSumZero
 
SumZeroFunctions.NullableBitSumZero - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumZeroFunctions.NullableBitSumZero() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableBitSumZero
 
SumZeroFunctions.NullableFloat4SumZero - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumZeroFunctions.NullableFloat4SumZero() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableFloat4SumZero
 
SumZeroFunctions.NullableFloat8SumZero - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumZeroFunctions.NullableFloat8SumZero() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableFloat8SumZero
 
SumZeroFunctions.NullableIntSumZero - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
SumZeroFunctions.NullableIntSumZero() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.SumZeroFunctions.NullableIntSumZero
 
supportDirectoryReads() - Method in class org.apache.drill.exec.store.dfs.BasicFormatMatcher
 
supportDirectoryReads() - Method in class org.apache.drill.exec.store.dfs.FormatMatcher
 
supportDirPrunig() - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
supportDirPruning() - Method in class org.apache.drill.exec.store.dfs.FormatSelection
 
SUPPORTED_SERVER_METHODS - Static variable in class org.apache.drill.exec.rpc.user.UserRpcConfig
Contains the list of methods supported by the server (from user to bit)
SUPPORTED_VERSIONS - Static variable in class org.apache.drill.exec.store.parquet.MetadataVersion.Constants
All historical versions of the Drill metadata cache files.
supportsAutoPartitioning() - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
supportsAutoPartitioning() - Method in interface org.apache.drill.exec.store.dfs.FormatPlugin
Indicates whether this FormatPlugin supports auto-partitioning for CTAS statements
supportsAutoPartitioning() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
supportsLimitPushdown() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
Default is not to support limit pushdown.
supportsLimitPushdown() - Method in interface org.apache.drill.exec.physical.base.GroupScan
Whether or not this GroupScan supports limit pushdown
supportsLimitPushdown() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
supportsMetadataCachePruning() - Method in class org.apache.drill.exec.planner.AbstractPartitionDescriptor
 
supportsMetadataCachePruning() - Method in class org.apache.drill.exec.planner.FileSystemPartitionDescriptor
 
supportsMetadataCachePruning() - Method in interface org.apache.drill.exec.planner.PartitionDescriptor
 
supportsOutOfOrderExchange() - Method in interface org.apache.drill.exec.physical.base.Receiver
Whether or not this receive supports out of order exchange.
supportsOutOfOrderExchange() - Method in class org.apache.drill.exec.physical.config.MergingReceiverPOP
 
supportsOutOfOrderExchange() - Method in class org.apache.drill.exec.physical.config.UnorderedReceiver
 
supportsPartitionFilterPushdown() - Method in class org.apache.drill.exec.physical.base.AbstractFileGroupScan
 
supportsPartitionFilterPushdown() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
 
supportsPartitionFilterPushdown() - Method in interface org.apache.drill.exec.physical.base.GroupScan
Whether or not this GroupScan supports pushdown of partition filters (directories for filesystems)
supportsPlainJava() - Method in class org.apache.drill.exec.expr.CodeGenerator
 
supportsPushDown() - Method in class org.apache.drill.exec.store.avro.AvroFormatPlugin
 
supportsPushDown() - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
supportsPushDown() - Method in class org.apache.drill.exec.store.easy.json.JSONFormatPlugin
 
supportsPushDown() - Method in class org.apache.drill.exec.store.easy.sequencefile.SequenceFileFormatPlugin
 
supportsPushDown() - Method in class org.apache.drill.exec.store.easy.text.TextFormatPlugin
 
supportsPushDown() - Method in class org.apache.drill.exec.store.httpd.HttpdLogFormatPlugin
This plugin supports pushing down into the parser.
supportsPushDown() - Method in class org.apache.drill.exec.store.pcap.PcapFormatPlugin
 
supportsRead() - Method in class org.apache.drill.exec.store.AbstractStoragePlugin
 
supportsRead() - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
supportsRead() - Method in class org.apache.drill.exec.store.dfs.FileSystemPlugin
 
supportsRead() - Method in interface org.apache.drill.exec.store.dfs.FormatPlugin
 
supportsRead() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaStoragePlugin
 
supportsRead() - Method in class org.apache.drill.exec.store.mock.MockStorageEngine
 
supportsRead() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
supportsRead() - Method in interface org.apache.drill.exec.store.StoragePlugin
Indicates if Drill can read the table from this format.
supportsSymlinks() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
supportsWrite() - Method in class org.apache.drill.exec.store.AbstractStoragePlugin
 
supportsWrite() - Method in class org.apache.drill.exec.store.dfs.easy.EasyFormatPlugin
 
supportsWrite() - Method in interface org.apache.drill.exec.store.dfs.FormatPlugin
 
supportsWrite() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
 
supportsWrite() - Method in interface org.apache.drill.exec.store.StoragePlugin
Indicates if Drill can write a table to this format (e.g.
sv2() - Method in class org.apache.drill.exec.cache.VectorSerializer.Reader
 
SVR_CPU_COST - Static variable in class org.apache.drill.exec.planner.cost.DrillCostBase
 
SVRemoverCreator - Class in org.apache.drill.exec.physical.impl.svremover
 
SVRemoverCreator() - Constructor for class org.apache.drill.exec.physical.impl.svremover.SVRemoverCreator
 
swap(int, int) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.SampleSortTemplate
 
swap(int, int) - Method in class org.apache.drill.exec.physical.impl.sort.SortTemplate
 
swap(int, int) - Method in class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
 
swap(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.MSortTemplate
 
swap(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopierTemplate
 
swap(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.MSortTemplate
 
swap(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.PriorityQueueCopierTemplate
 
swap(int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.SingleBatchSorterTemplate
 
swapHashJoin(Prel, Double) - Static method in class org.apache.drill.exec.planner.physical.visitor.SwapHashJoinVisitor
 
SwapHashJoinVisitor - Class in org.apache.drill.exec.planner.physical.visitor
Visit Prel tree.
switchTo(String) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
SwitchTo(int) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplTokenManager
 
SYMMETRIC - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
sync() - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalSyncableOutputStream
 
syncWithRemoteRegistry(long) - Method in class org.apache.drill.exec.expr.fn.FunctionImplementationRegistry
Purpose of this method is to synchronize remote and local function registries if needed and to inform if function registry was changed after given version.
SYS_PLUGIN - Static variable in interface org.apache.drill.exec.store.StoragePluginRegistry
 
SYS_SCHEMA_NAME - Static variable in class org.apache.drill.exec.store.sys.SystemTablePlugin
 
SYS_STORE_PROVIDER_CLASS - Static variable in class org.apache.drill.exec.ExecConstants
 
SYS_STORE_PROVIDER_LOCAL_ENABLE_WRITE - Static variable in class org.apache.drill.exec.ExecConstants
 
SYS_STORE_PROVIDER_LOCAL_PATH - Static variable in class org.apache.drill.exec.ExecConstants
 
SYSTEM - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SYSTEM_OPTIONS_NAME - Static variable in class org.apache.drill.exec.server.Drillbit
 
SYSTEM_TYPE - Static variable in class org.apache.drill.exec.server.options.PersistedOptionValue
This is present for forward compatability with Drill 1.11 and earlier
SYSTEM_USER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
SystemOptionManager - Class in org.apache.drill.exec.server.options
All the system options are externalized into conf file.
SystemOptionManager(LogicalPlanPersistence, PersistentStoreProvider, DrillConfig) - Constructor for class org.apache.drill.exec.server.options.SystemOptionManager
 
SystemOptionManager(LogicalPlanPersistence, PersistentStoreProvider, DrillConfig, CaseInsensitiveMap<OptionDefinition>) - Constructor for class org.apache.drill.exec.server.options.SystemOptionManager
 
SystemOptionManager(DrillConfig) - Constructor for class org.apache.drill.exec.server.options.SystemOptionManager
Test-only, in-memory version of the system option manager.
SystemTable - Enum in org.apache.drill.exec.store.sys
An enumeration of all tables in Drill's system ("sys") schema.
SystemTableBatchCreator - Class in org.apache.drill.exec.store.sys
This class creates batches based on the the type of SystemTable.
SystemTableBatchCreator() - Constructor for class org.apache.drill.exec.store.sys.SystemTableBatchCreator
 
SystemTablePlugin - Class in org.apache.drill.exec.store.sys
A "storage" plugin for system tables.
SystemTablePlugin(SystemTablePluginConfig, DrillbitContext, String) - Constructor for class org.apache.drill.exec.store.sys.SystemTablePlugin
 
SystemTablePluginConfig - Class in org.apache.drill.exec.store.sys
A namesake plugin configuration for system tables.
SystemTableScan - Class in org.apache.drill.exec.store.sys
 
SystemTableScan(SystemTable, StoragePluginRegistry) - Constructor for class org.apache.drill.exec.store.sys.SystemTableScan
 
SystemTableScan(SystemTable, SystemTablePlugin) - Constructor for class org.apache.drill.exec.store.sys.SystemTableScan
 

T

TAB_CATALOGS - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
TAB_COLUMNS - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
TAB_SCHEMATA - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
TAB_TABLES - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
TAB_VIEWS - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
TABLE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TABLE_CATALOG - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
TABLE_CATALOG - Variable in class org.apache.drill.exec.store.ischema.Records.Table
 
TABLE_CATALOG - Variable in class org.apache.drill.exec.store.ischema.Records.View
 
TABLE_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TABLE_NAME - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
TABLE_NAME - Variable in class org.apache.drill.exec.store.ischema.Records.Table
 
TABLE_NAME - Variable in class org.apache.drill.exec.store.ischema.Records.View
 
TABLE_SCHEMA - Variable in class org.apache.drill.exec.store.ischema.Records.Column
 
TABLE_SCHEMA - Variable in class org.apache.drill.exec.store.ischema.Records.Table
 
TABLE_SCHEMA - Variable in class org.apache.drill.exec.store.ischema.Records.View
 
TABLE_TYPE - Variable in class org.apache.drill.exec.store.ischema.Records.Table
 
TableBuilder - Class in org.apache.drill.exec.server.rest.profile
 
TableBuilder(String[], String[]) - Constructor for class org.apache.drill.exec.server.rest.profile.TableBuilder
 
TableBuilder(String[], String[], boolean) - Constructor for class org.apache.drill.exec.server.rest.profile.TableBuilder
 
TableConstructor() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a VALUES leaf query expression.
TableFunctionCall(SqlParserPos) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
TableOverOpt() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Allows an OVER clause following a table expression as an extension to standard SQL syntax.
TableRef() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a table reference in a FROM clause.
TABLES - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
tables(UserSession, DrillbitContext, UserProtos.GetTablesReq, ResponseSender) - Static method in class org.apache.drill.exec.work.metadata.MetadataProvider
 
TABLESAMPLE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
tabSize - Variable in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
take() - Method in interface org.apache.drill.exec.work.batch.BaseRawBatchBuffer.BufferQueue
 
tallyReadBytes(long) - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet
 
tallyWriteBytes(long) - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet
 
TBLS_COL_TABLE_TYPE - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
TCP_PROTOCOL - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
TEMP_DIRECTORIES - Static variable in class org.apache.drill.exec.ExecConstants
 
TEMP_FILESYSTEM - Static variable in class org.apache.drill.exec.ExecConstants
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.aggregate.HashAggregator
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.aggregate.StreamingAggregator
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.common.HashTable
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.flatten.Flattener
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.join.HashJoinProbe
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.join.JoinWorker
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.join.NestedLoopJoin
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.mergereceiver.MergingReceiverGeneratorBase
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionProjector
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.orderedpartitioner.SampleCopier
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.orderedpartitioner.SampleSorter
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.partitionsender.Partitioner
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.project.Projector
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.sort.Sorter
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.TopN.PriorityQueue
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.union.UnionAller
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.xsort.managed.MSorter
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.xsort.managed.PriorityQueueCopier
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.xsort.MSorter
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.xsort.PriorityQueueCopier
 
TEMPLATE_DEFINITION - Static variable in interface org.apache.drill.exec.physical.impl.xsort.SingleBatchSorter
 
TEMPLATE_DEFINITION2 - Static variable in interface org.apache.drill.exec.physical.impl.filter.Filterer
 
TEMPLATE_DEFINITION2 - Static variable in interface org.apache.drill.exec.physical.impl.svremover.Copier
 
TEMPLATE_DEFINITION4 - Static variable in interface org.apache.drill.exec.physical.impl.filter.Filterer
 
TEMPLATE_DEFINITION4 - Static variable in interface org.apache.drill.exec.physical.impl.svremover.Copier
 
TemplateClassDefinition<T> - Class in org.apache.drill.exec.compile
Defines a code generation "template" which consist of: An interface that defines the generated class. A template class which implements the interface to provide "generic" methods that need not be generated. A signature that lists the methods and vector holders used by the template.
TemplateClassDefinition(Class<T>, Class<X>) - Constructor for class org.apache.drill.exec.compile.TemplateClassDefinition
 
TEMPORARY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TEMPORARY - Static variable in class org.apache.drill.exec.store.StorageStrategy
Primary is used for temporary tables.
terminate() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
terminate() - Method in interface org.apache.drill.exec.physical.impl.partitionsender.PartitionOutgoingBatch
 
testFirstPattern() - Method in class org.apache.drill.exec.store.httpd.HttpdParserTest
 
TestMemoryRetention - Class in org.apache.drill.exec
 
TestMemoryRetention() - Constructor for class org.apache.drill.exec.TestMemoryRetention
 
text - Variable in class org.apache.drill.exec.planner.sql.handlers.ExplainHandler.LogicalExplain
 
text - Variable in class org.apache.drill.exec.planner.sql.handlers.ExplainHandler.PhysicalExplain
 
TEXT_ESTIMATED_ROW_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
TEXT_LINE_READER_BATCH_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
TEXT_LINE_READER_BUFFER_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
TextFormatPlugin - Class in org.apache.drill.exec.store.easy.text
 
TextFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig) - Constructor for class org.apache.drill.exec.store.easy.text.TextFormatPlugin
 
TextFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig, TextFormatPlugin.TextFormatConfig) - Constructor for class org.apache.drill.exec.store.easy.text.TextFormatPlugin
 
TextFormatPlugin.TextFormatConfig - Class in org.apache.drill.exec.store.easy.text
 
TextFormatPlugin.TextFormatConfig() - Constructor for class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
 
TextParsingSettings - Class in org.apache.drill.exec.store.easy.text.compliant
 
TextParsingSettings() - Constructor for class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
 
THEN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ThreadsIterator - Class in org.apache.drill.exec.store.sys
 
ThreadsIterator(FragmentContext) - Constructor for class org.apache.drill.exec.store.sys.ThreadsIterator
 
ThreadsIterator.ThreadsInfo - Class in org.apache.drill.exec.store.sys
 
ThreadsIterator.ThreadsInfo() - Constructor for class org.apache.drill.exec.store.sys.ThreadsIterator.ThreadsInfo
 
ThreadsResources - Class in org.apache.drill.exec.server.rest
 
ThreadsResources() - Constructor for class org.apache.drill.exec.server.rest.ThreadsResources
 
threshold() - Method in class org.apache.drill.exec.server.rest.DrillRoot.QueueInfo
 
ThrottledResourceManager - Class in org.apache.drill.exec.work.foreman.rm
Global resource manager that provides basic admission control (AC) via a configured queue: either the Zookeeper-based distributed queue or the in-process embedded Drillbit queue.
ThrottledResourceManager(DrillbitContext, QueryQueue) - Constructor for class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager
 
ThrottledResourceManager.QueuedQueryResourceManager - Class in org.apache.drill.exec.work.foreman.rm
Per-query resource manager.
ThrottledResourceManager.QueuedQueryResourceManager(ThrottledResourceManager, Foreman) - Constructor for class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedQueryResourceManager
 
ThrottledResourceManager.QueuedResourceAllocator - Class in org.apache.drill.exec.work.foreman.rm
 
ThrottledResourceManager.QueuedResourceAllocator(ThrottledResourceManager, QueryContext) - Constructor for class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedResourceAllocator
 
ThrottledResourceManager.QueuedResourceAllocator.BufferedOpFinder - Class in org.apache.drill.exec.work.foreman.rm
Searches a fragment operator tree to find buffered within that fragment.
ThrottledResourceManager.QueuedResourceAllocator.BufferedOpFinder() - Constructor for class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedResourceAllocator.BufferedOpFinder
 
throwChecked(Class<T>) - Method in class org.apache.drill.exec.testing.ExceptionInjection
Throw the checked exception specified by this injection.
throwException(String) - Static method in class org.apache.drill.exec.expr.fn.ExceptionFunction
 
throwSchemaNotFoundException(SchemaPlus, String) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
Utility method to throw UserException with context information
throwSchemaNotFoundException(SchemaPlus, List<String>) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
Utility method to throw UserException with context information
throwUnchecked() - Method in class org.apache.drill.exec.testing.ExceptionInjection
Throw the unchecked exception specified by this injection.
TIES - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TIME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TIME - Static variable in interface org.apache.drill.exec.vector.complex.fn.ExtendedTypeName
 
TimeAccessor - Class in org.apache.drill.exec.vector.accessor
 
TimeAccessor(TimeVector) - Constructor for class org.apache.drill.exec.vector.accessor.TimeAccessor
 
TimeBigIntFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
TimeBigIntFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeBigIntFunctions
 
TimeBigIntFunctions.BigIntTimeAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeBigIntFunctions.BigIntTimeAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeBigIntFunctions.BigIntTimeAddFunction
 
TimeBigIntFunctions.TimeBigIntAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeBigIntFunctions.TimeBigIntAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeBigIntFunctions.TimeBigIntAddFunction
 
TimeBigIntFunctions.TimeBigIntSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeBigIntFunctions.TimeBigIntSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeBigIntFunctions.TimeBigIntSubtractFunction
 
timeDataPageDecode - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
timeDataPageLoads - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
timeDataPagesDecompressed - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
timeDictPageDecode - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
timeDictPageLoads - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
timeDictPagesDecompressed - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
timeDiskScan - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
timeDiskScanWait - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
TimedRunnable<V> - Class in org.apache.drill.exec.store
Class used to allow parallel executions of tasks in a simplified way.
TimedRunnable() - Constructor for class org.apache.drill.exec.store.TimedRunnable
 
TimeEpochBEConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
TimeEpochBEConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.TimeEpochBEConvertFrom
 
TimeEpochBEConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
TimeEpochBEConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.TimeEpochBEConvertTo
 
TimeEpochConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
TimeEpochConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.TimeEpochConvertFrom
 
TimeEpochConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
TimeEpochConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.TimeEpochConvertTo
 
timeFixedColumnRead - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
TimeIntervalDayFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntervalDayFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntervalDayFunctions
 
TimeIntervalDayFunctions.IntervalDayTimeAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntervalDayFunctions.IntervalDayTimeAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntervalDayFunctions.IntervalDayTimeAddFunction
 
TimeIntervalDayFunctions.TimeIntervalDayAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntervalDayFunctions.TimeIntervalDayAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntervalDayFunctions.TimeIntervalDayAddFunction
 
TimeIntervalDayFunctions.TimeIntervalDaySubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntervalDayFunctions.TimeIntervalDaySubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntervalDayFunctions.TimeIntervalDaySubtractFunction
 
TimeIntervalFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntervalFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntervalFunctions
 
TimeIntervalFunctions.IntervalTimeAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntervalFunctions.IntervalTimeAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntervalFunctions.IntervalTimeAddFunction
 
TimeIntervalFunctions.TimeIntervalAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntervalFunctions.TimeIntervalAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntervalFunctions.TimeIntervalAddFunction
 
TimeIntervalFunctions.TimeIntervalSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntervalFunctions.TimeIntervalSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntervalFunctions.TimeIntervalSubtractFunction
 
TimeIntervalYearFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntervalYearFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntervalYearFunctions
 
TimeIntervalYearFunctions.IntervalYearTimeAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntervalYearFunctions.IntervalYearTimeAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntervalYearFunctions.IntervalYearTimeAddFunction
 
TimeIntervalYearFunctions.TimeIntervalYearAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntervalYearFunctions.TimeIntervalYearAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntervalYearFunctions.TimeIntervalYearAddFunction
 
TimeIntervalYearFunctions.TimeIntervalYearSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntervalYearFunctions.TimeIntervalYearSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntervalYearFunctions.TimeIntervalYearSubtractFunction
 
TimeIntFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntFunctions
 
TimeIntFunctions.IntTimeAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntFunctions.IntTimeAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntFunctions.IntTimeAddFunction
 
TimeIntFunctions.TimeIntAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntFunctions.TimeIntAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntFunctions.TimeIntAddFunction
 
TimeIntFunctions.TimeIntSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeIntFunctions.TimeIntSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeIntFunctions.TimeIntSubtractFunction
 
timeNs() - Method in class org.apache.drill.exec.cache.VectorSerializer.Reader
 
timeNs() - Method in class org.apache.drill.exec.cache.VectorSerializer.Writer
 
TIMEOUT_MS - Static variable in class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue
 
timeoutMs() - Method in exception org.apache.drill.exec.work.foreman.rm.QueryQueue.QueueTimeoutException
 
TimePrintMillis - Class in org.apache.drill.exec.vector.accessor.sql
 
TimePrintMillis(long) - Constructor for class org.apache.drill.exec.vector.accessor.sql.TimePrintMillis
 
timeProcess - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
TIMESTAMP - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TIMESTAMP - Static variable in interface org.apache.drill.exec.vector.complex.fn.ExtendedTypeName
 
TIMESTAMP_MICRO_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
TIMESTAMP_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
TimeStampAccessor - Class in org.apache.drill.exec.vector.accessor
 
TimeStampAccessor(TimeStampVector) - Constructor for class org.apache.drill.exec.vector.accessor.TimeStampAccessor
 
TimeStampBigIntFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampBigIntFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampBigIntFunctions
 
TimeStampBigIntFunctions.BigIntTimeStampAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampBigIntFunctions.BigIntTimeStampAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampBigIntFunctions.BigIntTimeStampAddFunction
 
TimeStampBigIntFunctions.TimeStampBigIntAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampBigIntFunctions.TimeStampBigIntAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampBigIntFunctions.TimeStampBigIntAddFunction
 
TimeStampBigIntFunctions.TimeStampBigIntSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampBigIntFunctions.TimeStampBigIntSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampBigIntFunctions.TimeStampBigIntSubtractFunction
 
TimeStampEpochBEConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
TimeStampEpochBEConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.TimeStampEpochBEConvertFrom
 
TimeStampEpochBEConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
TimeStampEpochBEConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.TimeStampEpochBEConvertTo
 
TimeStampEpochConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
TimeStampEpochConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.TimeStampEpochConvertFrom
 
TimeStampEpochConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
TimeStampEpochConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.TimeStampEpochConvertTo
 
timestampFormat - Variable in class org.apache.drill.exec.store.httpd.HttpdLogFormatPlugin.HttpdLogFormatConfig
 
TimeStampIntervalDayFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntervalDayFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalDayFunctions
 
TimeStampIntervalDayFunctions.IntervalDayTimeStampAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntervalDayFunctions.IntervalDayTimeStampAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalDayFunctions.IntervalDayTimeStampAddFunction
 
TimeStampIntervalDayFunctions.TimeStampIntervalDayAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntervalDayFunctions.TimeStampIntervalDayAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalDayFunctions.TimeStampIntervalDayAddFunction
 
TimeStampIntervalDayFunctions.TimeStampIntervalDaySubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntervalDayFunctions.TimeStampIntervalDaySubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalDayFunctions.TimeStampIntervalDaySubtractFunction
 
TimeStampIntervalFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntervalFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalFunctions
 
TimeStampIntervalFunctions.IntervalTimeStampAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntervalFunctions.IntervalTimeStampAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalFunctions.IntervalTimeStampAddFunction
 
TimeStampIntervalFunctions.TimeStampIntervalAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntervalFunctions.TimeStampIntervalAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalFunctions.TimeStampIntervalAddFunction
 
TimeStampIntervalFunctions.TimeStampIntervalSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntervalFunctions.TimeStampIntervalSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalFunctions.TimeStampIntervalSubtractFunction
 
TimeStampIntervalYearFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntervalYearFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalYearFunctions
 
TimeStampIntervalYearFunctions.IntervalYearTimeStampAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntervalYearFunctions.IntervalYearTimeStampAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalYearFunctions.IntervalYearTimeStampAddFunction
 
TimeStampIntervalYearFunctions.TimeStampIntervalYearAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntervalYearFunctions.TimeStampIntervalYearAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalYearFunctions.TimeStampIntervalYearAddFunction
 
TimeStampIntervalYearFunctions.TimeStampIntervalYearSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntervalYearFunctions.TimeStampIntervalYearSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntervalYearFunctions.TimeStampIntervalYearSubtractFunction
 
TimeStampIntFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntFunctions
 
TimeStampIntFunctions.IntTimeStampAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntFunctions.IntTimeStampAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntFunctions.IntTimeStampAddFunction
 
TimeStampIntFunctions.TimeStampIntAddFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntFunctions.TimeStampIntAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntFunctions.TimeStampIntAddFunction
 
TimeStampIntFunctions.TimeStampIntSubtractFunction - Class in org.apache.drill.exec.expr.fn.impl
 
TimeStampIntFunctions.TimeStampIntSubtractFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.TimeStampIntFunctions.TimeStampIntSubtractFunction
 
TimeUnit() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
timeVarColumnRead - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
TIMEZONE_HOUR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TIMEZONE_MINUTE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TINYINT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TinyIntAccessor - Class in org.apache.drill.exec.vector.accessor
 
TinyIntAccessor(TinyIntVector) - Constructor for class org.apache.drill.exec.vector.accessor.TinyIntAccessor
 
TinyIntConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
TinyIntConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.TinyIntConvertFrom
 
TinyIntConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
TinyIntConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.TinyIntConvertTo
 
TMP_SCHEMA - Static variable in class org.apache.drill.exec.util.StoragePluginTestUtils
 
TO - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
toByteArray() - Method in class org.apache.drill.exec.store.parquet.ColumnDataReader.HadoopBytesInput
 
toDrill(AggregateCall, List<String>, DrillImplementor) - Static method in class org.apache.drill.exec.planner.logical.DrillAggregateRel
 
toDrill(DrillParseContext, RelNode, RexNode) - Static method in class org.apache.drill.exec.planner.logical.DrillOptiq
Converts a tree of RexNode operators into a scalar expression in Drill syntax using one input.
toDrill(DrillParseContext, List<RelNode>, RexNode) - Static method in class org.apache.drill.exec.planner.logical.DrillOptiq
Converts a tree of RexNode operators into a scalar expression in Drill syntax using multiple inputs.
toDrill(AggregateCall, List<String>) - Method in class org.apache.drill.exec.planner.logical.DrillWindowRel
 
toDrill(AggregateCall, List<String>) - Method in class org.apache.drill.exec.planner.physical.AggPrelBase
 
toDrill(AggregateCall, List<String>) - Method in class org.apache.drill.exec.planner.physical.WindowPrel
 
token - Variable in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
Token - Class in org.apache.drill.exec.planner.sql.parser.impl
Describes the input token stream.
Token() - Constructor for class org.apache.drill.exec.planner.sql.parser.impl.Token
 
token_source - Variable in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
tokenImage - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
tokenImage - Variable in exception org.apache.drill.exec.planner.sql.parser.impl.ParseException
This is a reference to the "tokenImage" array of the generated parser within which the parse error occurred.
TokenMgrError - Error in org.apache.drill.exec.planner.sql.parser.impl
 
TokenMgrError() - Constructor for error org.apache.drill.exec.planner.sql.parser.impl.TokenMgrError
 
TokenMgrError(String, int) - Constructor for error org.apache.drill.exec.planner.sql.parser.impl.TokenMgrError
 
TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error org.apache.drill.exec.planner.sql.parser.impl.TokenMgrError
 
toMajorType(PrimitiveType.PrimitiveTypeName, int, TypeProtos.DataMode, SchemaElement, OptionManager) - Static method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetToDrillTypeConverter
 
toMajorType(PrimitiveType.PrimitiveTypeName, int, TypeProtos.DataMode, ConvertedType, int, int, OptionManager) - Static method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetToDrillTypeConverter
 
toOptionValue(OptionDefinition, OptionValue.OptionScope) - Method in class org.apache.drill.exec.server.options.PersistedOptionValue
 
TOP_LEVEL_COUNT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TOP_LEVEL_MAX_ALLOC - Static variable in class org.apache.drill.exec.memory.RootAllocatorFactory
 
toPersisted() - Method in class org.apache.drill.exec.server.options.OptionValue
 
TopN - Class in org.apache.drill.exec.physical.config
 
TopN(PhysicalOperator, List<Order.Ordering>, boolean, int) - Constructor for class org.apache.drill.exec.physical.config.TopN
 
TopNBatch - Class in org.apache.drill.exec.physical.impl.TopN
 
TopNBatch(TopN, FragmentContext, RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.TopN.TopNBatch
 
TopNBatch.SimpleSV4RecordBatch - Class in org.apache.drill.exec.physical.impl.TopN
 
TopNBatch.SimpleSV4RecordBatch(VectorContainer, SelectionVector4, FragmentContext) - Constructor for class org.apache.drill.exec.physical.impl.TopN.TopNBatch.SimpleSV4RecordBatch
 
TopNPrel - Class in org.apache.drill.exec.planner.physical
 
TopNPrel(RelOptCluster, RelTraitSet, RelNode, int, RelCollation) - Constructor for class org.apache.drill.exec.planner.physical.TopNPrel
 
TopNSortBatchCreator - Class in org.apache.drill.exec.physical.impl.TopN
 
TopNSortBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.TopN.TopNSortBatchCreator
 
TopProjectVisitor - Class in org.apache.drill.exec.planner.physical.visitor
Adds non-trivial top project to ensure the final output field names are preserved.
TopProjectVisitor(RelDataType) - Constructor for class org.apache.drill.exec.planner.physical.visitor.TopProjectVisitor
 
toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.drill.exec.planner.logical.DrillTable
 
toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.drill.exec.planner.logical.DrillTranslatableTable
 
toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.drill.exec.planner.logical.DrillViewTable
 
toRel(SqlNode) - Method in class org.apache.drill.exec.planner.sql.SqlConverter
 
toRel(LogicalOperator) - Method in class org.apache.drill.exec.planner.torel.ConversionContext
 
toResponse(Throwable) - Method in class org.apache.drill.exec.server.rest.GenericExceptionMapper
 
toRex(LogicalExpression) - Method in class org.apache.drill.exec.planner.torel.ConversionContext
 
toSchemaString() - Method in class org.apache.drill.exec.schema.ListSchema
 
toSchemaString() - Method in class org.apache.drill.exec.schema.ObjectSchema
 
toSchemaString() - Method in interface org.apache.drill.exec.schema.RecordSchema
 
toString() - Method in class org.apache.drill.exec.compile.sig.CodeGeneratorMethod
 
toString() - Method in class org.apache.drill.exec.compile.sig.SignatureHolder
 
toString() - Method in class org.apache.drill.exec.compile.TemplateClassDefinition
 
toString() - Method in class org.apache.drill.exec.expr.BatchReference
 
toString() - Method in class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
Convert holder to a string for debugging use.
toString() - Method in class org.apache.drill.exec.expr.DebugStringBuilder
 
toString() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
 
toString() - Method in class org.apache.drill.exec.expr.fn.impl.CharSequenceWrapper
The regexp_replace function is implemented in a way to avoid the call to toString() not to uselessly create a string object.
toString() - Method in class org.apache.drill.exec.expr.fn.ValueReference
 
toString() - Method in class org.apache.drill.exec.expr.fn.WorkspaceReference
 
toString() - Method in class org.apache.drill.exec.expr.stat.ParquetPredicates.EqualPredicate
 
toString() - Method in class org.apache.drill.exec.expr.stat.TypedFieldExpr
 
toString() - Method in class org.apache.drill.exec.expr.ValueVectorReadExpression
 
toString() - Method in class org.apache.drill.exec.physical.config.Screen
 
toString() - Method in class org.apache.drill.exec.physical.EndpointAffinity
 
toString() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
 
toString() - Method in class org.apache.drill.exec.physical.impl.materialize.QueryWritableBatch
 
toString() - Method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer.ColumnSize
 
toString() - Method in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer
 
toString() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
 
toString() - Method in class org.apache.drill.exec.physical.impl.window.Partition
 
toString() - Method in class org.apache.drill.exec.physical.MinorFragmentEndpoint
 
toString() - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
 
toString() - Method in class org.apache.drill.exec.planner.fragment.Fragment.ExchangeFragmentPair
 
toString() - Method in class org.apache.drill.exec.planner.fragment.Fragment
 
toString() - Method in class org.apache.drill.exec.planner.fragment.ParallelizationInfo.ParallelizationInfoCollector
 
toString() - Method in class org.apache.drill.exec.planner.fragment.ParallelizationInfo
 
toString() - Method in class org.apache.drill.exec.planner.fragment.PlanningSet
 
toString() - Method in class org.apache.drill.exec.planner.fragment.Stats
 
toString() - Method in class org.apache.drill.exec.planner.fragment.Wrapper
 
toString() - Method in class org.apache.drill.exec.planner.logical.DrillTranslatableTable
 
toString() - Method in class org.apache.drill.exec.planner.logical.StoragePlugins
 
toString() - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTrait.DistributionField
 
toString() - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
 
toString() - Method in class org.apache.drill.exec.planner.physical.explain.PrelSequencer.OpId
 
toString() - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor.VisualizationState
 
toString() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
toString() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
toString() - Method in class org.apache.drill.exec.planner.sql.parser.impl.Token
Returns the image.
toString() - Method in class org.apache.drill.exec.record.BatchSchema
 
toString(Charset) - Method in class org.apache.drill.exec.record.DeadBuf
 
toString(int, int, Charset) - Method in class org.apache.drill.exec.record.DeadBuf
 
toString() - Method in class org.apache.drill.exec.record.DeadBuf
 
toString() - Method in class org.apache.drill.exec.record.RawFragmentBatch
 
toString() - Method in class org.apache.drill.exec.record.selection.SelectionVector2
 
toString() - Method in class org.apache.drill.exec.record.SimpleVectorWrapper
 
toString() - Method in class org.apache.drill.exec.record.TypedFieldId
 
toString() - Method in class org.apache.drill.exec.record.VectorContainer
 
toString() - Method in class org.apache.drill.exec.record.VectorInitializer.AllocationHint
 
toString() - Method in class org.apache.drill.exec.record.VectorInitializer
 
toString() - Method in class org.apache.drill.exec.rpc.user.QueryDataBatch
 
toString() - Method in class org.apache.drill.exec.schema.DiffSchema
 
toString() - Method in class org.apache.drill.exec.schema.Field
 
toString() - Method in class org.apache.drill.exec.server.options.OptionValue
 
toString() - Method in class org.apache.drill.exec.server.options.PersistedOptionValue
 
toString() - Method in class org.apache.drill.exec.server.rest.QueryWrapper
 
toString() - Method in class org.apache.drill.exec.server.rest.StatusResources.OptionWrapper
 
toString() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
toString() - Method in class org.apache.drill.exec.store.AbstractRecordReader
 
toString() - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
 
toString() - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
toString() - Method in class org.apache.drill.exec.store.dfs.ReadEntryWithPath
 
toString() - Method in class org.apache.drill.exec.store.easy.json.JSONRecordReader
 
toString() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilter.ConstantExprNode
 
toString() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilter.FieldExprNode
 
toString() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilter.FunctionExprNode
 
toString() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilter
 
toString() - Method in class org.apache.drill.exec.store.mock.MockGroupScanPOP
 
toString() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
toString() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockScanEntry
 
toString() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v1
 
toString() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v2
 
toString() - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetFileMetadata_v3
 
toString() - Method in class org.apache.drill.exec.store.parquet.MetadataVersion
 
toString() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
 
toString() - Method in class org.apache.drill.exec.store.pojo.DynamicPojoRecordReader
 
toString() - Method in class org.apache.drill.exec.store.pojo.PojoRecordReader
 
toString() - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork
 
toString() - Method in class org.apache.drill.exec.testing.InjectionSite
 
toString() - Method in class org.apache.drill.exec.vector.accessor.sql.TimePrintMillis
 
toString() - Method in class org.apache.drill.exec.vector.complex.fn.FieldSelection
 
toString() - Method in class org.apache.drill.exec.work.foreman.FragmentData
 
toString() - Method in class org.apache.drill.exec.work.foreman.rm.EmbeddedQueryQueue.EmbeddedQueueLease
 
toString() - Method in enum org.apache.drill.exec.work.foreman.SqlUnsupportedException.ExceptionType
 
toString() - Method in class org.apache.drill.exec.work.fragment.FragmentExecutor
 
toStringFromUTF16(int, int, DrillBuf) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionHelpers
 
toStringFromUTF8(int, int, DrillBuf) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionHelpers
 
total_threads - Variable in class org.apache.drill.exec.store.sys.ThreadsIterator.ThreadsInfo
 
totalByteSize - Variable in class org.apache.drill.exec.util.filereader.DirectBufInputStream
The length of the data we expect to read.
totalCost() - Method in class org.apache.drill.exec.physical.PhysicalPlan
 
totalDataDecompressedBytes - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
totalDataPageReadBytes - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
totalDictDecompressedBytes - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
totalDictPageReadBytes - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
totalMemory() - Method in class org.apache.drill.exec.server.rest.DrillRoot.QueueInfo
 
totalValuesReadAndReadyToReadInPage() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
totalValuesReadAndReadyToReadInPage() - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
 
Trace - Class in org.apache.drill.exec.physical.config
 
Trace(PhysicalOperator, String) - Constructor for class org.apache.drill.exec.physical.config.Trace
 
TRACE_DUMP_DIRECTORY - Static variable in class org.apache.drill.exec.ExecConstants
 
TRACE_DUMP_FILESYSTEM - Static variable in class org.apache.drill.exec.ExecConstants
 
TraceBatchCreator - Class in org.apache.drill.exec.physical.impl.trace
 
TraceBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.trace.TraceBatchCreator
 
TraceInjector - Class in org.apache.drill.exec.physical.impl
 
TraceInjector() - Constructor for class org.apache.drill.exec.physical.impl.TraceInjector
 
tracer - Static variable in class org.apache.drill.exec.planner.logical.DrillAggregateRule
 
tracer - Static variable in class org.apache.drill.exec.planner.logical.DrillJoinRule
 
tracer - Static variable in class org.apache.drill.exec.planner.logical.DrillUnionAllRule
 
tracer - Static variable in class org.apache.drill.exec.planner.physical.HashAggPrule
 
tracer - Static variable in class org.apache.drill.exec.planner.physical.HashJoinPrule
 
tracer - Static variable in class org.apache.drill.exec.planner.physical.MergeJoinPrule
 
tracer - Static variable in class org.apache.drill.exec.planner.physical.NestedLoopJoinPrule
 
tracer - Static variable in class org.apache.drill.exec.planner.physical.StreamAggPrule
 
tracer - Static variable in class org.apache.drill.exec.planner.physical.UnionAllPrule
 
tracer - Static variable in class org.apache.drill.exec.planner.physical.UnionDistinctPrule
 
TraceRecordBatch - Class in org.apache.drill.exec.physical.impl.trace
 
TraceRecordBatch(Trace, RecordBatch, FragmentContext) - Constructor for class org.apache.drill.exec.physical.impl.trace.TraceRecordBatch
 
traceTag - Variable in class org.apache.drill.exec.physical.config.Trace
 
TrackingInstructionList - Class in org.apache.drill.exec.compile.bytecode
 
TrackingInstructionList(Frame<BasicValue>[], InsnList) - Constructor for class org.apache.drill.exec.compile.bytecode.TrackingInstructionList
 
TRAILING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TRANSACTION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TRANSACTIONS_ACTIVE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TRANSACTIONS_COMMITTED - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TRANSACTIONS_ROLLED_BACK - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
transfer(VectorWrapper<?>) - Method in class org.apache.drill.exec.record.HyperVectorWrapper
Transfer vectors to destination HyperVectorWrapper.
transfer(VectorWrapper<?>) - Method in class org.apache.drill.exec.record.SimpleVectorWrapper
 
transfer(VectorWrapper<?>) - Method in interface org.apache.drill.exec.record.VectorWrapper
 
transfer(BufferAllocator) - Method in class org.apache.drill.exec.record.WritableBatch
 
transferIn(VectorContainer) - Method in class org.apache.drill.exec.record.VectorContainer
Transfer vectors from containerIn to this.
transferOut(VectorContainer) - Method in class org.apache.drill.exec.record.VectorContainer
Transfer vectors from this to containerOut
transform(PlannerType, PlannerPhase, RelNode, RelTraitSet) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
Transform RelNode to a new RelNode, targeting the provided set of traits.
transform(PlannerType, PlannerPhase, RelNode, RelTraitSet, boolean) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
Transform RelNode to a new RelNode, targeting the provided set of traits.
TRANSFORM - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
transformColumns(Collection<SchemaPath>) - Method in class org.apache.drill.exec.store.AbstractRecordReader
 
TRANSFORMS - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TransientStore<V> - Interface in org.apache.drill.exec.coord.store
An abstraction for storing, retrieving and observing transient (key, value) pairs in a distributed environment.
TransientStoreConfig<V> - Class in org.apache.drill.exec.coord.store
 
TransientStoreConfig(String, InstanceSerializer<V>) - Constructor for class org.apache.drill.exec.coord.store.TransientStoreConfig
 
TransientStoreConfigBuilder<T> - Class in org.apache.drill.exec.coord.store
 
TransientStoreConfigBuilder() - Constructor for class org.apache.drill.exec.coord.store.TransientStoreConfigBuilder
 
TransientStoreEvent<V> - Class in org.apache.drill.exec.coord.store
Represents an event created as a result of an operation over a particular (key, value) entry in a store instance.
TransientStoreEvent(TransientStoreEventType, String, V) - Constructor for class org.apache.drill.exec.coord.store.TransientStoreEvent
 
TransientStoreEventType - Enum in org.apache.drill.exec.coord.store
Types of store events.
TransientStoreFactory - Interface in org.apache.drill.exec.coord.store
Factory that is used to obtain a store instance.
TransientStoreListener - Interface in org.apache.drill.exec.coord.store
A listener used for observing transient store events.
transition(String) - Method in class org.apache.drill.exec.compile.FsmCursor
Record a transition in the state machine.
TRANSLATE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TRANSLATION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
traverseClassDeclaration(Java.ClassDeclaration) - Method in class org.apache.drill.exec.expr.fn.MethodGrabbingVisitor.ClassFinder
 
traverseMethodDeclarator(Java.MethodDeclarator) - Method in class org.apache.drill.exec.expr.fn.MethodGrabbingVisitor.ClassFinder
 
traverseSingleStaticImportDeclaration(Java.CompilationUnit.SingleStaticImportDeclaration) - Method in class org.apache.drill.exec.expr.fn.ImportGrabber.ImportFinder
 
traverseSingleTypeImportDeclaration(Java.CompilationUnit.SingleTypeImportDeclaration) - Method in class org.apache.drill.exec.expr.fn.ImportGrabber.ImportFinder
 
traverseStaticImportOnDemandDeclaration(Java.CompilationUnit.StaticImportOnDemandDeclaration) - Method in class org.apache.drill.exec.expr.fn.ImportGrabber.ImportFinder
 
traverseTypeImportOnDemandDeclaration(Java.CompilationUnit.TypeImportOnDemandDeclaration) - Method in class org.apache.drill.exec.expr.fn.ImportGrabber.ImportFinder
 
TREAT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TRIGGER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TRIGGER_CATALOG - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TRIGGER_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TRIGGER_SCHEMA - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TrigoMathFunctions - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ACosBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ACosBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosBigInt
 
TrigoMathFunctions.ACosFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ACosFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosFloat4
 
TrigoMathFunctions.ACosFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ACosFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosFloat8
 
TrigoMathFunctions.ACosInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ACosInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosInt
 
TrigoMathFunctions.ACosSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ACosSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosSmallInt
 
TrigoMathFunctions.ACosTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ACosTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosTinyInt
 
TrigoMathFunctions.ACosUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ACosUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosUInt1
 
TrigoMathFunctions.ACosUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ACosUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosUInt2
 
TrigoMathFunctions.ACosUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ACosUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosUInt4
 
TrigoMathFunctions.ACosUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ACosUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ACosUInt8
 
TrigoMathFunctions.ASinBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ASinBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinBigInt
 
TrigoMathFunctions.ASinFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ASinFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinFloat4
 
TrigoMathFunctions.ASinFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ASinFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinFloat8
 
TrigoMathFunctions.ASinInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ASinInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinInt
 
TrigoMathFunctions.ASinSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ASinSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinSmallInt
 
TrigoMathFunctions.ASinTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ASinTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinTinyInt
 
TrigoMathFunctions.ASinUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ASinUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinUInt1
 
TrigoMathFunctions.ASinUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ASinUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinUInt2
 
TrigoMathFunctions.ASinUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ASinUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinUInt4
 
TrigoMathFunctions.ASinUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ASinUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ASinUInt8
 
TrigoMathFunctions.ATanBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ATanBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanBigInt
 
TrigoMathFunctions.ATanFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ATanFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanFloat4
 
TrigoMathFunctions.ATanFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ATanFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanFloat8
 
TrigoMathFunctions.ATanInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ATanInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanInt
 
TrigoMathFunctions.ATanSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ATanSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanSmallInt
 
TrigoMathFunctions.ATanTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ATanTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanTinyInt
 
TrigoMathFunctions.ATanUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ATanUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanUInt1
 
TrigoMathFunctions.ATanUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ATanUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanUInt2
 
TrigoMathFunctions.ATanUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ATanUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanUInt4
 
TrigoMathFunctions.ATanUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.ATanUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.ATanUInt8
 
TrigoMathFunctions.CosBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CosBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosBigInt
 
TrigoMathFunctions.CosFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CosFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosFloat4
 
TrigoMathFunctions.CosFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CosFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosFloat8
 
TrigoMathFunctions.CoshBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CoshBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshBigInt
 
TrigoMathFunctions.CoshFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CoshFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshFloat4
 
TrigoMathFunctions.CoshFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CoshFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshFloat8
 
TrigoMathFunctions.CoshInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CoshInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshInt
 
TrigoMathFunctions.CoshSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CoshSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshSmallInt
 
TrigoMathFunctions.CoshTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CoshTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshTinyInt
 
TrigoMathFunctions.CoshUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CoshUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshUInt1
 
TrigoMathFunctions.CoshUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CoshUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshUInt2
 
TrigoMathFunctions.CoshUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CoshUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshUInt4
 
TrigoMathFunctions.CoshUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CoshUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CoshUInt8
 
TrigoMathFunctions.CosInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CosInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosInt
 
TrigoMathFunctions.CosSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CosSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosSmallInt
 
TrigoMathFunctions.CosTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CosTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosTinyInt
 
TrigoMathFunctions.CosUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CosUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosUInt1
 
TrigoMathFunctions.CosUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CosUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosUInt2
 
TrigoMathFunctions.CosUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CosUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosUInt4
 
TrigoMathFunctions.CosUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CosUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CosUInt8
 
TrigoMathFunctions.CotBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CotBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotBigInt
 
TrigoMathFunctions.CotFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CotFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotFloat4
 
TrigoMathFunctions.CotFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CotFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotFloat8
 
TrigoMathFunctions.CotInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CotInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotInt
 
TrigoMathFunctions.CotSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CotSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotSmallInt
 
TrigoMathFunctions.CotTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CotTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotTinyInt
 
TrigoMathFunctions.CotUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CotUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotUInt1
 
TrigoMathFunctions.CotUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CotUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotUInt2
 
TrigoMathFunctions.CotUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CotUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotUInt4
 
TrigoMathFunctions.CotUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.CotUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.CotUInt8
 
TrigoMathFunctions.SinBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinBigInt
 
TrigoMathFunctions.SinFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinFloat4
 
TrigoMathFunctions.SinFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinFloat8
 
TrigoMathFunctions.SinhBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinhBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhBigInt
 
TrigoMathFunctions.SinhFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinhFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhFloat4
 
TrigoMathFunctions.SinhFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinhFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhFloat8
 
TrigoMathFunctions.SinhInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinhInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhInt
 
TrigoMathFunctions.SinhSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinhSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhSmallInt
 
TrigoMathFunctions.SinhTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinhTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhTinyInt
 
TrigoMathFunctions.SinhUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinhUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhUInt1
 
TrigoMathFunctions.SinhUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinhUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhUInt2
 
TrigoMathFunctions.SinhUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinhUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhUInt4
 
TrigoMathFunctions.SinhUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinhUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinhUInt8
 
TrigoMathFunctions.SinInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinInt
 
TrigoMathFunctions.SinSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinSmallInt
 
TrigoMathFunctions.SinTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinTinyInt
 
TrigoMathFunctions.SinUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinUInt1
 
TrigoMathFunctions.SinUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinUInt2
 
TrigoMathFunctions.SinUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinUInt4
 
TrigoMathFunctions.SinUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.SinUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.SinUInt8
 
TrigoMathFunctions.TanBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanBigInt
 
TrigoMathFunctions.TanFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanFloat4
 
TrigoMathFunctions.TanFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanFloat8
 
TrigoMathFunctions.TanhBigInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanhBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhBigInt
 
TrigoMathFunctions.TanhFloat4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanhFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhFloat4
 
TrigoMathFunctions.TanhFloat8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanhFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhFloat8
 
TrigoMathFunctions.TanhInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanhInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhInt
 
TrigoMathFunctions.TanhSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanhSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhSmallInt
 
TrigoMathFunctions.TanhTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanhTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhTinyInt
 
TrigoMathFunctions.TanhUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanhUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhUInt1
 
TrigoMathFunctions.TanhUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanhUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhUInt2
 
TrigoMathFunctions.TanhUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanhUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhUInt4
 
TrigoMathFunctions.TanhUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanhUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanhUInt8
 
TrigoMathFunctions.TanInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanInt
 
TrigoMathFunctions.TanSmallInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanSmallInt
 
TrigoMathFunctions.TanTinyInt - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanTinyInt
 
TrigoMathFunctions.TanUInt1 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanUInt1
 
TrigoMathFunctions.TanUInt2 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanUInt2
 
TrigoMathFunctions.TanUInt4 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanUInt4
 
TrigoMathFunctions.TanUInt8 - Class in org.apache.drill.exec.expr.fn.impl
 
TrigoMathFunctions.TanUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.TrigoMathFunctions.TanUInt8
 
TRIM - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
TRIVIAL_TABLE - Static variable in class org.apache.drill.exec.physical.base.ScanStats
 
TRUE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
truncate(Path, long) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
TYPE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
type - Variable in class org.apache.drill.exec.store.ischema.InfoSchemaFilter.ExprNode
 
type - Variable in class org.apache.drill.exec.store.ischema.InfoSchemaTable.Field
 
TYPE - Variable in class org.apache.drill.exec.store.ischema.Records.Schema
 
type - Variable in class org.apache.drill.exec.store.parquet2.DrillParquetReader.ProjectedColumnType
 
TYPE - Static variable in interface org.apache.drill.exec.vector.complex.fn.ExtendedTypeName
 
TYPE_INFERENCE - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
TYPE_INFERENCE_KEY - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
TypeCastRules - Class in org.apache.drill.exec.resolver
 
TypeCastRules() - Constructor for class org.apache.drill.exec.resolver.TypeCastRules
 
TypedFieldExpr - Class in org.apache.drill.exec.expr.stat
 
TypedFieldExpr(SchemaPath, TypeProtos.MajorType) - Constructor for class org.apache.drill.exec.expr.stat.TypedFieldExpr
 
TypedFieldId - Class in org.apache.drill.exec.record
Declares a value vector field, providing metadata about the field.
TypedFieldId(TypeProtos.MajorType, int...) - Constructor for class org.apache.drill.exec.record.TypedFieldId
 
TypedFieldId(TypeProtos.MajorType, IntArrayList, PathSegment) - Constructor for class org.apache.drill.exec.record.TypedFieldId
 
TypedFieldId(TypeProtos.MajorType, boolean, int...) - Constructor for class org.apache.drill.exec.record.TypedFieldId
 
TypedFieldId(TypeProtos.MajorType, TypeProtos.MajorType, TypeProtos.MajorType, boolean, PathSegment, int...) - Constructor for class org.apache.drill.exec.record.TypedFieldId
 
TypedFieldId(TypeProtos.MajorType, TypeProtos.MajorType, TypeProtos.MajorType, boolean, boolean, PathSegment, int...) - Constructor for class org.apache.drill.exec.record.TypedFieldId
 
TypedFieldId.Builder - Class in org.apache.drill.exec.record
 
TypedFieldId.Builder() - Constructor for class org.apache.drill.exec.record.TypedFieldId.Builder
 
TypeHelper - Class in org.apache.drill.exec.expr
 
TypeHelper() - Constructor for class org.apache.drill.exec.expr.TypeHelper
 
TypeInferenceUtils - Class in org.apache.drill.exec.planner.sql
 
TypeName() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
TypeValidators - Class in org.apache.drill.exec.server.options
 
TypeValidators() - Constructor for class org.apache.drill.exec.server.options.TypeValidators
 
TypeValidators.AdminUserGroupsValidator - Class in org.apache.drill.exec.server.options
Unless explicitly changed by the user previously, the admin user groups can only be determined at runtime
TypeValidators.AdminUserGroupsValidator(String) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.AdminUserGroupsValidator
 
TypeValidators.AdminUsersValidator - Class in org.apache.drill.exec.server.options
Unless explicitly changed by the user previously, the admin user can only be determined at runtime
TypeValidators.AdminUsersValidator(String) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.AdminUsersValidator
 
TypeValidators.BooleanValidator - Class in org.apache.drill.exec.server.options
 
TypeValidators.BooleanValidator(String) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.BooleanValidator
 
TypeValidators.DoubleValidator - Class in org.apache.drill.exec.server.options
 
TypeValidators.DoubleValidator(String) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.DoubleValidator
 
TypeValidators.EnumeratedStringValidator - Class in org.apache.drill.exec.server.options
Validator that checks if the given value is included in a list of acceptable values.
TypeValidators.EnumeratedStringValidator(String, String...) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.EnumeratedStringValidator
 
TypeValidators.LongValidator - Class in org.apache.drill.exec.server.options
 
TypeValidators.LongValidator(String) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.LongValidator
 
TypeValidators.MaxRangeDoubleValidator - Class in org.apache.drill.exec.server.options
 
TypeValidators.MaxRangeDoubleValidator(String, double, double, String) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.MaxRangeDoubleValidator
 
TypeValidators.MaxWidthValidator - Class in org.apache.drill.exec.server.options
Max width is a special validator which computes and validates the maxwidth.
TypeValidators.MaxWidthValidator(String) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.MaxWidthValidator
 
TypeValidators.MinRangeDoubleValidator - Class in org.apache.drill.exec.server.options
 
TypeValidators.MinRangeDoubleValidator(String, double, double, String) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.MinRangeDoubleValidator
 
TypeValidators.PositiveLongValidator - Class in org.apache.drill.exec.server.options
 
TypeValidators.PositiveLongValidator(String, long) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.PositiveLongValidator
 
TypeValidators.PowerOfTwoLongValidator - Class in org.apache.drill.exec.server.options
 
TypeValidators.PowerOfTwoLongValidator(String, long) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.PowerOfTwoLongValidator
 
TypeValidators.RangeDoubleValidator - Class in org.apache.drill.exec.server.options
 
TypeValidators.RangeDoubleValidator(String, double, double) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.RangeDoubleValidator
 
TypeValidators.RangeLongValidator - Class in org.apache.drill.exec.server.options
 
TypeValidators.RangeLongValidator(String, long, long) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.RangeLongValidator
 
TypeValidators.StringValidator - Class in org.apache.drill.exec.server.options
 
TypeValidators.StringValidator(String) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.StringValidator
 
TypeValidators.TypeValidator - Class in org.apache.drill.exec.server.options
 
TypeValidators.TypeValidator(String, OptionValue.Kind) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.TypeValidator
 

U

UDF_DIRECTORY_FS - Static variable in class org.apache.drill.exec.ExecConstants
 
UDF_DIRECTORY_LOCAL - Static variable in class org.apache.drill.exec.ExecConstants
 
UDF_DIRECTORY_REGISTRY - Static variable in class org.apache.drill.exec.ExecConstants
 
UDF_DIRECTORY_ROOT - Static variable in class org.apache.drill.exec.ExecConstants
 
UDF_DIRECTORY_STAGING - Static variable in class org.apache.drill.exec.ExecConstants
 
UDF_DIRECTORY_TMP - Static variable in class org.apache.drill.exec.ExecConstants
 
UDF_DISABLE_DYNAMIC - Static variable in class org.apache.drill.exec.ExecConstants
 
UDF_RETRY_ATTEMPTS - Static variable in class org.apache.drill.exec.ExecConstants
Configuration properties connected with dynamic UDFs support
UdfUtilities - Interface in org.apache.drill.exec.ops
Defines the query state and shared resources available to UDFs through injectables.
UDP_HEADER_LENGTH - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
UDP_PROTOCOL - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
UESCAPE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
UInt1Accessor - Class in org.apache.drill.exec.vector.accessor
 
UInt1Accessor(UInt1Vector) - Constructor for class org.apache.drill.exec.vector.accessor.UInt1Accessor
 
UInt2Accessor - Class in org.apache.drill.exec.vector.accessor
 
UInt2Accessor(UInt2Vector) - Constructor for class org.apache.drill.exec.vector.accessor.UInt2Accessor
 
UInt4Accessor - Class in org.apache.drill.exec.vector.accessor
 
UInt4Accessor(UInt4Vector) - Constructor for class org.apache.drill.exec.vector.accessor.UInt4Accessor
 
UInt4BEConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
UInt4BEConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.UInt4BEConvertFrom
 
UInt4BEConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
UInt4BEConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.UInt4BEConvertTo
 
UInt4ConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
UInt4ConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.UInt4ConvertFrom
 
UInt4ConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
UInt4ConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.UInt4ConvertTo
 
UInt8Accessor - Class in org.apache.drill.exec.vector.accessor
 
UInt8Accessor(UInt8Vector) - Constructor for class org.apache.drill.exec.vector.accessor.UInt8Accessor
 
UInt8ConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
UInt8ConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.UInt8ConvertFrom
 
UInt8ConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
UInt8ConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.UInt8ConvertTo
 
unaryOperation(AbstractInsnNode, BasicValue) - Method in class org.apache.drill.exec.compile.bytecode.ReplacingInterpreter
 
UNBOUNDED - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
unbuffer() - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
 
UNCOMMITTED - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
UNDEFINED_LENGTH - Static variable in class org.apache.drill.exec.store.parquet.columnreaders.ParquetColumnMetadata
 
UNDER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
UNDERSCORE_PREFIX - Static variable in class org.apache.drill.exec.store.dfs.DrillFileSystem
 
UNICODE_QUOTED_ESCAPE_CHAR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
UNICODE_QUOTED_IDENTIFIER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
UNICODE_STRING_LITERAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
UNION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
UnionAll - Class in org.apache.drill.exec.physical.config
 
UnionAll(List<PhysicalOperator>) - Constructor for class org.apache.drill.exec.physical.config.UnionAll
 
UNIONALL_DISTRIBUTE - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
UNIONALL_DISTRIBUTE_KEY - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
 
UnionAllBatchCreator - Class in org.apache.drill.exec.physical.impl.union
 
UnionAllBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.union.UnionAllBatchCreator
 
UnionAller - Interface in org.apache.drill.exec.physical.impl.union
 
UnionAllerTemplate - Class in org.apache.drill.exec.physical.impl.union
 
UnionAllerTemplate() - Constructor for class org.apache.drill.exec.physical.impl.union.UnionAllerTemplate
 
UnionAllPrel - Class in org.apache.drill.exec.planner.physical
 
UnionAllPrel(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.drill.exec.planner.physical.UnionAllPrel
 
UnionAllPrule - Class in org.apache.drill.exec.planner.physical
 
UnionAllRecordBatch - Class in org.apache.drill.exec.physical.impl.union
 
UnionAllRecordBatch(UnionAll, List<RecordBatch>, FragmentContext) - Constructor for class org.apache.drill.exec.physical.impl.union.UnionAllRecordBatch
 
UnionDistinctPrel - Class in org.apache.drill.exec.planner.physical
 
UnionDistinctPrel(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.drill.exec.planner.physical.UnionDistinctPrel
 
UnionDistinctPrule - Class in org.apache.drill.exec.planner.physical
 
UnionExchange - Class in org.apache.drill.exec.physical.config
 
UnionExchange(PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.config.UnionExchange
 
UnionExchangePrel - Class in org.apache.drill.exec.planner.physical
 
UnionExchangePrel(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.drill.exec.planner.physical.UnionExchangePrel
 
UnionFunctions - Class in org.apache.drill.exec.expr.fn.impl
The class contains additional functions for union types in addition to those in GUnionFunctions
UnionFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions
 
UnionFunctions.CastUnionList - Class in org.apache.drill.exec.expr.fn.impl
 
UnionFunctions.CastUnionList() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CastUnionList
 
UnionFunctions.CastUnionMap - Class in org.apache.drill.exec.expr.fn.impl
 
UnionFunctions.CastUnionMap() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CastUnionMap
 
UnionFunctions.CastUnionToUnion - Class in org.apache.drill.exec.expr.fn.impl
 
UnionFunctions.CastUnionToUnion() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CastUnionToUnion
 
UnionFunctions.CompareType - Class in org.apache.drill.exec.expr.fn.impl
Returns zero if the inputs have equivalent types.
UnionFunctions.CompareType() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CompareType
 
UnionFunctions.GetType - Class in org.apache.drill.exec.expr.fn.impl
 
UnionFunctions.GetType() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.GetType
 
UnionFunctions.IsNotNull - Class in org.apache.drill.exec.expr.fn.impl
 
UnionFunctions.IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.IsNotNull
 
UnionFunctions.IsNull - Class in org.apache.drill.exec.expr.fn.impl
 
UnionFunctions.IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.IsNull
 
UnionFunctions.UnionIsList - Class in org.apache.drill.exec.expr.fn.impl
 
UnionFunctions.UnionIsList() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.UnionIsList
 
UnionFunctions.UnionIsMap - Class in org.apache.drill.exec.expr.fn.impl
 
UnionFunctions.UnionIsMap() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.UnionIsMap
 
UnionPrel - Class in org.apache.drill.exec.planner.physical
 
UnionPrel(RelOptCluster, RelTraitSet, List<RelNode>, boolean, boolean) - Constructor for class org.apache.drill.exec.planner.physical.UnionPrel
 
unionRecords(int, int, int) - Method in interface org.apache.drill.exec.physical.impl.union.UnionAller
 
unionRecords(int, int, int) - Method in class org.apache.drill.exec.physical.impl.union.UnionAllerTemplate
 
UnionSqlAccessor - Class in org.apache.drill.exec.vector.accessor
 
UnionSqlAccessor(UnionVector) - Constructor for class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
 
unionTypeEnabled - Variable in class org.apache.drill.exec.record.AbstractRecordBatch
 
uniqifyFieldName(RelDataType, RelDataTypeFactory) - Static method in class org.apache.drill.exec.planner.common.DrillRelOptUtil
Returns a rowType having all unique field name.
uniqifyGraph(Prel) - Static method in class org.apache.drill.exec.planner.physical.visitor.RelUniqifier
 
UNIQUE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
uniqueFieldNames(RelDataType) - Method in class org.apache.drill.exec.planner.common.DrillJoinRelBase
 
UNIT_TEST_DFS_DEFAULT_PROP - Static variable in class org.apache.drill.exec.util.StoragePluginTestUtils
 
UNIT_TEST_DFS_ROOT_PROP - Static variable in class org.apache.drill.exec.util.StoragePluginTestUtils
 
UNIT_TEST_DFS_TMP_PROP - Static variable in class org.apache.drill.exec.util.StoragePluginTestUtils
 
UNIT_TEST_PROP_PREFIX - Static variable in class org.apache.drill.exec.util.StoragePluginTestUtils
 
UNKNOWN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
UNKNOWN_TYPE - Static variable in class org.apache.drill.exec.planner.sql.TypeInferenceUtils
 
UNLIMITED_WIDTH_NO_ENDPOINT_AFFINITY - Static variable in class org.apache.drill.exec.planner.fragment.ParallelizationInfo
 
UnlimitedRawBatchBuffer - Class in org.apache.drill.exec.work.batch
 
UnlimitedRawBatchBuffer(FragmentContext, int, int) - Constructor for class org.apache.drill.exec.work.batch.UnlimitedRawBatchBuffer
 
UNNAMED - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
UNNEST - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
unNestEvalBlock() - Method in class org.apache.drill.exec.expr.ClassGenerator
 
UnorderedDeMuxExchange - Class in org.apache.drill.exec.physical.config
UnorderedDeMuxExchange is a version of DeMuxExchange where the incoming batches are not sorted.
UnorderedDeMuxExchange(PhysicalOperator, LogicalExpression) - Constructor for class org.apache.drill.exec.physical.config.UnorderedDeMuxExchange
 
UnorderedDeMuxExchangePrel - Class in org.apache.drill.exec.planner.physical
 
UnorderedDeMuxExchangePrel(RelOptCluster, RelTraitSet, RelNode, List<DrillDistributionTrait.DistributionField>) - Constructor for class org.apache.drill.exec.planner.physical.UnorderedDeMuxExchangePrel
 
UnorderedMuxExchange - Class in org.apache.drill.exec.physical.config
UnorderedMuxExchange is a version of MuxExchange where the incoming batches are not sorted.
UnorderedMuxExchange(PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.config.UnorderedMuxExchange
 
UnorderedMuxExchangePrel - Class in org.apache.drill.exec.planner.physical
 
UnorderedMuxExchangePrel(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.drill.exec.planner.physical.UnorderedMuxExchangePrel
 
UnorderedReceiver - Class in org.apache.drill.exec.physical.config
 
UnorderedReceiver(int, List<MinorFragmentEndpoint>, boolean) - Constructor for class org.apache.drill.exec.physical.config.UnorderedReceiver
 
UnorderedReceiverBatch - Class in org.apache.drill.exec.physical.impl.unorderedreceiver
 
UnorderedReceiverBatch(FragmentContext, RawFragmentBatchProvider, UnorderedReceiver) - Constructor for class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
 
UnorderedReceiverBatch.Metric - Enum in org.apache.drill.exec.physical.impl.unorderedreceiver
 
UnorderedReceiverCreator - Class in org.apache.drill.exec.physical.impl.unorderedreceiver
 
UnorderedReceiverCreator() - Constructor for class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverCreator
 
unparse(Java.CompilationUnit, Writer) - Static method in class org.apache.drill.exec.expr.fn.ModifiedUnparseVisitor
Unparse the given Java.CompilationUnit to the given Writer.
unparse(ObjectWriter) - Method in class org.apache.drill.exec.physical.PhysicalPlan
Converts a physical plan to a string.
unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
unparse(SqlWriter, SqlCall, int, int) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
unparse(SqlWriter, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateFunction
 
unparse(SqlWriter, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateTable
 
unparse(SqlWriter, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.SqlCreateView
 
unparse(SqlWriter, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.SqlDescribeSchema
 
unparse(SqlWriter, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.SqlDescribeTable
 
unparse(SqlWriter, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropFunction
 
unparse(SqlWriter, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropTable
 
unparse(SqlWriter, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.SqlDropView
 
unparse(SqlWriter, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.SqlRefreshMetadata
 
unparse(SqlWriter, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowFiles
 
unparse(SqlWriter, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowSchemas
 
unparse(SqlWriter, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.SqlShowTables
 
unparse(SqlWriter, int, int) - Method in class org.apache.drill.exec.planner.sql.parser.SqlUseSchema
 
unparseSqlNodeList(SqlWriter, int, int, SqlNodeList) - Static method in class org.apache.drill.exec.planner.sql.handlers.SqlHandlerUtil
 
unpause() - Method in class org.apache.drill.exec.testing.PauseInjection
 
unpause() - Method in class org.apache.drill.exec.work.fragment.AbstractFragmentManager
 
unpause() - Method in class org.apache.drill.exec.work.fragment.FragmentExecutor
Resume all the pauses within the current context.
unpause() - Method in interface org.apache.drill.exec.work.fragment.FragmentManager
If the executor is paused (for testing), this method should unpause the executor.
unpauseAll() - Method in class org.apache.drill.exec.testing.ExecutionControls
This method resumes all pauses within the current context (QueryContext or FragmentContext).
unpauseFragment(RpcOutcomeListener<GeneralRPCProtos.Ack>, ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel
 
unquotedCasing() - Method in class org.apache.drill.exec.planner.sql.DrillParserConfig
 
unregister(ClusterCoordinator.RegistrationHandle) - Method in class org.apache.drill.exec.coord.ClusterCoordinator
 
unregister(ClusterCoordinator.RegistrationHandle) - Method in class org.apache.drill.exec.coord.local.LocalClusterCoordinator
 
unregister(ClusterCoordinator.RegistrationHandle) - Method in class org.apache.drill.exec.coord.zk.ZKClusterCoordinator
 
unregister(String) - Method in class org.apache.drill.exec.expr.fn.registry.LocalFunctionRegistry
Removes all function associated with the given jar name.
UNSIGNED_INTEGER_LITERAL - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
UnsignedIntLiteral() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
UnsignedNumericLiteral() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a unsigned numeric literal
UNSUPPORTED_REX_NODE_ERROR - Static variable in class org.apache.drill.exec.planner.logical.DrillOptiq
 
UnsupportedDataTypeException - Exception in org.apache.drill.exec.work.foreman
 
UnsupportedDataTypeException(String, String) - Constructor for exception org.apache.drill.exec.work.foreman.UnsupportedDataTypeException
 
UnsupportedDataTypeException(String) - Constructor for exception org.apache.drill.exec.work.foreman.UnsupportedDataTypeException
 
UnsupportedFunctionException - Exception in org.apache.drill.exec.work.foreman
 
UnsupportedFunctionException(String, String) - Constructor for exception org.apache.drill.exec.work.foreman.UnsupportedFunctionException
 
UnsupportedFunctionException(String) - Constructor for exception org.apache.drill.exec.work.foreman.UnsupportedFunctionException
 
UnsupportedOperatorCollector - Class in org.apache.drill.exec.exception
 
UnsupportedOperatorCollector() - Constructor for class org.apache.drill.exec.exception.UnsupportedOperatorCollector
 
UnsupportedOperatorsVisitor - Class in org.apache.drill.exec.planner.sql.parser
 
UnsupportedRelOperatorException - Exception in org.apache.drill.exec.work.foreman
 
UnsupportedRelOperatorException(String, String) - Constructor for exception org.apache.drill.exec.work.foreman.UnsupportedRelOperatorException
 
UnsupportedRelOperatorException(String) - Constructor for exception org.apache.drill.exec.work.foreman.UnsupportedRelOperatorException
 
UnusedExtension() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Defines a production which can never be accepted by the parser.
unwrap(Class<T>) - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
unwrap(Object, Class<T>) - Static method in class org.apache.drill.exec.planner.sql.handlers.AbstractSqlHandler
 
unwrap() - Method in class org.apache.drill.exec.record.DeadBuf
 
unwrapAsDrillSchemaInstance(SchemaPlus) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
Unwrap given SchemaPlus instance as Drill schema instance (AbstractSchema).
update(ClusterCoordinator.RegistrationHandle, CoordinationProtos.DrillbitEndpoint.State) - Method in class org.apache.drill.exec.coord.ClusterCoordinator
 
update(ClusterCoordinator.RegistrationHandle, CoordinationProtos.DrillbitEndpoint.State) - Method in class org.apache.drill.exec.coord.local.LocalClusterCoordinator
Update drillbit endpoint state.
update(ClusterCoordinator.RegistrationHandle, CoordinationProtos.DrillbitEndpoint.State) - Method in class org.apache.drill.exec.coord.zk.ZKClusterCoordinator
Update drillbit endpoint state.
UPDATE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
update(OperatorStats) - Method in class org.apache.drill.exec.store.parquet.ParquetReaderStats
 
updateAggrValuesInternal(int, int) - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate.BatchHolder
 
updateBatches() - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
 
updateBatches() - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
 
updateCounts(int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
 
updateEstimates(int, int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
Update the data-driven memory use numbers including: The average size of incoming records. The estimated spill and output batch size. The estimated number of average-size records per spill and output batch. The amount of memory set aside to hold the incoming batches before spilling starts.
updateIncoming(RecordBatch) - Method in class org.apache.drill.exec.physical.impl.common.ChainedHashTable
 
updateInputMetrics(int, long) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
 
updateLength(long, boolean) - Method in class org.apache.drill.exec.physical.impl.window.Partition
 
UpdateLineColumn(char) - Method in class org.apache.drill.exec.planner.sql.parser.impl.SimpleCharStream
 
updateMemory(long) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
 
updatePeakBatches(int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
 
updatePosition() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
updatePosition() - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
 
updatePosition() - Method in class org.apache.drill.exec.store.parquet.columnreaders.NullableVarLengthValuesColumn
 
updatePosition() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthValuesColumn
 
updateReadyToReadPosition() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
updateReadyToReadPosition() - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
 
updateReadyToReadPosition() - Method in class org.apache.drill.exec.store.parquet.columnreaders.NullableVarLengthValuesColumn
 
updateReadyToReadPosition() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthValuesColumn
 
updateRegistry(UserBitShared.Registry, DataChangeVersion) - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
 
updateRelativePaths(String) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadata_v3
If directories list and file metadata list contain relative paths, update it to absolute ones
updateRelativePaths(String) - Method in class org.apache.drill.exec.store.parquet.Metadata.ParquetTableMetadataDirs
If directories list contains relative paths, update it to absolute ones
updateSchema(VectorAccessible) - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter
 
updateSchema(VectorAccessible) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
 
updateSchema(VectorAccessible) - Method in interface org.apache.drill.exec.store.RecordWriter
Update the schema in RecordWriter.
updateSchema(VectorAccessible) - Method in class org.apache.drill.exec.store.StringOutputRecordWriter
 
updateSchemaLocation(String, StoragePluginRegistry, File, String...) - Static method in class org.apache.drill.exec.util.StoragePluginTestUtils
Update the workspace locations for a plugin.
updateStats(FragmentWritableBatch) - Method in class org.apache.drill.exec.physical.impl.broadcastsender.BroadcastSenderRootExec
 
updateStats(FragmentWritableBatch) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
 
updateStats(QueryWritableBatch) - Method in class org.apache.drill.exec.physical.impl.ScreenCreator.ScreenRoot
 
updateStats(FragmentWritableBatch) - Method in class org.apache.drill.exec.physical.impl.SingleSenderCreator.SingleSenderRootExec
 
updateSystemOption(String, String, String) - Method in class org.apache.drill.exec.server.rest.StatusResources
 
updateWriteBytes(long) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
 
upkeep(RawFragmentBatch) - Method in class org.apache.drill.exec.work.batch.BaseRawBatchBuffer
Handle miscellaneous tasks after batch retrieval
upkeep(RawFragmentBatch) - Method in class org.apache.drill.exec.work.batch.SpoolingRawBatchBuffer
 
upkeep(RawFragmentBatch) - Method in class org.apache.drill.exec.work.batch.UnlimitedRawBatchBuffer
 
UPPER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
UPSERT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
USAGE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
USE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
USE_DYNAMIC_UDFS - Static variable in class org.apache.drill.exec.ExecConstants
 
USE_DYNAMIC_UDFS_KEY - Static variable in class org.apache.drill.exec.ExecConstants
 
USE_IP_ADDRESS - Static variable in class org.apache.drill.exec.ExecConstants
 
USE_LOGIN_PRINCIPAL - Static variable in class org.apache.drill.exec.ExecConstants
 
useAsyncColReader - Variable in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
useAsyncColReader() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
 
useAsyncPageReader - Variable in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
useBufferedReader - Variable in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
useDefaultCosting() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
 
useEncryptedCounter - Variable in class org.apache.drill.exec.rpc.AbstractRpcMetrics
 
useFadvise - Variable in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
 
USER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
USER_AUTHENTICATION_ENABLED - Static variable in class org.apache.drill.exec.ExecConstants
 
USER_AUTHENTICATOR_IMPL - Static variable in class org.apache.drill.exec.ExecConstants
 
USER_DEFINED_TYPE_CATALOG - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
USER_DEFINED_TYPE_CODE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
USER_DEFINED_TYPE_NAME - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
USER_DEFINED_TYPE_SCHEMA - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
USER_ENCRYPTION_SASL_ENABLED - Static variable in class org.apache.drill.exec.ExecConstants
 
USER_ENCRYPTION_SASL_MAX_WRAPPED_SIZE - Static variable in class org.apache.drill.exec.ExecConstants
 
user_port - Variable in class org.apache.drill.exec.store.sys.DrillbitIterator.DrillbitInstance
 
user_port - Variable in class org.apache.drill.exec.store.sys.MemoryIterator.MemoryInfo
 
user_port - Variable in class org.apache.drill.exec.store.sys.ThreadsIterator.ThreadsInfo
 
USER_RPC_TIMEOUT - Static variable in class org.apache.drill.exec.ExecConstants
 
USER_SERVER_RPC_THREADS - Static variable in class org.apache.drill.exec.ExecConstants
 
USER_SSL_ENABLED - Static variable in class org.apache.drill.exec.ExecConstants
 
UserAuthenticationException - Exception in org.apache.drill.exec.rpc.user.security
 
UserAuthenticationException() - Constructor for exception org.apache.drill.exec.rpc.user.security.UserAuthenticationException
 
UserAuthenticationException(String) - Constructor for exception org.apache.drill.exec.rpc.user.security.UserAuthenticationException
 
UserAuthenticator - Interface in org.apache.drill.exec.rpc.user.security
Interface to provide various username/password based implementations for authentication.
UserAuthenticatorFactory - Class in org.apache.drill.exec.rpc.user.security
Factory class which provides UserAuthenticator implementation based on the BOOT options.
UserAuthenticatorFactory() - Constructor for class org.apache.drill.exec.rpc.user.security.UserAuthenticatorFactory
 
UserAuthenticatorTemplate - Annotation Type in org.apache.drill.exec.rpc.user.security
Annotation for UserAuthenticator implementation to identify the implementation type.
UserClient - Class in org.apache.drill.exec.rpc.user
 
UserClient(String, DrillConfig, Properties, boolean, BufferAllocator, EventLoopGroup, Executor, CoordinationProtos.DrillbitEndpoint) - Constructor for class org.apache.drill.exec.rpc.user.UserClient
 
UserClient.UserToBitConnection - Class in org.apache.drill.exec.rpc.user
 
UserClientConnection - Interface in org.apache.drill.exec.rpc
Interface for getting user session properties and interacting with user connection.
UserNameFilter - Class in org.apache.drill.exec.server.rest
Responsible for filtering out POST requests that do not contain valid User-Name header.
UserNameFilter() - Constructor for class org.apache.drill.exec.server.rest.UserNameFilter
 
UserProtobufLengthDecoder - Class in org.apache.drill.exec.rpc.user
 
UserProtobufLengthDecoder(BufferAllocator, OutOfMemoryHandler) - Constructor for class org.apache.drill.exec.rpc.user.UserProtobufLengthDecoder
 
UserResultsListener - Interface in org.apache.drill.exec.rpc.user
 
UserRpcConfig - Class in org.apache.drill.exec.rpc.user
 
UserRpcMetrics - Class in org.apache.drill.exec.rpc.user
Holds metrics related to bit user rpc layer
UserRpcUtils - Class in org.apache.drill.exec.rpc.user
Utility class for User RPC
UserServer - Class in org.apache.drill.exec.rpc.user
 
UserServer(BootStrapContext, BufferAllocator, EventLoopGroup, UserWorker) - Constructor for class org.apache.drill.exec.rpc.user.UserServer
 
UserServer.BitToUserConnection - Class in org.apache.drill.exec.rpc.user
AbstractRemoteConnection implementation for user connection.
UserSession - Class in org.apache.drill.exec.rpc.user
 
UserSession.Builder - Class in org.apache.drill.exec.rpc.user
 
UserSession.QueryCountIncrementer - Interface in org.apache.drill.exec.rpc.user
Implementations of this interface are allowed to increment queryCount.
UserWorker - Class in org.apache.drill.exec.work.user
 
UserWorker(WorkManager.WorkerBee) - Constructor for class org.apache.drill.exec.work.user.UserWorker
 
UseSchemaHandler - Class in org.apache.drill.exec.planner.sql.handlers
 
UseSchemaHandler(QueryContext) - Constructor for class org.apache.drill.exec.planner.sql.handlers.UseSchemaHandler
 
useSystemTrustStore() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
useSystemTrustStore() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
useSystemTrustStore() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
USING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
UTF16ConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
UTF16ConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.UTF16ConvertFrom
 
UTF16ConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
UTF16ConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.UTF16ConvertTo
 
utf8CharLen(ByteBuf, int) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionUtil
 
utf8CharLen(byte) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionUtil
 
UTF8ConvertFrom - Class in org.apache.drill.exec.expr.fn.impl.conv
 
UTF8ConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.UTF8ConvertFrom
 
UTF8ConvertTo - Class in org.apache.drill.exec.expr.fn.impl.conv
 
UTF8ConvertTo() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.UTF8ConvertTo
 
Utilities - Class in org.apache.drill.exec.util
 
Utilities() - Constructor for class org.apache.drill.exec.util.Utilities
 

V

V1 - Static variable in class org.apache.drill.exec.store.parquet.MetadataVersion.Constants
Version 1: Introduces parquet file metadata caching.
See DRILL-2743
V2 - Static variable in class org.apache.drill.exec.store.parquet.MetadataVersion.Constants
Version 2: Metadata cache file size is reduced.
See DRILL-4053
V3 - Static variable in class org.apache.drill.exec.store.parquet.MetadataVersion.Constants
Version 3: Difference between v3 and v2 : min/max, type_length, precision, scale, repetitionLevel, definitionLevel.
Filter pushdown for Parquet is implemented.
V3_1 - Static variable in class org.apache.drill.exec.store.parquet.MetadataVersion.Constants
Version 3.1: Absolute paths of files and directories are replaced with relative ones.
V3_2 - Static variable in class org.apache.drill.exec.store.parquet.MetadataVersion.Constants
Version 3.2: An array with the components of the field name in Metadata.ColumnTypeMetadata_v3.Key class is replaced by the SchemaPath.
See DRILL-4264
V3_3 - Static variable in class org.apache.drill.exec.store.parquet.MetadataVersion.Constants
Version 3.3: Changed serialization of BINARY and FIXED_LEN_BYTE_ARRAY fields.
See DRILL-4139
val - Variable in class org.apache.drill.exec.store.sys.ExtendedOptionIterator.ExtendedOptionValueWrapper
 
validate(String, String) - Method in class org.apache.drill.exec.client.DumpCat.BatchNumValidator
 
validate(Path) - Method in class org.apache.drill.exec.expr.fn.FunctionImplementationRegistry
Using given local path to jar creates unique class loader for this jar.
validate(String, ScanResult) - Method in class org.apache.drill.exec.expr.fn.registry.LocalFunctionRegistry
Validates all functions, present in jars.
validate() - Method in class org.apache.drill.exec.physical.impl.validate.BatchValidator
 
validate(SqlNode) - Method in class org.apache.drill.exec.planner.sql.SqlConverter
 
validate(OptionValue, OptionMetaData, OptionSet) - Method in class org.apache.drill.exec.rpc.user.InboundImpersonationManager.InboundImpersonationPolicyValidator
 
validate(OptionValue, OptionMetaData, OptionSet) - Method in class org.apache.drill.exec.server.options.OptionValidator
Validates the option value.
validate(OptionValue, OptionMetaData, OptionSet) - Method in class org.apache.drill.exec.server.options.TypeValidators.EnumeratedStringValidator
 
validate(OptionValue, OptionMetaData, OptionSet) - Method in class org.apache.drill.exec.server.options.TypeValidators.MaxRangeDoubleValidator
 
validate(OptionValue, OptionMetaData, OptionSet) - Method in class org.apache.drill.exec.server.options.TypeValidators.MinRangeDoubleValidator
 
validate(OptionValue, OptionMetaData, OptionSet) - Method in class org.apache.drill.exec.server.options.TypeValidators.PositiveLongValidator
 
validate(OptionValue, OptionMetaData, OptionSet) - Method in class org.apache.drill.exec.server.options.TypeValidators.PowerOfTwoLongValidator
 
validate(OptionValue, OptionMetaData, OptionSet) - Method in class org.apache.drill.exec.server.options.TypeValidators.RangeDoubleValidator
 
validate(OptionValue, OptionMetaData, OptionSet) - Method in class org.apache.drill.exec.server.options.TypeValidators.RangeLongValidator
 
validate(OptionValue, OptionMetaData, OptionSet) - Method in class org.apache.drill.exec.server.options.TypeValidators.TypeValidator
 
validate(UserIdentity) - Method in class org.apache.drill.exec.server.rest.auth.DrillRestLoginService
 
validate(OptionValue, OptionMetaData, OptionSet) - Method in class org.apache.drill.exec.testing.ExecutionControls.ControlsOptionValidator
 
validate(RecordBatch) - Static method in class org.apache.drill.exec.vector.VectorValidator
 
validateAndConvert(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
 
validateControlsString(String) - Static method in class org.apache.drill.exec.testing.ExecutionControls
 
validateHandshake(BitControl.BitControlHandshake) - Method in class org.apache.drill.exec.rpc.control.ControlClient
 
validateHandshake(BitData.BitServerHandshake) - Method in class org.apache.drill.exec.rpc.data.DataClient
 
validateHandshake(UserProtos.BitToUserHandshake) - Method in class org.apache.drill.exec.rpc.user.UserClient
 
validateKeyStore() - Method in class org.apache.drill.exec.ssl.SSLConfig
 
validateKeyStore(boolean) - Method in class org.apache.drill.exec.ssl.SSLConfigBuilder
 
validateKeyStore() - Method in class org.apache.drill.exec.ssl.SSLConfigClient
 
validateKeyStore() - Method in class org.apache.drill.exec.ssl.SSLConfigServer
 
validRexOperands(int, boolean) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
 
validRexOperands(int, boolean) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
 
validRexOperands(int, boolean) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
 
value - Variable in class org.apache.drill.exec.physical.impl.common.IndexPointer
 
VALUE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
value - Variable in class org.apache.drill.exec.store.ischema.InfoSchemaFilter.ConstantExprNode
 
value() - Method in class org.apache.drill.exec.store.mock.BooleanGen
 
value() - Method in class org.apache.drill.exec.store.mock.VaryingStringGen
 
value - Variable in class org.apache.drill.exec.work.EndpointListener
 
valueCount - Variable in class org.apache.drill.exec.physical.impl.spill.RecordBatchSizer.ColumnSize
Number of occurrences of the value in the batch.
ValueHolderReplacementVisitor - Class in org.apache.drill.exec.compile.bytecode
 
ValueHolderReplacementVisitor(ClassVisitor, boolean) - Constructor for class org.apache.drill.exec.compile.bytecode.ValueHolderReplacementVisitor
 
valueIndex - Variable in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch.Node
 
valueOf(String) - Static method in enum org.apache.drill.exec.cache.DistributedCache.SerializationMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.cache.SerializationDefinition
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.client.QuerySubmitter.Format
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.client.ServerMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.compile.ClassCompilerSelector.CompilerPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.compile.ClassTransformer.ScalarReplacementOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.coord.store.TransientStoreEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.dotdrill.DotDrillType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.expr.annotations.FunctionTemplate.FunctionCostCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.expr.annotations.FunctionTemplate.FunctionScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.expr.annotations.FunctionTemplate.NullHandling
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.expr.annotations.FunctionTemplate.ReturnType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.expr.BooleanType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.expr.ClassGenerator.BlkCreateMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.expr.ClassGenerator.BlockType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.expr.fn.impl.RegexpUtil.SqlPatternType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor.Trivalent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry.Action
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.base.Exchange.ParallelizationDependency
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.base.ScanStats.GroupScanProperty
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.DataValidationMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.aggregate.HashAggregator.AggIterOutcome
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.aggregate.HashAggregator.AggOutcome
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate.Metric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.aggregate.StreamingAggregator.AggOutcome
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.broadcastsender.BroadcastSenderRootExec.Metric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.common.Comparator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.common.HashTable.PutStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.join.HashJoinBatch.Metric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.join.HashJoinProbe.ProbeState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.join.JoinUtils.JoinCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.join.JoinWorker.JoinOutcome
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch.Metric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec.Metric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.ScreenCreator.ScreenRoot.Metric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.SingleSenderCreator.SingleSenderRootExec.Metric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch.Metric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.window.WindowFunction.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch.Metric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch.Metric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.xsort.managed.MergeSortWrapper.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager.MergeAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.planner.fragment.DistributionAffinity
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.planner.physical.AggPrelBase.OperatorPhase
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.planner.physical.DrillDistributionTrait.DistributionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.planner.physical.JoinPruleBase.PhysicalJoinType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.planner.PlannerPhase
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.planner.PlannerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.planner.sql.parser.SqlCreateView.SqlCreateViewType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.record.AbstractRecordBatch.BatchState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.record.BatchSchema.SelectionVectorMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.record.RecordBatch.IterOutcome
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.server.DrillbitStateManager.DrillbitState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.server.options.OptionValue.AccessibleScopes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.server.options.OptionValue.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.server.options.OptionValue.OptionScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.ssl.SSLConfig.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.store.ColumnExplorer.ImplicitFileColumns
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.store.dfs.MetadataContext.PruneStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.store.easy.json.JsonProcessor.ReadState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor.JsonExceptionProcessingState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.store.ischema.InfoSchemaFilter.ExprNode.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.store.ischema.InfoSchemaFilter.Result
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.store.ischema.InfoSchemaTableType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader.Metric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.store.parquet.ParquetReaderUtility.DateCorruptionStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.store.pcap.schema.PcapTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.store.sys.ExtendedOptionIterator.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.store.sys.OptionIterator.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.store.sys.PersistentStoreMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.store.sys.SystemTable
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.vector.complex.fn.DateOutputFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.vector.complex.fn.ExtendedType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.work.foreman.Foreman.ProfileOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.drill.exec.work.foreman.SqlUnsupportedException.ExceptionType
Returns the enum constant of this type with the specified name.
ValueReference - Class in org.apache.drill.exec.expr.fn
 
ValueReference(TypeProtos.MajorType, String) - Constructor for class org.apache.drill.exec.expr.fn.ValueReference
 
values() - Static method in enum org.apache.drill.exec.cache.DistributedCache.SerializationMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.cache.SerializationDefinition
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.client.QuerySubmitter.Format
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.client.ServerMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.compile.ClassCompilerSelector.CompilerPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.compile.ClassTransformer.ScalarReplacementOption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.drill.exec.coord.store.BaseTransientStore
 
values() - Method in interface org.apache.drill.exec.coord.store.TransientStore
Returns an iterator of values.
values() - Static method in enum org.apache.drill.exec.coord.store.TransientStoreEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.dotdrill.DotDrillType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.expr.annotations.FunctionTemplate.FunctionCostCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.expr.annotations.FunctionTemplate.FunctionScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.expr.annotations.FunctionTemplate.NullHandling
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.expr.annotations.FunctionTemplate.ReturnType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.expr.BooleanType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.expr.ClassGenerator.BlkCreateMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.expr.ClassGenerator.BlockType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.expr.fn.impl.RegexpUtil.SqlPatternType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor.Trivalent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry.Action
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.base.Exchange.ParallelizationDependency
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.base.ScanStats.GroupScanProperty
Returns an array containing the constants of this enum type, in the order they are declared.
Values - Class in org.apache.drill.exec.physical.config
 
Values(JSONOptions) - Constructor for class org.apache.drill.exec.physical.config.Values
 
values() - Static method in enum org.apache.drill.exec.physical.DataValidationMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.aggregate.HashAggregator.AggIterOutcome
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.aggregate.HashAggregator.AggOutcome
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate.Metric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.aggregate.StreamingAggregator.AggOutcome
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.broadcastsender.BroadcastSenderRootExec.Metric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.common.Comparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.common.HashTable.PutStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.join.HashJoinBatch.Metric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.join.HashJoinProbe.ProbeState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.join.JoinUtils.JoinCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.join.JoinWorker.JoinOutcome
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch.Metric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec.Metric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.ScreenCreator.ScreenRoot.Metric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.SingleSenderCreator.SingleSenderRootExec.Metric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch.Metric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.window.WindowFunction.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch.Metric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch.Metric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.xsort.managed.MergeSortWrapper.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager.MergeAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.planner.fragment.DistributionAffinity
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.planner.physical.AggPrelBase.OperatorPhase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.planner.physical.DrillDistributionTrait.DistributionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.planner.physical.JoinPruleBase.PhysicalJoinType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.planner.PlannerPhase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.planner.PlannerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
 
VALUES - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
values() - Static method in enum org.apache.drill.exec.planner.sql.parser.SqlCreateView.SqlCreateViewType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.record.AbstractRecordBatch.BatchState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.record.BatchSchema.SelectionVectorMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.record.RecordBatch.IterOutcome
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.server.DrillbitStateManager.DrillbitState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.server.options.OptionValue.AccessibleScopes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.server.options.OptionValue.Kind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.server.options.OptionValue.OptionScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.ssl.SSLConfig.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.store.ColumnExplorer.ImplicitFileColumns
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.store.dfs.MetadataContext.PruneStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.store.easy.json.JsonProcessor.ReadState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor.JsonExceptionProcessingState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.store.ischema.InfoSchemaFilter.ExprNode.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.store.ischema.InfoSchemaFilter.Result
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.store.ischema.InfoSchemaTableType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader.Metric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.store.parquet.ParquetReaderUtility.DateCorruptionStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.store.pcap.schema.PcapTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.store.sys.ExtendedOptionIterator.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.store.sys.OptionIterator.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.store.sys.PersistentStoreMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.store.sys.SystemTable
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.vector.complex.fn.DateOutputFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.vector.complex.fn.ExtendedType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.work.foreman.Foreman.ProfileOption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.drill.exec.work.foreman.SqlUnsupportedException.ExceptionType
Returns an array containing the constants of this enum type, in the order they are declared.
ValuesBatchCreator - Class in org.apache.drill.exec.physical.impl.values
 
ValuesBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.values.ValuesBatchCreator
 
ValuesPrel - Class in org.apache.drill.exec.planner.physical
Physical Values implementation in Drill.
ValuesPrel(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>, RelTraitSet) - Constructor for class org.apache.drill.exec.planner.physical.ValuesPrel
 
ValuesPrel(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>, RelTraitSet, JSONOptions) - Constructor for class org.apache.drill.exec.planner.physical.ValuesPrel
 
ValuesPrule - Class in org.apache.drill.exec.planner.physical
 
ValueVectorReadExpression - Class in org.apache.drill.exec.expr
Wraps a value vector field to be read, providing metadata about the field.
ValueVectorReadExpression(TypedFieldId) - Constructor for class org.apache.drill.exec.expr.ValueVectorReadExpression
 
ValueVectorReadExpression(TypedFieldId, BatchReference) - Constructor for class org.apache.drill.exec.expr.ValueVectorReadExpression
 
ValueVectorWriteExpression - Class in org.apache.drill.exec.expr
 
ValueVectorWriteExpression(TypedFieldId, LogicalExpression) - Constructor for class org.apache.drill.exec.expr.ValueVectorWriteExpression
 
ValueVectorWriteExpression(TypedFieldId, LogicalExpression, boolean) - Constructor for class org.apache.drill.exec.expr.ValueVectorWriteExpression
 
Var16CharAccessor - Class in org.apache.drill.exec.vector.accessor
 
Var16CharAccessor(Var16CharVector) - Constructor for class org.apache.drill.exec.vector.accessor.Var16CharAccessor
 
VAR_POP - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
VAR_SAMP - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
VARBINARY - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
VarBinaryAccessor - Class in org.apache.drill.exec.vector.accessor
 
VarBinaryAccessor(VarBinaryVector) - Constructor for class org.apache.drill.exec.vector.accessor.VarBinaryAccessor
 
VARCHAR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
VARCHAR - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaTable
 
VarCharAccessor - Class in org.apache.drill.exec.vector.accessor
 
VarCharAccessor(VarCharVector) - Constructor for class org.apache.drill.exec.vector.accessor.VarCharAccessor
 
varCharVector - Variable in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.VarCharColumn
 
VarHelpers - Class in org.apache.drill.exec.expr.fn.impl
 
VarHelpers() - Constructor for class org.apache.drill.exec.expr.fn.impl.VarHelpers
 
variableWidth(String, int) - Method in class org.apache.drill.exec.record.VectorInitializer
 
variableWidthArray(String, float, float) - Method in class org.apache.drill.exec.record.VectorInitializer
 
VariancePopFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions
 
VariancePopFunctions.BigIntVariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.BigIntVariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.BigIntVariancePop
 
VariancePopFunctions.Float4VariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.Float4VariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.Float4VariancePop
 
VariancePopFunctions.Float8VariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.Float8VariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.Float8VariancePop
 
VariancePopFunctions.IntVariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.IntVariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.IntVariancePop
 
VariancePopFunctions.NullableBigIntVariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.NullableBigIntVariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableBigIntVariancePop
 
VariancePopFunctions.NullableFloat4VariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.NullableFloat4VariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableFloat4VariancePop
 
VariancePopFunctions.NullableFloat8VariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.NullableFloat8VariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableFloat8VariancePop
 
VariancePopFunctions.NullableIntVariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.NullableIntVariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableIntVariancePop
 
VariancePopFunctions.NullableSmallIntVariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.NullableSmallIntVariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableSmallIntVariancePop
 
VariancePopFunctions.NullableTinyIntVariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.NullableTinyIntVariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableTinyIntVariancePop
 
VariancePopFunctions.NullableUInt1VariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.NullableUInt1VariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt1VariancePop
 
VariancePopFunctions.NullableUInt2VariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.NullableUInt2VariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt2VariancePop
 
VariancePopFunctions.NullableUInt4VariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.NullableUInt4VariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt4VariancePop
 
VariancePopFunctions.NullableUInt8VariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.NullableUInt8VariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.NullableUInt8VariancePop
 
VariancePopFunctions.SmallIntVariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.SmallIntVariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.SmallIntVariancePop
 
VariancePopFunctions.TinyIntVariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.TinyIntVariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.TinyIntVariancePop
 
VariancePopFunctions.UInt1VariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.UInt1VariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt1VariancePop
 
VariancePopFunctions.UInt2VariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.UInt2VariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt2VariancePop
 
VariancePopFunctions.UInt4VariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.UInt4VariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt4VariancePop
 
VariancePopFunctions.UInt8VariancePop - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VariancePopFunctions.UInt8VariancePop() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VariancePopFunctions.UInt8VariancePop
 
VarianceSampleFunctions - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions
 
VarianceSampleFunctions.BigIntVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.BigIntVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.BigIntVarianceSample
 
VarianceSampleFunctions.Float4VarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.Float4VarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.Float4VarianceSample
 
VarianceSampleFunctions.Float8VarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.Float8VarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.Float8VarianceSample
 
VarianceSampleFunctions.IntVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.IntVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.IntVarianceSample
 
VarianceSampleFunctions.NullableBigIntVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.NullableBigIntVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableBigIntVarianceSample
 
VarianceSampleFunctions.NullableFloat4VarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.NullableFloat4VarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableFloat4VarianceSample
 
VarianceSampleFunctions.NullableFloat8VarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.NullableFloat8VarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableFloat8VarianceSample
 
VarianceSampleFunctions.NullableIntVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.NullableIntVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableIntVarianceSample
 
VarianceSampleFunctions.NullableSmallIntVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.NullableSmallIntVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableSmallIntVarianceSample
 
VarianceSampleFunctions.NullableTinyIntVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.NullableTinyIntVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableTinyIntVarianceSample
 
VarianceSampleFunctions.NullableUInt1VarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.NullableUInt1VarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt1VarianceSample
 
VarianceSampleFunctions.NullableUInt2VarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.NullableUInt2VarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt2VarianceSample
 
VarianceSampleFunctions.NullableUInt4VarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.NullableUInt4VarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt4VarianceSample
 
VarianceSampleFunctions.NullableUInt8VarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.NullableUInt8VarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.NullableUInt8VarianceSample
 
VarianceSampleFunctions.SmallIntVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.SmallIntVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.SmallIntVarianceSample
 
VarianceSampleFunctions.TinyIntVarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.TinyIntVarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.TinyIntVarianceSample
 
VarianceSampleFunctions.UInt1VarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.UInt1VarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt1VarianceSample
 
VarianceSampleFunctions.UInt2VarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.UInt2VarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt2VarianceSample
 
VarianceSampleFunctions.UInt4VarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.UInt4VarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt4VarianceSample
 
VarianceSampleFunctions.UInt8VarianceSample - Class in org.apache.drill.exec.expr.fn.impl.gaggr
 
VarianceSampleFunctions.UInt8VarianceSample() - Constructor for class org.apache.drill.exec.expr.fn.impl.gaggr.VarianceSampleFunctions.UInt8VarianceSample
 
VarLenBinaryReader - Class in org.apache.drill.exec.store.parquet.columnreaders
 
VarLenBinaryReader(ParquetRecordReader, List<VarLengthColumn<? extends ValueVector>>) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.VarLenBinaryReader
 
VarLengthColumn<V extends ValueVector> - Class in org.apache.drill.exec.store.parquet.columnreaders
 
VarLengthColumnReaders - Class in org.apache.drill.exec.store.parquet.columnreaders
 
VarLengthColumnReaders() - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders
 
VarLengthColumnReaders.Decimal28Column - Class in org.apache.drill.exec.store.parquet.columnreaders
 
VarLengthColumnReaders.Decimal38Column - Class in org.apache.drill.exec.store.parquet.columnreaders
 
VarLengthColumnReaders.NullableDecimal28Column - Class in org.apache.drill.exec.store.parquet.columnreaders
 
VarLengthColumnReaders.NullableDecimal38Column - Class in org.apache.drill.exec.store.parquet.columnreaders
 
VarLengthColumnReaders.NullableVarBinaryColumn - Class in org.apache.drill.exec.store.parquet.columnreaders
 
VarLengthColumnReaders.NullableVarCharColumn - Class in org.apache.drill.exec.store.parquet.columnreaders
 
VarLengthColumnReaders.VarBinaryColumn - Class in org.apache.drill.exec.store.parquet.columnreaders
 
VarLengthColumnReaders.VarCharColumn - Class in org.apache.drill.exec.store.parquet.columnreaders
 
varLengthReader() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
 
VarLengthValuesColumn<V extends ValueVector> - Class in org.apache.drill.exec.store.parquet.columnreaders
 
varTypesToInt(int, int, DrillBuf) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionHelpers
 
varTypesToLong(int, int, DrillBuf) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionHelpers
 
VARYING - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
VaryingStringGen - Class in org.apache.drill.exec.store.mock
 
VaryingStringGen() - Constructor for class org.apache.drill.exec.store.mock.VaryingStringGen
 
vector - Variable in class org.apache.drill.exec.store.pojo.AbstractPojoWriter
 
VectorAccessible - Interface in org.apache.drill.exec.record
 
VectorAccessibleComplexWriter - Class in org.apache.drill.exec.record
 
VectorAccessibleComplexWriter(VectorContainer) - Constructor for class org.apache.drill.exec.record.VectorAccessibleComplexWriter
 
VectorAccessibleSerializable - Class in org.apache.drill.exec.cache
A wrapper around a VectorAccessible.
VectorAccessibleSerializable(BufferAllocator) - Constructor for class org.apache.drill.exec.cache.VectorAccessibleSerializable
 
VectorAccessibleSerializable(WritableBatch, BufferAllocator) - Constructor for class org.apache.drill.exec.cache.VectorAccessibleSerializable
 
VectorAccessibleSerializable(WritableBatch, SelectionVector2, BufferAllocator) - Constructor for class org.apache.drill.exec.cache.VectorAccessibleSerializable
Creates a wrapper around batch and sv2 for writing to a stream.
VectorAccessibleUtilities - Class in org.apache.drill.exec.record
VectorAccessible is an interface.
VectorContainer - Class in org.apache.drill.exec.record
 
VectorContainer() - Constructor for class org.apache.drill.exec.record.VectorContainer
 
VectorContainer(OperatorContext) - Constructor for class org.apache.drill.exec.record.VectorContainer
 
VectorContainer(BufferAllocator) - Constructor for class org.apache.drill.exec.record.VectorContainer
 
VectorContainer(BufferAllocator, BatchSchema) - Constructor for class org.apache.drill.exec.record.VectorContainer
Create a new vector container given a pre-defined schema.
VectorContainerWriter - Class in org.apache.drill.exec.vector.complex.impl
 
VectorContainerWriter(OutputMutator, boolean) - Constructor for class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
 
VectorContainerWriter(OutputMutator) - Constructor for class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
 
vectorData - Variable in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
 
VectorInitializer - Class in org.apache.drill.exec.record
Prototype mechanism to allocate vectors based on expected data sizes.
VectorInitializer() - Constructor for class org.apache.drill.exec.record.VectorInitializer
 
VectorInitializer.AllocationHint - Class in org.apache.drill.exec.record
 
VectorRecordMaterializer - Class in org.apache.drill.exec.physical.impl.materialize
 
VectorRecordMaterializer(FragmentContext, OperatorContext, RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.materialize.VectorRecordMaterializer
 
VectorSerializer - Class in org.apache.drill.exec.cache
Serializes vector containers to an output stream or from an input stream.
VectorSerializer() - Constructor for class org.apache.drill.exec.cache.VectorSerializer
 
VectorSerializer.Reader - Class in org.apache.drill.exec.cache
Read one or more vector containers from an input stream.
VectorSerializer.Reader(BufferAllocator, InputStream) - Constructor for class org.apache.drill.exec.cache.VectorSerializer.Reader
 
VectorSerializer.Writer - Class in org.apache.drill.exec.cache
Writes multiple VectorAccessible or VectorContainer objects to an output stream.
VectorSerializer.Writer(BufferAllocator, OutputStream) - Constructor for class org.apache.drill.exec.cache.VectorSerializer.Writer
 
VectorUtil - Class in org.apache.drill.exec.util
 
VectorUtil() - Constructor for class org.apache.drill.exec.util.VectorUtil
 
VectorValidator - Class in org.apache.drill.exec.vector
 
VectorValidator() - Constructor for class org.apache.drill.exec.vector.VectorValidator
 
VectorWrapper<T extends ValueVector> - Interface in org.apache.drill.exec.record
 
VER_IHL_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
 
verbose() - Method in class org.apache.drill.exec.server.rest.profile.SimpleDurationFormat
Return a verbose representation of elapsed time down to millisecond granularity
verify(ClassReader, boolean, PrintWriter) - Static method in class org.apache.drill.exec.compile.DrillCheckClassAdapter
See CheckClassAdapter.verify(ClassReader, boolean, PrintWriter).
VERSION - Static variable in class org.apache.drill.common.util.DrillVersionInfo
The version extracted from Maven POM file at build time.
VERSION - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
version - Variable in class org.apache.drill.exec.store.sys.DrillbitIterator.DrillbitInstance
 
version - Variable in class org.apache.drill.exec.store.sys.VersionIterator.VersionInfo
 
VersionIterator - Class in org.apache.drill.exec.store.sys
 
VersionIterator() - Constructor for class org.apache.drill.exec.store.sys.VersionIterator
 
VersionIterator.VersionInfo - Class in org.apache.drill.exec.store.sys
 
VersionIterator.VersionInfo() - Constructor for class org.apache.drill.exec.store.sys.VersionIterator.VersionInfo
 
VersionMismatchException - Exception in org.apache.drill.exec.exception
 
VersionMismatchException(String, int, Throwable) - Constructor for exception org.apache.drill.exec.exception.VersionMismatchException
 
VersionMismatchException(String, int) - Constructor for exception org.apache.drill.exec.exception.VersionMismatchException
 
View - Class in org.apache.drill.exec.dotdrill
 
View(String, String, RelDataType, List<String>) - Constructor for class org.apache.drill.exec.dotdrill.View
 
View(String, String, List<View.FieldType>, List<String>) - Constructor for class org.apache.drill.exec.dotdrill.View
 
VIEW - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
View.FieldType - Class in org.apache.drill.exec.dotdrill
 
View.FieldType(String, SqlTypeName, Integer, Integer, TimeUnit, TimeUnit, Integer, Boolean) - Constructor for class org.apache.drill.exec.dotdrill.View.FieldType
 
View.FieldType(String, RelDataType) - Constructor for class org.apache.drill.exec.dotdrill.View.FieldType
 
VIEW_DEFINITION - Variable in class org.apache.drill.exec.store.ischema.Records.View
 
ViewableWithPermissions - Class in org.apache.drill.exec.server.rest
Overrides Viewable to create a model which contains additional info of what control to display in menubar.
ViewExpansionContext - Class in org.apache.drill.exec.ops
Contains context information about view expansion(s) in a query.
ViewExpansionContext(QueryContext) - Constructor for class org.apache.drill.exec.ops.ViewExpansionContext
 
ViewExpansionContext(DrillConfig, SchemaConfig.SchemaConfigInfoProvider) - Constructor for class org.apache.drill.exec.ops.ViewExpansionContext
 
ViewExpansionContext.ViewExpansionToken - Class in org.apache.drill.exec.ops
Represents token issued to a view owner for expanding the view.
ViewHandler - Class in org.apache.drill.exec.planner.sql.handlers
 
ViewHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ViewHandler
 
ViewHandler.CreateView - Class in org.apache.drill.exec.planner.sql.handlers
Handler for Create View DDL command
ViewHandler.CreateView(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ViewHandler.CreateView
 
ViewHandler.DropView - Class in org.apache.drill.exec.planner.sql.handlers
Handler for Drop View [If Exists] DDL command.
ViewHandler.DropView(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ViewHandler.DropView
 
VIEWS_COL_VIEW_DEFINITION - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaConstants
 
visit(int, int, String, String, String, String[]) - Method in class org.apache.drill.exec.compile.bytecode.ValueHolderReplacementVisitor
 
visit(int, int, String, String, String, String[]) - Method in class org.apache.drill.exec.compile.CheckClassVisitorFsm
 
visit(int, int, String, String, String, String[]) - Method in class org.apache.drill.exec.compile.InnerClassAccessStripper
 
visit(Fragment, V) - Method in interface org.apache.drill.exec.planner.fragment.FragmentVisitor
 
visit(LogicalAggregate) - Method in class org.apache.drill.exec.planner.logical.PreProcessLogicalRel
 
visit(LogicalProject) - Method in class org.apache.drill.exec.planner.logical.PreProcessLogicalRel
 
visit(LogicalFilter) - Method in class org.apache.drill.exec.planner.logical.PreProcessLogicalRel
 
visit(LogicalJoin) - Method in class org.apache.drill.exec.planner.logical.PreProcessLogicalRel
 
visit(LogicalUnion) - Method in class org.apache.drill.exec.planner.logical.PreProcessLogicalRel
 
visit(TableScan) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler.MetaDataProviderModifier
 
visit(TableFunctionScan) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler.MetaDataProviderModifier
 
visit(LogicalValues) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler.MetaDataProviderModifier
 
visit(LogicalSort) - Method in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor
 
visit(RelNode) - Method in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor
 
visit(LogicalAggregate) - Method in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor
 
visit(LogicalIntersect) - Method in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor
 
visit(LogicalJoin) - Method in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor
 
visit(LogicalMinus) - Method in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor
 
visit(LogicalUnion) - Method in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor
 
visit(SqlIdentifier) - Method in class org.apache.drill.exec.planner.sql.parser.CompoundIdentifierConverter
 
visit(SqlCall) - Method in class org.apache.drill.exec.planner.sql.parser.CompoundIdentifierConverter
 
visit(SqlDataTypeSpec) - Method in class org.apache.drill.exec.planner.sql.parser.UnsupportedOperatorsVisitor
 
visit(SqlCall) - Method in class org.apache.drill.exec.planner.sql.parser.UnsupportedOperatorsVisitor
 
visitAbstractPlan(PhysicalPlan) - Method in class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager.DefaultResourceAllocator
 
visitAbstractPlan(PhysicalPlan) - Method in interface org.apache.drill.exec.work.foreman.rm.QueryResourceAllocator
Make any needed adjustments to the query plan before parallelization.
visitAbstractPlan(PhysicalPlan) - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedResourceAllocator
 
visitAnnotation(String, boolean) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitAnnotation(String, boolean) - Method in class org.apache.drill.exec.compile.CheckClassVisitorFsm
 
visitAnnotation(String, boolean) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitAnnotationDefault() - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitAnnotationDefault() - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitAttribute(Attribute) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitAttribute(Attribute) - Method in class org.apache.drill.exec.compile.CheckClassVisitorFsm
 
visitAttribute(Attribute) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitBooleanConstant(ValueExpressions.BooleanExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitBooleanConstant(ValueExpressions.BooleanExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitBooleanConstant(ValueExpressions.BooleanExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitBooleanConstant(ValueExpressions.BooleanExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitBooleanOperator(BooleanOperator, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitBooleanOperator(BooleanOperator, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitBooleanOperator(BooleanOperator, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitBooleanOperator(BooleanOperator, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitBooleanOperator(BooleanOperator, Void) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilterBuilder
 
visitBooleanOperator(BooleanOperator, Set<LogicalExpression>) - Method in class org.apache.drill.exec.store.parquet.ParquetFilterBuilder
 
visitBroadcastSender(BroadcastSender, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitBroadcastSender(BroadcastSender, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitCall(RexCall) - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
 
visitCall(RexCall) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteAsBinaryOperators
 
visitCall(RexCall) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteCombineBinaryOperators
 
visitCall(RexCall) - Method in class org.apache.drill.exec.planner.physical.visitor.RexVisitorComplexExprSplitter
 
visitCastExpression(CastExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitCastExpression(CastExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitCastExpression(CastExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitCastExpression(CastExpression, Void) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilterBuilder
 
visitCatalog() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Catalogs
 
visitCatalog() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
Visit the catalog.
visitChild(DrillRel, int, RelNode) - Method in class org.apache.drill.exec.planner.logical.DrillImplementor
 
visitChild(RelNode, int, RelNode) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler.MetaDataProviderModifier
 
visitChildren(PhysicalOperator, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitCode() - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitCode() - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitConvertExpression(ConvertExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitConvertExpression(ConvertExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitConvertExpression(ConvertExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitConvertExpression(ConvertExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
 
visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteAsBinaryOperators
 
visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteCombineBinaryOperators
 
visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.drill.exec.planner.physical.visitor.RexVisitorComplexExprSplitter
 
visitDateConstant(ValueExpressions.DateExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitDateConstant(ValueExpressions.DateExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitDateConstant(ValueExpressions.DateExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitDateConstant(ValueExpressions.DateExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitDateConstant(ValueExpressions.DateExpression, Void) - Method in class org.apache.drill.exec.expr.stat.RangeExprEvaluator
 
visitDateConstant(ValueExpressions.DateExpression, Set<LogicalExpression>) - Method in class org.apache.drill.exec.store.parquet.ParquetFilterBuilder
 
visitDecimal18Constant(ValueExpressions.Decimal18Expression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitDecimal18Constant(ValueExpressions.Decimal18Expression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitDecimal18Constant(ValueExpressions.Decimal18Expression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitDecimal18Constant(ValueExpressions.Decimal18Expression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitDecimal28Constant(ValueExpressions.Decimal28Expression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitDecimal28Constant(ValueExpressions.Decimal28Expression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitDecimal28Constant(ValueExpressions.Decimal28Expression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitDecimal28Constant(ValueExpressions.Decimal28Expression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitDecimal38Constant(ValueExpressions.Decimal38Expression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitDecimal38Constant(ValueExpressions.Decimal38Expression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitDecimal38Constant(ValueExpressions.Decimal38Expression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitDecimal38Constant(ValueExpressions.Decimal38Expression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitDecimal9Constant(ValueExpressions.Decimal9Expression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitDecimal9Constant(ValueExpressions.Decimal9Expression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitDecimal9Constant(ValueExpressions.Decimal9Expression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitDecimal9Constant(ValueExpressions.Decimal9Expression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitDoubleConstant(ValueExpressions.DoubleExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitDoubleConstant(ValueExpressions.DoubleExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitDoubleConstant(ValueExpressions.DoubleExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitDoubleConstant(ValueExpressions.DoubleExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitDoubleConstant(ValueExpressions.DoubleExpression, Void) - Method in class org.apache.drill.exec.expr.stat.RangeExprEvaluator
 
visitDoubleConstant(ValueExpressions.DoubleExpression, Set<LogicalExpression>) - Method in class org.apache.drill.exec.store.parquet.ParquetFilterBuilder
 
visitDynamicParam(RexDynamicParam) - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
 
visitDynamicParam(RexDynamicParam) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteAsBinaryOperators
 
visitDynamicParam(RexDynamicParam) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteCombineBinaryOperators
 
visitDynamicParam(RexDynamicParam) - Method in class org.apache.drill.exec.planner.physical.visitor.RexVisitorComplexExprSplitter
 
visitEnd() - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitEnd() - Method in class org.apache.drill.exec.compile.bytecode.InstructionModifier
 
visitEnd() - Method in class org.apache.drill.exec.compile.bytecode.ScalarReplacementNode
 
visitEnd() - Method in class org.apache.drill.exec.compile.CheckClassVisitorFsm
 
visitEnd() - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitExchange(Exchange, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitExchange(Exchange, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitExchange(Exchange, Wrapper) - Method in class org.apache.drill.exec.planner.AbstractOpWrapperVisitor
 
visitExchange(Exchange, Materializer.IndexedFragmentNode) - Method in class org.apache.drill.exec.planner.fragment.contrib.ExchangeRemoverMaterializer
 
visitExchange(Exchange, Fragment) - Method in class org.apache.drill.exec.planner.fragment.MakeFragmentsVisitor
 
visitExchange(Exchange, Materializer.IndexedFragmentNode) - Method in class org.apache.drill.exec.planner.fragment.Materializer
 
visitExchange(ExchangePrel, PrelSequencer.Frag) - Method in class org.apache.drill.exec.planner.physical.explain.PrelSequencer
 
visitExchange(ExchangePrel, EXTRA) - Method in class org.apache.drill.exec.planner.physical.visitor.BasePrelVisitor
 
visitExchange(ExchangePrel, ExcessiveExchangeIdentifier.MajorFragmentStat) - Method in class org.apache.drill.exec.planner.physical.visitor.ExcessiveExchangeIdentifier
 
visitExchange(ExchangePrel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.InsertLocalExchangeVisitor
 
visitExchange(ExchangePrel, EXTRA) - Method in interface org.apache.drill.exec.planner.physical.visitor.PrelVisitor
 
visitExchange(ExchangePrel, PrelVisualizerVisitor.VisualizationState) - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor
 
visitField(int, String, String, String, Object) - Method in class org.apache.drill.exec.compile.CheckClassVisitorFsm
 
visitField(String, String, RelDataTypeField) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Columns
 
visitField(String, String, RelDataTypeField) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
Visit the given field.
visitFieldAccess(RexFieldAccess) - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
 
visitFieldAccess(RexFieldAccess) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteAsBinaryOperators
 
visitFieldAccess(RexFieldAccess) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteCombineBinaryOperators
 
visitFieldAccess(RexFieldAccess) - Method in class org.apache.drill.exec.planner.physical.visitor.RexVisitorComplexExprSplitter
 
visitFieldInsn(int, String, String, String) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitFieldInsn(int, String, String, String) - Method in class org.apache.drill.exec.compile.bytecode.InstructionModifier
 
visitFieldInsn(int, String, String, String) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitFilter(Filter, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitFilter(Filter, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitFilter(Filter, ScanFieldDeterminer.FieldList) - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer
 
visitFlatten(FlattenPOP, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitFlatten(FlattenPOP, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitFloatConstant(ValueExpressions.FloatExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitFloatConstant(ValueExpressions.FloatExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitFloatConstant(ValueExpressions.FloatExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitFloatConstant(ValueExpressions.FloatExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitFloatConstant(ValueExpressions.FloatExpression, Void) - Method in class org.apache.drill.exec.expr.stat.RangeExprEvaluator
 
visitFloatConstant(ValueExpressions.FloatExpression, Set<LogicalExpression>) - Method in class org.apache.drill.exec.store.parquet.ParquetFilterBuilder
 
visitFrame(int, int, Object[], int, Object[]) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitFrame(int, int, Object[], int, Object[]) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitFunctionCall(FunctionCall, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitFunctionCall(FunctionCall, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitFunctionCall(FunctionCall, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitFunctionCall(FunctionCall, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitFunctionCall(FunctionCall, Void) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilterBuilder
 
visitFunctionHolderExpression(FunctionHolderExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitFunctionHolderExpression(FunctionHolderExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitFunctionHolderExpression(FunctionHolderExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitFunctionHolderExpression(FunctionHolderExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitFunctionHolderExpression(FunctionHolderExpression, Void) - Method in class org.apache.drill.exec.expr.stat.RangeExprEvaluator
 
visitFunctionHolderExpression(FunctionHolderExpression, Set<LogicalExpression>) - Method in class org.apache.drill.exec.store.parquet.ParquetFilterBuilder
 
visitGroupingAggregate(GroupingAggregate, ScanFieldDeterminer.FieldList) - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer
 
visitGroupScan(GroupScan, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitGroupScan(GroupScan, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitGroupScan(GroupScan, Materializer.IndexedFragmentNode) - Method in class org.apache.drill.exec.planner.fragment.contrib.ExchangeRemoverMaterializer
 
visitGroupScan(GroupScan, Materializer.IndexedFragmentNode) - Method in class org.apache.drill.exec.planner.fragment.Materializer
 
visitGroupScan(GroupScan, Wrapper) - Method in class org.apache.drill.exec.planner.fragment.StatsCollector
 
visitHashAggregate(HashAggregate, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitHashAggregate(HashAggregate, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitHashJoin(HashJoinPOP, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitHashJoin(HashJoinPOP, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitHashPartitionSender(HashPartitionSender, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitHashPartitionSender(HashToRandomExchange, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitHashPartitionSender(HashPartitionSender, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitHashPartitionSender(HashToRandomExchange, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitIfExpression(IfExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitIfExpression(IfExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitIfExpression(IfExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitIfExpression(IfExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitIincInsn(int, int) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitIincInsn(int, int) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitInnerClass(String, String, String, int) - Method in class org.apache.drill.exec.compile.CheckClassVisitorFsm
 
visitInputRef(RexInputRef) - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
 
visitInputRef(RexInputRef) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteAsBinaryOperators
 
visitInputRef(RexInputRef) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteCombineBinaryOperators
 
visitInputRef(RexInputRef) - Method in class org.apache.drill.exec.planner.physical.PrelUtil.InputRewriter
 
visitInputRef(RexInputRef) - Method in class org.apache.drill.exec.planner.physical.visitor.RexVisitorComplexExprSplitter
 
visitInsn(int) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitInsn(int) - Method in class org.apache.drill.exec.compile.bytecode.InstructionModifier
 
visitInsn(int) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitInsn(int) - Method in class org.apache.drill.exec.compile.DrillInitMethodVisitor
 
visitInsnAnnotation(int, TypePath, String, boolean) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitInsnAnnotation(int, TypePath, String, boolean) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitIntConstant(ValueExpressions.IntExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitIntConstant(ValueExpressions.IntExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitIntConstant(ValueExpressions.IntExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitIntConstant(ValueExpressions.IntExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitIntConstant(ValueExpressions.IntExpression, Void) - Method in class org.apache.drill.exec.expr.stat.RangeExprEvaluator
 
visitIntConstant(ValueExpressions.IntExpression, Set<LogicalExpression>) - Method in class org.apache.drill.exec.store.parquet.ParquetFilterBuilder
 
visitIntervalDayConstant(ValueExpressions.IntervalDayExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitIntervalDayConstant(ValueExpressions.IntervalDayExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitIntervalDayConstant(ValueExpressions.IntervalDayExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitIntervalDayConstant(ValueExpressions.IntervalDayExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitIntervalYearConstant(ValueExpressions.IntervalYearExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitIntervalYearConstant(ValueExpressions.IntervalYearExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitIntervalYearConstant(ValueExpressions.IntervalYearExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitIntervalYearConstant(ValueExpressions.IntervalYearExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitIntInsn(int, int) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitIntInsn(int, int) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitInvokeDynamicInsn(String, String, Handle, Object...) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitInvokeDynamicInsn(String, String, Handle, Object...) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitIteratorValidator(IteratorValidator, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitIteratorValidator(IteratorValidator, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitJoin(Join, ScanFieldDeterminer.FieldList) - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer
 
visitJoin(JoinPrel, EXTRA) - Method in class org.apache.drill.exec.planner.physical.visitor.BasePrelVisitor
 
visitJoin(JoinPrel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.JoinPrelRenameVisitor
 
visitJoin(JoinPrel, EXTRA) - Method in interface org.apache.drill.exec.planner.physical.visitor.PrelVisitor
 
visitJoin(JoinPrel, PrelVisualizerVisitor.VisualizationState) - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor
 
visitJoin(JoinPrel, Double) - Method in class org.apache.drill.exec.planner.physical.visitor.SwapHashJoinVisitor
 
visitJumpInsn(int, Label) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitJumpInsn(int, Label) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitLabel(Label) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitLabel(Label) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitLdcInsn(Object) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitLdcInsn(Object) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitLimit(Limit, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitLimit(Limit, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitLimit(Limit, ScanFieldDeterminer.FieldList) - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer
 
visitLineNumber(int, Label) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitLineNumber(int, Label) - Method in class org.apache.drill.exec.compile.bytecode.InstructionModifier
 
visitLineNumber(int, Label) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitLiteral(RexLiteral) - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
 
visitLiteral(RexLiteral) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteAsBinaryOperators
 
visitLiteral(RexLiteral) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteCombineBinaryOperators
 
visitLiteral(RexLiteral) - Method in class org.apache.drill.exec.planner.physical.visitor.RexVisitorComplexExprSplitter
 
visitLocalRef(RexLocalRef) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteAsBinaryOperators
 
visitLocalRef(RexLocalRef) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteCombineBinaryOperators
 
visitLocalRef(RexLocalRef) - Method in class org.apache.drill.exec.planner.physical.PrelUtil.InputRewriter
 
visitLocalRef(RexLocalRef) - Method in class org.apache.drill.exec.planner.physical.visitor.RexVisitorComplexExprSplitter
 
visitLocalVariable(String, String, String, Label, Label, int) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitLocalVariable(String, String, String, Label, Label, int) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitLocalVariableAnnotation(int, TypePath, Label[], Label[], int[], String, boolean) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitLocalVariableAnnotation(int, TypePath, Label[], Label[], int[], String, boolean) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitLongConstant(ValueExpressions.LongExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitLongConstant(ValueExpressions.LongExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitLongConstant(ValueExpressions.LongExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitLongConstant(ValueExpressions.LongExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitLongConstant(ValueExpressions.LongExpression, Void) - Method in class org.apache.drill.exec.expr.stat.RangeExprEvaluator
 
visitLongConstant(ValueExpressions.LongExpression, Set<LogicalExpression>) - Method in class org.apache.drill.exec.store.parquet.ParquetFilterBuilder
 
visitLookupSwitchInsn(Label, int[], Label[]) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitLookupSwitchInsn(Label, int[], Label[]) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitMaxs(int, int) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitMaxs(int, int) - Method in class org.apache.drill.exec.compile.bytecode.InstructionModifier
 
visitMaxs(int, int) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitMergeJoin(MergeJoinPOP, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitMergeJoin(MergeJoinPOP, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitMergingReceiver(MergingReceiverPOP, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitMergingReceiver(MergingReceiverPOP, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitMethod(int, String, String, String, String[]) - Method in class org.apache.drill.exec.compile.bytecode.ValueHolderReplacementVisitor
 
visitMethod(int, String, String, String, String[]) - Method in class org.apache.drill.exec.compile.CheckClassVisitorFsm
 
visitMethodDeclarator(Java.MethodDeclarator) - Method in class org.apache.drill.exec.expr.fn.ModifiedUnparseVisitor
 
visitMethodInsn(int, String, String, String) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
Deprecated.
visitMethodInsn(int, String, String, String, boolean) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitMethodInsn(int, String, String, String) - Method in class org.apache.drill.exec.compile.bytecode.InstructionModifier
 
visitMethodInsn(int, String, String, String, boolean) - Method in class org.apache.drill.exec.compile.bytecode.InstructionModifier
 
visitMethodInsn(int, String, String, String) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
Deprecated.
visitMethodInsn(int, String, String, String, boolean) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitMultiANewArrayInsn(String, int) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitMultiANewArrayInsn(String, int) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitNestedLoopJoin(NestedLoopJoinPOP, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitNestedLoopJoin(NestedLoopJoinPOP, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitNullConstant(TypedNullConstant, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitNullConstant(TypedNullConstant, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitNullConstant(TypedNullConstant, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitNullConstant(TypedNullConstant, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitNullExpression(NullExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitNullExpression(NullExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitNullExpression(NullExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitNullExpression(NullExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitOp(PhysicalOperator, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitOp(PhysicalOperator, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitOp(PhysicalOperator, FragmentContext) - Method in class org.apache.drill.exec.physical.impl.TraceInjector
Traverse the physical plan and inject the trace operator after every operator.
visitOp(PhysicalOperator, FragmentContext) - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorInjector
Traverse the physical plan and inject the IteratorValidator operator after every operator.
visitOp(PhysicalOperator, Materializer.IndexedFragmentNode) - Method in class org.apache.drill.exec.planner.fragment.contrib.ExchangeRemoverMaterializer
 
visitOp(PhysicalOperator, Integer) - Method in class org.apache.drill.exec.planner.fragment.contrib.OperatorIdVisitor
 
visitOp(PhysicalOperator, Fragment) - Method in class org.apache.drill.exec.planner.fragment.MakeFragmentsVisitor
 
visitOp(PhysicalOperator, Materializer.IndexedFragmentNode) - Method in class org.apache.drill.exec.planner.fragment.Materializer
 
visitOp(PhysicalOperator, List<BitControl.Collector>) - Method in class org.apache.drill.exec.planner.fragment.SimpleParallelizer.CountRequiredFragments
 
visitOp(PhysicalOperator, Wrapper) - Method in class org.apache.drill.exec.planner.fragment.StatsCollector
 
visitOp(PhysicalOperator, List<PhysicalOperator>) - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedResourceAllocator.BufferedOpFinder
 
visitOrder(Order, ScanFieldDeterminer.FieldList) - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer
 
visitOrderedPartitionSender(OrderedPartitionSender, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitOrderedPartitionSender(OrderedPartitionSender, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitOuterClass(String, String, String) - Method in class org.apache.drill.exec.compile.CheckClassVisitorFsm
 
visitOver(RexOver) - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
 
visitOver(RexOver) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteAsBinaryOperators
 
visitOver(RexOver) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteCombineBinaryOperators
 
visitOver(RexOver) - Method in class org.apache.drill.exec.planner.physical.visitor.RexVisitorComplexExprSplitter
 
visitParameter(String, int) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitParameter(String, int) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitParameterAnnotation(int, String, boolean) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitParameterAnnotation(int, String, boolean) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitPhysicalPlan(QueryWorkUnit) - Method in class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager.DefaultResourceAllocator
 
visitPhysicalPlan(QueryWorkUnit) - Method in interface org.apache.drill.exec.work.foreman.rm.QueryResourceAllocator
Provide the manager with the physical plan and node assignments for the query to be run.
visitPhysicalPlan(QueryWorkUnit) - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedResourceAllocator
 
visitPrel(Prel, PrelSequencer.Frag) - Method in class org.apache.drill.exec.planner.physical.explain.PrelSequencer
 
visitPrel(Prel, EXTRA) - Method in class org.apache.drill.exec.planner.physical.visitor.BasePrelVisitor
 
visitPrel(Prel, ExcessiveExchangeIdentifier.MajorFragmentStat) - Method in class org.apache.drill.exec.planner.physical.visitor.ExcessiveExchangeIdentifier
 
visitPrel(Prel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.FinalColumnReorderer
 
visitPrel(Prel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.InsertLocalExchangeVisitor
 
visitPrel(Prel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.JoinPrelRenameVisitor
 
visitPrel(Prel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.MemoryEstimationVisitor
 
visitPrel(Prel, EXTRA) - Method in interface org.apache.drill.exec.planner.physical.visitor.PrelVisitor
 
visitPrel(Prel, PrelVisualizerVisitor.VisualizationState) - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor
 
visitPrel(Prel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.ProducerConsumerPrelVisitor
 
visitPrel(Prel, Set<Prel>) - Method in class org.apache.drill.exec.planner.physical.visitor.RelUniqifier
 
visitPrel(Prel, Object) - Method in class org.apache.drill.exec.planner.physical.visitor.RewriteProjectToFlatten
 
visitPrel(Prel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.SelectionVectorPrelVisitor
 
visitPrel(Prel, Object) - Method in class org.apache.drill.exec.planner.physical.visitor.SplitUpComplexExpressions
 
visitPrel(Prel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.StarColumnConverter
 
visitPrel(Prel, Double) - Method in class org.apache.drill.exec.planner.physical.visitor.SwapHashJoinVisitor
 
visitPrel(Prel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.TopProjectVisitor
 
visitProducerConsumer(ProducerConsumer, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitProducerConsumer(ProducerConsumer, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitProject(Project, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitProject(Project, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitProject(Project, ScanFieldDeterminer.FieldList) - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer
 
visitProject(ProjectPrel, EXTRA) - Method in class org.apache.drill.exec.planner.physical.visitor.BasePrelVisitor
 
visitProject(ProjectPrel, EXTRA) - Method in interface org.apache.drill.exec.planner.physical.visitor.PrelVisitor
 
visitProject(ProjectPrel, PrelVisualizerVisitor.VisualizationState) - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor
 
visitProject(ProjectPrel, Object) - Method in class org.apache.drill.exec.planner.physical.visitor.RewriteProjectToFlatten
 
visitProject(ProjectPrel, Object) - Method in class org.apache.drill.exec.planner.physical.visitor.SplitUpComplexExpressions
 
visitProject(ProjectPrel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.StarColumnConverter
 
visitQuotedStringConstant(ValueExpressions.QuotedString, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitQuotedStringConstant(ValueExpressions.QuotedString, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitQuotedStringConstant(ValueExpressions.QuotedString, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitQuotedStringConstant(ValueExpressions.QuotedString, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitQuotedStringConstant(ValueExpressions.QuotedString, Void) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilterBuilder
 
visitRangeRef(RexRangeRef) - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
 
visitRangeRef(RexRangeRef) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteAsBinaryOperators
 
visitRangeRef(RexRangeRef) - Method in class org.apache.drill.exec.planner.logical.partition.RewriteCombineBinaryOperators
 
visitRangeRef(RexRangeRef) - Method in class org.apache.drill.exec.planner.physical.visitor.RexVisitorComplexExprSplitter
 
visitRangeSender(RangeSender, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitRangeSender(RangeSender, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitReceiver(Receiver, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitReceiver(Receiver, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitReceiver(Receiver, List<BitControl.Collector>) - Method in class org.apache.drill.exec.planner.fragment.SimpleParallelizer.CountRequiredFragments
 
visitReceivingExchange(Exchange, Wrapper) - Method in class org.apache.drill.exec.planner.AbstractOpWrapperVisitor
 
visitReceivingExchange(Exchange, Wrapper) - Method in class org.apache.drill.exec.planner.fragment.StatsCollector
 
visitReturnStatement(Java.ReturnStatement) - Method in class org.apache.drill.exec.expr.fn.ModifiedUnparseVisitor
 
visitScan(Scan, ScanFieldDeterminer.FieldList) - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer
 
visitScan(ScanPrel, EXTRA) - Method in class org.apache.drill.exec.planner.physical.visitor.BasePrelVisitor
 
visitScan(ScanPrel, ExcessiveExchangeIdentifier.MajorFragmentStat) - Method in class org.apache.drill.exec.planner.physical.visitor.ExcessiveExchangeIdentifier
 
visitScan(ScanPrel, EXTRA) - Method in interface org.apache.drill.exec.planner.physical.visitor.PrelVisitor
 
visitScan(ScanPrel, PrelVisualizerVisitor.VisualizationState) - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor
 
visitScan(ScanPrel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.ProducerConsumerPrelVisitor
 
visitScan(ScanPrel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.StarColumnConverter
 
visitSchema(String, SchemaPlus) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Schemata
 
visitSchema(String, SchemaPlus) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
Visit the given schema.
visitSchemaPath(SchemaPath, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitSchemaPath(SchemaPath, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitSchemaPath(SchemaPath, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitSchemaPath(SchemaPath, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitSchemaPath(SchemaPath, Void) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilterBuilder
 
visitSchemaPath(SchemaPath, Void) - Method in class org.apache.drill.exec.store.parquet.ParquetRGFilterEvaluator.FieldReferenceFinder
 
visitScreen(Screen, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitScreen(Screen, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitScreen(ScreenPrel, EXTRA) - Method in class org.apache.drill.exec.planner.physical.visitor.BasePrelVisitor
 
visitScreen(ScreenPrel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.ComplexToJsonPrelVisitor
 
visitScreen(ScreenPrel, ExcessiveExchangeIdentifier.MajorFragmentStat) - Method in class org.apache.drill.exec.planner.physical.visitor.ExcessiveExchangeIdentifier
 
visitScreen(ScreenPrel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.FinalColumnReorderer
 
visitScreen(ScreenPrel, EXTRA) - Method in interface org.apache.drill.exec.planner.physical.visitor.PrelVisitor
 
visitScreen(ScreenPrel, PrelVisualizerVisitor.VisualizationState) - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor
 
visitScreen(ScreenPrel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.StarColumnConverter
 
visitScreen(ScreenPrel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.TopProjectVisitor
 
visitSender(Sender, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitSender(Sender, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitSendingExchange(Exchange, Wrapper) - Method in class org.apache.drill.exec.planner.AbstractOpWrapperVisitor
 
visitSendingExchange(Exchange, Wrapper) - Method in class org.apache.drill.exec.planner.fragment.StatsCollector
 
visitSingleSender(SingleSender, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitSingleSender(SingleSender, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitSort(Sort, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitSort(Sort, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitSource(String, String) - Method in class org.apache.drill.exec.compile.CheckClassVisitorFsm
 
visitStore(Store, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitStore(Store, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitStore(Store, Materializer.IndexedFragmentNode) - Method in class org.apache.drill.exec.planner.fragment.contrib.ExchangeRemoverMaterializer
 
visitStore(Store, Materializer.IndexedFragmentNode) - Method in class org.apache.drill.exec.planner.fragment.Materializer
 
visitStore(Store, Wrapper) - Method in class org.apache.drill.exec.planner.fragment.StatsCollector
 
visitStore(Store, ScanFieldDeterminer.FieldList) - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer
 
visitStreamingAggregate(StreamingAggregate, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitStreamingAggregate(StreamingAggregate, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitSubScan(SubScan, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitSubScan(SubScan, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitSubScan(SubScan, Materializer.IndexedFragmentNode) - Method in class org.apache.drill.exec.planner.fragment.contrib.ExchangeRemoverMaterializer
 
visitSubScan(SubScan, Integer) - Method in class org.apache.drill.exec.planner.fragment.contrib.OperatorIdVisitor
 
visitSubScan(SubScan, Materializer.IndexedFragmentNode) - Method in class org.apache.drill.exec.planner.fragment.Materializer
 
visitTable(String, String, Table) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Tables
 
visitTable(String, String, Table) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Views
 
visitTable(String, String, Table) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
Visit the given table.
visitTables(String, SchemaPlus) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Tables
 
visitTables(String, SchemaPlus) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
Visit the tables in the given schema.
visitTableSwitchInsn(int, int, Label, Label...) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitTableSwitchInsn(int, int, Label, Label...) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitTimeConstant(ValueExpressions.TimeExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitTimeConstant(ValueExpressions.TimeExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitTimeConstant(ValueExpressions.TimeExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitTimeConstant(ValueExpressions.TimeExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitTimeConstant(ValueExpressions.TimeExpression, Void) - Method in class org.apache.drill.exec.expr.stat.RangeExprEvaluator
 
visitTimeConstant(ValueExpressions.TimeExpression, Set<LogicalExpression>) - Method in class org.apache.drill.exec.store.parquet.ParquetFilterBuilder
 
visitTimeStampConstant(ValueExpressions.TimeStampExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitTimeStampConstant(ValueExpressions.TimeStampExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitTimeStampConstant(ValueExpressions.TimeStampExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitTimeStampConstant(ValueExpressions.TimeStampExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitTimeStampConstant(ValueExpressions.TimeStampExpression, Void) - Method in class org.apache.drill.exec.expr.stat.RangeExprEvaluator
 
visitTimeStampConstant(ValueExpressions.TimeStampExpression, Set<LogicalExpression>) - Method in class org.apache.drill.exec.store.parquet.ParquetFilterBuilder
 
visitTrace(Trace, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitTrace(Trace, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitTryCatchAnnotation(int, TypePath, String, boolean) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitTryCatchAnnotation(int, TypePath, String, boolean) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitTryCatchBlock(Label, Label, Label, String) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitTryCatchBlock(Label, Label, Label, String) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitTypeAnnotation(int, TypePath, String, boolean) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitTypeAnnotation(int, TypePath, String, boolean) - Method in class org.apache.drill.exec.compile.CheckClassVisitorFsm
 
visitTypeAnnotation(int, TypePath, String, boolean) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitTypeInsn(int, String) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitTypeInsn(int, String) - Method in class org.apache.drill.exec.compile.bytecode.InstructionModifier
 
visitTypeInsn(int, String) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitUnion(UnionAll, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitUnion(UnionAll, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitUnion(Union, ScanFieldDeterminer.FieldList) - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer
 
visitUnionExchange(UnionExchange, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitUnionExchange(UnionExchange, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitUnknown(LogicalExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
 
visitUnknown(LogicalExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
 
visitUnknown(LogicalExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitUnknown(LogicalExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
 
visitUnknown(LogicalExpression, Void) - Method in class org.apache.drill.exec.expr.stat.RangeExprEvaluator
 
visitUnknown(LogicalExpression, Void) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilterBuilder
 
visitUnknown(LogicalExpression, Set<LogicalExpression>) - Method in class org.apache.drill.exec.store.parquet.ParquetFilterBuilder
 
visitUnknown(LogicalExpression, Void) - Method in class org.apache.drill.exec.store.parquet.ParquetRGFilterEvaluator.FieldReferenceFinder
 
visitUnorderedReceiver(UnorderedReceiver, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitUnorderedReceiver(UnorderedReceiver, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitValues(Values, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitValues(Values, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitValues(Values, ScanFieldDeterminer.FieldList) - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer
 
visitValueVectorReadExpression(ValueVectorReadExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
 
visitVarInsn(int, int) - Method in class org.apache.drill.exec.compile.bytecode.AloadPopRemover
 
visitVarInsn(int, int) - Method in class org.apache.drill.exec.compile.bytecode.InstructionModifier
 
visitVarInsn(int, int) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
 
visitWindowFrame(WindowPOP, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitWindowFrame(WindowPOP, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitWriter(Writer, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
 
visitWriter(Writer, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
 
visitWriter(WriterPrel, EXTRA) - Method in class org.apache.drill.exec.planner.physical.visitor.BasePrelVisitor
 
visitWriter(WriterPrel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.FinalColumnReorderer
 
visitWriter(WriterPrel, EXTRA) - Method in interface org.apache.drill.exec.planner.physical.visitor.PrelVisitor
 
visitWriter(WriterPrel, PrelVisualizerVisitor.VisualizationState) - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor
 
visitWriter(WriterPrel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.StarColumnConverter
 
visitWriter(WriterPrel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.TopProjectVisitor
 
visualize(Prel) - Static method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor
 
VVReadBatch - Annotation Type in org.apache.drill.exec.compile.sig
Marker annotation to determine which fields should be included as parameters for the function.
VVWriteBatch - Annotation Type in org.apache.drill.exec.compile.sig
Marker annotation to determine which fields should be included as parameters for the function.

W

waitForGracePeriod() - Method in class org.apache.drill.exec.server.Drillbit
 
waitForSendComplete() - Method in class org.apache.drill.exec.ops.FragmentContext
Wait for ack that all outgoing batches have been sent
waitNanos - Variable in class org.apache.drill.exec.ops.OperatorStats
 
waitToExit(Drillbit, boolean) - Method in class org.apache.drill.exec.work.WorkManager
Waits until it is safe to exit.
wasAllPartitionsPruned() - Method in class org.apache.drill.exec.store.dfs.FileSelection
 
WEB_LOGS_MAX_LINES - Static variable in class org.apache.drill.exec.ExecConstants
Web settings
WEB_LOGS_MAX_LINES_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
 
WebServer - Class in org.apache.drill.exec.server.rest
Wrapper class around jetty based webserver.
WebServer(BootStrapContext, WorkManager, Drillbit) - Constructor for class org.apache.drill.exec.server.rest.WebServer
Create Jetty based web server.
WebSessionResources - Class in org.apache.drill.exec.server.rest
Class holding all the resources required for Web User Session.
webSessionResources - Variable in class org.apache.drill.exec.server.rest.WebUserConnection
 
WebUserConnection - Class in org.apache.drill.exec.server.rest
WebUserConnectionWrapper which represents the UserClientConnection between WebServer and Foreman, for the WebUser submitting the query.
WebUserConnection.AnonWebUserConnection - Class in org.apache.drill.exec.server.rest
 
WHEN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
WHENEVER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
WhenMatchedClause(SqlNode, SqlIdentifier) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
WhenNotMatchedClause(SqlNode) - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
WHERE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
WhereOpt() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses the optional WHERE clause for SELECT, DELETE, and UPDATE.
WHITESPACE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
width - Variable in class org.apache.drill.exec.record.MajorTypeSerDe.MajorTypeHolder
 
width - Variable in class org.apache.drill.exec.store.mock.ColumnDef
 
width - Variable in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
 
WIDTH_BUCKET - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
WINDOW - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
WindowDataBatch - Class in org.apache.drill.exec.physical.impl.window
 
WindowDataBatch(VectorAccessible, OperatorContext) - Constructor for class org.apache.drill.exec.physical.impl.window.WindowDataBatch
 
WindowFrameBatchCreator - Class in org.apache.drill.exec.physical.impl.window
 
WindowFrameBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.window.WindowFrameBatchCreator
 
WindowFramer - Interface in org.apache.drill.exec.physical.impl.window
 
WindowFrameRecordBatch - Class in org.apache.drill.exec.physical.impl.window
support for OVER(PARTITION BY expression1,expression2,...
WindowFrameRecordBatch(WindowPOP, FragmentContext, RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.window.WindowFrameRecordBatch
 
WindowFunction - Class in org.apache.drill.exec.physical.impl.window
 
WindowFunction.Type - Enum in org.apache.drill.exec.physical.impl.window
 
WindowOpt() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses the optional WINDOW clause for SELECT
WindowPOP - Class in org.apache.drill.exec.physical.config
 
WindowPOP(PhysicalOperator, List<NamedExpression>, List<NamedExpression>, List<Order.Ordering>, boolean, WindowPOP.Bound, WindowPOP.Bound) - Constructor for class org.apache.drill.exec.physical.config.WindowPOP
 
WindowPOP.Bound - Class in org.apache.drill.exec.physical.config
 
WindowPOP.Bound(boolean, long) - Constructor for class org.apache.drill.exec.physical.config.WindowPOP.Bound
 
WindowPrel - Class in org.apache.drill.exec.planner.physical
 
WindowPrel(RelOptCluster, RelTraitSet, RelNode, List<RexLiteral>, RelDataType, Window.Group) - Constructor for class org.apache.drill.exec.planner.physical.WindowPrel
 
WindowPrule - Class in org.apache.drill.exec.planner.physical
 
WindowRange() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
WindowSpecification() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
Parses a window specification.
WITH - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
withCredentials(UserBitShared.UserCredentials) - Method in class org.apache.drill.exec.rpc.user.UserSession.Builder
 
WITHIN - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
withIndex() - Method in class org.apache.drill.exec.record.TypedFieldId.Builder
 
WithItem() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
WithList() - Method in class org.apache.drill.exec.planner.sql.parser.impl.DrillParserImpl
 
withOptionManager(OptionManager) - Method in class org.apache.drill.exec.rpc.user.UserSession.Builder
 
WITHOUT - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
withUserProperties(UserProtos.UserProperties) - Method in class org.apache.drill.exec.rpc.user.UserSession.Builder
 
WORK - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
work - Variable in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedResourceAllocator
 
workBuf - Variable in class org.apache.drill.exec.store.bson.BsonRecordReader
 
workBuf - Variable in class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
 
WorkEventBus - Class in org.apache.drill.exec.rpc.control
 
WorkEventBus() - Constructor for class org.apache.drill.exec.rpc.control.WorkEventBus
 
WorkManager - Class in org.apache.drill.exec.work
Manages the running fragments in a Drillbit.
WorkManager(BootStrapContext) - Constructor for class org.apache.drill.exec.work.WorkManager
 
WorkManager.WorkerBee - Class in org.apache.drill.exec.work
Narrowed interface to WorkManager that is made available to tasks it is managing.
WorkManager.WorkerBee() - Constructor for class org.apache.drill.exec.work.WorkManager.WorkerBee
 
Workspace - Annotation Type in org.apache.drill.exec.expr.annotations
Describes the field will provide output from the given function.
WorkspaceConfig - Class in org.apache.drill.exec.store.dfs
Stores the workspace related config.
WorkspaceConfig(String, boolean, String, boolean) - Constructor for class org.apache.drill.exec.store.dfs.WorkspaceConfig
 
WorkspaceReference - Class in org.apache.drill.exec.expr.fn
 
WorkspaceReference(Class<?>, String, boolean) - Constructor for class org.apache.drill.exec.expr.fn.WorkspaceReference
 
workspaces - Variable in class org.apache.drill.exec.store.dfs.FileSystemConfig
 
WorkspaceSchemaFactory - Class in org.apache.drill.exec.store.dfs
 
WorkspaceSchemaFactory(FileSystemPlugin, String, String, WorkspaceConfig, List<FormatMatcher>, LogicalPlanPersistence, ScanResult) - Constructor for class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory
 
WorkspaceSchemaFactory.WorkspaceSchema - Class in org.apache.drill.exec.store.dfs
 
WorkspaceSchemaFactory.WorkspaceSchema(List<String>, String, SchemaConfig, DrillFileSystem) - Constructor for class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
 
WORST_CASE_BUFFER_RATIO - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
On really bad days, we will add one more byte (or value) to a vector than fits in a power-of-two sized buffer, forcing a doubling.
Wrapper - Class in org.apache.drill.exec.planner.fragment
A wrapping class that allows us to add additional information to each fragment node for planning purposes.
Wrapper(Fragment, int) - Constructor for class org.apache.drill.exec.planner.fragment.Wrapper
 
WRAPPER - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
wrappers - Variable in class org.apache.drill.exec.record.VectorContainer
 
WritableBatch - Class in org.apache.drill.exec.record
A specialized version of record batch that can moves out buffers and preps them for writing.
writableBytes() - Method in class org.apache.drill.exec.record.DeadBuf
 
write(DataOutput) - Method in class org.apache.drill.exec.cache.CachedVectorContainer
 
write(DataOutput) - Method in interface org.apache.drill.exec.cache.DrillSerializable
 
write(VectorAccessible) - Method in class org.apache.drill.exec.cache.VectorSerializer.Writer
 
write(VectorAccessible, SelectionVector2) - Method in class org.apache.drill.exec.cache.VectorSerializer.Writer
 
write(WritableBatch, SelectionVector2) - Method in class org.apache.drill.exec.cache.VectorSerializer.Writer
 
write(char[], int, int) - Method in class org.apache.drill.exec.compile.LogWriter
 
write(RecordBatch) - Method in interface org.apache.drill.exec.disk.Spool
 
write(TypeProtos.MajorType, JVar, ClassGenerator.HoldingContainer, JExpression, String) - Static method in class org.apache.drill.exec.expr.GetSetVectorHelper
 
write(int) - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingOutputStream
 
write(byte[]) - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingOutputStream
 
write(byte[], int, int) - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingOutputStream
 
WRITE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
write(BaseWriter.ComplexWriter, BsonReader) - Method in class org.apache.drill.exec.store.bson.BsonRecordReader
 
write(BaseWriter.ComplexWriter) - Method in interface org.apache.drill.exec.store.easy.json.JsonProcessor
 
write(BaseWriter.ComplexWriter) - Method in class org.apache.drill.exec.store.easy.json.reader.CountingJsonReader
 
write(int) - Method in class org.apache.drill.exec.store.EventBasedRecordWriter
 
write(int) - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalSyncableOutputStream
 
write(BaseWriter.ComplexWriter) - Method in class org.apache.drill.exec.vector.complex.fn.JsonReader
 
write(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.JsonWriter
 
writeAllTo(OutputStream) - Method in class org.apache.drill.exec.store.parquet.ColumnDataReader.HadoopBytesInput
 
writeBigInt(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeBigInt(int, FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeBigInt(long) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeBigInt(long) - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeBigInt(long) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeBigInt(FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeBigInt(int, FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeBigIntNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeBigIntNull() - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeBigIntNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeBinary(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeBinary(int, FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeBinary(byte[]) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeBinary(byte[]) - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeBinary(byte[]) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeBinary(FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeBinary(int, FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeBinaryNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeBinaryNull() - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeBinaryNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeBoolean(boolean) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeBoolean(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeBoolean(int, FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeBoolean(boolean) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeBoolean(boolean) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeBoolean(FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeBoolean(int, FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeBooleanNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeBooleanNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeByte(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeBytes(ByteBuf) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeBytes(ByteBuf, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeBytes(ByteBuf, int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeBytes(byte[]) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeBytes(byte[], int, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeBytes(ByteBuffer) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeBytes(InputStream, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeBytes(ScatteringByteChannel, int) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeChar(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeDate(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeDate(int, FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeDate(DateTime) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeDate(DateTime) - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeDate(DateTime) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeDate(FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeDate(int, FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeDateNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeDateNull() - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeDateNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeDecimal(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeDecimal(int, FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeDecimal(BigDecimal) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeDecimal(BigDecimal) - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeDecimal(BigDecimal) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeDecimal(FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeDecimal(int, FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeDecimalNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeDecimalNull() - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeDecimalNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeDouble(double) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeDouble(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeDouble(int, FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeDouble(double) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeDouble(double) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeDouble(FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeDouble(int, FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeDoubleNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeDoubleNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeEndArray() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeEndArray() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeEndObject() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeEndObject() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
WriteEntry - Interface in org.apache.drill.exec.physical
 
writeField() - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter.MapJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter.RepeatedListJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter.RepeatedMapJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter.UnionJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.EventBasedRecordWriter.FieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.BigIntJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.BitJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.DateJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal18JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal28DenseJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal28SparseJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal38DenseJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal38SparseJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Decimal9JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Float4JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Float8JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.IntervalDayJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.IntervalJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.IntervalYearJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.IntJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableBigIntJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableBitJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDateJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal18JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal28DenseJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal28SparseJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal38DenseJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal38SparseJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableDecimal9JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableFloat4JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableFloat8JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableIntervalDayJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableIntervalJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableIntervalYearJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableIntJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableSmallIntJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableTimeJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableTimeStampJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableTinyIntJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableUInt1JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableUInt2JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableUInt4JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableUInt8JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableVar16CharJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableVarBinaryJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.NullableVarCharJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedBigIntJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedBitJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDateJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal18JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal28DenseJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal28SparseJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal38DenseJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal38SparseJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedDecimal9JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedFloat4JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedFloat8JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedIntervalDayJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedIntervalJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedIntervalYearJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedIntJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedSmallIntJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedTimeJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedTimeStampJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedTinyIntJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedUInt1JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedUInt2JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedUInt4JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedUInt8JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedVar16CharJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedVarBinaryJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.RepeatedVarCharJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.SmallIntJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.TimeJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.TimeStampJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.TinyIntJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.UInt1JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.UInt2JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.UInt4JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.UInt8JsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.Var16CharJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.VarBinaryJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.JSONOutputRecordWriter.VarCharJsonConverter
 
writeField() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter.MapParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter.RepeatedMapParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.BigIntParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.BitParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.DateParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.Decimal18ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.Decimal28DenseParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.Decimal28SparseParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.Decimal38DenseParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.Decimal38SparseParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.Decimal9ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.Float4ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.Float8ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.IntervalDayParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.IntervalParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.IntervalYearParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.IntParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableBigIntParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableBitParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableDateParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableDecimal18ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableDecimal28DenseParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableDecimal28SparseParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableDecimal38DenseParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableDecimal38SparseParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableDecimal9ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableFloat4ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableFloat8ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableIntervalDayParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableIntervalParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableIntervalYearParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableIntParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableSmallIntParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableTimeParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableTimeStampParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableTinyIntParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableUInt1ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableUInt2ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableUInt4ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableUInt8ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableVar16CharParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableVarBinaryParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.NullableVarCharParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedBigIntParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedBitParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedDateParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedDecimal18ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedDecimal28DenseParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedDecimal28SparseParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedDecimal38DenseParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedDecimal38SparseParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedDecimal9ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedFloat4ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedFloat8ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedIntervalDayParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedIntervalParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedIntervalYearParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedIntParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedSmallIntParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedTimeParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedTimeStampParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedTinyIntParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedUInt1ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedUInt2ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedUInt4ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedUInt8ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedVar16CharParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedVarBinaryParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.RepeatedVarCharParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.SmallIntParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.TimeParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.TimeStampParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.TinyIntParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.UInt1ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.UInt2ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.UInt4ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.UInt8ParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.Var16CharParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.VarBinaryParquetConverter
 
writeField() - Method in class org.apache.drill.exec.store.ParquetOutputRecordWriter.VarCharParquetConverter
 
writeField(Object, int) - Method in interface org.apache.drill.exec.store.pojo.PojoWriter
Writes given value to the given position of the bit to set.
writeField(Object, int) - Method in class org.apache.drill.exec.store.pojo.PojoWriters.BitWriter
 
writeField(Object, int) - Method in class org.apache.drill.exec.store.pojo.PojoWriters.DoubleWriter
 
writeField(Object, int) - Method in class org.apache.drill.exec.store.pojo.PojoWriters.EnumWriter
 
writeField(Object, int) - Method in class org.apache.drill.exec.store.pojo.PojoWriters.IntWriter
 
writeField(Object, int) - Method in class org.apache.drill.exec.store.pojo.PojoWriters.LongWriter
 
writeField(Object, int) - Method in class org.apache.drill.exec.store.pojo.PojoWriters.NBigIntWriter
 
writeField(Object, int) - Method in class org.apache.drill.exec.store.pojo.PojoWriters.NBooleanWriter
 
writeField(Object, int) - Method in class org.apache.drill.exec.store.pojo.PojoWriters.NDoubleWriter
 
writeField(Object, int) - Method in class org.apache.drill.exec.store.pojo.PojoWriters.NIntWriter
 
writeField(Object, int) - Method in class org.apache.drill.exec.store.pojo.PojoWriters.NTimeStampWriter
 
writeField(Object, int) - Method in class org.apache.drill.exec.store.pojo.PojoWriters.StringWriter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.BigIntStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.BitStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.DateStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.Decimal18StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.Decimal28DenseStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.Decimal28SparseStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.Decimal38DenseStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.Decimal38SparseStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.Decimal9StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.Float4StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.Float8StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.IntervalDayStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.IntervalStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.IntervalYearStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.IntStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableBigIntStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableBitStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableDateStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableDecimal18StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableDecimal28DenseStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableDecimal28SparseStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableDecimal38DenseStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableDecimal38SparseStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableDecimal9StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableFloat4StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableFloat8StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableIntervalDayStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableIntervalStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableIntervalYearStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableIntStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableSmallIntStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableTimeStampStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableTimeStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableTinyIntStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableUInt1StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableUInt2StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableUInt4StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableUInt8StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableVar16CharStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableVarBinaryStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.NullableVarCharStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedBigIntStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedBitStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedDateStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedDecimal18StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedDecimal28DenseStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedDecimal28SparseStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedDecimal38DenseStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedDecimal38SparseStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedDecimal9StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedFloat4StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedFloat8StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedIntervalDayStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedIntervalStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedIntervalYearStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedIntStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedSmallIntStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedTimeStampStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedTimeStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedTinyIntStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedUInt1StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedUInt2StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedUInt4StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedUInt8StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedVar16CharStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedVarBinaryStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.RepeatedVarCharStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.SmallIntStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.TimeStampStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.TimeStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.TinyIntStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.UInt1StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.UInt2StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.UInt4StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.UInt8StringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.Var16CharStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.VarBinaryStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.StringOutputRecordWriter.VarCharStringFieldConverter
 
writeField() - Method in class org.apache.drill.exec.store.text.DrillTextRecordWriter.ComplexStringFieldConverter
 
writeFieldName(String) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeFieldName(String) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeFloat(float) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeFloat(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeFloat(int, FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeFloat(float) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeFloat(float) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeFloat(FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeFloat(int, FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeFloatNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeFloatNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeInt(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeInt(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeInt(int, FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeInt(int) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeInt(int) - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeInt(int) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeInt(FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeInt(int, FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeInterval(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeInterval(int, FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeInterval(Period) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeInterval(Period) - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeInterval(Period) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeInterval(FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeInterval(int, FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeIntervalNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeIntervalNull() - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeIntervalNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeIntNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeIntNull() - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeIntNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeJson(OptionList) - Method in class org.apache.drill.exec.planner.PhysicalPlanReader
 
writeJson(PhysicalOperator) - Method in class org.apache.drill.exec.planner.PhysicalPlanReader
 
writeLastValue(int, int) - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
 
writeLong(long) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeMedium(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
writer(BufferAllocator, OutputStream) - Static method in class org.apache.drill.exec.cache.VectorSerializer
 
writer() - Method in class org.apache.drill.exec.expr.DebugStringBuilder
 
Writer - Interface in org.apache.drill.exec.physical.base
Writer physical operator
WRITER_VERSION - Static variable in class org.apache.drill.exec.store.parquet.ParquetWriter
Version of Drill's Parquet writer.
WRITER_VERSION_PROPERTY - Static variable in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
 
writerIndex() - Method in class org.apache.drill.exec.record.DeadBuf
 
writerIndex(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
WriterPrel - Class in org.apache.drill.exec.planner.physical
 
WriterPrel(RelOptCluster, RelTraitSet, RelNode, CreateTableEntry) - Constructor for class org.apache.drill.exec.planner.physical.WriterPrel
 
WriterPrule - Class in org.apache.drill.exec.planner.physical
 
WriterPrule() - Constructor for class org.apache.drill.exec.planner.physical.WriterPrule
 
WriterRecordBatch - Class in org.apache.drill.exec.physical.impl
 
WriterRecordBatch(Writer, RecordBatch, FragmentContext, RecordWriter) - Constructor for class org.apache.drill.exec.physical.impl.WriterRecordBatch
 
writers - Variable in class org.apache.drill.exec.store.pojo.AbstractPojoRecordReader
 
writeShort(int) - Method in class org.apache.drill.exec.record.DeadBuf
 
writeSmallInt(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeSmallInt(int, FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeSmallInt(short) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeSmallInt(short) - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeSmallInt(short) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeSmallInt(FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeSmallInt(int, FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeSmallIntNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeSmallIntNull() - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeSmallIntNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeStartArray() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeStartArray() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeStartObject() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeStartObject() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeTime(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeTime(int, FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeTime(DateTime) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeTime(DateTime) - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeTime(DateTime) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeTime(FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeTime(int, FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeTimeNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeTimeNull() - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeTimeNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeTimestamp(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeTimestamp(int, FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeTimestamp(DateTime) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeTimestamp(DateTime) - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeTimestamp(DateTime) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeTimestamp(FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeTimestamp(int, FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeTimestampNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeTimestampNull() - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeTimestampNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeTinyInt(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeTinyInt(int, FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeTinyInt(byte) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeTinyInt(byte) - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeTinyInt(byte) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeTinyInt(FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeTinyInt(int, FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeTinyIntNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeTinyIntNull() - Method in class org.apache.drill.exec.vector.complex.fn.ExtendedJsonOutput
 
writeTinyIntNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeToMapFromReader(FieldReader, BaseWriter.MapWriter) - Static method in class org.apache.drill.exec.vector.complex.MapUtility
 
writeToStream(OutputStream) - Method in class org.apache.drill.exec.cache.AbstractStreamSerializable
 
writeToStream(OutputStream) - Method in interface org.apache.drill.exec.cache.DrillSerializable
 
writeToStream(OutputStream) - Method in class org.apache.drill.exec.cache.VectorAccessibleSerializable
Serializes the VectorAccessible va and writes it to an output stream
writeToStreamAndRetain(OutputStream) - Method in class org.apache.drill.exec.cache.VectorAccessibleSerializable
 
writeUntypedNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeUntypedNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeVar16Char(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeVar16Char(int, FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeVar16Char(String) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeVar16Char(String) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeVar16Char(FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeVar16Char(int, FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeVar16charNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeVar16charNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeVarChar(FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeVarChar(int, FieldReader) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeVarChar(String) - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeVarChar(String) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeVarChar(FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeVarChar(int, FieldReader) - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeVarcharNull() - Method in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
 
writeVarcharNull() - Method in interface org.apache.drill.exec.vector.complex.fn.JsonOutput
 
writeVInt(DrillBuf, int, int, int) - Static method in class org.apache.drill.exec.util.ByteBufUtil.HadoopWritables
Serializes an integer to a binary stream with zero-compressed encoding.
writeVLong(DrillBuf, int, int, long) - Static method in class org.apache.drill.exec.util.ByteBufUtil.HadoopWritables
Serializes a long to a binary stream with zero-compressed encoding.
writeZero(int) - Method in class org.apache.drill.exec.record.DeadBuf
 

X

XML - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
XXHash - Class in org.apache.drill.exec.expr.fn.impl
 
XXHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.XXHash
 

Y

YEAR - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 

Z

ZERO_RECORD_TABLE - Static variable in class org.apache.drill.exec.physical.base.ScanStats
 
zeroVectors() - Method in class org.apache.drill.exec.record.VectorContainer
Clears the contained vectors.
ZK_CONNECTION - Static variable in class org.apache.drill.exec.ExecConstants
 
ZK_REFRESH - Static variable in class org.apache.drill.exec.ExecConstants
 
ZK_RETRY_DELAY - Static variable in class org.apache.drill.exec.ExecConstants
 
ZK_RETRY_TIMES - Static variable in class org.apache.drill.exec.ExecConstants
 
ZK_ROOT - Static variable in class org.apache.drill.exec.ExecConstants
 
ZK_TIMEOUT - Static variable in class org.apache.drill.exec.ExecConstants
 
ZKClusterCoordinator - Class in org.apache.drill.exec.coord.zk
Manages cluster coordination utilizing zookeeper.
ZKClusterCoordinator(DrillConfig) - Constructor for class org.apache.drill.exec.coord.zk.ZKClusterCoordinator
 
ZKClusterCoordinator(DrillConfig, String) - Constructor for class org.apache.drill.exec.coord.zk.ZKClusterCoordinator
 
ZkDistributedSemaphore - Class in org.apache.drill.exec.coord.zk
 
ZkDistributedSemaphore(CuratorFramework, String, int) - Constructor for class org.apache.drill.exec.coord.zk.ZkDistributedSemaphore
 
ZkEphemeralStore<V> - Class in org.apache.drill.exec.coord.zk
 
ZkEphemeralStore(TransientStoreConfig<V>, CuratorFramework) - Constructor for class org.apache.drill.exec.coord.zk.ZkEphemeralStore
 
ZkPStoreProvider - Class in org.apache.drill.exec.store.sys.zk
Deprecated.
will be removed in 1.7 use ZookeeperPersistentStoreProvider instead.
ZkPStoreProvider(PersistentStoreRegistry<ZKClusterCoordinator>) - Constructor for class org.apache.drill.exec.store.sys.zk.ZkPStoreProvider
Deprecated.
 
ZKRegistrationHandle - Class in org.apache.drill.exec.coord.zk
 
ZKRegistrationHandle(String, CoordinationProtos.DrillbitEndpoint) - Constructor for class org.apache.drill.exec.coord.zk.ZKRegistrationHandle
 
ZkTransientStoreFactory - Class in org.apache.drill.exec.coord.zk
 
ZkTransientStoreFactory(CuratorFramework) - Constructor for class org.apache.drill.exec.coord.zk.ZkTransientStoreFactory
 
ZONE - Static variable in interface org.apache.drill.exec.planner.sql.parser.impl.DrillParserImplConstants
 
ZookeeperClient - Class in org.apache.drill.exec.coord.zk
A namespace aware Zookeeper client.
ZookeeperClient(CuratorFramework, String, CreateMode) - Constructor for class org.apache.drill.exec.coord.zk.ZookeeperClient
 
ZookeeperPersistentStore<V> - Class in org.apache.drill.exec.store.sys.store
Zookeeper based implementation of PersistentStore.
ZookeeperPersistentStore(CuratorFramework, PersistentStoreConfig<V>) - Constructor for class org.apache.drill.exec.store.sys.store.ZookeeperPersistentStore
 
ZookeeperPersistentStoreProvider - Class in org.apache.drill.exec.store.sys.store.provider
 
ZookeeperPersistentStoreProvider(PersistentStoreRegistry<ZKClusterCoordinator>) - Constructor for class org.apache.drill.exec.store.sys.store.provider.ZookeeperPersistentStoreProvider
 
ZookeeperPersistentStoreProvider(DrillConfig, CuratorFramework) - Constructor for class org.apache.drill.exec.store.sys.store.provider.ZookeeperPersistentStoreProvider
 
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 

Copyright © 2017 The Apache Software Foundation. All rights reserved.