- c - Static variable in class org.apache.drill.exec.ExecTest
-
- c - Static variable in class org.apache.drill.exec.RunRootExec
-
- c - Static variable in class org.apache.drill.exec.work.filter.BloomFilterTest
-
- CacheConfig(Class<K>, Class<V>, String, DistributedCache.SerializationMode) - Constructor for class org.apache.drill.exec.cache.DistributedCache.CacheConfig
-
- 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
-
- CachedSingleFileSystem - Class in org.apache.drill.exec.store
-
- CachedSingleFileSystem(String) - Constructor for class org.apache.drill.exec.store.CachedSingleFileSystem
-
- 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 - Static variable in interface org.apache.drill.exec.planner.RuleInstance
-
- CALC_INSTANCE_DRILL - Static variable in class org.apache.drill.exec.planner.logical.DrillReduceExpressionsRule
-
- calculateReservedMemory(int, long, long, long) - Static method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.PostBuildCalculationsImpl
-
- calculateSize(HashJoinMemoryCalculator.PartitionStat, double) - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinHelperSizeCalculator
-
- calculateSize(HashJoinMemoryCalculator.PartitionStat, double) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelperSizeCalculatorImpl
-
- calculateSize(HashJoinMemoryCalculator.PartitionStat, double) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelperUnusedSizeImpl
-
- calculateSize(HashJoinMemoryCalculator.PartitionStat, Map<String, Long>, double, double, double) - Method in interface org.apache.drill.exec.physical.impl.join.HashTableSizeCalculator
-
- calculateSize(HashJoinMemoryCalculator.PartitionStat, Map<String, Long>, double, double, double) - Method in class org.apache.drill.exec.physical.impl.join.HashTableSizeCalculatorConservativeImpl
-
- calculateSize(HashJoinMemoryCalculator.PartitionStat, Map<String, Long>, double, double, double) - Method in class org.apache.drill.exec.physical.impl.join.HashTableSizeCalculatorLeanImpl
-
- calculateSize(HashJoinMemoryCalculator.PartitionStat, double) - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl.MockHashJoinHelperSizeCalculator
-
- calculateSize(HashJoinMemoryCalculator.PartitionStat, Map<String, Long>, double, double, double) - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl.MockHashTableSizeCalculator
-
- call - Variable in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- call - Variable in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- call() - Method in class org.apache.drill.exec.store.TimedCallable
-
- call() - Method in class org.apache.drill.exec.util.concurrent.ExecutorServiceUtil.CallableTaskWrapper
- CallableTaskWrapper(Callable<T>) - Constructor for class org.apache.drill.exec.util.concurrent.ExecutorServiceUtil.CallableTaskWrapper
-
CTOR.
- callBack - Variable in class org.apache.drill.exec.record.AbstractUnaryRecordBatch
-
- callBack - Variable in class org.apache.drill.test.rowSet.AbstractRowSet
-
- canAddNewData(BatchSizingMemoryUtil.ColumnMemoryUsageInfo, int, int, int) - Static method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.BatchSizingMemoryUtil
-
This method will also load detailed information about this column's current memory usage (with regard
to the value vectors).
- canBeDropped() - Method in interface org.apache.drill.exec.planner.common.OrderedRel
-
A method to return if this relational node can be dropped during optimization process.
- canBeDropped() - Method in class org.apache.drill.exec.planner.logical.DrillSortRel
-
- canBeDropped() - Method in class org.apache.drill.exec.planner.physical.SortPrel
-
- canBeDropped() - Method in class org.apache.drill.exec.planner.physical.TopNPrel
-
- cancel() - Method in class org.apache.drill.exec.physical.impl.protocol.OperatorDriver
-
Cancels the operator before reaching EOF.
- cancel() - Method in interface org.apache.drill.exec.physical.impl.protocol.OperatorExec
-
Alerts the operator that the query was cancelled.
- cancel() - Method in class org.apache.drill.exec.rpc.data.TestBitBitKerberos.MockFragmentManager
-
- cancel() - Method in class org.apache.drill.exec.rpc.data.TestBitRpc.MockFragmentManager
-
- cancel(boolean) - Method in class org.apache.drill.exec.util.concurrent.ExecutorServiceUtil.CallableTaskWrapper
-
This method will block waiting if the callbale thread is still executing and the "mayInterruptIfRunning"
flag is set; this method will return when:
The callbale thread is done executing
The current thread got interrupted; no exception will be thrown and instead the interrupted flag will
be set
- cancel() - Method in class org.apache.drill.exec.work.foreman.Foreman
-
Cancel the query (move query in cancellation requested state).
- cancel() - Method in class org.apache.drill.exec.work.foreman.QueryStateProcessor
-
Transition query to
CANCELLATION_REQUESTED
state if it is
not already in the terminal states
QueryState#CANCELED, CANCELED
,
QueryState#COMPLETED, COMPLETED
or
QueryState#FAILED, FAILED
.
- 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(boolean) - Method in class org.apache.drill.test.QueryBuilder.QuerySummaryFuture
-
Unsupported at present.
- cancelAfterAllResultsProduced() - Method in class org.apache.drill.exec.server.TestDrillbitResilience
-
- cancelAfterEverythingIsCompleted() - Method in class org.apache.drill.exec.server.TestDrillbitResilience
-
- cancelDeleteOnExit(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
-
- cancelForeman(UserBitShared.QueryId, DrillUserPrincipal) - Method in class org.apache.drill.exec.work.WorkManager.WorkerBee
-
- cancelFragment(RpcOutcomeListener<GeneralRPCProtos.Ack>, ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel
-
- cancelFragment(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.work.batch.ControlMessageHandler
-
- cancelInMiddleOfFetchingResults() - Method in class org.apache.drill.exec.server.TestDrillbitResilience
-
- cancelQuery(UserBitShared.QueryId) - Method in class org.apache.drill.exec.client.DrillClient
-
- CancelQuery(UserBitShared.QueryId) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.CancelQuery
-
- 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
-
- cancelWhenQueryIdArrives() - Method in class org.apache.drill.exec.server.TestDrillbitResilience
-
- canConvert(RelOptPlanner, DrillDistributionTrait, DrillDistributionTrait) - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTraitDef
-
- canDoFullTransfer() - Method in class org.apache.drill.exec.record.selection.SelectionVector2
-
- canDoWork(int, WindowPOP, boolean, boolean) - Method in class org.apache.drill.exec.physical.impl.window.WindowFunction
-
- canExpand(ScalarWriter, int) - Method in class org.apache.drill.exec.physical.rowSet.impl.ColumnState.PrimitiveColumnState
-
- canExpand(int) - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- 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.physical.base.SchemalessScan
-
- 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.AbstractParquetGroupScan
-
- 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.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.NullableVarDecimalColumn
-
- 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
-
- capacity() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.VarDecimalColumn
-
- cardinality - Variable in class org.apache.drill.exec.physical.rowSet.impl.ColumnState
-
Cardinality of the value itself.
- cartesianJoinPlanningException() - Static method in class org.apache.drill.exec.physical.impl.join.JoinUtils
-
Creates new exception for queries that cannot be planned due
to presence of cartesian or inequality join.
- cascadeRowCount(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple
-
- CaseInsensitivePersistentStore<V> - Class in org.apache.drill.exec.store.sys
-
Wrapper around
PersistentStore
to ensure all passed keys are converted to lower case and stored this way.
- CaseInsensitivePersistentStore(PersistentStore<V>) - Constructor for class org.apache.drill.exec.store.sys.CaseInsensitivePersistentStore
-
- caseSensitive() - Method in class org.apache.drill.exec.planner.sql.DrillParserConfig
-
- cast() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- CAST_EMPTY_STRING_TO_NULL - Static variable in class org.apache.drill.exec.ExecConstants
-
- CAST_EMPTY_STRING_TO_NULL_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
-
- CastBigIntTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
-
- CastBigIntTimeStamp() - Constructor for class org.apache.drill.exec.expr.fn.impl.CastBigIntTimeStamp
-
- CastBooleanVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleCastFunctions.CastBooleanVarChar
-
- CastDateToTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.CastDateToTime
-
- CastIntTime - Class in org.apache.drill.exec.expr.fn.impl
-
- CastIntTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.CastIntTime
-
- castSum() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- CastTimeStampToTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.CastTimeStampToTime
-
- castToBit() - Method in class org.apache.drill.exec.expr.TestLogicalExprSerDe
-
- CastUnionList() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CastUnionList
-
- CastUnionMap() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CastUnionMap
-
- CastUnionToUnion() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CastUnionToUnion
-
- CastVarCharBoolean() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleCastFunctions.CastVarCharBoolean
-
- CastVarCharVar16Char - Class in org.apache.drill.exec.expr.fn.impl
-
- CastVarCharVar16Char() - Constructor for class org.apache.drill.exec.expr.fn.impl.CastVarCharVar16Char
-
- Catalog(String, String, String) - Constructor for class org.apache.drill.exec.store.ischema.Records.Catalog
-
- 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 - 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() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- Catalogs(OptionManager) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Catalogs
-
- Catalogs() - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaTable.Catalogs
-
- catalogs(UserSession, DrillbitContext, UserProtos.GetCatalogsReq, ResponseSender) - Static method in class org.apache.drill.exec.work.metadata.MetadataProvider
-
- catalogs() - Method in class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- catalogsWithFilter() - Method in class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- catalogsWithFilterNegative() - Method in class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- CATS_COL_CATALOG_CONNECT - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- CATS_COL_CATALOG_DESCRIPTION - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- CATS_COL_CATALOG_NAME - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- cg - Variable in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
-
- cg - Variable in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
-
- cg - Variable in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate
-
- ChainedHashTable - Class in org.apache.drill.exec.physical.impl.common
-
This is a master class used to generate code for
HashTable
s.
- 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
-
- changeSessionAndNotSystem() - Method in class org.apache.drill.exec.server.TestOptions
-
- changeSessionAndSystemButRevertSession() - Method in class org.apache.drill.exec.server.TestOptions
-
- changeSystemAndNotSession() - Method in class org.apache.drill.exec.server.TestOptions
-
- changeToFinalProbeState() - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinProbe
-
- changeToFinalProbeState() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinProbeTemplate
-
- 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_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- 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
-
- charAt(int) - Method in class org.apache.drill.exec.expr.fn.impl.CharSequenceWrapper
-
- CharLength() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.CharLength
-
- 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
-
- 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
-
- 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, DrillJoin, 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.
- checkCartesianJoin(RelNode) - Static method in class org.apache.drill.exec.physical.impl.join.JoinUtils
-
Check if the given RelNode contains any Cartesian join.
- checkChangedColumn() - Method in class org.apache.drill.exec.server.TestOptions
-
- 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)
.
- checkColumnDef(BatchSchema) - Method in class org.apache.drill.test.DrillTestWrapper
-
- checkComplexExpressionParsing() - Method in class org.apache.drill.exec.sql.TestSqlBracketlessSyntax
-
- checkDecimalTypeEnabled(OptionManager) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
-
- checkDrillbits() - Method in class org.apache.drill.exec.server.TestDrillbitResilience
-
- checkedInjection() - Method in class org.apache.drill.exec.testing.TestExceptionInjection
-
- checkFlags() - Method in class org.apache.drill.exec.store.pcap.TestPcapRecordReader
-
- 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.
- checkForEarlyFinish(RecordBatch.IterOutcome, RecordBatch.IterOutcome) - Method in class org.apache.drill.exec.record.AbstractBinaryRecordBatch
-
Checks for the operator specific early terminal condition.
- checkForNewPartition(int) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
-
- 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)
.
- checkNullHandling(FunctionTemplate.NullHandling) - Method in class org.apache.drill.exec.expr.fn.DrillComplexWriterFuncHolder
-
- checkNullHandling(FunctionTemplate.NullHandling) - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
-
Check if function type supports provided null handling strategy.
- 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.DrillCalciteSqlBetweenOperatorWrapper
-
Since Calcite has its rule for type compatibility
(see SqlTypeUtil.isComparable(org.apache.calcite.rel.type.RelDataType,
org.apache.calcite.rel.type.RelDataType)
), which is usually different from Drill's, this method is overridden here to avoid
Calcite early terminating the queries.
- 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(DrillJoin, RelNode, RelNode, PlannerSettings) - Method in class org.apache.drill.exec.planner.physical.JoinPruleBase
-
- checkPreconditions(DrillJoin, RelNode, RelNode, PlannerSettings) - Method in class org.apache.drill.exec.planner.physical.NestedLoopJoinPrule
-
- checkReadWriteExtended() - Method in class org.apache.drill.exec.vector.complex.writer.TestExtendedTypes
-
- checkRowKey(List<SchemaPath>) - Method in class org.apache.drill.exec.planner.index.generators.AbstractIndexPlanGenerator
-
- checkScan(DrillScanRel) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
check if we want to apply index rules on this scan,
if group scan is not instance of DbGroupScan, or this DbGroupScan instance does not support secondary index, or
this scan is already an index scan or Restricted Scan, do not apply index plan rules on it.
- checkScan(DrillScanRel) - Method in class org.apache.drill.exec.planner.index.rules.AbstractMatchFunction
-
- checkScan(GroupScan) - Method in class org.apache.drill.exec.planner.index.rules.AbstractMatchFunction
-
- checkSimpleExchangePlan() - Method in class org.apache.drill.exec.pop.TestFragmentChecker
-
- 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
-
- checkValidationException() - Method in class org.apache.drill.exec.server.TestOptions
-
- 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
-
- childCache(String) - Method in class org.apache.drill.exec.physical.rowSet.impl.NullResultVectorCacheImpl
-
- childCache(String) - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultVectorCacheImpl
-
- childCache(String) - Method in interface org.apache.drill.exec.physical.rowSet.ResultVectorCache
-
- childEvent(CuratorFramework, PathChildrenCacheEvent) - Method in class org.apache.drill.exec.coord.zk.EventDispatcher
-
- childProvider(ColumnMetadata) - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.ArraySchemaCreator
-
- childProvider(ColumnMetadata) - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.ArraySchemaRetrieval
-
- childProvider(ColumnMetadata) - Method in interface org.apache.drill.exec.physical.rowSet.model.MetadataProvider
-
- childProvider(ColumnMetadata) - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.MetadataCreator
-
- childProvider(ColumnMetadata) - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.MetadataRetrieval
-
- childProvider(ColumnMetadata) - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.VariantSchemaCreator
-
- childProvider(ColumnMetadata) - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.VariantSchemaRetrieval
-
- childProvider() - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.VectorDescrip
-
- children - Variable in class org.apache.drill.exec.physical.base.AbstractMultiple
-
- children - Variable in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple
-
- children - Variable in class org.apache.drill.test.ProfileParser.OperatorSummary
-
- childSchema() - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- childSchema(ColumnMetadata) - Method in class org.apache.drill.exec.record.metadata.RepeatedListColumnMetadata
-
- childSchema() - Method in class org.apache.drill.exec.record.metadata.RepeatedListColumnMetadata
-
- ChildVerifier(TypeProtos.MajorType...) - Constructor for class org.apache.drill.exec.record.vector.TestValueVector.ChildVerifier
-
- 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
-
- ClassFinder() - Constructor for class org.apache.drill.exec.expr.fn.MethodGrabbingVisitor.ClassFinder
-
- 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.
- ClassicTestServices() - Constructor for class org.apache.drill.test.BaseTestQuery.ClassicTestServices
-
Deprecated.
- ClassNames(String) - Constructor for class org.apache.drill.exec.compile.ClassTransformer.ClassNames
-
- ClassPathFileSystem - Class in org.apache.drill.exec.store
-
- ClassPathFileSystem() - Constructor for class org.apache.drill.exec.store.ClassPathFileSystem
-
- classpathScan - Variable in class org.apache.drill.test.PhysicalOpUnitTestBase
-
- ClassSet(ClassTransformer.ClassSet, String, String) - Constructor for class org.apache.drill.exec.compile.ClassTransformer.ClassSet
-
- classSetup() - Static method in class org.apache.drill.test.SubOperatorTest
-
- classTeardown() - Static method in class org.apache.drill.test.SubOperatorTest
-
- 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.ClassSet - Class in org.apache.drill.exec.compile
-
- 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
-
- cleanTest() - Static method in class org.apache.drill.exec.rpc.data.TestBitBitKerberos
-
- cleanTest() - Static method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberos
-
- cleanTest() - Static method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberosEncryption
-
- cleanTest() - Static method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSL
-
- cleanTest() - Static method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSLServer
-
- cleanTest() - Static method in class org.apache.drill.exec.server.rest.spnego.TestDrillSpnegoAuthenticator
-
- cleanTest() - Static method in class org.apache.drill.exec.server.rest.spnego.TestSpnegoAuthentication
-
- cleanTest() - Static method in class org.apache.drill.exec.server.rest.spnego.TestSpnegoConfig
-
- cleanup() - Method in class org.apache.drill.exec.expr.fn.impl.TestSqlPatterns
-
- 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 class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate.HashAggUpdater
-
- 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(boolean) - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
Free all in-memory allocated structures.
- cleanup() - Method in interface org.apache.drill.exec.physical.impl.common.SpilledState.Updater
-
Does any necessary cleanup if we've spilled too much and abort the query.
- cleanup() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch.HashJoinUpdater
-
- 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.bson.TestBsonRecordReader
-
- cleanup() - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter
-
- cleanUp() - Static method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- cleanup() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
-
- cleanup() - Static method in class org.apache.drill.exec.store.parquet2.TestDrillParquetReader
-
- 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 class org.apache.drill.exec.store.text.DrillTextRecordWriter
-
- cleanup() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- cleanup() - Method in class org.apache.drill.SingleRowListener
-
Clean up any resources used.
- 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.ExecTest
-
- 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
-
Frees all the direct memory consumed by the
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.BuildInfo
-
- clear() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelper
-
- clear() - Method in interface org.apache.drill.exec.physical.impl.OutputMutator
-
Clear this mutator i.e.
- 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.scan.project.TestRowBatchMerger.RowSetSource
-
- 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.store.TestOutputMutator
-
- clear() - Method in class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
-
- clear() - Method in class org.apache.drill.test.BaseDirTestWatcher
-
Clear contents of cluster directories
- clear() - Method in class org.apache.drill.test.rowSet.AbstractRowSet
-
- clear() - Method in class org.apache.drill.test.rowSet.HyperRowSetImpl
-
- clear() - Method in class org.apache.drill.test.rowSet.IndirectRowSet
-
- clear() - Method in interface org.apache.drill.test.rowSet.RowSet
-
- clearAll() - Method in class org.apache.drill.exec.planner.index.AbstractIndexCollection
-
- clearAll() - Method in interface org.apache.drill.exec.planner.index.IndexCollection
-
Clears all entries from this index collection
- clearControls(DrillClient) - Static method in class org.apache.drill.exec.testing.ControlsInjectionUtil
-
Clears all the controls.
- clearInflightBatches() - Method in class org.apache.drill.exec.record.RecordIterator
-
- clearStatus(String) - Method in class org.apache.drill.exec.store.dfs.MetadataContext
-
- Client(BufferAllocator, OutOfMemoryHandler) - Constructor for class org.apache.drill.exec.rpc.data.DataProtobufLengthDecoder.Client
-
- client - Variable in class org.apache.drill.exec.store.sys.BitToUserConnectionIterator.ConnectionInfo
-
- client - Static variable in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- client() - Method in class org.apache.drill.test.ClientFixture
-
- client(String, int) - Method in class org.apache.drill.test.ClusterFixture
-
Create a test client for a specific host and port.
- client() - Method in class org.apache.drill.test.ClusterFixture
-
- client - Static variable in class org.apache.drill.test.ClusterTest
-
- CLIENT_PRINCIPAL - Variable in class org.apache.drill.exec.rpc.security.KerberosHelper
-
- CLIENT_RPC_THREADS - Static variable in class org.apache.drill.exec.ExecConstants
-
- CLIENT_SHORT_NAME - Variable in class org.apache.drill.exec.rpc.security.KerberosHelper
-
- CLIENT_SUPPORT_COMPLEX_TYPES - Static variable in class org.apache.drill.exec.ExecConstants
-
- ClientAuthenticatorProvider - Class in org.apache.drill.exec.rpc.security
-
- ClientBuilder(ClusterFixture) - Constructor for class org.apache.drill.test.ClientFixture.ClientBuilder
-
- clientBuilder() - Method in class org.apache.drill.test.ClusterFixture
-
- ClientFixture - Class in org.apache.drill.test
-
Represents a Drill client.
- ClientFixture(ClientFixture.ClientBuilder) - Constructor for class org.apache.drill.test.ClientFixture
-
- clientFixture() - Method in class org.apache.drill.test.ClusterFixture
-
- ClientFixture.ClientBuilder - Class in org.apache.drill.test
-
- ClientFixture.StatementParser - Class in org.apache.drill.test
-
Very simple parser for semi-colon separated lists of SQL statements which
handles quoted semicolons.
- clientKeytab - Variable in class org.apache.drill.exec.rpc.security.KerberosHelper
-
- clientNeedsEncryptionWithNoServerSupport() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberosEncryption
-
Test to validate that clients which needs encrypted connection fails to connect
to server with encryption disabled.
- clientNeedsEncryptionWithServerSupport() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberosEncryption
-
Test to validate that clients which needs encrypted connection connects
to server with encryption enabled.
- clientProps - Variable in class org.apache.drill.test.ClusterFixtureBuilder
-
- clients - Variable in class org.apache.drill.test.ClusterFixture
-
- 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(List<SchemaPath>) - Method in class org.apache.drill.exec.physical.base.SchemalessScan
-
- clone() - Method in class org.apache.drill.exec.planner.logical.ScanFieldDeterminer.FieldList
-
- clone() - Method in class org.apache.drill.exec.planner.physical.DirectScanPrel
-
- 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.Metadata_V1.ParquetTableMetadata_v1
-
- clone() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetTableMetadata_v2
-
- clone() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetTableMetadata_v3
-
- clone() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.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(List<SchemaPath>) - Method in class org.apache.drill.exec.store.sys.SystemTableScan
-
- clone(SystemTableScan, int) - 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
-
- cloneDefaultTestConfigProperties() - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- cloneEmpty() - Method in class org.apache.drill.exec.record.metadata.MapColumnMetadata
-
- cloneEmpty() - Method in class org.apache.drill.exec.record.metadata.PrimitiveColumnMetadata
-
- cloneEmpty() - Method in class org.apache.drill.exec.record.metadata.RepeatedListColumnMetadata
-
- cloneEmpty() - Method in class org.apache.drill.exec.record.metadata.VariantColumnMetadata
-
- cloneEmpty() - Method in class org.apache.drill.exec.record.metadata.VariantSchema
-
- CloneOutputWidthCalculator() - Constructor for class org.apache.drill.exec.expr.fn.output.OutputWidthCalculators.CloneOutputWidthCalculator
-
- 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
-
- cloneWithFileSelection(Collection<String>) - Method in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- cloneWithFileSelection(Collection<String>) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
-
- cloneWithRemainder(PathSegment) - Method in class org.apache.drill.exec.record.TypedFieldId
-
- close() - Method in class org.apache.drill.exec.cache.VectorSerializer.Writer
-
- 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
-
- 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 interface org.apache.drill.exec.ops.FragmentContext
-
- close() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- 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.common.HashPartition
-
- close() - Method in class org.apache.drill.exec.physical.impl.filter.FilterRecordBatch
-
- close() - Method in class org.apache.drill.exec.physical.impl.filter.RuntimeFilterRecordBatch
-
- close() - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenRecordBatch
-
- close() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
-
- close() - Method in class org.apache.drill.exec.physical.impl.join.LateralJoinBatch
-
- 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.join.RowKeyJoinBatch
-
- close() - Method in class org.apache.drill.exec.physical.impl.limit.LimitRecordBatch
-
- close() - Method in class org.apache.drill.exec.physical.impl.limit.PartitionLimitRecordBatch
-
- close() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
-
- close() - Method in class org.apache.drill.exec.physical.impl.MockRecordBatch
-
- 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.protocol.OperatorDriver
-
- close() - Method in interface org.apache.drill.exec.physical.impl.protocol.OperatorExec
-
Close the operator by releasing all resources that the operator
held.
- close() - Method in class org.apache.drill.exec.physical.impl.protocol.OperatorRecordBatch
-
- close() - Method in class org.apache.drill.exec.physical.impl.rangepartitioner.RangePartitionRecordBatch
-
- close() - Method in interface org.apache.drill.exec.physical.impl.scan.project.MetadataManager
-
Event indicating the end of a scan.
- close() - Method in class org.apache.drill.exec.physical.impl.scan.project.NoOpMetadataManager
-
- close() - Method in class org.apache.drill.exec.physical.impl.scan.project.NullColumnBuilder
-
- close() - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple
-
- close() - Method in class org.apache.drill.exec.physical.impl.scan.project.ScanSchemaOrchestrator
-
- close() - Method in class org.apache.drill.exec.physical.impl.scan.project.ScanSchemaOrchestrator.ReaderSchemaOrchestrator
-
- close() - Method in class org.apache.drill.exec.physical.impl.scan.project.StaticColumnLoader
-
- 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.SimpleRootExec
-
Deprecated.
- 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(VectorSerializer.Writer) - 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.union.UnionAllRecordBatch
-
- close() - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- close() - Method in interface org.apache.drill.exec.physical.impl.unnest.Unnest
-
- close() - Method in class org.apache.drill.exec.physical.impl.unnest.UnnestImpl
-
- close() - Method in class org.apache.drill.exec.physical.impl.unnest.UnnestRecordBatch
-
- 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.physical.rowSet.impl.ColumnState.BaseContainerColumnState
-
- close() - Method in class org.apache.drill.exec.physical.rowSet.impl.ColumnState
-
- close() - Method in class org.apache.drill.exec.physical.rowSet.impl.ContainerState
-
Clean up state (such as backup vectors) associated with the state
for each vector.
- close() - Method in class org.apache.drill.exec.physical.rowSet.impl.ListState.ListVectorState
-
- close() - Method in class org.apache.drill.exec.physical.rowSet.impl.NullableVectorState
-
- close() - Method in class org.apache.drill.exec.physical.rowSet.impl.NullVectorState
-
- close() - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedListState.RepeatedListVectorState
-
- close() - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedVectorState
-
- close() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- close() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultVectorCacheImpl
-
- close() - Method in class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState
-
- close() - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState.MapVectorState
-
- close() - Method in class org.apache.drill.exec.physical.rowSet.impl.UnionState.UnionVectorState
-
- close() - Method in interface org.apache.drill.exec.physical.rowSet.impl.VectorState
-
Clear the vector(s) associated with this state.
- close() - Method in interface org.apache.drill.exec.physical.rowSet.ResultSetLoader
-
Called after all rows are returned, whether because no more data is
available, or the caller wishes to cancel the current row batch
and complete.
- close() - Method in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor.RelDataTypeReader
-
- 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.SchemalessBatch
-
- 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 class org.apache.drill.exec.rpc.user.security.testing.UserAuthenticatorTestImpl
-
- 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.avro.AvroTestUtil.AvroTestRecordWriter
-
- close() - Method in class org.apache.drill.exec.store.CachedSingleFileSystem
-
- 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.image.ImageRecordReader
-
- close() - Method in class org.apache.drill.exec.store.log.LogRecordReader
-
- 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.batchsizing.RecordBatchSizerManager
-
Closes all resources managed by this object
- 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.pcapng.PcapngRecordReader
-
- 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.CaseInsensitivePersistentStore
-
- 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.UndefinedVersionDelegatingStore
-
- close() - Method in class org.apache.drill.exec.store.sys.store.VersionedDelegatingStore
-
- 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 interface org.apache.drill.exec.work.batch.DataCollector
-
- 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.filter.RuntimeFilterSink
-
- close() - Method in class org.apache.drill.exec.work.filter.RuntimeFilterWritable
-
- close() - Method in class org.apache.drill.exec.work.foreman.Foreman.ForemanResult
-
- close() - Method in class org.apache.drill.exec.work.foreman.QueryManager
-
- close() - Method in class org.apache.drill.exec.work.foreman.QueryStateProcessor
-
On close set proper increment / decrement counters depending on final query state.
- 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.drill.test.ClientFixture
-
- close() - Method in class org.apache.drill.test.ClusterFixture
-
Close the clients, Drillbits, allocator and
Zookeeper.
- close() - Method in class org.apache.drill.test.LogFixture
-
- close() - Method in class org.apache.drill.test.OperatorFixture
-
- close() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- close() - Method in class org.apache.drill.test.QueryResultSet
-
- close() - Method in class org.apache.drill.test.RestClientFixture
-
- 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
-
- closeClient() - Static method in class org.apache.drill.exec.testing.TestResourceLeak
-
- closeClient() - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- closeDrillbit(String) - Method in class org.apache.drill.test.ClusterFixture
-
Shutdown the drillbit given the name of the drillbit.
- closeOperator() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
- closeOutputStream() - Method in class org.apache.drill.exec.physical.impl.xsort.BatchGroup
-
- closeReader() - Method in class org.apache.drill.exec.physical.impl.scan.project.ScanSchemaOrchestrator
-
- closeSSL() - Method in class org.apache.drill.exec.rpc.user.UserServer
-
- closeWriter() - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
Close the writer without deleting the spill file
- closeWriter() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.SpilledRun
-
- cluster() - Method in class org.apache.drill.test.ClientFixture
-
- cluster - Static variable in class org.apache.drill.test.ClusterTest
-
- 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
-
- ClusterFixture - Class in org.apache.drill.test
-
Test fixture to start a Drillbit with provide options, create a client, and
execute queries.
- ClusterFixture.FixtureTestServices - Class in org.apache.drill.test
-
Shim class to allow the
TestBuilder
class to work with the
cluster fixture.
- ClusterFixtureBuilder - Class in org.apache.drill.test
-
Build a Drillbit and client with the options provided.
- ClusterFixtureBuilder(BaseDirTestWatcher) - Constructor for class org.apache.drill.test.ClusterFixtureBuilder
-
- ClusterFixtureBuilder.RuntimeOption - Class in org.apache.drill.test
-
- ClusterInfo(Collection<DrillRoot.DrillbitInfo>, String, Collection<String>, boolean, boolean, boolean, DrillRoot.QueueInfo, boolean) - Constructor for class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
-
- ClusterInfo(Collection<DrillRoot.DrillbitInfo>, String, Collection<String>, boolean, boolean, boolean, DrillRoot.QueueInfo, String, String, String, String, boolean) - Constructor for class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
-
- ClusterMockStorageFixture - Class in org.apache.drill.test
-
- clusterSize(int) - Method in class org.apache.drill.test.ClusterFixtureBuilder
-
The number of Drillbits to start in the cluster.
- ClusterTest - Class in org.apache.drill.test
-
Base class for tests that use a single cluster fixture for a set of
tests.
- ClusterTest() - Constructor for class org.apache.drill.test.ClusterTest
-
- coalesce() - Method in class org.apache.drill.exec.work.prepare.TestLimit0VsRegularQueriesMetadata
-
- 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.
- CodeCompilerTestFactory - Class in org.apache.drill.exec.compile
-
- CodeCompilerTestFactory() - Constructor for class org.apache.drill.exec.compile.CodeCompilerTestFactory
-
- 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
-
- CodeGenMemberInjector - Class in org.apache.drill.exec.physical.impl.common
-
- CodeGenMemberInjector() - Constructor for class org.apache.drill.exec.physical.impl.common.CodeGenMemberInjector
-
- 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
-
- collation - Variable in class org.apache.drill.exec.planner.physical.TopNPrel
-
- CollationContext - Class in org.apache.drill.exec.planner.index
-
- CollationContext(Map<LogicalExpression, RelFieldCollation>, List<RelFieldCollation>) - Constructor for class org.apache.drill.exec.planner.index.CollationContext
-
- collationMap - Variable in class org.apache.drill.exec.planner.index.CollationContext
-
- collect(List<RowGroupInfo>, MetadataBase.ParquetTableMetadataBase) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScanStatistics
-
- 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
-
- collectRuntimeFilterParallelAndControlInfo() - Method in class org.apache.drill.exec.work.filter.RuntimeFilterRouter
-
This method is to collect the parallel information of the RuntimetimeFilters.
- COLS_COL_CHARACTER_MAXIMUM_LENGTH - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- COLS_COL_CHARACTER_OCTET_LENGTH - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- COLS_COL_COLUMN_DEFAULT - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- COLS_COL_COLUMN_NAME - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- COLS_COL_DATA_TYPE - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- COLS_COL_DATETIME_PRECISION - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- COLS_COL_INTERVAL_PRECISION - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- COLS_COL_INTERVAL_TYPE - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- COLS_COL_IS_NULLABLE - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- COLS_COL_NUMERIC_PRECISION - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- COLS_COL_NUMERIC_PRECISION_RADIX - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- COLS_COL_NUMERIC_SCALE - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- COLS_COL_ORDINAL_POSITION - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- column(int) - Method in class org.apache.drill.exec.physical.rowSet.model.BaseTupleModel
-
- column(String) - Method in class org.apache.drill.exec.physical.rowSet.model.BaseTupleModel
-
- column(int) - Method in interface org.apache.drill.exec.physical.rowSet.model.TupleModel
-
- column(String) - Method in interface org.apache.drill.exec.physical.rowSet.model.TupleModel
-
- column(String) - Method in class org.apache.drill.exec.record.metadata.TupleSchema
-
- column(int) - Method in class org.apache.drill.exec.record.metadata.TupleSchema
-
- Column(String, String, String, RelDataTypeField) - Constructor for class org.apache.drill.exec.store.ischema.Records.Column
-
- Column - Interface in org.apache.drill.exec.store.pcapng.schema
-
- COLUMN_DEFAULT - Variable in class org.apache.drill.exec.store.ischema.Records.Column
-
- 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
-
- ColumnBuilder - Class in org.apache.drill.exec.physical.rowSet.impl
-
Algorithms for building a column given a metadata description of the column and
the parent context that will hold the column.
- ColumnBuilder - Class in org.apache.drill.test.rowSet.schema
-
Build a column schema (AKA "materialized field") based on name and a
variety of schema options.
- ColumnBuilder(String, TypeProtos.MinorType) - Constructor for class org.apache.drill.test.rowSet.schema.ColumnBuilder
-
- ColumnChunkIncPageReader(ColumnChunkMetaData, ColumnDescriptor, FSDataInputStream) - Constructor for class org.apache.parquet.hadoop.ColumnChunkIncReadStore.ColumnChunkIncPageReader
-
- 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
-
- 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
-
- 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(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.
- ColumnMemoryQuota() - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager.ColumnMemoryQuota
-
- ColumnMemoryQuota(int) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager.ColumnMemoryQuota
-
- ColumnMemoryUsageInfo() - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.BatchSizingMemoryUtil.ColumnMemoryUsageInfo
-
- ColumnMetadata() - Constructor for class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ColumnMetadata
-
- ColumnMetadata_v1() - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ColumnMetadata_v1
-
- ColumnMetadata_v1(SchemaPath, PrimitiveType.PrimitiveTypeName, OriginalType, Object, Object, Long) - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ColumnMetadata_v1
-
- ColumnMetadata_v2() - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnMetadata_v2
-
- ColumnMetadata_v2(String[], PrimitiveType.PrimitiveTypeName, Object, Long) - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnMetadata_v2
-
- ColumnMetadata_v3() - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnMetadata_v3
-
- ColumnMetadata_v3(String[], PrimitiveType.PrimitiveTypeName, Object, Object, Long) - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnMetadata_v3
-
- columnNames - Variable in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor.RelDataTypeReader
-
- ColumnProjection - Interface in org.apache.drill.exec.physical.impl.scan.project
-
Core interface for a projected column.
- ColumnReader<V extends ValueVector> - Class in org.apache.drill.exec.store.parquet.columnreaders
-
- ColumnReader(ParquetRecordReader, 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.scan.project.ConstantColumnLoader
-
- columns() - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple
-
- columns() - Method in class org.apache.drill.exec.physical.impl.scan.project.ScanLevelProjection
-
The entire set of output columns, in output order.
- columns - Variable in class org.apache.drill.exec.physical.rowSet.impl.TupleState
-
The set of columns added via the writers: includes both projected
and unprojected columns.
- columns() - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState
-
Returns an ordered set of the columns which make up the tuple.
- columns - Variable in class org.apache.drill.exec.physical.rowSet.model.BaseTupleModel
-
Columns within the tuple.
- columns() - Method in class org.apache.drill.exec.record.RecordBatchSizer
-
- columns - Variable in class org.apache.drill.exec.server.rest.QueryWrapper.QueryResult
-
- columns - Variable in class org.apache.drill.exec.server.rest.WebUserConnection
-
- Columns(OptionManager) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Columns
-
- Columns() - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaTable.Columns
-
- columns - Variable in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- columns - Variable in class org.apache.drill.exec.store.parquet.AbstractParquetRowGroupScan
-
- columns - Variable in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.RowGroupMetadata_v1
-
- columns - Variable in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.RowGroupMetadata_v2
-
- columns - Variable in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.RowGroupMetadata_v3
-
- columns(UserSession, DrillbitContext, UserProtos.GetColumnsReq, ResponseSender) - Static method in class org.apache.drill.exec.work.metadata.MetadataProvider
-
- columns() - Method in class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- columns - Variable in class org.apache.drill.test.ProfileParser.OperatorSummary
-
- columnSchema(String, TypeProtos.MinorType, TypeProtos.DataMode) - Static method in class org.apache.drill.test.rowSet.schema.SchemaBuilder
-
Create a column schema using the "basic three" properties of name, type and
cardinality (AKA "data mode.") Use the
ColumnBuilder
for to set
other schema attributes.
- columnsInIndexFields(Collection<LogicalExpression>, Collection<LogicalExpression>) - Method in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- ColumnSize(ValueVector, String) - Constructor for class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
- columnsList() - Method in class org.apache.drill.exec.record.RecordBatchSizer
-
This is a convenience method to get the sizes of columns in the same order that the corresponding value vectors
are stored within a
VectorAccessible
.
- ColumnStatCollector - Interface in org.apache.drill.exec.store.parquet.stat
-
- ColumnState - Class in org.apache.drill.exec.physical.rowSet.impl
-
Represents the write-time state for a column including the writer and the (optional)
backing vector.
- ColumnState(LoaderInternals, AbstractObjectWriter, VectorState) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.ColumnState
-
- ColumnState.BaseContainerColumnState - Class in org.apache.drill.exec.physical.rowSet.impl
-
- ColumnState.PrimitiveColumnState - Class in org.apache.drill.exec.physical.rowSet.impl
-
Primitive (non-map) column state.
- ColumnState.State - Enum in org.apache.drill.exec.physical.rowSet.impl
-
Columns move through various lifecycle states as identified by this
enum.
- columnStates() - Method in class org.apache.drill.exec.physical.rowSet.impl.ContainerState
-
- columnStates() - Method in class org.apache.drill.exec.physical.rowSet.impl.ListState
-
- columnStates() - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedListState
-
- columnStates() - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState
-
- columnStates() - Method in class org.apache.drill.exec.physical.rowSet.impl.UnionState
-
- ColumnStatistics<T extends Comparable<T>> - Class in org.apache.drill.exec.store.parquet.stat
-
- ColumnStatistics(Statistics<T>, TypeProtos.MajorType) - Constructor for class org.apache.drill.exec.store.parquet.stat.ColumnStatistics
-
- columnsToRead(SchemaPath...) - Method in class org.apache.drill.exec.physical.unit.MiniPlanUnitTestBase.ScanPopBuider
-
- columnsToRead(String...) - Method in class org.apache.drill.exec.physical.unit.MiniPlanUnitTestBase.ScanPopBuider
-
- columnsWithAllSupportedFilters() - Method in class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- columnsWithColumnNameFilter() - Method in class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- columnsWithColumnNameFilterAndTableNameFilter() - Method in class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- columnTypeInfo - Variable in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetTableMetadata_v2
-
- columnTypeInfo - Variable in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetTableMetadata_v3
-
- ColumnTypeMetadata_v2() - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnTypeMetadata_v2
-
- ColumnTypeMetadata_v2(String[], PrimitiveType.PrimitiveTypeName, OriginalType) - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnTypeMetadata_v2
-
- ColumnTypeMetadata_v3() - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnTypeMetadata_v3
-
- ColumnTypeMetadata_v3(String[], PrimitiveType.PrimitiveTypeName, OriginalType, int, int, int, int) - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnTypeMetadata_v3
-
- columnTypes - Variable in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor.RelDataTypeReader
-
- combineOrderedTestFail() - Method in class org.apache.drill.test.OperatorTestBuilderTest
-
- combineOrderedTestPass() - Method in class org.apache.drill.test.OperatorTestBuilderTest
-
- combineOutputBatches() - Method in class org.apache.drill.test.OperatorTestBuilder
-
Combines all the batches output by the operator into a single batch for comparison.
- combineUnorderedTestFail() - Method in class org.apache.drill.test.OperatorTestBuilderTest
-
- combineUnorderedTestPass() - Method in class org.apache.drill.test.OperatorTestBuilderTest
-
- comment - Variable in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
-
- 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
-
- 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(IndexGroup, IndexGroup) - Method in class org.apache.drill.exec.planner.index.IndexSelector.IndexComparator
-
- compare(Object, Object) - Method in class org.apache.drill.test.rowSet.RowSetComparison.ObjectComparator
-
- 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
-
- compareMergedOnHeapVectors() - Method in class org.apache.drill.test.DrillTestWrapper
-
- compareMergedVectors(Map<String, List<Object>>, Map<String, List<Object>>) - Static method in class org.apache.drill.test.DrillTestWrapper
-
- compareOrderedResults() - Method in class org.apache.drill.test.DrillTestWrapper
-
Use this method only if necessary to validate one query against another.
- compareParquetReadersColumnar(String, String) - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- compareParquetReadersHyperVector(String, String) - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- comparePartitionStat(HashJoinMemoryCalculator.PartitionStat, boolean, long, int, long) - Static method in class org.apache.drill.exec.physical.impl.join.TestPartitionStat
-
- comparePerfs() - Method in class org.apache.drill.exec.compile.TestClassCompilationTypes
-
- compareResultsHyperVector() - Method in class org.apache.drill.test.DrillTestWrapper
-
- compareSchemaOnly() - Method in class org.apache.drill.test.DrillTestWrapper
-
- 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.metadata.MetadataVersion
-
- compareTo(CompleteWork) - Method in class org.apache.drill.exec.store.parquet.RowGroupInfo
-
- compareTo(CompleteWork) - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork
-
- CompareType() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.CompareType
-
- compareTypes(TypeProtos.MinorType, TypeProtos.MinorType) - Static method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions
-
- compareUnorderedResults() - Method in class org.apache.drill.test.DrillTestWrapper
-
Use this method only if necessary to validate one query against another.
- CompareUntypedNull - Class in org.apache.drill.exec.expr.fn.impl
-
- CompareUntypedNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.CompareUntypedNull
-
- CompareUntypedNull.CompareUntypedNullHigh - Class in org.apache.drill.exec.expr.fn.impl
-
- CompareUntypedNull.CompareUntypedNullLow - Class in org.apache.drill.exec.expr.fn.impl
-
- CompareUntypedNullHigh() - Constructor for class org.apache.drill.exec.expr.fn.impl.CompareUntypedNull.CompareUntypedNullHigh
-
- CompareUntypedNullLow() - Constructor for class org.apache.drill.exec.expr.fn.impl.CompareUntypedNull.CompareUntypedNullLow
-
- compareValues(Object, Object, int, String) - Static method in class org.apache.drill.test.DrillTestWrapper
-
- compareValuesErrorOnMismatch(Object, Object, int, String) - Static method in class org.apache.drill.test.DrillTestWrapper
-
- 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
-
- completeAnInnerBatch(boolean, boolean) - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- completeAnOuterBatch(boolean) - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- completed(QueryBuilder.QuerySummary) - Method in class org.apache.drill.test.QueryBuilder.QuerySummaryFuture
-
- 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
-
- completeLocalOutput(Path, Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
-
- completeSchemaRef1() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- CompleteWork - Interface in org.apache.drill.exec.store.schedule
-
Container that holds a complete work unit.
- complex1CTAS() - Method in class org.apache.drill.exec.physical.impl.writer.TestWriter
-
- complex2CTAS() - Method in class org.apache.drill.exec.physical.impl.writer.TestWriter
-
- COMPLEX_FIELD_ESTIMATE - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- complexNullableSchema - Static variable in class org.apache.drill.exec.store.parquet.ParquetSimpleTestFileGenerator
-
- complexNullableSchemaMsg - Static variable in class org.apache.drill.exec.store.parquet.ParquetSimpleTestFileGenerator
-
- complexSchema - Static variable in class org.apache.drill.exec.store.parquet.ParquetSimpleTestFileGenerator
-
- complexSchemaMsg - Static variable in class org.apache.drill.exec.store.parquet.ParquetSimpleTestFileGenerator
-
- ComplexStringFieldConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.text.DrillTextRecordWriter.ComplexStringFieldConverter
-
- 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
-
- ComplexUnnestVisitor - Class in org.apache.drill.exec.planner.sql.handlers
-
Visitor that moves non-RexFieldAccess
rex node from project below Uncollect
to the left side of the Correlate
.
- CompliantTextRecordReader - Class in org.apache.drill.exec.store.easy.text.compliant
-
- CompliantTextRecordReader(FileSplit, DrillFileSystem, TextParsingSettings, List<SchemaPath>) - Constructor for class org.apache.drill.exec.store.easy.text.compliant.CompliantTextRecordReader
-
- 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
-
- computeDuration(long, long) - Method in class org.apache.drill.exec.store.sys.ProfileIterator
-
- computeFixedLengthVectorMemory(ParquetColumnMetadata, int) - Static method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.BatchSizingMemoryUtil
-
- 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
-
- computeHashJoinCostWithRowCntKeySize(RelOptPlanner, double, double, int) - Static 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
-
- computeMaxBatchSize(long, int, int, double, double, boolean) - Static method in class org.apache.drill.exec.physical.impl.join.BatchSizePredictorImpl
-
- computeMaxBatchSizeNoHash(long, int, int, double, double) - Static method in class org.apache.drill.exec.physical.impl.join.BatchSizePredictorImpl
-
- computeMaxVectorSize(Map<String, Long>, long, double) - Static method in class org.apache.drill.exec.physical.impl.join.HashTableSizeCalculatorLeanImpl
-
- 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.
- computeOutputRowCount(int, int) - Static method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- computePartitionBatchSize(long, int, int) - Static method in class org.apache.drill.exec.physical.impl.join.BatchSizePredictorImpl
-
- computeProbeRecordsPerBatch(long, int, int, int, long, long, long) - Static method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.PostBuildCalculationsImpl
-
- computeQueryMemory(DrillConfig, OptionSet, long) - Static method in class org.apache.drill.exec.util.MemoryAllocationUtilities
-
Per-node memory calculations based on a number of constraints.
- computeScalePrecision(int, int, int, int) - Method in class org.apache.drill.exec.planner.types.decimal.DecimalScalePrecisionAddFunction
-
- computeScalePrecision(int, int, int, int) - Method in class org.apache.drill.exec.planner.types.decimal.DecimalScalePrecisionDivideFunction
-
- computeScalePrecision(int, int, int, int) - Method in class org.apache.drill.exec.planner.types.decimal.DecimalScalePrecisionModFunction
-
- computeScalePrecision(int, int, int, int) - Method in class org.apache.drill.exec.planner.types.decimal.DecimalScalePrecisionMulFunction
-
- computeScalePrecision(int, int, int, int) - Method in class org.apache.drill.exec.planner.types.decimal.DrillBaseComputeScalePrecision
-
- 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.DrillLateralJoinRelBase
-
- 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.common.DrillUnnestRelBase
-
- 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.DirectScanPrel
-
- 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.RangePartitionExchangePrel
-
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.drill.exec.planner.physical.RowKeyJoinPrel
-
- 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.
- computeValueVectorSize(long, long) - Static method in class org.apache.drill.exec.physical.impl.join.BatchSizePredictorImpl
-
- computeValueVectorSize(long, long, double) - Static method in class org.apache.drill.exec.physical.impl.join.BatchSizePredictorImpl
-
- computeVariableLengthVectorMemory(ParquetColumnMetadata, int, int) - Static method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.BatchSizingMemoryUtil
-
- computeVectorSizes(Map<String, Long>, long, double) - Static method in class org.apache.drill.exec.physical.impl.join.HashTableSizeCalculatorConservativeImpl
-
- computeVectorSizes(Map<String, Long>, long, double) - Static method in class org.apache.drill.exec.physical.impl.join.HashTableSizeCalculatorLeanImpl
-
- Concat() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Concat
-
- concat() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- concat(Path, Path[]) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
-
- concat() - Method in class org.apache.drill.exec.work.prepare.TestLimit0VsRegularQueriesMetadata
-
- ConcatBothNullInput() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatBothNullInput
-
- ConcatLeftNullInput() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatLeftNullInput
-
- concatOp() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- ConcatOperator() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatOperator
-
- ConcatOutputWidthCalculator() - Constructor for class org.apache.drill.exec.expr.fn.output.OutputWidthCalculators.ConcatOutputWidthCalculator
-
- ConcatPcap - Class in org.apache.drill.exec.store.pcap
-
Concatenates PCAP files.
- ConcatPcap() - Constructor for class org.apache.drill.exec.store.pcap.ConcatPcap
-
- ConcatReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
-
- ConcatReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.ConcatReturnTypeInference
-
- ConcatRightNullInput() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.ConcatRightNullInput
-
- concatTest(String, int, boolean) - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- condition - Variable in class org.apache.drill.exec.physical.base.AbstractJoinPop
-
- condition - Variable in class org.apache.drill.exec.planner.index.AbstractIndexStatistics
-
- ConditionalMockBatchSizePredictor() - Constructor for class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl.ConditionalMockBatchSizePredictor
-
- ConditionalMockBatchSizePredictor(List<Integer>, List<Long>, boolean) - Constructor for class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl.ConditionalMockBatchSizePredictor
-
- conditionIndexed(IndexableExprMarker, IndexDescriptor) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
Check if any of the fields of the index are present in a list of LogicalExpressions supplied
as part of IndexableExprMarker
- conditions - Variable in class org.apache.drill.exec.physical.base.AbstractJoinPop
-
- conf - Static variable in class org.apache.drill.exec.store.parquet.ParquetSimpleTestFileGenerator
-
- config - Variable in class org.apache.drill.exec.coord.store.BaseTransientStore
-
- config - Variable in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
-
- CONFIG - Static variable in class org.apache.drill.exec.pop.PopUnitTestBase
-
- config(DrillConfig) - Method in class org.apache.drill.exec.ssl.SSLConfigBuilder
-
- config - Variable in class org.apache.drill.test.BaseFixture
-
- config() - Method in class org.apache.drill.test.BaseFixture
-
- config - Static variable in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- configBuilder - Variable in class org.apache.drill.test.ClusterFixtureBuilder
-
- configBuilder() - Method in class org.apache.drill.test.ClusterFixtureBuilder
-
The configuration builder which this fixture builder uses.
- ConfigBuilder - Class in org.apache.drill.test
-
- ConfigBuilder() - Constructor for class org.apache.drill.test.ConfigBuilder
-
- configBuilder() - Method in class org.apache.drill.test.OperatorFixture.Builder
-
- configClientProperty(String, Object) - Method in class org.apache.drill.test.ClusterFixtureBuilder
-
Add an additional property for the client connection URL.
- configProperty(String, Object) - Method in class org.apache.drill.test.ClusterFixtureBuilder
-
Add an additional boot-time property for the embedded Drillbit.
- configProps - Variable in class org.apache.drill.test.ConfigBuilder
-
- configProps(Properties) - Method in class org.apache.drill.test.ConfigBuilder
-
Use the given configuration properties as overrides.
- configProps(DrillConfig) - Method in class org.apache.drill.test.ConfigBuilder
-
- configResource(String) - Method in class org.apache.drill.test.ClusterFixtureBuilder
-
Use the given configuration file, stored as a resource, to start the
embedded Drillbit.
- configResource - Variable in class org.apache.drill.test.ConfigBuilder
-
- 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
-
- conformance() - Method in class org.apache.drill.exec.planner.sql.DrillParserConfig
-
- 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
-
Start's a connection from client to server
- connect(String, Properties) - Method in class org.apache.drill.exec.client.DrillClient
-
Start's a connection from client to server
- connect(CoordinationProtos.DrillbitEndpoint, DrillProperties, UserBitShared.UserCredentials) - Method in class org.apache.drill.exec.rpc.user.UserClient
-
Connects, and if required, authenticates.
- CONNECTION_COUNTER_PREFIX - Static variable in class org.apache.drill.exec.rpc.AbstractRpcMetrics
-
- ConnectionConfig - Interface in org.apache.drill.exec.rpc
-
- ConnectionInfo(Map.Entry<UserServer.BitToUserConnection, UserServer.BitToUserConnectionConfig>, String) - Constructor for class org.apache.drill.exec.store.sys.BitToUserConnectionIterator.ConnectionInfo
-
- ConnectionManagerRegistry - Class in org.apache.drill.exec.rpc.control
-
- ConnectionManagerRegistry(ControlConnectionConfig) - Constructor for class org.apache.drill.exec.rpc.control.ConnectionManagerRegistry
-
- ConnectionManagerRegistryTest - Class in org.apache.drill.exec.rpc.control
-
- ConnectionManagerRegistryTest() - Constructor for class org.apache.drill.exec.rpc.control.ConnectionManagerRegistryTest
-
- connectionsTable() - Method in class org.apache.drill.exec.store.sys.TestSystemTable
-
- ConnectTriesPropertyTestClusterBits - Class in org.apache.drill.exec.client
-
- ConnectTriesPropertyTestClusterBits() - Constructor for class org.apache.drill.exec.client.ConnectTriesPropertyTestClusterBits
-
- 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
-
- ConstantColumnLoader - Class in org.apache.drill.exec.physical.impl.scan.project
-
Populate metadata columns either file metadata (AKA "implicit
columns") or directory metadata (AKA "partition columns.") In both
cases the column type is nullable Varchar and the column value
is predefined by the projection planner; this class just copies
that value into each row.
- ConstantColumnLoader(ResultVectorCache, List<? extends ConstantColumnLoader.ConstantColumnSpec>) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.ConstantColumnLoader
-
- ConstantColumnLoader.ConstantColumnSpec - Interface in org.apache.drill.exec.physical.impl.scan.project
-
- ConstantExpressionIdentifier - Class in org.apache.drill.exec.compile.sig
-
- ConstantExprNode(String) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaFilter.ConstantExprNode
-
- Constants() - Constructor for class org.apache.drill.exec.store.parquet.metadata.MetadataVersion.Constants
-
- constants() - Method in class org.apache.drill.exec.work.prepare.TestLimit0VsRegularQueriesMetadata
-
- constructMuxPrel(Prel, OptionManager) - Method in class org.apache.drill.exec.planner.physical.ExchangePrel
-
The derived classes can override this method to create relevant mux exchanges.
- constructMuxPrel(Prel, OptionManager) - Method in class org.apache.drill.exec.planner.physical.HashToRandomExchangePrel
-
This method creates a new UnorderedMux and Demux exchanges if mux operators are enabled.
- constructMuxPrel(Prel, OptionManager) - Method in class org.apache.drill.exec.planner.physical.SingleMergeExchangePrel
-
This method creates a new OrderedMux exchange if mux operators are enabled.
- constructRowType(RelDataType) - Method in class org.apache.drill.exec.planner.common.DrillLateralJoinRelBase
-
- Consumer<T> - Interface in org.apache.drill.exec.ops
-
- container - Variable in class org.apache.drill.exec.physical.impl.MockRecordBatch
-
- container() - Method in class org.apache.drill.exec.physical.rowSet.impl.ColumnState.BaseContainerColumnState
-
- container() - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedListState.RepeatedListColumnState
-
- container() - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState.MapColumnState
-
- container() - Method in class org.apache.drill.exec.physical.rowSet.impl.UnionState.UnionColumnState
-
- container() - Method in interface org.apache.drill.exec.physical.rowSet.model.TupleModel.RowSetModel
-
- container - Variable in class org.apache.drill.exec.record.AbstractRecordBatch
-
- container - Variable in class org.apache.drill.test.rowSet.AbstractRowSet
-
- container() - Method in class org.apache.drill.test.rowSet.AbstractRowSet
-
- container() - Method in interface org.apache.drill.test.rowSet.RowSet
-
- ContainerAndSv2Accessor() - Constructor for class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor.ContainerAndSv2Accessor
-
- ContainerAndSv4Accessor() - Constructor for class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor.ContainerAndSv4Accessor
-
- ContainerState - Class in org.apache.drill.exec.physical.rowSet.impl
-
Abstract representation of a container of vectors: a row, a map, a
repeated map, a list or a union.
- ContainerState(LoaderInternals, ResultVectorCache, RequestedTuple) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.ContainerState
-
- ContainerVisitor<R,A> - Class in org.apache.drill.exec.physical.rowSet.model
-
- ContainerVisitor() - Constructor for class org.apache.drill.exec.physical.rowSet.model.ContainerVisitor
-
- containInputRef(RexNode) - Method in class org.apache.drill.exec.planner.index.IndexableExprMarker
-
- contains(String) - Method in class org.apache.drill.exec.store.sys.CaseInsensitivePersistentStore
-
- contains(String) - 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) - Method in class org.apache.drill.exec.store.sys.store.LocalPersistentStore
-
- contains(String, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.store.UndefinedVersionDelegatingStore
-
- contains(String, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.store.VersionedDelegatingStore
-
- 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, DataChangeVersion) - Method in interface org.apache.drill.exec.store.sys.VersionedPersistentStore
-
Checks if lookup key is present in store.
- contains(String) - Method in class org.apache.drill.exec.testing.store.NoWriteLocalStore
-
- ContainsBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsBigInt
-
- ContainsBit() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsBit
-
- containsComplexColumn(ParquetMetadata, List<SchemaPath>) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
-
Check whether any of columns in the given list is either nested or repetitive.
- 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
-
- ContainsFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsFloat4
-
- ContainsFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsFloat8
-
- containsImplicitColumns() - Method in class org.apache.drill.exec.store.ColumnExplorer
-
Checks if current column selection contains implicit columns.
- ContainsInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsInt
-
- containsJar(String) - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
-
- 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.
- containsStar(DbGroupScan) - Static method in class org.apache.drill.exec.planner.index.rules.AbstractMatchFunction
-
- 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
-
- ContainsTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsTinyInt
-
- containsValue(Object) - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
-
- ContainsVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.ContainsVarChar
-
- content - Variable in class org.apache.drill.exec.planner.common.DrillValuesRelBase
-
- context - Variable in class org.apache.drill.exec.ops.BaseOperatorContext
-
- context - Variable in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
-
- context - Variable in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
-
- context - Variable in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate
-
- 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.store.AbstractStoragePlugin
-
- 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.SessionId - Class in org.apache.drill.exec.expr.fn.impl
-
Implement "session_id" function.
- ContextFunctions.User - Class in org.apache.drill.exec.expr.fn.impl
-
Implement "user", "session_user" or "system_user" function.
- 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
-
- 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
-
- ControlConnectionConfig - Class in org.apache.drill.exec.rpc.control
-
- ControlConnectionManager - Class in org.apache.drill.exec.rpc.control
-
Maintains connection between two particular bits.
- ControlConnectionManager(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
- Controls - Class in org.apache.drill.exec.testing
-
- controls - Variable in class org.apache.drill.test.OperatorFixture.Builder
-
- Controls.Builder - Class in org.apache.drill.exec.testing
-
A builder to create a controls string, a JSON that holds a list of injections that are to be injected in code for
testing purposes.
- ControlServer - Class in org.apache.drill.exec.rpc.control
-
- ControlServer(ControlConnectionConfig, ConnectionManagerRegistry) - Constructor for class org.apache.drill.exec.rpc.control.ControlServer
-
- ControlsInjectionUtil - Class in org.apache.drill.exec.testing
-
Static methods for constructing exception and pause injections for testing purposes.
- 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
-
- ControlsOptionValidator(String, int, OptionValidator.OptionDescription) - Constructor for class org.apache.drill.exec.testing.ExecutionControls.ControlsOptionValidator
-
Constructor for controls option validator.
- 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.CustomFuture<RECEIVE> - Class in org.apache.drill.exec.rpc.control
-
A class used to return a synchronous future when doing custom rpc messages.
- ControlTunnel.CustomMessageSender - Class in org.apache.drill.exec.rpc.control
-
- 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.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.RequestProfile - Class in org.apache.drill.exec.rpc.control
-
- ControlTunnel.SendFragment - Class in org.apache.drill.exec.rpc.control
-
- ControlTunnel.SendFragmentStatus - Class in org.apache.drill.exec.rpc.control
-
- ControlTunnel.SignalFragment - Class in org.apache.drill.exec.rpc.control
-
- ControlTunnel.SyncCustomMessageSender - Class in org.apache.drill.exec.rpc.control
-
- 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(Join, ConversionContext) - Static method in class org.apache.drill.exec.planner.logical.RowKeyJoinRel
-
- 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(JsonNode) - Method in class org.apache.drill.exec.store.pojo.DynamicPojoRecordReader.Converter
-
- CONVERT_TO_BIGINT_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- CONVERT_TO_BOOLEAN_BYTE_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- CONVERT_TO_DATE_EPOCH_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- CONVERT_TO_DOUBLE_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- CONVERT_TO_FLOAT_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- CONVERT_TO_HADOOPV_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- CONVERT_TO_INT_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- CONVERT_TO_SMALLINT_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- CONVERT_TO_TIME_EPOCH_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- CONVERT_TO_TIMESTAMP_EPOCH_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- CONVERT_TO_TINYINT_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- CONVERT_TO_UINT4_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- CONVERT_TO_UINT8_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- 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(RelNode, RelNode) - Method in class org.apache.drill.exec.planner.index.generators.AbstractIndexPlanGenerator
-
- convertChild(RelNode, RelNode) - Method in class org.apache.drill.exec.planner.index.generators.CoveringIndexPlanGenerator
-
- convertChild(RelNode, RelNode) - Method in class org.apache.drill.exec.planner.index.generators.CoveringPlanNoFilterGenerator
-
- convertChild() - Method in class org.apache.drill.exec.planner.index.generators.CoveringPlanNoFilterGenerator
-
- convertChild(RelNode, RelNode) - Method in class org.apache.drill.exec.planner.index.generators.IndexIntersectPlanGenerator
-
- convertChild(RelNode, RelNode) - Method in class org.apache.drill.exec.planner.index.generators.NonCoveringIndexPlanGenerator
-
- convertChild(T, RelNode) - Method in class org.apache.drill.exec.planner.physical.SubsetTransformer
-
- convertConditionForIndexScan(RexNode, RelNode, RelDataType, RexBuilder, FunctionalIndexInfo) - Static method in class org.apache.drill.exec.planner.index.FunctionalIndexHelper
-
- 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
-
- ConvertedRelNode(RelNode, RelDataType) - Constructor for class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler.ConvertedRelNode
-
- Converter(ObjectMapper) - Constructor for class org.apache.drill.exec.store.pojo.DynamicPojoRecordReader.Converter
-
- 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
-
- ConvertFromJson() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertFrom.ConvertFromJson
-
- convertFromJson() - Method in class org.apache.drill.exec.physical.impl.limit.TestLateLimit0Optimization
-
- ConvertFromJsonNullableInput() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertFrom.ConvertFromJsonNullableInput
-
- ConvertFromJsonVarchar() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertFrom.ConvertFromJsonVarchar
-
- ConvertFromJsonVarcharNullableInput() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertFrom.ConvertFromJsonVarcharNullableInput
-
- convertInt(byte[], int) - Static method in class org.apache.drill.exec.store.pcap.PcapFormatUtils
-
- convertLiteral(RexLiteral) - Static method in class org.apache.drill.exec.util.Utilities
-
Converts literal into path segment based on its type.
- ConvertMapToKeyValuePairs() - Constructor for class org.apache.drill.exec.expr.fn.impl.Mappify.ConvertMapToKeyValuePairs
-
- convertNext() - Method in interface org.apache.drill.exec.physical.impl.materialize.RecordMaterializer
-
- convertNext() - Method in class org.apache.drill.exec.physical.impl.materialize.VectorRecordMaterializer
-
- convertRowType(RelDataType, RelDataTypeFactory) - Method in class org.apache.drill.exec.planner.index.generators.AbstractIndexPlanGenerator
-
- convertRowTypeForIndexScan(DrillScanRelBase, IndexableExprMarker, IndexGroupScan, FunctionalIndexInfo) - Static method in class org.apache.drill.exec.planner.index.FunctionalIndexHelper
-
For IndexScan in non-covering case, rowType to return contains only row_key('_id') of primary table.
- 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
- convertToAbsolutePaths(List<String>, String) - Static method in class org.apache.drill.exec.store.parquet.metadata.MetadataPathUtils
-
Helper method that converts a list of relative paths to absolute ones
- convertToCalciteType(RelDataTypeFactory, TypeProtos.MajorType, boolean) - Static method in class org.apache.drill.exec.planner.sql.TypeInferenceUtils
-
Creates a RelDataType using specified RelDataTypeFactory which corresponds to specified TypeProtos.MajorType.
- 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.
- ConvertToExtendedJson() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertTo.ConvertToExtendedJson
-
- convertToFilesWithAbsolutePaths(List<Metadata_V3.ParquetFileMetadata_v3>, String) - Static method in class org.apache.drill.exec.store.parquet.metadata.MetadataPathUtils
-
Convert a list of files with relative paths to files with absolute ones
- convertToIntBE() - Method in class org.apache.drill.exec.physical.impl.limit.TestLateLimit0Optimization
-
- ConvertToJson() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.JsonConvertTo.ConvertToJson
-
- convertToLocalDateTime(String) - Static method in class org.apache.drill.test.TestBuilder
-
Helper method for the timestamp values that depend on the local timezone
- convertToLocalTimestamp(String) - Static method in class org.apache.drill.test.TestBuilder
-
Helper method for the timestamp values that depend on the local timezone
- convertToNullableType(LogicalExpression, TypeProtos.MinorType, FunctionLookupContext, ErrorCollector) - Static method in class org.apache.drill.exec.expr.ExpressionTreeMaterializer
-
- convertToOthers() - Method in class org.apache.drill.exec.physical.impl.limit.TestLateLimit0Optimization
-
- 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
-
- CopierTester(OperatorFixture) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.SortTestUtilities.CopierTester
-
- 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, RelNode, RelNode, CorrelationId, ImmutableBitSet, SemiJoinType) - Method in class org.apache.drill.exec.planner.logical.DrillLateralJoinRel
-
- 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, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.drill.exec.planner.logical.DrillSemiJoinRel
-
- 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, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.drill.exec.planner.logical.RowKeyJoinRel
-
- 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, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.DirectScanPrel
-
- 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, RelNode, RelNode, CorrelationId, ImmutableBitSet, SemiJoinType) - Method in class org.apache.drill.exec.planner.physical.LateralJoinPrel
-
- 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.OrderedMuxExchangePrel
-
- 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.RangePartitionExchangePrel
-
- copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.drill.exec.planner.physical.RowKeyJoinPrel
-
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.drill.exec.planner.physical.RuntimeFilterPrel
-
- 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
-
- copy() - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- copy() - Method in class org.apache.drill.exec.record.metadata.MapColumnMetadata
-
- copy() - Method in class org.apache.drill.exec.record.metadata.PrimitiveColumnMetadata
-
- copy() - Method in class org.apache.drill.exec.record.metadata.RepeatedListColumnMetadata
-
- copy() - Method in class org.apache.drill.exec.record.metadata.TupleSchema
-
- copy() - Method in class org.apache.drill.exec.record.metadata.VariantColumnMetadata
-
- copy(SelectionVector4) - Method in class org.apache.drill.exec.record.selection.SelectionVector4
-
- copy(List<SchemaPath>) - Method in class org.apache.drill.exec.store.parquet.AbstractParquetRowGroupScan
-
- copy(List<SchemaPath>) - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
-
- copy(boolean, InputStream, DataOutputStream) - Static method in class org.apache.drill.exec.store.pcap.ConcatPcap
-
Concatenates a stream onto the output.
- copyData() - Static method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDownForComplexTypes
-
- copyData() - Static method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- copyData() - Static method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- copyEntry(int, int) - Method in class org.apache.drill.exec.physical.impl.svremover.AbstractCopier
-
- copyEntry(int, int) - Method in class org.apache.drill.exec.physical.impl.svremover.GenericSV2Copier
-
- copyEntry(int, int) - Method in class org.apache.drill.exec.physical.impl.svremover.GenericSV4Copier
-
- copyEntryIndirect(int, int) - Method in class org.apache.drill.exec.physical.impl.svremover.AbstractCopier
-
- copyEntryIndirect(int, int) - Method in class org.apache.drill.exec.physical.impl.svremover.AbstractSV2Copier
-
- copyEntryIndirect(int, int) - Method in class org.apache.drill.exec.physical.impl.svremover.AbstractSV4Copier
-
- copyFileToRoot(Path) - Method in class org.apache.drill.test.BaseDirTestWatcher
-
This copies a filed or directory from the maven project into the temp root directory (corresponding to dfs.root).
- 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
-
- copyNext(int, int) - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
-
copies value(s) from inIndex row to outIndex row.
- copyOverflow(int, int) - Method in class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState
-
- copyOverflow(int, int) - Method in class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState.OffsetVectorState
-
- copyOverflow(int, int) - Method in class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState.SimpleVectorState
-
- 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 class org.apache.drill.exec.physical.impl.svremover.AbstractCopier
-
- copyRecords(int, int) - Method in class org.apache.drill.exec.physical.impl.svremover.AbstractSV2Copier
-
- 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.GenericCopier
-
- copyRecords(int, int) - Method in class org.apache.drill.exec.physical.impl.svremover.StraightCopier
-
- copyResourceToRoot(Path) - Method in class org.apache.drill.test.BaseDirTestWatcher
-
This copies a file or directory from src/test/resources into the temp root directory (corresponding to dfs.root).
- copyResourceToRoot(Path, Path) - Method in class org.apache.drill.test.BaseDirTestWatcher
-
This copies a file or directory from src/test/resources into the temp root directory (corresponding to dfs.root).
- copyResourceToTestTmp(Path, Path) - Method in class org.apache.drill.test.BaseDirTestWatcher
-
This copies a file or directory from src/test/resources into the temp root directory (corresponding to dfs.root).
- 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
-
- 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
- correctDatesInMetadataCache(MetadataBase.ParquetTableMetadataBase) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
-
- CorrelateVarReplacer(RexShuttle) - Constructor for class org.apache.drill.exec.planner.physical.visitor.LateralUnnestRowIDVisitor.CorrelateVarReplacer
-
- CorruptionDetectingDateConverter(DateWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.CorruptionDetectingDateConverter
-
- CostPrinter() - Constructor for class org.apache.drill.test.ProfileParser.CostPrinter
-
- count - Variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager.MergeTask
-
- count - Variable in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
-
The number of valid bytes in internalBuffer
.
- countAggFlattened() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- countDistinct() - Method in class org.apache.drill.exec.physical.impl.limit.TestLateLimit0Optimization
-
- 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
-
- countEmptyNullableInput() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- Counter - Interface in org.apache.drill.exec.cache
-
- CountingInputStream(InputStream) - Constructor for class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingInputStream
-
- CountingJsonReader - Class in org.apache.drill.exec.store.easy.json.reader
-
- CountingJsonReader(DrillBuf, boolean) - Constructor for class org.apache.drill.exec.store.easy.json.reader.CountingJsonReader
-
- CountingOutputStream(OutputStream) - Constructor for class org.apache.drill.exec.physical.impl.spill.SpillSet.CountingOutputStream
-
- CountRequiredFragments() - Constructor for class org.apache.drill.exec.planner.fragment.SimpleParallelizer.CountRequiredFragments
-
- countResults(List<QueryDataBatch>) - Method in class org.apache.drill.test.ClientFixture
-
- counts() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- CoveringIndexPlanGenerator - Class in org.apache.drill.exec.planner.index.generators
-
Generate a covering index plan that is equivalent to the original plan.
- CoveringIndexPlanGenerator(IndexLogicalPlanCallContext, FunctionalIndexInfo, IndexGroupScan, RexNode, RexNode, RexBuilder, PlannerSettings) - Constructor for class org.apache.drill.exec.planner.index.generators.CoveringIndexPlanGenerator
-
- CoveringPlanNoFilterGenerator - Class in org.apache.drill.exec.planner.index.generators
-
- CoveringPlanNoFilterGenerator(IndexCallContext, FunctionalIndexInfo, boolean, PlannerSettings) - Constructor for class org.apache.drill.exec.planner.index.generators.CoveringPlanNoFilterGenerator
-
- 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(RecordBatch, double, double) - Method in interface org.apache.drill.exec.physical.impl.join.BatchSizePredictor.Factory
-
Creates a predictor with a batch whose data needs to be used to predict other batch sizes.
- create(RecordBatch, double, double) - Method in class org.apache.drill.exec.physical.impl.join.BatchSizePredictorImpl.Factory
-
- 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, RelNode, RexNode, ImmutableIntList, ImmutableIntList) - Static method in class org.apache.drill.exec.planner.logical.DrillSemiJoinRel
-
- create(KEY) - Method in interface org.apache.drill.exec.planner.sql.ExpandingConcurrentMap.MapValueFactory
-
- 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.CachedSingleFileSystem
-
- 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
-
- CREATE_PREPARE_STATEMENT_TIMEOUT_MILLIS_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
-
- createAndAddWorkspace(String, String, short, String, String, Map<String, WorkspaceConfig>) - Static method in class org.apache.drill.exec.impersonation.BaseTestImpersonation
-
- 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
-
- createAndSetupCopier(RecordBatch, VectorContainer, SchemaChangeCallBack) - Static method in class org.apache.drill.exec.physical.impl.svremover.GenericCopierFactory
-
- createAndSetupHashTable(TypedFieldId[]) - Method in class org.apache.drill.exec.physical.impl.common.ChainedHashTable
-
- createAndSetupNonSVGenericCopier(RecordBatch, VectorContainer) - Static method in class org.apache.drill.exec.physical.impl.svremover.GenericCopierFactory
-
- 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.
- createBooleanKindTest() - Method in class org.apache.drill.exec.server.options.OptionValueTest
-
- createBooleanPredicate(String, String, List<LogicalExpression>, ExpressionPosition) - Static method in class org.apache.drill.exec.expr.stat.ParquetBooleanPredicate
-
- createBroadcastPlan(RelOptRuleCall, DrillJoin, 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.HashPrelUtil.RexNodeBasedHashExpressionCreatorHelper
-
- createCall(SqlLiteral, SqlParserPos, SqlNode...) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
-
- createClient(DrillConfig, RemoteServiceSet, int, Properties) - Static method in class org.apache.drill.test.QueryTestUtil
-
Create a DrillClient that can be used to query a drill cluster.
- createComparisonPredicate(String, LogicalExpression, LogicalExpression) - Static method in class org.apache.drill.exec.expr.stat.ParquetComparisonPredicate
-
- 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
-
- createCopier(RecordBatch, VectorContainer, SchemaChangeCallBack) - Method in class org.apache.drill.exec.physical.impl.svremover.AbstractGenericCopierTest
-
- createCopier(RecordBatch, VectorContainer, SchemaChangeCallBack) - Method in class org.apache.drill.exec.physical.impl.svremover.GenericCopierTest
-
- 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
-
- 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, DrillJoin, JoinPruleBase.PhysicalJoinType, RelNode, RelNode, RelCollation, RelCollation, boolean) - Method in class org.apache.drill.exec.planner.physical.JoinPruleBase
-
- createDoubleKindTest() - Method in class org.apache.drill.exec.server.options.OptionValueTest
-
- createEventLoop(int, String) - Static method in class org.apache.drill.exec.client.DrillClient
-
- createException(Class<?>, String, int, int, Class<? extends Throwable>) - Static method in class org.apache.drill.exec.testing.ControlsInjectionUtil
-
Create a single exception injection.
- createExceptionOnBit(Class<?>, String, int, int, Class<? extends Throwable>, CoordinationProtos.DrillbitEndpoint) - Static method in class org.apache.drill.exec.testing.ControlsInjectionUtil
-
Create a single exception injection on a specific bit.
- createExpectedRowset(BufferAllocator) - Method in class org.apache.drill.exec.physical.impl.svremover.AbstractGenericCopierTest
-
- 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.
- createFiles(int, int, String, String) - Method in class org.apache.drill.exec.fn.interp.TestConstantFolding.SmallFileCreator
-
- createFiles(int, int, String) - Method in class org.apache.drill.exec.fn.interp.TestConstantFolding.SmallFileCreator
-
- createFiles(int, int) - Method in class org.apache.drill.exec.fn.interp.TestConstantFolding.SmallFileCreator
-
- 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
-
- createHash64Expression(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.
- 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
-
- createIsPredicate(String, LogicalExpression) - Static method in class org.apache.drill.exec.expr.stat.ParquetIsPredicate
-
- createJsonWithEmptyList() - Method in class org.apache.drill.TestExampleQueries
-
- createKeysAndExprs() - Method in class org.apache.drill.exec.planner.physical.AggPrelBase
-
- createLatch(Class<?>, String) - Static method in class org.apache.drill.exec.testing.ControlsInjectionUtil
-
Create a latch injection.
- createLeftMappingSet() - Static method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
-
- createList(FieldReader, BaseWriter.ComplexWriter, String) - Static method in class org.apache.drill.exec.expr.fn.impl.MappifyUtility
-
- createLoginPage(String) - Static method in class org.apache.drill.exec.server.rest.ViewableWithPermissions
-
Create a login page.
- createLongKindTest() - Method in class org.apache.drill.exec.server.options.OptionValueTest
-
- createMainLoginPage(Object) - Static method in class org.apache.drill.exec.server.rest.ViewableWithPermissions
-
- createMainMappingSet() - Static method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
-
- createMap(FieldReader, BaseWriter.ComplexWriter, String) - Static method in class org.apache.drill.exec.expr.fn.impl.MappifyUtility
-
- createMap(AbstractMapVector, MaterializedField, BufferAllocator) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedMap
-
- createMap(AbstractMapVector, MaterializedField, BufferAllocator) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedMapArray
-
- createMap(AbstractMapVector, MaterializedField, BufferAllocator) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedSingleMap
-
- createMeta(FileSystem, String, ParquetReaderConfig) - Static method in class org.apache.drill.exec.store.parquet.metadata.Metadata
-
Create the parquet metadata file for the directory at the given path, and for any subdirectories.
- createMetadataWithRelativePaths(Metadata_V3.ParquetTableMetadata_v3, String) - Static method in class org.apache.drill.exec.store.parquet.metadata.MetadataPathUtils
-
Creates a new parquet table metadata from the tableMetadataWithAbsolutePaths
parquet table.
- createMockPropOptionDefinition() - Static method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- createNewFile(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
-
- createNewPriorityQueue(MappingSet, MappingSet, MappingSet, List<Order.Ordering>, VectorAccessible, boolean, boolean, int, BufferAllocator, BatchSchema.SelectionVectorMode, FragmentContext) - Static method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
-
- createNewRowType(RelDataTypeFactory) - Method in class org.apache.drill.exec.planner.common.DrillRelOptUtil.ProjectPushInfo
-
Creates new row type based on stores types and field names.
- 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
-
- createParquetTable() - Static method in class org.apache.drill.TestPartitionFilter
-
- createPartitioner() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec
-
- createPartitionSublists() - Method in class org.apache.drill.exec.planner.AbstractPartitionDescriptor
-
- 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.
- createPause(Class<?>, String, int) - Static method in class org.apache.drill.exec.testing.ControlsInjectionUtil
-
Create a pause injection.
- createPauseOnBit(Class<?>, String, int, CoordinationProtos.DrillbitEndpoint) - Static method in class org.apache.drill.exec.testing.ControlsInjectionUtil
-
Create a pause injection on a specific bit.
- createPreparedStatement(String) - Method in class org.apache.drill.exec.client.DrillClient
-
Create a prepared statement for given the query
.
- createPrepareStmt(String, boolean, UserBitShared.DrillPBError.ErrorType) - Method in class org.apache.drill.exec.work.prepare.PreparedStatementTestBase
-
- 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
-
- createRangeDistRight(RelNode, RelDataTypeField, DbGroupScan) - Method in class org.apache.drill.exec.planner.index.generators.AbstractIndexPlanGenerator
-
- createRangePartitionRightPlan(RelOptRuleCall, RowKeyJoinRel, JoinPruleBase.PhysicalJoinType, boolean, RelNode, RelNode, RelCollation, RelCollation) - Method in class org.apache.drill.exec.planner.physical.JoinPruleBase
-
- 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.
- createRepeatedMapOrList(FieldReader, BaseWriter.ComplexWriter, String) - Static method in class org.apache.drill.exec.expr.fn.impl.MappifyUtility
-
- createRightMappingSet() - Static method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
-
- createRootSchema(StoragePluginRegistry, SchemaConfig) - Static method in class org.apache.calcite.jdbc.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(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(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
-
- createSortExprs() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- createSortExprs() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- createSortExprs() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- createSrcRowSet(BufferAllocator) - Method in class org.apache.drill.exec.physical.impl.svremover.AbstractGenericCopierTest
-
- createSrcRowSet(BufferAllocator) - Method in class org.apache.drill.exec.physical.impl.svremover.GenericCopierTest
-
- createSrcRowSet(BufferAllocator) - Method in class org.apache.drill.exec.physical.impl.svremover.GenericSV2BatchCopierTest
-
- createSrcRowSet(BufferAllocator) - Method in class org.apache.drill.exec.physical.impl.svremover.GenericSV2CopierTest
-
- createSrcRowSet(BufferAllocator) - Method in class org.apache.drill.exec.physical.impl.svremover.GenericSV4CopierTest
-
- 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
-
- createStringKindTest() - Method in class org.apache.drill.exec.server.options.OptionValueTest
-
- 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
- createTableWhenATableWithSameNameAlreadyExists() - Method in class org.apache.drill.exec.sql.TestCTAS
-
- createTableWhenAViewWithSameNameAlreadyExists() - Method in class org.apache.drill.exec.sql.TestCTAS
-
- createTableWithCustomUmask() - Method in class org.apache.drill.exec.sql.TestCTAS
-
- createTempFile() - Static method in class org.apache.drill.exec.store.dfs.TestDrillFileSystem
-
- createTestSchema(BatchSchema.SelectionVectorMode) - Method in class org.apache.drill.exec.physical.impl.svremover.AbstractGenericCopierTest
-
- createTimedPause(Class<?>, String, int, long) - Static method in class org.apache.drill.exec.testing.ControlsInjectionUtil
-
Create a time-bound pause injection.
- createTimedPauseOnBit(Class<?>, String, int, CoordinationProtos.DrillbitEndpoint, long) - Static method in class org.apache.drill.exec.testing.ControlsInjectionUtil
-
Create a pause injection on a specific bit.
- createView(String, String, short, String, String, String) - Static method in class org.apache.drill.exec.impersonation.BaseTestImpersonation
-
- createView(String, String, String, String) - Static method in class org.apache.drill.exec.impersonation.BaseTestImpersonation
-
- createView() - Static method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- CreateView(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ViewHandler.CreateView
-
- 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
-
- createViewHelper(String, String, String, String, String) - Static method in class org.apache.drill.exec.sql.TestBaseViewSupport
-
Create view with given parameters.
- createViewIfNotExistsWhenTableAlreadyExists() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- createViewIfNotExistsWhenViewAlreadyExists() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- createViewWhenATableWithSameNameAlreadyExists() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- createViewWhenInEqualColumnCountInViewDefVsInViewQuery() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- createViewWhenViewAlreadyExists() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- createViewWhenViewQueryColumnHasStarAndViewFiledListIsSpecified() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- createViewWithBothOrReplaceAndIfNotExists() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- createViewWithDuplicateColumnsInDef1() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- createViewWithDuplicateColumnsInDef2() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- createViewWithDuplicateColumnsInDef3() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- createViewWithDuplicateColumnsInDef4() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- createViewWithDuplicateColumnsInDef5() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- createViewWithDuplicateColumnsInDef6() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- createViewWithUniqueColsInFieldListDuplicateColsInQuery1() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- createViewWithUniqueColsInFieldListDuplicateColsInQuery2() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- 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
-
- CrossJoinTest - Class in org.apache.drill.exec.planner.sql
-
- CrossJoinTest() - Constructor for class org.apache.drill.exec.planner.sql.CrossJoinTest
-
- CSV - Static variable in class org.apache.drill.exec.store.TestImplicitFileColumns
-
- CSV_TBL - Static variable in class org.apache.drill.exec.store.TestImplicitFileColumns
-
- csvBaselineFile(String) - Method in class org.apache.drill.test.TestBuilder
-
- 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
-
- ctasPartitionWithEmptyList() - Method in class org.apache.drill.exec.sql.TestCTAS
-
- ctasWatcher - Variable in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- ctasWithPartition() - Method in class org.apache.drill.exec.sql.TestCTAS
-
- ctasWithQueryOrderby() - Method in class org.apache.drill.exec.sql.TestCTAS
-
- cume_dist - Variable in class org.apache.drill.exec.physical.impl.window.Partition
-
- 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 - Variable in class org.apache.drill.exec.store.sys.DrillbitIterator.DrillbitInstance
-
- currentContainer - Variable in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
-
- CurrentDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.CurrentDate
-
- currentField - Variable in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
-
- currentFieldName - Variable in class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
-
The name of the current field being parsed.
- CurrentSchema() - Constructor for class org.apache.drill.exec.expr.fn.impl.ContextFunctions.CurrentSchema
-
- currentSchemaUDFWhenDefaultSchemaNotSet() - Method in class org.apache.drill.exec.fn.impl.TestContextFunctions
-
- currentSchemaUDFWithMultiLevelDefaultSchema() - Method in class org.apache.drill.exec.fn.impl.TestContextFunctions
-
- currentSchemaUDFWithSingleLevelDefaultSchema() - Method in class org.apache.drill.exec.fn.impl.TestContextFunctions
-
- CurrentTime() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.CurrentTime
-
- currValueCount - Variable in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.BatchSizingMemoryUtil.ColumnMemoryUsageInfo
-
Current record count stored within the value vector
- CustomAbsFunction - Class in org.apache.drill.udf.dynamic
-
- CustomAbsFunction() - Constructor for class org.apache.drill.udf.dynamic.CustomAbsFunction
-
- CustomFuture(Controller.CustomSerDe<RECEIVE>, DrillRpcFuture<BitControl.CustomMessage>) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.CustomFuture
-
- CustomHandlerRegistry - Class in org.apache.drill.exec.rpc.control
-
- CustomHandlerRegistry() - Constructor for class org.apache.drill.exec.rpc.control.CustomHandlerRegistry
-
- CustomLogFunction - Class in org.apache.drill.udf.dynamic
-
- CustomLogFunction() - Constructor for class org.apache.drill.udf.dynamic.CustomLogFunction
-
- CustomLowerDummyFunction - Class in org.apache.drill.udf.dynamic
-
- CustomLowerDummyFunction() - Constructor for class org.apache.drill.udf.dynamic.CustomLowerDummyFunction
-
- CustomLowerFunction - Class in org.apache.drill.udf.dynamic
-
- CustomLowerFunction() - Constructor for class org.apache.drill.udf.dynamic.CustomLowerFunction
-
- CustomLowerFunctionV2 - Class in org.apache.drill.udf.dynamic
-
- CustomLowerFunctionV2() - Constructor for class org.apache.drill.udf.dynamic.CustomLowerFunctionV2
-
- CustomMessageSender(RpcOutcomeListener<BitControl.CustomMessage>, BitControl.CustomMessage, ByteBuf[]) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.CustomMessageSender
-
- CustomUpperFunction - Class in org.apache.drill.udf.dynamic
-
- CustomUpperFunction() - Constructor for class org.apache.drill.udf.dynamic.CustomUpperFunction
-
- data() - Static method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- DATA_GROUP - Static variable in class org.apache.drill.exec.impersonation.TestInboundImpersonation
-
- 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.LoggingResultsListener
-
- 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
-
- dataArrived(QueryDataBatch, ConnectionThrottle) - Method in class org.apache.drill.exec.store.parquet.ParquetResultListener
-
- dataArrived(QueryDataBatch, ConnectionThrottle) - Method in class org.apache.drill.SingleRowListener
-
- dataArrived(QueryDataBatch, ConnectionThrottle) - Method in class org.apache.drill.test.BaseTestQuery.SilentListener
-
Deprecated.
- dataArrived(QueryDataBatch, ConnectionThrottle) - Method in class org.apache.drill.test.BufferingQueryEventListener
-
- dataArrived(QueryDataBatch, ConnectionThrottle) - Method in class org.apache.drill.test.PrintingResultsListener
-
- dataArrived(QueryDataBatch, ConnectionThrottle) - Method in class org.apache.drill.test.QueryBuilder.SummaryOnlyQueryEventListener
-
- dataByteCapacity - Variable in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.BatchSizingMemoryUtil.VectorMemoryUsageInfo
-
Data vector capacity
- dataByteLen - Variable in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchOverflow.FieldOverflowDefinition
-
Data byte length
- dataBytesUsed - Variable in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.BatchSizingMemoryUtil.VectorMemoryUsageInfo
-
Data vector used up capacity
- DataChangeVersion - Class in org.apache.drill.exec.store.sys.store
-
Holder for store version.
- 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
-
- DataCollector - Interface in org.apache.drill.exec.work.batch
-
- 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
-
- DataGenerator(OperatorFixture, int, int) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl.DataGenerator
-
- DataGenerator(OperatorFixture, int, int, int, int) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl.DataGenerator
-
- 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.Server - Class in org.apache.drill.exec.rpc.data
-
- 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
-
- DataTunnel - Class in org.apache.drill.exec.rpc.data
-
- DataTunnel(DataConnectionManager) - Constructor for class org.apache.drill.exec.rpc.data.DataTunnel
-
- DataValidationMode - Enum in org.apache.drill.exec.physical
-
- DataValidator(int, int) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl.DataValidator
-
- 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.
- DATE_ONLY_PATTERN - Static variable in class org.apache.drill.exec.store.log.TestLogReader
-
- DATE_TIME_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- 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
-
- DateHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.DateHash
-
- DateHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.DateHash
-
- DateHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.DateHash
-
- DateHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.DateHash
-
- DateOutputFormat - Enum in org.apache.drill.exec.vector.complex.fn
-
Describes the default date output format to use for JSON.
- DatePartFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.DatePartFunction
-
- DATETIME_PRECISION - Variable in class org.apache.drill.exec.store.ischema.Records.Column
-
- DateTimeAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.DateTimeAddFunction
-
- DateTimeFormatValidator(String, OptionValidator.OptionDescription) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.DateTimeFormatValidator
-
- dateTruncOnDateCentury() - Method in class org.apache.drill.exec.fn.impl.TestDateTruncFunctions
-
- dateTruncOnDateMillennium() - Method in class org.apache.drill.exec.fn.impl.TestDateTruncFunctions
-
- dateTruncOnDateSimpleUnits() - Method in class org.apache.drill.exec.fn.impl.TestDateTruncFunctions
-
- dateTruncOnIntervalDay() - Method in class org.apache.drill.exec.fn.impl.TestDateTruncFunctions
-
- dateTruncOnIntervalYear() - Method in class org.apache.drill.exec.fn.impl.TestDateTruncFunctions
-
- dateTruncOnTime() - Method in class org.apache.drill.exec.fn.impl.TestDateTruncFunctions
-
- dateTruncOnTimeStampCentury() - Method in class org.apache.drill.exec.fn.impl.TestDateTruncFunctions
-
- dateTruncOnTimeStampMillennium() - Method in class org.apache.drill.exec.fn.impl.TestDateTruncFunctions
-
- dateTruncOnTimeStampSimpleUnits() - Method in class org.apache.drill.exec.fn.impl.TestDateTruncFunctions
-
- DateType() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.DateType
-
- 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.AgeDateFunction - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.AgeTimeStamp2Function - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.AgeTimeStampFunction - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.CastDateToTime - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.CastTimeStampToTime - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.CurrentDate - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.CurrentTime - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.DatePartFunction - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.DateTimeAddFunction - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.DateType - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.IntervalDayType - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.IntervalType - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.IntervalYearType - Class in org.apache.drill.exec.expr.fn.impl
-
- 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.IsDateRequiredInput - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.LocalTimeStampNiladic - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.LocalTimeStampNonNiladic - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.TimeDateAddFunction - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.TimeOfDay - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.TimeStampType - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.TimeType - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.UnixTimeStamp - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.UnixTimeStampForDate - Class in org.apache.drill.exec.expr.fn.impl
-
- DateTypeFunctions.UnixTimeStampForDateWithPattern - Class in org.apache.drill.exec.expr.fn.impl
-
- DbGroupScan - Interface in org.apache.drill.exec.physical.base
-
A DbGroupScan operator represents the scan associated with a database.
- DbScanSortRemovalRule - Class in org.apache.drill.exec.planner.index.rules
-
- DbScanToIndexScanPrule - Class in org.apache.drill.exec.planner.index.rules
-
- DbSubScan - Interface in org.apache.drill.exec.physical.base
-
- De() - Constructor for class org.apache.drill.exec.coord.DrillbitEndpointSerDe.De
-
- De() - Constructor for class org.apache.drill.exec.record.MajorTypeSerDe.De
-
- DEAD_BUFFER - Static variable in class org.apache.drill.exec.record.DeadBuf
-
- DeadBuf - Class in org.apache.drill.exec.record
-
- debug - Variable in class org.apache.drill.exec.compile.AbstractClassCompiler
-
- DebugStackTrace(Path, StackTraceElement[]) - Constructor for class org.apache.drill.exec.store.dfs.DrillFileSystem.DebugStackTrace
-
- 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
-
- 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.vector.complex.fn.ExtendedTypeName
-
- DECIMAL_DISABLE_ERR_MSG - Static variable in interface org.apache.drill.exec.work.ExecErrorConstants
-
- DecimalAddReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalAddReturnTypeInference
-
- DecimalAggReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalAggReturnTypeInference
-
- DecimalAvgAggReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalAvgAggReturnTypeInference
-
- DecimalCastReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalCastReturnTypeInference
-
- DecimalDivScaleReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalDivScaleReturnTypeInference
-
- DecimalMaxScaleReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalMaxScaleReturnTypeInference
-
- DecimalModScaleReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalModScaleReturnTypeInference
-
- 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
-
- DecimalReturnTypeInference.DecimalAggReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
-
- DecimalReturnTypeInference.DecimalAvgAggReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
-
- DecimalReturnTypeInference.DecimalCastReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
-
- DecimalReturnTypeInference.DecimalDivScaleReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
-
- DecimalReturnTypeInference.DecimalMaxScaleReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
-
- DecimalReturnTypeInference.DecimalModScaleReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
-
- DecimalReturnTypeInference.DecimalSetScaleReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
-
- DecimalReturnTypeInference.DecimalSumAggReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
-
- DecimalReturnTypeInference.DecimalSumScaleReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
-
- DecimalReturnTypeInference.DecimalZeroScaleReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
-
- DecimalScalePrecisionAddFunction - Class in org.apache.drill.exec.planner.types.decimal
-
- DecimalScalePrecisionAddFunction(int, int, int, int) - Constructor for class org.apache.drill.exec.planner.types.decimal.DecimalScalePrecisionAddFunction
-
- DecimalScalePrecisionDivideFunction - Class in org.apache.drill.exec.planner.types.decimal
-
- DecimalScalePrecisionDivideFunction(int, int, int, int) - Constructor for class org.apache.drill.exec.planner.types.decimal.DecimalScalePrecisionDivideFunction
-
- DecimalScalePrecisionModFunction - Class in org.apache.drill.exec.planner.types.decimal
-
- DecimalScalePrecisionModFunction(int, int, int, int) - Constructor for class org.apache.drill.exec.planner.types.decimal.DecimalScalePrecisionModFunction
-
- DecimalScalePrecisionMulFunction - Class in org.apache.drill.exec.planner.types.decimal
-
- DecimalScalePrecisionMulFunction(int, int, int, int) - Constructor for class org.apache.drill.exec.planner.types.decimal.DecimalScalePrecisionMulFunction
-
- DecimalSetScaleReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalSetScaleReturnTypeInference
-
- DecimalSumAggReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalSumAggReturnTypeInference
-
- DecimalSumScaleReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalSumScaleReturnTypeInference
-
- DecimalValueWriter - Class in org.apache.drill.exec.store.parquet.decimal
-
- DecimalValueWriter() - Constructor for class org.apache.drill.exec.store.parquet.decimal.DecimalValueWriter
-
- DecimalWriter(String) - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters.DecimalWriter
-
- DecimalZeroScaleReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DecimalReturnTypeInference.DecimalZeroScaleReturnTypeInference
-
- 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(TypeProtos.MajorType, String, boolean) - Method in class org.apache.drill.exec.expr.ClassGenerator
-
Adds local variable declaration based on given name and type.
- declareClassConstField(String, JType, Function<DrillBuf, ? extends ValueHolder>) - Method in class org.apache.drill.exec.expr.ClassGenerator
-
- declareClassConstField(String, JType, JExpression, Function<DrillBuf, ? extends ValueHolder>) - Method in class org.apache.drill.exec.expr.ClassGenerator
-
declare a constant field for the class.
- 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
-
- decode(Collection<SchemaPath>) - Static method in class org.apache.drill.exec.util.EncodedSchemaPathSet
-
Returns the decoded Collection of SchemaPath from the input which
may contain a mix of encoded and non-encoded SchemaPaths.
- decode(String...) - Static method in class org.apache.drill.exec.util.EncodedSchemaPathSet
-
Returns the decoded array of SchemaPath strings from the input which
may contain a mix of encoded and non-encoded SchemaPaths.
- decodePacket(byte[], int, Packet, int, int) - 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.common.JoinControl
-
- DEFAULT - Static variable in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
-
- 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_BATCH_BYTE_COUNT - Static variable in class org.apache.drill.exec.physical.impl.scan.project.ScanSchemaOrchestrator
-
- DEFAULT_BATCH_ROW_COUNT - Static variable in class org.apache.drill.exec.physical.impl.scan.project.ScanSchemaOrchestrator
-
- DEFAULT_BIT_NAME - Static variable in class org.apache.drill.test.ClusterFixture
-
- 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_CONSOLE_FORMAT - Static variable in class org.apache.drill.test.LogFixture
-
- 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_DECIMAL_FORMATTER - Static variable in class org.apache.drill.test.rowSet.file.JsonFileBuilder
-
- DEFAULT_DOUBLE_FORMATTER - Static variable in class org.apache.drill.test.rowSet.file.JsonFileBuilder
-
- DEFAULT_FORMATTERS - Static variable in class org.apache.drill.test.rowSet.file.JsonFileBuilder
-
- DEFAULT_IDENTIFIER_MAX_LENGTH - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- DEFAULT_INPUT_INDEX - Static variable in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- DEFAULT_INTEGER_FORMATTER - Static variable in class org.apache.drill.test.rowSet.file.JsonFileBuilder
-
- DEFAULT_LOAD_FACTOR - Static variable in interface org.apache.drill.exec.physical.impl.common.HashTable
-
The default load factor of a hash table.
- DEFAULT_LONG_FORMATTER - Static variable in class org.apache.drill.test.rowSet.file.JsonFileBuilder
-
- DEFAULT_MERGE_LIMIT - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
-
- DEFAULT_NAME - Static variable in class org.apache.drill.exec.store.easy.json.JSONFormatPlugin
-
- DEFAULT_NAME - Static variable in class org.apache.drill.exec.store.log.LogFormatPlugin
-
- DEFAULT_NAME - Static variable in class org.apache.drill.exec.store.pcapng.PcapngFormatPlugin
-
- DEFAULT_NULL_TYPE - Static variable in class org.apache.drill.exec.physical.impl.scan.project.NullColumnLoader
-
- DEFAULT_PERIOD_FORMATTER - Static variable in class org.apache.drill.test.rowSet.file.JsonFileBuilder
-
- DEFAULT_PORT - Static variable in class org.apache.drill.exec.util.MiniZooKeeperCluster
-
- DEFAULT_RECORD_BATCH_SIZE - Static variable in interface org.apache.drill.exec.physical.impl.partitionsender.Partitioner
-
- DEFAULT_RECORDS_PER_BATCH - Static variable in class org.apache.drill.exec.store.pojo.AbstractPojoRecordReader
-
- DEFAULT_ROW_COUNT - Static variable in interface org.apache.drill.exec.physical.rowSet.ResultSetLoader
-
- 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_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_STRING_FORMATTER - Static variable in class org.apache.drill.test.rowSet.file.JsonFileBuilder
-
- 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_VL_COLUMN_AVG_PRECISION - Static variable in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.BatchSizingMemoryUtil
-
Default variable length column average precision;
computed in such a way that 64k values will fit within one MB to minimize internal fragmentation
- DEFAULT_WS_NAME - Static variable in interface org.apache.drill.exec.store.SchemaFactory
-
- DEFAULT_ZK_REFRESH - Static variable in class org.apache.drill.test.ClusterFixtureBuilder
-
- 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
-
- defaultLogicalPlanPersistence(DrillConfig) - Static method in class org.apache.drill.exec.planner.PhysicalPlanReaderTestFactory
-
- DefaultOutputWidthCalculator() - Constructor for class org.apache.drill.exec.expr.fn.output.OutputWidthCalculators.DefaultOutputWidthCalculator
-
- defaultPhysicalPlanReader(DrillConfig, StoragePluginRegistry) - Static method in class org.apache.drill.exec.planner.PhysicalPlanReaderTestFactory
-
- defaultPhysicalPlanReader(DrillConfig) - Static method in class org.apache.drill.exec.planner.PhysicalPlanReaderTestFactory
-
- defaultPhysicalPlanReader(DrillbitContext) - Static method in class org.apache.drill.exec.planner.PhysicalPlanReaderTestFactory
-
- defaultPhysicalPlanReader(DrillbitContext, StoragePluginRegistry) - Static method in class org.apache.drill.exec.planner.PhysicalPlanReaderTestFactory
-
- 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
-
- DefaultQueryResourceManager(DefaultResourceManager, Foreman) - Constructor for class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager.DefaultQueryResourceManager
-
- DefaultResourceAllocator(QueryContext) - Constructor for class org.apache.drill.exec.work.foreman.rm.DefaultResourceManager.DefaultResourceAllocator
-
- 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.DefaultResourceAllocator - Class in org.apache.drill.exec.work.foreman.rm
-
- DefaultReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
-
- DefaultReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.DefaultReturnTypeInference
-
- defaultSchemaClasspath() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- defaultSchemaDfs() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- defaultSchemaPathColumns() - Method in class org.apache.drill.exec.vector.complex.fn.JsonReader.Builder
-
- 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.MetaDataProviderModifier - Class in org.apache.drill.exec.planner.sql.handlers
-
- define() - Method in interface org.apache.drill.exec.physical.impl.scan.project.MetadataManager
-
Define (materialize) the columns which this manager
represents.
- define() - Method in class org.apache.drill.exec.physical.impl.scan.project.NoOpMetadataManager
-
- defineOrdering() - Static method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
- defineWorkspace(String, String, String, String) - Method in class org.apache.drill.test.ClusterFixture
-
Define a workspace within an existing storage plugin.
- defineWorkspace(String, String, String, String, FormatPluginConfig) - Method in class org.apache.drill.test.ClusterFixture
-
- defineWorkspace(Drillbit, String, String, String, String, FormatPluginConfig) - Static method in class org.apache.drill.test.ClusterFixture
-
- definitionLevel - Variable in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnTypeMetadata_v3
-
- definitions - Variable in class org.apache.drill.test.ConfigBuilder
-
- defn - Variable in class org.apache.drill.test.ProfileParser.OperatorProfile
-
- 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(Path) - Method in class org.apache.drill.exec.store.CachedSingleFileSystem
-
- delete(Path, boolean) - Method in class org.apache.drill.exec.store.CachedSingleFileSystem
-
- 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 class org.apache.drill.exec.store.sys.CaseInsensitivePersistentStore
-
- delete(String) - Method in interface org.apache.drill.exec.store.sys.Store
-
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.UndefinedVersionDelegatingStore
-
- delete(String) - Method in class org.apache.drill.exec.store.sys.store.VersionedDelegatingStore
-
- 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
-
- deleteTempFile() - Static method in class org.apache.drill.exec.store.dfs.TestDrillFileSystem
-
- 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
-
- deriveRowType() - Method in class org.apache.drill.exec.planner.common.DrillLateralJoinRelBase
-
- 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.logical.RowKeyJoinRel
-
- deriveRowType() - Method in class org.apache.drill.exec.planner.physical.DirectScanPrel
-
- deriveRowType() - Method in class org.apache.drill.exec.planner.physical.JoinPrel
-
- 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 - Variable in class org.apache.drill.exec.testing.Injection
-
- describePartialSchema() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- 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
-
- describeSchemaInvalid() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- describeSchemaOutput() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- DescribeSchemaResult(String, String) - Constructor for class org.apache.drill.exec.planner.sql.handlers.DescribeSchemaHandler.DescribeSchemaResult
-
- describeSchemaSyntax() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- describeTable() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- DescribeTableHandler - Class in org.apache.drill.exec.planner.sql.handlers
-
- DescribeTableHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.DescribeTableHandler
-
- describeTableWithColQualifier() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- describeTableWithColumnName() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- describeTableWithSchema() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- describeTableWithSchemaAndColQualifier() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- describeTableWithSchemaAndColumnName() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- describeWhenSameTableNameExistsInMultipleSchemas() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- description - Variable in enum org.apache.drill.exec.planner.PlannerPhase
-
- description - Variable in class org.apache.drill.exec.store.sys.ExtendedOptionIterator.ExtendedOptionValueWrapper
-
- descriptive - Variable in class org.apache.drill.exec.store.image.ImageFormatConfig
-
- 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.Metadata_V2.ColumnMetadata_v2.DeSerializer
-
- deserializeKey(String, DeserializationContext) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnTypeMetadata_v2.Key.DeSerializer
-
- deserializeKey(String, DeserializationContext) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnTypeMetadata_v3.Key.DeSerializer
-
- deserializeKey(String, DeserializationContext) - Method in class org.apache.drill.exec.testing.InjectionSite.InjectionSiteKeyDeserializer
-
- Deserializer(JavaType) - Constructor for class org.apache.drill.exec.server.options.PersistedOptionValue.Deserializer
-
- Deserializer(StdDeserializer<?>) - Constructor for class org.apache.drill.exec.server.options.PersistedOptionValue.Deserializer
-
- DeSerializer() - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnMetadata_v2.DeSerializer
-
- DeSerializer() - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnTypeMetadata_v2.Key.DeSerializer
-
- DeSerializer() - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnTypeMetadata_v3.Key.DeSerializer
-
- 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
-
- DesiredField(String, RelDataType, RexNode) - Constructor for class org.apache.drill.exec.planner.logical.FieldsReWriterUtil.DesiredField
-
- 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
-
- destroyAllocator() - Static method in class org.apache.drill.exec.vector.complex.writer.TestRepeated
-
- 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.
- determineTotalSize() - Method in class org.apache.drill.exec.HyperVectorValueIterator
-
- 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
-
- dfsCluster - Static variable in class org.apache.drill.exec.impersonation.BaseTestImpersonation
-
- dfsConf - Static variable in class org.apache.drill.exec.impersonation.BaseTestImpersonation
-
- 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
-
- 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
-
- dimensions() - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- dimensions() - Method in class org.apache.drill.exec.record.metadata.RepeatedListColumnMetadata
-
- 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
-
- DIRECT_MEMORY_OOM_MESSAGE - Static variable in class org.apache.drill.exec.server.FailureUtils
-
This message is used to distinguish between direct memory and heap memory
OutOfMemoryError
s.
- 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
-
- DirectPlan - Class in org.apache.drill.exec.planner.sql
-
- DirectPlan() - Constructor for class org.apache.drill.exec.planner.sql.DirectPlan
-
- DirectRowIndex - Class in org.apache.drill.exec.physical.rowSet.model.single
-
Reader index that points directly to each row in the row set.
- DirectRowIndex(int) - Constructor for class org.apache.drill.exec.physical.rowSet.model.single.DirectRowIndex
-
- DirectRowSet - Class in org.apache.drill.test.rowSet
-
Implementation of a single row set with no indirection (selection)
vector.
- DirectRowSet(AbstractSingleRowSet) - Constructor for class org.apache.drill.test.rowSet.DirectRowSet
-
- DirectRowSet.RowSetWriterBuilder - Class in org.apache.drill.test.rowSet
-
- DirectScanPrel - Class in org.apache.drill.exec.planner.physical
-
- 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
-
- dirTestWatcher - Static variable in class org.apache.drill.exec.cache.TestBatchSerialization
-
- dirTestWatcher - Static variable in class org.apache.drill.exec.dotdrill.TestDotDrillUtil
-
- dirTestWatcher - Static variable in class org.apache.drill.exec.ExecTest
-
- dirTestWatcher - Variable in class org.apache.drill.exec.physical.impl.agg.TestHashAggrSpill
-
- dirTestWatcher - Variable in class org.apache.drill.exec.physical.impl.common.HashPartitionTest
-
- dirTestWatcher - Static variable in class org.apache.drill.exec.physical.impl.TestSchema
-
- dirTestWatcher - Variable in class org.apache.drill.exec.physical.impl.TopN.TopNBatchTest
-
- dirTestWatcher - Static variable in class org.apache.drill.exec.physical.impl.validate.TestBatchValidator
-
- dirTestWatcher - Variable in class org.apache.drill.exec.physical.impl.validate.TestValidationOptions
-
- dirTestWatcher - Static variable in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
- dirTestWatcher - Variable in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl
-
- dirTestWatcher - Variable in class org.apache.drill.exec.physical.impl.xsort.TestSimpleExternalSort
-
- dirTestWatcher - Static variable in class org.apache.drill.exec.physical.impl.xsort.TestSortSpillWithException
-
- dirTestWatcher - Static variable in class org.apache.drill.exec.record.TestVectorContainer
-
- dirTestWatcher - Variable in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- dirTestWatcher - Variable in class org.apache.drill.exec.server.rest.StatusResourcesTest
-
- dirTestWatcher - Static variable in class org.apache.drill.exec.store.log.TestLogReader
-
- dirTestWatcher - Static variable in class org.apache.drill.exec.store.parquet.ParquetInternalsTest
-
- dirTestWatcher - Variable in class org.apache.drill.exec.store.sys.TestPStoreProviders
-
- dirTestWatcher - Variable in class org.apache.drill.exec.util.TestQueryMemoryAlloc
-
- dirTestWatcher - Variable in class org.apache.drill.test.ClusterFixtureBuilder
-
- dirTestWatcher - Static variable in class org.apache.drill.test.ClusterTest
-
- dirTestWatcher - Variable in class org.apache.drill.test.ExampleTest
-
This test watcher creates all the temp directories that are required for an integration test with a Drillbit.
- dirTestWatcher - Variable in class org.apache.drill.test.PhysicalOpUnitTestBase
-
- dirTestWatcher - Static variable in class org.apache.drill.test.SubOperatorTest
-
- disable() - Method in class org.apache.drill.test.LogFixture.LogFixtureBuilder
-
Turns off all logging.
- DISABLE_CACHE_CONFIG - Static variable in class org.apache.drill.exec.compile.CodeCompiler
-
Disables the code cache.
- DISABLE_FULL_TABLE_SCAN - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- DISABLE_HJ - Static variable in class org.apache.drill.exec.physical.impl.join.JoinTestBase
-
- DISABLE_JOIN_OPTIMIZATION - Static variable in class org.apache.drill.exec.physical.impl.join.JoinTestBase
-
- DISABLE_MJ - Static variable in class org.apache.drill.exec.physical.impl.join.JoinTestBase
-
- DISABLE_NLJ_SCALAR - Static variable in class org.apache.drill.exec.physical.impl.join.JoinTestBase
-
- 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
-
- disableDecimalDataType() - Static method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- disableDecimalDataType() - Static method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- disableDecimalDataType() - Static method in class org.apache.drill.exec.store.parquet.columnreaders.TestColumnReaderFactory
-
- disableDecimalDataType() - Static method in class org.apache.drill.exec.store.parquet.TestFixedlenDecimal
-
- disableDecimalDataType() - Static method in class org.apache.drill.exec.store.parquet.TestVarlenDecimal
-
- disableDecimalDataType() - Static method in class org.apache.drill.TestFunctionsQuery
-
- disableFunctionReturn() - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
-
Clear the indication that this value is used as a function return value.
- disableHashJoin() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- 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
-
- disableMergeJoin() - Static method in class org.apache.drill.exec.physical.impl.join.TestHashJoinAdvanced
-
- 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
-
- dispatcher - Variable in class org.apache.drill.exec.coord.zk.ZkEphemeralStore
-
- dispose(DrillClient) - Method in class org.apache.drill.exec.server.DrillClientFactory
-
- 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
-
- DistributedCache - Interface in org.apache.drill.exec.cache
-
- DistributedCache.CacheConfig<K,V> - Class in org.apache.drill.exec.cache
-
- 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.
- 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.
- DistributionField(int) - Constructor for class org.apache.drill.exec.planner.physical.DrillDistributionTrait.DistributionField
-
- divideBy(RelOptCost) - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
-
- 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
-
- doDouble() - Method in class org.apache.drill.exec.compile.ExampleTemplateWithInner.TheInnerClass
-
Not overridden.
- doDouble() - Method in class org.apache.drill.exec.compile.ExampleTemplateWithInner.TheInnerClass.DoubleInner
-
- 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.TopN.PriorityQueueTemplate
-
Evaluates the value of record at leftIndex and rightIndex w.r.t min heap condition.
- 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
-
- doInside() - Method in class org.apache.drill.exec.compile.ExampleTemplateWithInner.TheInnerClass
-
Because of how Drill does byte-code merging, the methods
on the inner class cannot be abstract; they must have an
empty implementation which is discarded and replaced with the
generated implementation.
- doInsideOutside() - Method in interface org.apache.drill.exec.compile.ExampleInner
-
- doInsideOutside() - Method in class org.apache.drill.exec.compile.ExampleTemplateWithInner
-
- 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
-
- doMatch(RelOptRuleCall, ScanPrel, ProjectPrel, FilterPrel) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaPushFilterIntoRecordGenerator
-
- done() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLenColumnBulkInput
- done() - Method in interface org.apache.drill.test.rowSet.RowSetWriter
-
Finish writing and finalize the row set being
written.
- done() - Method in class org.apache.drill.test.rowSet.RowSetWriterImpl
-
- dontPushdownIntoTopNWhenNoLimit() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitPlanning
-
- doOnMatch(IndexLogicalPlanCallContext) - Method in class org.apache.drill.exec.planner.index.rules.DbScanToIndexScanPrule
-
- doOnMatch(RelOptRuleCall, DrillLimitRel, DrillScanRel, DrillProjectRel) - Method in class org.apache.drill.exec.planner.logical.DrillPushLimitToScanRule
-
- doOnMatch(RowKeyJoinCallContext) - Method in class org.apache.drill.exec.planner.logical.DrillPushRowKeyJoinToScanRule
-
- 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
-
- doOutside() - Method in interface org.apache.drill.exec.compile.ExampleInner
-
- doOutside() - Method in class org.apache.drill.exec.compile.ExampleTemplateWithInner
-
Outer class methods can be abstract.
- 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<BitControl.CustomMessage>, ControlConnection) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.CustomMessageSender
-
- 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
-
- doRpcCall(RpcOutcomeListener<BitControl.CustomMessage>, ControlConnection) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.SyncCustomMessageSender
-
- doSetup(RecordBatch) - Method in interface org.apache.drill.exec.expr.fn.impl.ValueVectorHashHelper.Hash64
-
- doSetup(RecordBatch) - Method in class org.apache.drill.exec.expr.fn.impl.ValueVectorHashHelper.Hash64Template
-
- doSetup(RecordBatch) - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
-
- doSetup(VectorContainer, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
-
- doSetup(FragmentContextImpl, 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, 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(VectorContainer, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
-
Stores the reference to the hyperBatch container which holds all the records across incoming batches in it.
- doSetup(FragmentContext, RecordBatch, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.union.UnionAllerTemplate
-
- doSetup(FragmentContext, 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(FragmentContext, VectorAccessible, RecordBatch) - Method in class org.apache.drill.exec.physical.impl.xsort.SingleBatchSorterTemplate
-
- doSetup(DrillbitContext) - Method in class org.apache.drill.exec.server.rest.auth.DrillHttpConstraintSecurityHandler
-
- doSetup(DrillbitContext) - Method in class org.apache.drill.exec.server.rest.auth.FormSecurityHanlder
-
- doSetup(DrillbitContext) - Method in class org.apache.drill.exec.server.rest.auth.SpnegoSecurityHandler
-
- doSort() - Method in class org.apache.drill.exec.SortTest
-
- doStart() - Method in class org.apache.drill.exec.server.rest.auth.DrillHttpConstraintSecurityHandler
-
- doStart() - Method in class org.apache.drill.exec.server.rest.auth.DrillHttpSecurityHandlerProvider
-
- doStart() - Method in class org.apache.drill.exec.server.rest.auth.DrillSpnegoLoginService
-
- doStop() - Method in class org.apache.drill.exec.server.rest.auth.DrillHttpConstraintSecurityHandler
-
- doStop() - Method in class org.apache.drill.exec.server.rest.auth.DrillHttpSecurityHandlerProvider
-
- dot - Variable in class org.apache.drill.exec.compile.ClassTransformer.ClassNames
-
- 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
-
- doTest(String, String[], TypeProtos.MajorType[], String[]) - Method in class org.apache.drill.exec.fn.interp.ExpressionInterpreterTest
-
- doTest(String, String[], TypeProtos.MajorType[], String[], BitControl.PlanFragment) - Method in class org.apache.drill.exec.fn.interp.ExpressionInterpreterTest
-
- doTest() - Method in class org.apache.drill.test.rowSet.test.PerformanceTool.ArrayWriterTester
-
- doTest() - Method in class org.apache.drill.test.rowSet.test.PerformanceTool.NullableVectorTester
-
- doTest() - Method in class org.apache.drill.test.rowSet.test.PerformanceTool.NullableWriterTester
-
- doTest() - Method in class org.apache.drill.test.rowSet.test.PerformanceTool.PerfTester
-
- doTest() - Method in class org.apache.drill.test.rowSet.test.PerformanceTool.RepeatedVectorTester
-
- doTest() - Method in class org.apache.drill.test.rowSet.test.PerformanceTool.RequiredVectorTester
-
- doTest() - Method in class org.apache.drill.test.rowSet.test.PerformanceTool.RequiredWriterTester
-
- doubleArray(Double...) - Static method in class org.apache.drill.test.rowSet.RowSetUtilities
-
- 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
-
- DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.DoubleHash
-
- DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.DoubleHash
-
- DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.DoubleHash
-
- DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.DoubleHash
-
- DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.DoubleHash
-
- DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.DoubleHash
-
- DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.DoubleHash
-
- DoubleHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.DoubleHash
-
- DoubleInner() - Constructor for class org.apache.drill.exec.compile.ExampleTemplateWithInner.TheInnerClass.DoubleInner
-
- DoubleValidator(String, OptionValidator.OptionDescription) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.DoubleValidator
-
- DoubleWriter(String) - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters.DoubleWriter
-
- 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(RecordBatch.IterOutcome) - Method in interface org.apache.drill.exec.physical.impl.aggregate.StreamingAggregator
-
- doWork(RecordBatch.IterOutcome) - 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.filter.RuntimeFilterRecordBatch
-
- 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() - Method in class org.apache.drill.exec.physical.impl.limit.PartitionLimitRecordBatch
-
- 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.rangepartitioner.RangePartitionRecordBatch
-
- 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.unnest.UnnestRecordBatch
-
- 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.AbstractUnaryRecordBatch
-
- drill() - Method in class org.apache.drill.exec.cache.DistributedCache.CacheConfigBuilder
-
- DRILL1061() - Method in class org.apache.drill.TestBugFixes
-
- DRILL1126() - Method in class org.apache.drill.TestBugFixes
-
- drill1649() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- drill1652() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- drill1653() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- drill1660() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- drill1671() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- drill1673() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- Drill2130JavaExecHamcrestConfigurationTest - Class in org.apache.drill.exec.test
-
- Drill2130JavaExecHamcrestConfigurationTest() - Constructor for class org.apache.drill.exec.test.Drill2130JavaExecHamcrestConfigurationTest
-
- Drill2283InfoSchemaVarchar1BugTest - Class in org.apache.drill.exec.store.ischema
-
- Drill2283InfoSchemaVarchar1BugTest() - Constructor for class org.apache.drill.exec.store.ischema.Drill2283InfoSchemaVarchar1BugTest
-
- drill3069() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- drill3370() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- Drill3484() - Method in class org.apache.drill.TestBugFixes
-
This test is not checking results because the bug fixed only appears with functions taking no arguments.
- DRILL883() - Method in class org.apache.drill.TestBugFixes
-
- drill_3353() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- drill_4032() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- drill_4479() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- drill_958bugTest() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- DRILL_CONFORMANCE - Static variable in class org.apache.drill.exec.planner.sql.DrillParserConfig
-
- DRILL_EXEC_SYS_STORE_PROVIDER_ZK_BLOBROOT - Static variable in class org.apache.drill.exec.store.sys.store.provider.ZookeeperPersistentStoreProvider
-
- DRILL_FILTER_INTO_JOIN - Static variable in class org.apache.drill.exec.planner.logical.DrillFilterJoinRules
-
The same as above, but with Drill's operators.
- DRILL_FILTER_MERGE_RULE - Static variable in interface org.apache.drill.exec.planner.RuleInstance
-
- 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_PUSH_TRANSITIVE_PREDICATES_RULE - Static variable in interface org.apache.drill.exec.planner.RuleInstance
-
Instance of the rule that infers predicates from on a
Join
and creates
Filter
s if those predicates can be pushed
to its inputs.
- 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_AGGREGATE_FACTORY - Static variable in class org.apache.drill.exec.planner.logical.DrillRelFactories
-
- 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.DrillFilterAggregateTransposeRule
-
- DRILL_LOGICAL_INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillPushProjectIntoScanRule
-
- 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_SEMI_JOIN_FACTORY - Static variable in class org.apache.drill.exec.planner.logical.DrillRelFactories
-
- 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(SqlKind) - Constructor for class org.apache.drill.exec.planner.sql.DrillAvgVarianceConvertlet
-
- DrillBaseComputeScalePrecision - Class in org.apache.drill.exec.planner.types.decimal
-
- DrillBaseComputeScalePrecision(int, int, int, int) - Constructor for class org.apache.drill.exec.planner.types.decimal.DrillBaseComputeScalePrecision
-
- DrillBigIntConverter(BigIntWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillBigIntConverter
-
- 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 - Variable in class org.apache.drill.exec.store.sys.BitToUserConnectionIterator.ConnectionInfo
-
- drillbit() - Method in class org.apache.drill.test.ClusterFixture
-
- drillbit(String) - Method in class org.apache.drill.test.ClusterFixture
-
- 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
-
- drillbitContext - Variable in class org.apache.drill.test.PhysicalOpUnitTestBase
-
- drillBitCount - Static variable in class org.apache.drill.exec.client.ConnectTriesPropertyTestClusterBits
-
- 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.Se - Class in org.apache.drill.exec.coord
-
- DrillbitInfo(CoordinationProtos.DrillbitEndpoint, boolean, boolean) - Constructor for class org.apache.drill.exec.server.rest.DrillRoot.DrillbitInfo
-
- DrillbitInstance() - Constructor for class org.apache.drill.exec.store.sys.DrillbitIterator.DrillbitInstance
-
- DrillbitIterator - Class in org.apache.drill.exec.store.sys
-
- DrillbitIterator(ExecutorFragmentContext) - Constructor for class org.apache.drill.exec.store.sys.DrillbitIterator
-
- DrillbitIterator.DrillbitInstance - Class in org.apache.drill.exec.store.sys
-
- 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.
- drillbits - Static variable in class org.apache.drill.exec.client.ConnectTriesPropertyTestClusterBits
-
- drillbits() - Method in class org.apache.drill.test.ClusterFixture
-
- 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.
- DrillBoolConverter(BitWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillBoolConverter
-
- 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
-
- DrillCalciteSqlBetweenOperatorWrapper - Class in org.apache.drill.exec.planner.sql
-
This class serves as a wrapper class for SqlBetweenOperator.
- DrillCalciteSqlBetweenOperatorWrapper(SqlBetweenOperator) - Constructor for class org.apache.drill.exec.planner.sql.DrillCalciteSqlBetweenOperatorWrapper
-
- 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
-
- DrillCalciteWrapperUtility - Class in org.apache.drill.exec.planner.sql.parser
-
This utility contains the static functions to manipulate
DrillCalciteSqlWrapper
,
DrillCalciteSqlOperatorWrapper
DrillCalciteSqlFunctionWrapper
and
DrillCalciteSqlAggFunctionWrapper
.
- 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
-
- DrillClientFactory - Class in org.apache.drill.exec.server
-
- DrillClientFactory() - Constructor for class org.apache.drill.exec.server.DrillClientFactory
-
- DrillClientSystemTest - Class in org.apache.drill.exec.client
-
- DrillClientSystemTest() - Constructor for class org.apache.drill.exec.client.DrillClientSystemTest
-
- DrillClientTest - Class in org.apache.drill.exec.client
-
The unit test case will read a physical plan in json format.
- DrillClientTest() - Constructor for class org.apache.drill.exec.client.DrillClientTest
-
- DrillComplexWriterAggFuncHolder - Class in org.apache.drill.exec.expr.fn
-
- DrillComplexWriterAggFuncHolder(FunctionAttributes, FunctionInitializer) - Constructor for class org.apache.drill.exec.expr.fn.DrillComplexWriterAggFuncHolder
-
- 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
-
- DrillConditions - Class in org.apache.drill.exec.planner.logical
-
- DrillConditions() - Constructor for class org.apache.drill.exec.planner.logical.DrillConditions
-
- drillConf - Variable in class org.apache.drill.test.PhysicalOpUnitTestBase
-
- drillConfig - Static variable in class org.apache.drill.exec.client.ConnectTriesPropertyTestClusterBits
-
- 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
-
- DrillConformance - Class in org.apache.drill.exec.planner.sql
-
Drill's SQL conformance is SqlConformanceEnum.DEFAULT with a couple of deviations.
- DrillConformance() - Constructor for class org.apache.drill.exec.planner.sql.DrillConformance
-
- DrillConformance(SqlConformanceEnum) - Constructor for class org.apache.drill.exec.planner.sql.DrillConformance
-
- 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
-
- DrillCorrelateRule - Class in org.apache.drill.exec.planner.logical
-
- DrillCorruptedDateConverter(DateWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillCorruptedDateConverter
-
- 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
-
- DrillCostFactory() - Constructor for class org.apache.drill.exec.planner.cost.DrillCostBase.DrillCostFactory
-
- DrillDateConverter(DateWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillDateConverter
-
- DrillDefaultRelMetadataProvider - Class in org.apache.drill.exec.planner.cost
-
- DrillDirectScanRel - Class in org.apache.drill.exec.planner.logical
-
- 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(DrillDistributionTrait.DistributionType, ImmutableList<DrillDistributionTrait.DistributionField>, PartitionFunction) - Constructor for class org.apache.drill.exec.planner.physical.DrillDistributionTrait
-
- DrillDistributionTrait.DistributionField - Class in org.apache.drill.exec.planner.physical
-
- DrillDistributionTrait.DistributionType - Enum in org.apache.drill.exec.planner.physical
-
- DrillDistributionTraitDef - Class in org.apache.drill.exec.planner.physical
-
- DrillErrorHandler - Class in org.apache.drill.exec.server.rest.auth
-
Custom ErrorHandler class for Drill's WebServer to have better error message in case when SPNEGO login failed and
what to do next.
- DrillErrorHandler() - Constructor for class org.apache.drill.exec.server.rest.auth.DrillErrorHandler
-
- DrillExceptionUtilTest - Class in org.apache.drill.exec.util
-
- DrillExceptionUtilTest() - Constructor for class org.apache.drill.exec.util.DrillExceptionUtilTest
-
- 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, OperatorStats) - Constructor for class org.apache.drill.exec.store.dfs.DrillFileSystem
-
- DrillFileSystem.DebugStackTrace - Class in org.apache.drill.exec.store.dfs
-
- 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
-
- DrillFileSystemUtilTest - Class in org.apache.drill.exec.util
-
- DrillFileSystemUtilTest() - Constructor for class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- DrillFilterAggregateTransposeRule - Class in org.apache.drill.exec.planner.logical
-
- DrillFilterItemStarReWriterRule - Class in org.apache.drill.exec.planner.logical
-
Rule will transform item star fields in filter and replaced with actual field references.
- DrillFilterItemStarReWriterRule() - Constructor for class org.apache.drill.exec.planner.logical.DrillFilterItemStarReWriterRule
-
- DrillFilterJoinRules - Class in org.apache.drill.exec.planner.logical
-
- 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 LogicalFilter
to a Drill "filter" operation.
- DrillFixedBinaryToTimeStampConverter(TimeStampWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillFixedBinaryToTimeStampConverter
-
- DrillFixedBinaryToVarbinaryConverter(VarBinaryWriter, int, DrillBuf) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillFixedBinaryToVarbinaryConverter
-
- DrillFixedLengthByteArrayToInterval(IntervalWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillFixedLengthByteArrayToInterval
-
- 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
-
- DrillFloat4Converter(Float4Writer) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillFloat4Converter
-
- DrillFloat8Converter(Float8Writer) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillFloat8Converter
-
- 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, OperatorStats) - Constructor for class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
-
- DrillFSDataInputStream(FSDataInputStream, OperatorStats, 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
-
- DrillHttpConstraintSecurityHandler - Class in org.apache.drill.exec.server.rest.auth
-
Accessor class that extends the ConstraintSecurityHandler to expose protected method's for start and stop of Handler.
- DrillHttpConstraintSecurityHandler() - Constructor for class org.apache.drill.exec.server.rest.auth.DrillHttpConstraintSecurityHandler
-
- DrillHttpSecurityHandlerProvider - Class in org.apache.drill.exec.server.rest.auth
-
- DrillHttpSecurityHandlerProvider(DrillConfig, DrillbitContext) - Constructor for class org.apache.drill.exec.server.rest.auth.DrillHttpSecurityHandlerProvider
-
- 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
-
- DrillIndexCollection - Class in org.apache.drill.exec.planner.index
-
- DrillIndexCollection(RelNode, Set<DrillIndexDescriptor>) - Constructor for class org.apache.drill.exec.planner.index.DrillIndexCollection
-
- DrillIndexDefinition - Class in org.apache.drill.exec.planner.index
-
- DrillIndexDefinition(List<LogicalExpression>, CollationContext, List<LogicalExpression>, List<LogicalExpression>, String, String, IndexDefinition.IndexType, RelFieldCollation.NullDirection) - Constructor for class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- DrillIndexDescriptor - Class in org.apache.drill.exec.planner.index
-
- DrillIndexDescriptor(List<LogicalExpression>, CollationContext, List<LogicalExpression>, List<LogicalExpression>, String, String, IndexDefinition.IndexType, RelFieldCollation.NullDirection) - Constructor for class org.apache.drill.exec.planner.index.DrillIndexDescriptor
-
- DrillIndexDescriptor(DrillIndexDefinition) - Constructor for class org.apache.drill.exec.planner.index.DrillIndexDescriptor
-
- DrillIndexProperties(IndexDescriptor, boolean, RexNode, RexBuilder, int, double, DrillScanRelBase) - Constructor for class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- DrillInitMethodVisitor - Class in org.apache.drill.exec.compile
-
- DrillInitMethodVisitor(String, MethodVisitor) - Constructor for class org.apache.drill.exec.compile.DrillInitMethodVisitor
-
- DrillIntConverter(IntWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillIntConverter
-
- DrillJoin - Interface in org.apache.drill.exec.planner.logical
-
Interface which needs to be implemented by all the join relation expressions.
- 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
-
- DrillJoinRel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, int) - Constructor for class org.apache.drill.exec.planner.logical.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.
- DrillLateralJoinRel - Class in org.apache.drill.exec.planner.logical
-
- DrillLateralJoinRel(RelOptCluster, RelTraitSet, RelNode, RelNode, boolean, CorrelationId, ImmutableBitSet, SemiJoinType) - Constructor for class org.apache.drill.exec.planner.logical.DrillLateralJoinRel
-
- DrillLateralJoinRelBase - Class in org.apache.drill.exec.planner.common
-
- DrillLateralJoinRelBase(RelOptCluster, RelTraitSet, RelNode, RelNode, boolean, CorrelationId, ImmutableBitSet, SemiJoinType) - Constructor for class org.apache.drill.exec.planner.common.DrillLateralJoinRelBase
-
- 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
-
- DrillLimitRel(RelOptCluster, RelTraitSet, RelNode, RexNode, RexNode, boolean) - 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
- DrillLogicalTestUtils - Class in org.apache.drill.exec.planner.logical
-
- DrillLogicalTestUtils() - Constructor for class org.apache.drill.exec.planner.logical.DrillLogicalTestUtils
-
- DrillMergeFilterRule - Class in org.apache.drill.exec.planner.logical
-
MergeFilterRule implements the rule for combining two Filter
s
- DrillMergeProjectRule - Class in org.apache.drill.exec.planner.logical
-
Rule for merging two projects provided the projects aren't projecting identical sets of
input references.
- 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
-
- DrillOptiq.RexToDrill - Class in org.apache.drill.exec.planner.logical
-
- DrillOptiqTest - Class in org.apache.drill.exec.planner.logical
-
- DrillOptiqTest() - Constructor for class org.apache.drill.exec.planner.logical.DrillOptiqTest
-
- 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.DrillBigIntConverter - Class in org.apache.drill.exec.store.parquet2
-
- DrillParquetGroupConverter.DrillBoolConverter - Class in org.apache.drill.exec.store.parquet2
-
- DrillParquetGroupConverter.DrillCorruptedDateConverter - Class in org.apache.drill.exec.store.parquet2
-
- DrillParquetGroupConverter.DrillDateConverter - Class in org.apache.drill.exec.store.parquet2
-
- 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.DrillFixedBinaryToVarbinaryConverter - Class in org.apache.drill.exec.store.parquet2
-
Parquet currently supports a fixed binary type, which is not implemented in Drill.
- DrillParquetGroupConverter.DrillFixedLengthByteArrayToInterval - Class in org.apache.drill.exec.store.parquet2
-
- DrillParquetGroupConverter.DrillFloat4Converter - Class in org.apache.drill.exec.store.parquet2
-
- DrillParquetGroupConverter.DrillFloat8Converter - Class in org.apache.drill.exec.store.parquet2
-
- DrillParquetGroupConverter.DrillIntConverter - Class in org.apache.drill.exec.store.parquet2
-
- DrillParquetGroupConverter.DrillTimeConverter - Class in org.apache.drill.exec.store.parquet2
-
- DrillParquetGroupConverter.DrillTimeStampConverter - Class in org.apache.drill.exec.store.parquet2
-
- DrillParquetGroupConverter.DrillVarBinaryConverter - Class in org.apache.drill.exec.store.parquet2
-
- DrillParquetGroupConverter.DrillVarCharConverter - Class in org.apache.drill.exec.store.parquet2
-
- DrillParquetGroupConverter.DrillVarDecimalConverter - Class in org.apache.drill.exec.store.parquet2
-
- 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, 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
-
- 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
-
- DrillProjectLateralJoinTransposeRule - Class in org.apache.drill.exec.planner.logical
-
- DrillProjectLateralJoinTransposeRule(PushProjector.ExprCondition, RelBuilderFactory) - Constructor for class org.apache.drill.exec.planner.logical.DrillProjectLateralJoinTransposeRule
-
- DrillProjectPushIntoLateralJoinRule - Class in org.apache.drill.exec.planner.logical
-
- DrillProjectPushIntoLateralJoinRule(RelBuilderFactory) - Constructor for class org.apache.drill.exec.planner.logical.DrillProjectPushIntoLateralJoinRule
-
- 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.
- DrillPushFilterPastProjectRule - Class in org.apache.drill.exec.planner.logical
-
- DrillPushLimitToScanRule - Class in org.apache.drill.exec.planner.logical
-
- DrillPushProjectIntoScanRule - Class in org.apache.drill.exec.planner.logical
-
When table support project push down, rule can be applied to reduce number of read columns
thus improving scan operator performance.
- 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
-
- DrillPushRowKeyJoinToScanRule - Class in org.apache.drill.exec.planner.logical
-
This rule implements the run-time filter pushdown via the rowkey join for queries with row-key filters.
- DrillPushRowKeyJoinToScanRule.MatchRelJ - 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.
- DrillRelBuilder - Class in org.apache.drill.exec.planner
-
- DrillRelBuilder(Context, RelOptCluster, RelOptSchema) - Constructor for class org.apache.drill.exec.planner.DrillRelBuilder
-
- 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
-
- DrillRelMdSelectivity - Class in org.apache.drill.exec.planner.cost
-
- DrillRelMdSelectivity() - Constructor for class org.apache.drill.exec.planner.cost.DrillRelMdSelectivity
-
- 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
-
- DrillRelOptUtil.InputRefVisitor - Class in org.apache.drill.exec.planner.common
-
InputRefVisitor is a utility class used to collect all the RexInputRef nodes in a
RexNode.
- DrillRelOptUtil.ProjectPushInfo - Class in org.apache.drill.exec.planner.common
-
Stores information about fields, their names and types.
- DrillRelOptUtil.RexFieldsTransformer - Class in org.apache.drill.exec.planner.common
-
RexFieldsTransformer is a utility class used to convert column refs in a RexNode
based on inputRefMap (input to output ref map).
- 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.AnonWebUserConnectionProvider - Class in org.apache.drill.exec.server.rest
-
- DrillRestServer.AuthWebUserConnectionProvider - Class in org.apache.drill.exec.server.rest
-
- DrillRestServer.DrillUserPrincipalProvider - Class in org.apache.drill.exec.server.rest
-
- DrillRestServer.UserAuthEnabled - Class in org.apache.drill.exec.server.rest
-
- 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.DrillbitInfo - Class in org.apache.drill.exec.server.rest
-
- DrillRoot.QueueInfo - Class in org.apache.drill.exec.server.rest
-
Pretty-printing wrapper class around the ZK-based queue summary.
- 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/physical scan rel implemented in Drill.
- DrillScanRelBase(RelOptCluster, RelTraitSet, RelOptTable, List<SchemaPath>) - Constructor for class org.apache.drill.exec.planner.common.DrillScanRelBase
-
- DrillScanRelBase(RelOptCluster, RelTraitSet, GroupScan, RelOptTable) - Constructor for class org.apache.drill.exec.planner.common.DrillScanRelBase
-
- DrillScanRule - Class in org.apache.drill.exec.planner.logical
-
- DrillSchemaFactory(String) - Constructor for class org.apache.drill.exec.store.StoragePluginRegistryImpl.DrillSchemaFactory
-
- 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
-
- DrillSemiJoinRel - Class in org.apache.drill.exec.planner.logical
-
- DrillSemiJoinRel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, ImmutableIntList, ImmutableIntList) - Constructor for class org.apache.drill.exec.planner.logical.DrillSemiJoinRel
-
- DrillSeparatePlanningTest - Class in org.apache.drill.exec
-
Class to test different planning use cases (separate from query execution)
- DrillSeparatePlanningTest() - Constructor for class org.apache.drill.exec.DrillSeparatePlanningTest
-
- 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.
- DrillSpnegoAuthenticator - Class in org.apache.drill.exec.server.rest.auth
-
Custom SpnegoAuthenticator for Drill
- DrillSpnegoAuthenticator(String) - Constructor for class org.apache.drill.exec.server.rest.auth.DrillSpnegoAuthenticator
-
- DrillSpnegoLoginService - Class in org.apache.drill.exec.server.rest.auth
-
Custom implementation of DrillSpnegoLoginService to avoid the need of passing targetName in a config file,
to include the SPNEGO OID and the way UserIdentity is created.
- DrillSpnegoLoginService(DrillbitContext) - Constructor for class org.apache.drill.exec.server.rest.auth.DrillSpnegoLoginService
-
- 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
-
- 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
-
- DrillSqlDescribeTable - Class in org.apache.drill.exec.planner.sql.parser
-
Sql parser tree node to represent statement:
{ DESCRIBE | DESC } tblname [col_name | wildcard ]
- DrillSqlDescribeTable(SqlParserPos, SqlIdentifier, SqlIdentifier, SqlNode) - Constructor for class org.apache.drill.exec.planner.sql.parser.DrillSqlDescribeTable
-
- DrillSqlLineApplication - Class in org.apache.drill.exec.client
-
Drill SqlLine application configuration.
- DrillSqlLineApplication() - Constructor for class org.apache.drill.exec.client.DrillSqlLineApplication
-
- DrillSqlLineApplication(String, String) - Constructor for class org.apache.drill.exec.client.DrillSqlLineApplication
-
- DrillSqlLineApplicationTest - Class in org.apache.drill.exec.client
-
- DrillSqlLineApplicationTest() - Constructor for class org.apache.drill.exec.client.DrillSqlLineApplicationTest
-
- 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
-
- 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>, List<RexNode>, 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>, List<RexNode>, boolean) - Constructor for class org.apache.drill.exec.planner.common.DrillStoreRelBase
-
- DrillSystemTestBase - Class in org.apache.drill.exec
-
Base class for Drill system tests.
- DrillSystemTestBase() - Constructor for class org.apache.drill.exec.DrillSystemTestBase
-
- 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.
- DrillTestWrapper - Class in org.apache.drill.test
-
An object to encapsulate the options for a Drill unit test, as well as the execution methods to perform the tests and
validation of results.
- DrillTestWrapper(TestBuilder, DrillTestWrapper.TestServices, Object, UserBitShared.QueryType, String, String, UserBitShared.QueryType, boolean, boolean, String[], List<Map<String, Object>>, int, int) - Constructor for class org.apache.drill.test.DrillTestWrapper
-
- DrillTestWrapper.TestServices - Interface in org.apache.drill.test
-
- 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
-
- DrillTimeConverter(TimeWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillTimeConverter
-
- DrillTimeStampConverter(TimeStampWriter) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillTimeStampConverter
-
- 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
-
- DrillUnnestRel - Class in org.apache.drill.exec.planner.logical
-
- DrillUnnestRel(RelOptCluster, RelTraitSet, RelDataType, RexNode) - Constructor for class org.apache.drill.exec.planner.logical.DrillUnnestRel
-
- DrillUnnestRelBase - Class in org.apache.drill.exec.planner.common
-
- DrillUnnestRelBase(RelOptCluster, RelTraitSet, RexNode) - Constructor for class org.apache.drill.exec.planner.common.DrillUnnestRelBase
-
- DrillUnnestRule - Class in org.apache.drill.exec.planner.logical
-
- 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
-
- DrillUserPrincipalProvider() - Constructor for class org.apache.drill.exec.server.rest.DrillRestServer.DrillUserPrincipalProvider
-
- DrillValuesRel - Class in org.apache.drill.exec.planner.logical
-
Logical Values implementation in Drill.
- DrillValuesRel(RelOptCluster, RelDataType, List<? extends List<RexLiteral>>, RelTraitSet) - Constructor for class org.apache.drill.exec.planner.logical.DrillValuesRel
-
- DrillValuesRel(RelOptCluster, RelDataType, List<? extends List<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, List<? extends List<RexLiteral>>, RelTraitSet) - Constructor for class org.apache.drill.exec.planner.common.DrillValuesRelBase
-
- DrillValuesRelBase(RelOptCluster, RelDataType, List<? extends List<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.
- DrillVarBinaryConverter(VarBinaryWriter, DrillBuf) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillVarBinaryConverter
-
- DrillVarCharConverter(VarCharWriter, DrillBuf) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillVarCharConverter
-
- DrillVarDecimalConverter(VarDecimalWriter, int, int, DrillBuf) - Constructor for class org.apache.drill.exec.store.parquet2.DrillParquetGroupConverter.DrillVarDecimalConverter
-
- 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
-
- 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(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ViewHandler.DropView
-
- 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.
- dropViewHelper(String, String, String) - Static method in class org.apache.drill.exec.sql.TestBaseViewSupport
-
Drop view with given parameters.
- dropViewIfExistsHelper(String, String, String, Boolean) - Static method in class org.apache.drill.exec.sql.TestBaseViewSupport
-
Drop view if exists with given parameters.
- dropViewIfExistsWhenItIsATable() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- dropViewIfExistsWhenViewDoesNotExist() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- dropViewIfExistsWhenViewExists() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- DUMMY_FILTER - Static variable in class org.apache.drill.exec.util.FileSystemUtil
-
Filter that will accept all files and directories.
- DummyArrayImpl - Class in org.apache.drill.exec.store.pcapng.schema
-
- DummyArrayImpl() - Constructor for class org.apache.drill.exec.store.pcapng.schema.DummyArrayImpl
-
- 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
-
- DummyImpl - Class in org.apache.drill.exec.store.pcapng.schema
-
- DummyImpl() - Constructor for class org.apache.drill.exec.store.pcapng.schema.DummyImpl
-
- DummyWriterTest - Class in org.apache.drill.test.rowSet.test
-
- DummyWriterTest() - Constructor for class org.apache.drill.test.rowSet.test.DummyWriterTest
-
- DummyWriterTest.RootWriterFixture - Class in org.apache.drill.test.rowSet.test
-
Test only, bare-bones tuple writer used to gather the dummy
column writers.
- dump(StringBuilder, int) - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
-
Dump the value's members to a StringBuilder.
- dump() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.filter.FilterRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.filter.RuntimeFilterRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.join.LateralJoinBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.join.MergeJoinBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.join.RowKeyJoinBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.limit.LimitRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.limit.PartitionLimitRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.MockRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.producer.ProducerConsumerBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.project.ProjectRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.protocol.OperatorRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.rangepartitioner.RangePartitionRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.sort.SortBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.svremover.RemovingRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.TopN.TopNBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.trace.TraceRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.union.UnionAllRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.unnest.UnnestRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
-
- dump() - Method in class org.apache.drill.exec.physical.impl.window.WindowFrameRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.WriterRecordBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatch
-
- dump() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.ExternalSortBatch
-
- dump(HierarchicalFormatter) - Method in class org.apache.drill.exec.physical.rowSet.impl.ColumnState
-
- dump(HierarchicalFormatter) - Method in class org.apache.drill.exec.physical.rowSet.impl.ColumnState.PrimitiveColumnState
-
- dump(HierarchicalFormatter) - Method in class org.apache.drill.exec.physical.rowSet.impl.ListState.ListVectorState
-
- dump(HierarchicalFormatter) - Method in class org.apache.drill.exec.physical.rowSet.impl.NullableVectorState
-
- dump(HierarchicalFormatter) - Method in class org.apache.drill.exec.physical.rowSet.impl.NullVectorState
-
- dump(HierarchicalFormatter) - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedListState.RepeatedListVectorState
-
- dump(HierarchicalFormatter) - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedVectorState
-
- dump(HierarchicalFormatter) - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- dump(HierarchicalFormatter) - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl.ResultSetOptions
-
- dump(HierarchicalFormatter) - Method in class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState
-
- dump(HierarchicalFormatter) - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState
-
- dump(HierarchicalFormatter) - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState.MapState
-
- dump(HierarchicalFormatter) - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState.MapVectorState
-
- dump(HierarchicalFormatter) - Method in class org.apache.drill.exec.physical.rowSet.impl.UnionState.UnionVectorState
-
- dump(HierarchicalFormatter) - Method in interface org.apache.drill.exec.physical.rowSet.impl.VectorState
-
- dump() - Method in interface org.apache.drill.exec.record.RecordBatch
-
Perform dump of this batch's state to logs.
- dump() - Method in class org.apache.drill.exec.record.SchemalessBatch
-
- dump() - Method in class org.apache.drill.exec.record.SimpleRecordBatch
-
- dumpBatches() - Method in class org.apache.drill.exec.physical.impl.BaseRootExec
-
- dumpBatches() - Method in interface org.apache.drill.exec.physical.impl.RootExec
-
Dump failed batches' state preceded by its parent's state to logs.
- dumpBatches() - Method in class org.apache.drill.exec.physical.impl.SimpleRootExec
-
Deprecated.
- 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.
- DumpCatTest - Class in org.apache.drill.exec.client
-
The unit test case will read a physical plan in json format.
- DumpCatTest() - Constructor for class org.apache.drill.exec.client.DumpCatTest
-
- duplicate() - Method in class org.apache.drill.exec.record.DeadBuf
-
- duplicate(BufferAllocator) - Method in class org.apache.drill.exec.work.filter.RuntimeFilterWritable
-
- duration - Variable in class org.apache.drill.exec.store.sys.BitToUserConnectionIterator.ConnectionInfo
-
- 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.
- 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(LinkedHashMap<String, Class<?>>, List<List<T>>, int) - 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.
- 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.calcite.jdbc
-
This class is to allow us loading schemas from storage plugins later when CalciteSchema.getSubSchema(String, boolean)
is called.
- DynamicSchema - Class in org.apache.calcite.jdbc
-
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.calcite.jdbc.DynamicSchema
-
- GE - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
-
- gen - Variable in class org.apache.drill.exec.vector.complex.fn.BasicJsonOutput
-
- 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
-
- generateDoubleNestedSchema_NoNullValues() - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- 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
-
- generateFile() - Static method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- generateFileWork(List<FileStatus>, boolean) - Method in class org.apache.drill.exec.store.schedule.BlockMapBuilder
-
- generateLimit(OrderedRel) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- generateLinkedList() - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- generateMapSchema_withNullValues() - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- generateMapSchemaComplex_withNullValues() - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- generateNestedArraySchema() - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- generateNestedArraySchema(int, int) - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- generateParquetFile(String, ParquetTestProperties) - Static method in class org.apache.drill.exec.store.parquet.TestFileGenerator
-
- generateSimpleArraySchema_NoNullValues() - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- generateSimpleEnumSchema_NoNullValues() - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- generateSimpleNestedSchema_NoNullValues() - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- generateSimplePrimitiveSchema_NoNullValues() - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- generateSimplePrimitiveSchema_NoNullValues(int) - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- generateSimplePrimitiveSchema_NoNullValues(int, String) - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
Generates Avro table with specified rows number in specified path.
- generateStringAndUtf8Data() - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- generateSV2Filterer() - Method in class org.apache.drill.exec.physical.impl.filter.FilterRecordBatch
-
- generateSV4Filterer() - Method in class org.apache.drill.exec.physical.impl.filter.FilterRecordBatch
-
- GenerateTestData - Class in org.apache.drill.exec.physical.impl.window
-
- GenerateTestData() - Constructor for class org.apache.drill.exec.physical.impl.window.GenerateTestData
-
- generateTestData() - Static method in class org.apache.drill.exec.TestQueriesOnLargeFile
-
- generateTestDataAndQueries() - Static method in class org.apache.drill.exec.physical.impl.partitionsender.TestPartitionSender
-
- generateTestDataAndQueries() - Static method in class org.apache.drill.exec.physical.impl.TestLocalExchange
-
Generate data for two tables.
- generateTestDataAndQueries() - Static method in class org.apache.drill.exec.physical.impl.TestOrderedMuxExchange
-
Generate data for two tables.
- generateTestFiles() - Static method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- generateTypeString(StringBuilder, boolean) - Method in class org.apache.drill.exec.planner.logical.ExtendableRelDataType
-
- 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
-
- generateUnionNestedArraySchema_withNullValues() - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- generateUnionNestedSchema_withNullValues() - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- generateUnionSchema_WithNonNullValues() - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- generateUnionSchema_WithNullValues() - Static method in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- generateViewName() - Static method in class org.apache.drill.exec.sql.TestBaseViewSupport
-
Generate a view name by appending the test class with a increasing counter.
- 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.
- GeneratorFunctions - Class in org.apache.drill.exec.fn.impl.testing
-
- GeneratorFunctions() - Constructor for class org.apache.drill.exec.fn.impl.testing.GeneratorFunctions
-
- GeneratorFunctions.IncreasingBigInt - Class in org.apache.drill.exec.fn.impl.testing
-
- GeneratorFunctions.RandomBigInt - Class in org.apache.drill.exec.fn.impl.testing
-
- GeneratorFunctions.RandomBigIntGauss - Class in org.apache.drill.exec.fn.impl.testing
-
- GeneratorFunctions.RandomFloat8 - Class in org.apache.drill.exec.fn.impl.testing
-
- GeneratorFunctions.RandomFloat8Gauss - Class in org.apache.drill.exec.fn.impl.testing
-
- 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
-
- GenericAccessorTest - Class in org.apache.drill.exec.vector.accessor
-
- GenericAccessorTest() - Constructor for class org.apache.drill.exec.vector.accessor.GenericAccessorTest
-
- GenericCopier - Class in org.apache.drill.exec.physical.impl.svremover
-
- GenericCopier() - Constructor for class org.apache.drill.exec.physical.impl.svremover.GenericCopier
-
- GenericCopierFactory - Class in org.apache.drill.exec.physical.impl.svremover
-
- GenericCopierFactory() - Constructor for class org.apache.drill.exec.physical.impl.svremover.GenericCopierFactory
-
- GenericCopierTest - Class in org.apache.drill.exec.physical.impl.svremover
-
- GenericCopierTest() - Constructor for class org.apache.drill.exec.physical.impl.svremover.GenericCopierTest
-
- GenericErrorMessage(String) - Constructor for class org.apache.drill.exec.server.rest.GenericExceptionMapper.GenericErrorMessage
-
- 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
-
- GenericMetadataDescriptor - Class in org.apache.drill.exec.store.image
-
- GenericMetadataDescriptor(GenericMetadataDirectory) - Constructor for class org.apache.drill.exec.store.image.GenericMetadataDescriptor
-
- GenericMetadataDirectory - Class in org.apache.drill.exec.store.image
-
- GenericMetadataDirectory() - Constructor for class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- GenericMetadataReader - Class in org.apache.drill.exec.store.image
-
- GenericMetadataReader() - Constructor for class org.apache.drill.exec.store.image.GenericMetadataReader
-
- GenericSV2BatchCopierTest - Class in org.apache.drill.exec.physical.impl.svremover
-
Verifies optimization in SV2 such that when total record to copy is same as number of records in the
underlying batch for SV2 then SV2 will do transfer rather than row by row copy
- GenericSV2BatchCopierTest() - Constructor for class org.apache.drill.exec.physical.impl.svremover.GenericSV2BatchCopierTest
-
- GenericSV2Copier - Class in org.apache.drill.exec.physical.impl.svremover
-
- GenericSV2Copier(RecordBatch, VectorContainer, SchemaChangeCallBack) - Constructor for class org.apache.drill.exec.physical.impl.svremover.GenericSV2Copier
-
- GenericSV2CopierTest - Class in org.apache.drill.exec.physical.impl.svremover
-
- GenericSV2CopierTest() - Constructor for class org.apache.drill.exec.physical.impl.svremover.GenericSV2CopierTest
-
- GenericSV4Copier - Class in org.apache.drill.exec.physical.impl.svremover
-
- GenericSV4Copier(RecordBatch, VectorContainer, SchemaChangeCallBack) - Constructor for class org.apache.drill.exec.physical.impl.svremover.GenericSV4Copier
-
- GenericSV4CopierTest - Class in org.apache.drill.exec.physical.impl.svremover
-
- GenericSV4CopierTest() - Constructor for class org.apache.drill.exec.physical.impl.svremover.GenericSV4CopierTest
-
- 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(int, int) - Method in class org.apache.drill.exec.expr.EscapeTest1.Monkey
-
- get(int, int, EscapeTest1.RR) - Method in class org.apache.drill.exec.expr.EscapeTest1.Monkey
-
- get(int) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PartitionStatSet
-
- get(String) - Method in class org.apache.drill.exec.physical.rowSet.project.ImpliedTupleRequest
-
- get(String) - Method in interface org.apache.drill.exec.physical.rowSet.project.RequestedTuple
-
- get(String) - Method in class org.apache.drill.exec.physical.rowSet.project.RequestedTupleImpl
-
- 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(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(VectorAccessible) - 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(Configuration, String) - Method in class org.apache.drill.exec.store.parquet.AbstractParquetScanBatchCreator.AbstractDrillFileSystemManager
-
- 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) - Method in class org.apache.drill.exec.store.sys.CaseInsensitivePersistentStore
-
- 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) - 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.UndefinedVersionDelegatingStore
-
- get(String, DataChangeVersion) - Method in class org.apache.drill.exec.store.sys.store.VersionedDelegatingStore
-
- 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, DataChangeVersion) - Method in interface org.apache.drill.exec.store.sys.VersionedPersistentStore
-
Returns the value for the given key if exists, null otherwise.
- get(String) - 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.
- get() - Method in class org.apache.drill.exec.util.concurrent.ExecutorServiceUtil.CallableTaskWrapper
- get(long, TimeUnit) - Method in class org.apache.drill.exec.util.concurrent.ExecutorServiceUtil.CallableTaskWrapper
- get() - Method in class org.apache.drill.test.BufferingQueryEventListener
-
- get() - Method in class org.apache.drill.test.QueryBuilder.QuerySummaryFuture
-
- get(long, TimeUnit) - Method in class org.apache.drill.test.QueryBuilder.QuerySummaryFuture
-
Not supported at present, just does a non-timeout get.
- getABit() - Method in class org.apache.drill.exec.DrillSystemTestBase
-
- getAccessibleScopes() - Method in class org.apache.drill.exec.server.options.OptionMetaData
-
- getAccessibleScopes() - Method in class org.apache.drill.exec.server.rest.StatusResources.OptionWrapper
-
- getAckNumber() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
-
- getAclForPath(String) - Method in class org.apache.drill.exec.coord.zk.ZKACLProviderDelegate
-
- getACLProvider(DrillConfig, String, BootStrapContext) - Static method in class org.apache.drill.exec.coord.zk.ZKACLProviderFactory
-
- getAclStatus(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
-
- getActiveEndpoints() - Method in class org.apache.drill.exec.ops.QueryContext
-
- getActualSize() - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
-
The amount of direct memory consumed by the hash table.
- getActualSize() - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate.BatchHolder
-
- getActualSize() - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
-
- getActualSize() - Method in class org.apache.drill.exec.record.RecordBatchSizer
-
- 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 class org.apache.drill.exec.store.sys.CaseInsensitivePersistentStore
-
- 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(AtomicInteger) - 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
-
- getAllJarNames() - Method in class org.apache.drill.exec.expr.fn.registry.LocalFunctionRegistry
-
Returns list of jar names registered in function registry.
- getAllJarsWithFunctionHolders() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
-
Retrieves all functions (holders) associated with all the jars
This is read operation, so several users can perform this operation at the same time.
- getAllJarsWithFunctionsHolders() - Method in class org.apache.drill.exec.expr.fn.FunctionImplementationRegistry
-
Retrieve all functions, mapped by source jars (after syncing)
- getAllJarsWithFunctionsHolders() - Method in class org.apache.drill.exec.expr.fn.registry.LocalFunctionRegistry
-
Returns a map of all function holders mapped by source jars
- getAlloc(EscapeTest1.Monkey) - Method in class org.apache.drill.exec.expr.EscapeTest1
-
- getAllocator() - Method in class org.apache.drill.exec.client.DrillClient
-
- getAllocator() - Method in class org.apache.drill.exec.ops.BaseOperatorContext
-
- getAllocator() - Method in interface org.apache.drill.exec.ops.FragmentContext
-
- getAllocator() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
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
-
- getAllocator() - Method in class org.apache.drill.exec.work.batch.AbstractDataCollector
- getAllocator() - Method in interface org.apache.drill.exec.work.batch.DataCollector
-
- getAllocator() - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- getAllocator() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- getAllocSizePerEntry() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
This returns actual entry size if rowCount > 0 or allocation size otherwise.
- 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
-
- getArgs() - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthExpression.FunctionCallExpr
-
- 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
-
- getAuthorizedProfiles(String, boolean) - Method in class org.apache.drill.exec.store.sys.ProfileIterator
-
- 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
-
- getAverageColumnSize(GroupScan) - Method in interface org.apache.drill.exec.planner.cost.PluginCost
-
- getAvgDensity() - Method in class org.apache.drill.exec.record.RecordBatchSizer
-
- getAvgInputBatchSize() - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getAvgInputBatchSize(int) - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getAvgInputRowWidth() - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getAvgInputRowWidth(int) - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getAvgOutputBatchSize() - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getAvgOutputRowWidth() - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getAvgRowSize() - Method in interface org.apache.drill.exec.planner.index.IndexProperties
-
- getAvgRowSize() - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- getAvgRowSize(String, boolean) - Method in interface org.apache.drill.exec.planner.index.Statistics
-
Returns the average row size for the specified filter condition
- getAvgRowSize() - Method in interface org.apache.drill.exec.planner.index.StatisticsPayload
-
- getAvgVariableLengthColumnTypePrecision(ParquetColumnMetadata) - Static method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.BatchSizingMemoryUtil
-
This method will return a default value for variable columns; it aims at minimizing internal fragmentation.
- getBackupZooKeeperServerNum() - Method in class org.apache.drill.exec.util.MiniZooKeeperCluster
-
- getBaseName() - Method in class org.apache.drill.exec.dotdrill.DotDrillFile
-
Return base file name without the parent directory and extensions.
- getBasePath() - Method in class org.apache.drill.exec.store.sys.store.LocalPersistentStore
-
- 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(ExecutorFragmentContext, SchemalessScan, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.base.SchemalessBatchCreator
-
- getBatch(ExecutorFragmentContext, HashAggregate, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggBatchCreator
-
- getBatch(ExecutorFragmentContext, StreamingAggregate, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggBatchCreator
-
- getBatch(ExecutorFragmentContext, T, List<RecordBatch>) - Method in interface org.apache.drill.exec.physical.impl.BatchCreator
-
- getBatch(ExecutorFragmentContext, Filter, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.filter.FilterBatchCreator
-
- getBatch(ExecutorFragmentContext, RuntimeFilterPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.filter.RuntimeFilterBatchCreator
-
- getBatch(ExecutorFragmentContext, FlattenPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenBatchCreator
-
- getBatch(ExecutorFragmentContext, HashJoinPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatchCreator
-
- getBatch(ExecutorFragmentContext, LateralJoinPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.join.LateralJoinBatchCreator
-
- getBatch(ExecutorFragmentContext, MergeJoinPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.join.MergeJoinCreator
-
- getBatch(ExecutorFragmentContext, NestedLoopJoinPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatchCreator
-
- getBatch(ExecutorFragmentContext, RowKeyJoinPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.join.RowKeyJoinBatchCreator
-
- getBatch(ExecutorFragmentContext, Limit, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.limit.LimitBatchCreator
-
- getBatch(ExecutorFragmentContext, PartitionLimit, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.limit.PartitionLimitBatchCreator
-
- getBatch(ExecutorFragmentContext, MergingReceiverPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.MergingReceiverCreator
-
- getBatch(ExecutorFragmentContext, ProducerConsumer, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.producer.ProducerConsumerBatchCreator
-
- getBatch(ExecutorFragmentContext, ComplexToJson, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.project.ComplexToJsonBatchCreator
-
- getBatch(ExecutorFragmentContext, Project, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.project.ProjectBatchCreator
-
- getBatch(ExecutorFragmentContext, Sort, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.sort.SortBatchCreator
-
- getBatch(ExecutorFragmentContext, SelectionVectorRemover, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.svremover.SVRemoverCreator
-
- getBatch(ExecutorFragmentContext, TopN, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.TopN.TopNSortBatchCreator
-
- getBatch(ExecutorFragmentContext, Trace, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.trace.TraceBatchCreator
-
- getBatch(ExecutorFragmentContext, UnionAll, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.union.UnionAllBatchCreator
-
- getBatch(ExecutorFragmentContext, UnnestPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.unnest.UnnestBatchCreator
-
- getBatch(ExecutorFragmentContext, UnorderedReceiver, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverCreator
-
- getBatch(ExecutorFragmentContext, IteratorValidator, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorCreator
-
- getBatch(ExecutorFragmentContext, Values, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.values.ValuesBatchCreator
-
- getBatch(ExecutorFragmentContext, WindowPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.window.WindowFrameBatchCreator
-
- getBatch(ExecutorFragmentContext, ExternalSort, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.xsort.ExternalSortBatchCreator
-
- getBatch(ExecutorFragmentContext, EasySubScan, List<RecordBatch>) - Method in class org.apache.drill.exec.store.dfs.easy.EasyReaderBatchCreator
-
- getBatch(ExecutorFragmentContext, EasyWriter, List<RecordBatch>) - Method in class org.apache.drill.exec.store.dfs.easy.EasyWriterBatchCreator
-
- getBatch(ExecutorFragmentContext, DirectSubScan, List<RecordBatch>) - Method in class org.apache.drill.exec.store.direct.DirectBatchCreator
-
- getBatch(ExecutorFragmentContext, InfoSchemaSubScan, List<RecordBatch>) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaBatchCreator
-
- getBatch(ExecutorFragmentContext, MockSubScanPOP, List<RecordBatch>) - Method in class org.apache.drill.exec.store.mock.MockScanBatchCreator
-
- getBatch(ExecutorFragmentContext, AbstractParquetRowGroupScan, OperatorContext) - Method in class org.apache.drill.exec.store.parquet.AbstractParquetScanBatchCreator
-
- getBatch(ExecutorFragmentContext, ParquetRowGroupScan, List<RecordBatch>) - Method in class org.apache.drill.exec.store.parquet.ParquetScanBatchCreator
-
- getBatch(ExecutorFragmentContext, ParquetWriter, List<RecordBatch>) - Method in class org.apache.drill.exec.store.parquet.ParquetWriterBatchCreator
-
- getBatch(ExecutorFragmentContext, SystemTableScan, List<RecordBatch>) - Method in class org.apache.drill.exec.store.sys.SystemTableBatchCreator
-
- getBatchActualRecordCount() - Method in class org.apache.drill.exec.record.selection.SelectionVector2
-
- 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
-
- getBatchMemoryManager() - Method in class org.apache.drill.exec.record.AbstractBinaryRecordBatch
-
- 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 interface org.apache.drill.exec.physical.impl.join.BatchSizePredictor
-
- getBatchSize() - Method in class org.apache.drill.exec.physical.impl.join.BatchSizePredictorImpl
-
- getBatchSize() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.BatchStat
-
- getBatchSize() - Method in class org.apache.drill.exec.physical.impl.join.TestBuildSidePartitioningImpl.MockBatchSizePredictor
-
- getBatchSize() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl.ConditionalMockBatchSizePredictor
-
- 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
-
- getBatchSizeEstimate(RecordBatch) - Static method in class org.apache.drill.exec.physical.impl.join.BatchSizePredictorImpl
-
- getBatchSizesMgr() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
-
- getBatchState() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
-
- getBatchState() - Method in interface org.apache.drill.exec.physical.impl.join.RowKeyJoin
-
Get the current BatchState (this is useful when performing row key join)
- getBatchState() - Method in class org.apache.drill.exec.physical.impl.join.RowKeyJoinBatch
-
- getBatchStatsContext() - Method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager
-
- getBee() - Method in class org.apache.drill.exec.work.foreman.FragmentsRunner
-
- getBee() - Method in class org.apache.drill.exec.work.WorkManager
-
- getBestIndexNoFilter() - Method in class org.apache.drill.exec.planner.index.IndexSelector
-
we assume all the indexes added in indexPropList are all applicable (and covering).
- 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 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 interface org.apache.drill.exec.ops.ExecutorFragmentContext
-
- getBits() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getBits() - Method in class org.apache.drill.exec.server.DrillbitContext
-
- getBits() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- getBitsInMask() - Method in class org.apache.drill.exec.physical.impl.common.SpilledState
-
- 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(GroupScan) - Method in interface org.apache.drill.exec.planner.cost.PluginCost
-
- getBlockSize(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
-
Deprecated.
- getBloomFilterDefs() - Method in class org.apache.drill.exec.work.filter.RuntimeFilterDef
-
- 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.BoundCheckingAccessor
-
- 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.FragmentContextImpl
-
- getBufferManager() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- getBufferMemoryLimit() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
-
- getBuffers() - Method in interface org.apache.drill.exec.ops.ExchangeFragmentContext
-
- getBuffers() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- 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() - Method in interface org.apache.drill.exec.work.batch.DataCollector
-
- getBuffers() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- 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.
- getBuildField() - Method in class org.apache.drill.exec.work.filter.BloomFilterDef
-
- getBuildHashCode(int) - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- getBuildHashCode(int) - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
-
Computes the hash code for the record at the given index in the build side batch.
- getBuildHashCode(int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
-
Return the Hash Value for the row in the Build incoming batch at index:
(For Hash Aggregate there's no "Build" side -- only one batch - this one)
- getBuildReservedMemory() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMechanicalMemoryCalculator.MechanicalBuildSidePartitioning
-
- getBuildReservedMemory() - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.BuildSidePartitioning
-
- getBuildReservedMemory() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.BuildSidePartitioningImpl
-
- getBuildReservedMemory() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.NoopBuildSidePartitioningImpl
-
- 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 interface org.apache.drill.exec.vector.accessor.SqlAccessor
-
- 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.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 interface org.apache.drill.exec.vector.accessor.SqlAccessor
-
- getBytes(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
-
- getBytesWritten() - Method in class org.apache.drill.exec.cache.VectorSerializer.Writer
-
- getCache() - Method in class org.apache.drill.exec.coord.zk.ZookeeperClient
-
- getCacheFileRoot() - Method in class org.apache.drill.exec.store.dfs.FileSelection
-
- getCacheFileRoot() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
-
- 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
- getCalculator() - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthExpression.FunctionCallExpr
-
- getCalculatorImpl() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
-
Determines the memory calculator to use.
- getCall() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getCall() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getCall() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- getCall() - Method in class org.apache.drill.exec.planner.logical.RowKeyJoinCallContext
-
- getCallBack() - Method in interface org.apache.drill.exec.physical.impl.OutputMutator
-
- getCallBack() - Method in class org.apache.drill.exec.physical.impl.ScanBatch.Mutator
-
- getCallBack() - Method in class org.apache.drill.exec.store.TestOutputMutator
-
- getCandidateIndexes(IndexConditionInfo.Builder, List<IndexGroup>, List<IndexGroup>, List<IndexGroup>) - Method in class org.apache.drill.exec.planner.index.IndexSelector
-
Run the index selection algorithm and return the top N indexes
- 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
-
- getCardinality() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
- 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 interface org.apache.drill.exec.vector.accessor.SqlAccessor
-
- 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
-
- getChildren() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
- 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
-
- getClientPort() - Method in class org.apache.drill.exec.util.MiniZooKeeperCluster
-
- getClientProps() - Method in class org.apache.drill.test.ClusterFixture
-
- 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 interface org.apache.drill.exec.ops.ExecutorFragmentContext
-
- getClusterCoordinator() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getClusterCoordinator() - Method in class org.apache.drill.exec.server.DrillbitContext
-
- getClusterCoordinator() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- getClusterInfo() - Method in class org.apache.drill.exec.server.rest.DrillRoot
-
- getClusterInfoJSON() - Method in class org.apache.drill.exec.server.rest.DrillRoot
-
- getClusterPath() - Method in interface org.apache.drill.exec.coord.zk.ZKACLContextProvider
-
- getClusterPath() - Method in class org.apache.drill.exec.coord.zk.ZKACLContextProviderImpl
-
- getCode() - Method in class org.apache.drill.exec.expr.SingleClassStringWriter
-
- getCodecFactory() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
-
- getCodegenDir() - Method in class org.apache.drill.test.BaseDirTestWatcher
-
Gets the temp directory that should be used to save generated code files.
- getCodeGenerator() - Method in class org.apache.drill.exec.expr.ClassGenerator
-
- getCollation() - Method in interface org.apache.drill.exec.planner.common.OrderedRel
-
A method to return ordering columns of the result.
- getCollation() - Method in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- getCollation() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getCollation() - Method in interface org.apache.drill.exec.planner.index.IndexDefinition
-
Get the collation property (physical ordering) of the index.
- getCollation() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getCollation() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- getCollation(Sort) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- getCollation() - Method in class org.apache.drill.exec.planner.physical.HashToMergeExchangePrel
-
- getCollation() - Method in class org.apache.drill.exec.planner.physical.SingleMergeExchangePrel
-
- getCollation() - Method in class org.apache.drill.exec.planner.physical.TopNPrel
-
- getCollationList() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getCollationList() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getCollationList() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- getCollationMap() - Method in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- getCollationMap() - Method in interface org.apache.drill.exec.planner.index.IndexDefinition
-
Get a mapping of the LogicalExpresion/SchemaPath to its field collation
- e.g Ascending/Descending, Nulls First/Nulls Last
- getCollations() - Method in class org.apache.drill.exec.planner.index.AbstractIndexStatistics
-
- getCollations() - Method in interface org.apache.drill.exec.planner.index.IndexStatistics
-
Returns the collections of columns on which this table is sorted.
- getCollectiveInfo(IndexLogicalPlanCallContext) - Method in class org.apache.drill.exec.planner.index.IndexConditionInfo.Builder
-
Get a single IndexConditionInfo in which indexCondition has field on all indexes in this.indexes
- getCollector(int) - Method in class org.apache.drill.exec.work.batch.IncomingBuffers
-
- getCollectors(PhysicalOperator) - Static method in class org.apache.drill.exec.planner.fragment.SimpleParallelizer.CountRequiredFragments
-
- getColNameToColumnDescriptorMapping(ParquetMetadata) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
-
Map full column paths to all ColumnDescriptors in file schema
- getColNameToSchemaElementMapping(ParquetMetadata) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
-
Map full schema paths in format `a`.`b`.`c` to respective SchemaElement objects.
- getColumn() - Method in class org.apache.drill.exec.physical.config.FlattenPOP
-
- getColumn() - Method in class org.apache.drill.exec.physical.config.UnnestPOP
-
- getColumn(int) - Method in class org.apache.drill.exec.record.BatchSchema
-
- getColumn(String) - Method in class org.apache.drill.exec.record.RecordBatchSizer
-
- 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.DrillSqlDescribeTable
-
- 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.physical.base.AbstractDbGroupScan
-
- getColumns() - Method in interface org.apache.drill.exec.physical.base.DbGroupScan
-
- getColumns() - Method in interface org.apache.drill.exec.physical.base.IndexGroupScan
-
- getColumns() - Method in class org.apache.drill.exec.planner.logical.DrillScanRel
-
- 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.AbstractParquetGroupScan
-
- getColumns() - Method in class org.apache.drill.exec.store.parquet.AbstractParquetRowGroupScan
-
- getColumns() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.RowGroupMetadata_v1
-
- getColumns() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.RowGroupMetadata_v2
-
- getColumns() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.RowGroupMetadata_v3
-
- getColumns() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.RowGroupMetadata
-
- getColumns() - Method in class org.apache.drill.exec.store.parquet.RowGroupInfo
-
- getColumns() - Method in class org.apache.drill.exec.store.pcap.schema.Schema
-
Return list with all columns names and its types
- getColumns() - Static method in class org.apache.drill.exec.store.pcapng.schema.Schema
-
- getColumns(String) - Method in class org.apache.drill.test.ProfileParser
-
- getColumnSize(int, String) - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getColumnSize(String) - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getColumnsNames() - Static method in class org.apache.drill.exec.store.pcapng.schema.Schema
-
- getColumnType() - Method in class org.apache.drill.exec.store.pcap.dto.ColumnDto
-
- getColumnTypeInfo(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetTableMetadata_v2
-
- getColumnTypeInfo(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.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.AbstractParquetGroupScan
-
Return column value count for the specified column.
- getColumnValueCount(SchemaPath) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScanStatistics
-
- getCommandHandlers(SqlLine) - Method in class org.apache.drill.exec.client.DrillSqlLineApplication
-
- 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 interface org.apache.drill.exec.ops.FragmentContext
-
- getCompiler() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getCompiler() - Method in class org.apache.drill.exec.server.DrillbitContext
-
- getCompiler() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- 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.base.AbstractJoinPop
-
- getCondition() - Method in interface org.apache.drill.exec.planner.logical.DrillJoin
-
- getConditions() - Method in class org.apache.drill.exec.physical.base.AbstractJoinPop
-
- 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.client.DrillSqlLineApplication
-
- getConfig() - Method in class org.apache.drill.exec.coord.store.BaseTransientStore
-
- getConfig() - Method in interface org.apache.drill.exec.ops.FragmentContext
-
Returns the Drill configuration for this run.
- getConfig() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- 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(String) - Method in class org.apache.drill.exec.planner.logical.StoragePlugins
-
Return storage plugin config for certain plugin name
- 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.FileSystemConfig
-
- 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
-
- getConfig() - Method in class org.apache.drill.exec.ZookeeperHelper
-
Get the DrillConfig used for the Zookeeper instance.
- getConfig() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- getConfigLocation() - Method in class org.apache.drill.exec.server.StartupOptions
-
- getConfigMemorySizePerBatch() - Method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager
-
- getConfigProperty() - Method in class org.apache.drill.exec.server.options.OptionValidator
-
- getConfigProperty() - Method in class org.apache.drill.exec.server.options.TypeValidators.TypeValidator
-
- getConfigRecordsPerBatch() - Method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager
-
- getConnection() - Method in class org.apache.drill.exec.store.dfs.FileSystemConfig
-
- getConnectionManager(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.rpc.control.ConnectionManagerRegistry
-
- getConnectionString() - Method in class org.apache.drill.exec.ZookeeperHelper
-
- getConnectionUrlExamples() - Method in class org.apache.drill.exec.client.DrillSqlLineApplication
-
- 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.FragmentContextImpl
-
- 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.
- getConstantValueHolder(String, TypeProtos.MinorType, Function<DrillBuf, ValueHolder>) - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- getConstantVars() - Method in class org.apache.drill.exec.expr.ClassGenerator
-
- getConsumedMemory() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PartitionStatSet
-
- getConsumedMemory() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.PostBuildCalculationsImpl
-
- getContainer() - Method in class org.apache.drill.exec.expr.HoldingContainerExpression
-
- getContainer() - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
-
- getContainer() - Method in class org.apache.drill.exec.physical.impl.MockRecordBatch
-
- getContainer() - Method in class org.apache.drill.exec.physical.impl.protocol.OperatorRecordBatch
-
- getContainer() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
-
- getContainer() - Method in class org.apache.drill.exec.physical.impl.sort.RecordBatchData
-
- getContainer() - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- getContainer() - Method in class org.apache.drill.exec.physical.impl.unorderedreceiver.UnorderedReceiverBatch
-
- getContainer() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
-
- 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.AbstractRecordBatch
-
- getContainer() - Method in interface org.apache.drill.exec.record.RecordBatch
-
Return the internal vector container
- getContainer() - Method in class org.apache.drill.exec.record.RecordBatchLoader
-
- getContainer() - Method in class org.apache.drill.exec.record.SchemalessBatch
-
- getContainer() - Method in class org.apache.drill.exec.record.SimpleRecordBatch
-
- getContainer() - Method in class org.apache.drill.exec.store.TestOutputMutator
-
- getContainers() - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- 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
-
- getContent() - Method in class org.apache.drill.exec.work.filter.BloomFilter
-
- 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.filter.RuntimeFilterRecordBatch
-
- getContext() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
-
- getContext() - Method in class org.apache.drill.exec.physical.impl.MockRecordBatch
-
- getContext() - Method in class org.apache.drill.exec.physical.impl.protocol.OperatorRecordBatch
-
- getContext() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
-
- getContext() - Method in class org.apache.drill.exec.physical.impl.ScreenCreator.ScreenRoot
-
- getContext() - Method in class org.apache.drill.exec.physical.impl.SimpleRootExec
-
Deprecated.
- getContext() - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- 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.SchemalessBatch
-
- 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.AbstractStoragePlugin
-
- 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.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.FragmentContextImpl
-
- 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.
- getContextInformation() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- getContextOperatorId() - Method in class org.apache.drill.exec.util.record.RecordBatchStats.RecordBatchStatsContext
-
- getController() - Method in interface org.apache.drill.exec.ops.ExchangeFragmentContext
-
- getController() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getController() - Method in class org.apache.drill.exec.server.DrillbitContext
-
- getController() - Method in class org.apache.drill.exec.service.ServiceEngine
-
- getController() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- getControlMessageHandler() - Method in class org.apache.drill.exec.work.WorkManager
-
- getControlPort() - Method in class org.apache.drill.exec.server.rest.DrillRoot.DrillbitInfo
-
- 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(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(IndexProperties, RelOptPlanner, int, GroupScan) - Method in class org.apache.drill.exec.planner.index.AbstractIndexDescriptor
-
- getCost(IndexProperties, RelOptPlanner, int, GroupScan) - Method in interface org.apache.drill.exec.planner.index.IndexDescriptor
-
Get the total cost of index access (I/O, CPU) in the context of the current query
- 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
-
- getCurrentField() - Method in class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
-
- getCurrentFieldBatchMemory(String) - Method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager
-
- getCurrentHandler() - Method in class org.apache.drill.exec.rpc.AbstractServerConnection
-
- getCurrentMapping() - Method in class org.apache.drill.exec.compile.sig.MappingSet
-
- getCurrentMemorySizePerBatch() - Method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager
-
- getCurrentPosition() - Method in class org.apache.drill.exec.record.RecordIterator
-
- getCurrentRecord() - Method in class org.apache.drill.exec.store.parquet2.DrillParquetRecordMaterializer
-
- getCurrentRecordsPerBatch() - Method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager
-
- getCurrentRowCount() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate.BatchHolder
-
- 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
-
- getCycle() - Method in class org.apache.drill.exec.physical.impl.common.AbstractSpilledPartitionMetadata
-
- getCycle() - Method in interface org.apache.drill.exec.physical.impl.common.SpilledPartitionMetadata
-
The spill cycle for a partition.
- getCycle() - Method in class org.apache.drill.exec.physical.impl.common.SpilledState
-
Gets the current spill cycle.
- getData() - Method in class org.apache.drill.exec.cache.CachedVectorContainer
-
- getData() - Method in interface org.apache.drill.exec.compile.ExampleExternalInterface
-
- getData() - Method in class org.apache.drill.exec.compile.ExampleTemplate
-
- 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
-
- getData() - Method in class org.apache.drill.exec.work.filter.RuntimeFilterWritable
-
- getDataAddr() - Method in class org.apache.drill.exec.record.selection.SelectionVector2
-
- getDataBodies() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.CustomMessageSender
-
- getDataBodies() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.SyncCustomMessageSender
-
- 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
-
- getDataSizePerEntry() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
This is the average actual per entry data size in bytes.
- getDataTunnel(CoordinationProtos.DrillbitEndpoint) - Method in interface org.apache.drill.exec.ops.ExchangeFragmentContext
-
- getDataTunnel(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getDataTunnel(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- getDataType(int) - Method in class org.apache.drill.exec.store.log.LogFormatConfig
-
- getDataTypeLength() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetColumnMetadata
-
Returns data type length for a given ColumnDescriptor
and it's corresponding
SchemaElement
.
- getDataWidth() - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthExpression.FixedLenExpr
-
- getDataWidthOfFixedWidthType(TypeProtos.MajorType) - Static method in class org.apache.drill.exec.physical.impl.project.ProjectMemoryManager
-
- 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 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.
- getDateFormat(int) - Method in class org.apache.drill.exec.store.log.LogFormatConfig
-
- 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
-
- getDecimalValueWriterForType(PrimitiveType.PrimitiveTypeName) - Static method in class org.apache.drill.exec.store.parquet.decimal.DecimalValueWriter
-
Creates and returns writer suitable for specified PrimitiveType.PrimitiveTypeName type
.
- 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
-
- getDefault() - Static method in class org.apache.drill.exec.store.sys.ProfileInfoIterator.ProfileInfo
-
If unable to get ProfileInfo, use this default instance instead.
- getDefault() - Static method in class org.apache.drill.exec.store.sys.ProfileJsonIterator.ProfileJson
-
If unable to get ProfileInfo, use this default instance instead.
- getDefaultAcl() - Method in class org.apache.drill.exec.coord.zk.ZKACLProviderDelegate
-
- 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
-
- getDefaultInstance() - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderConfig
-
- getDefaultLocation() - Method in class org.apache.drill.exec.store.dfs.WorkspaceSchemaFactory.WorkspaceSchema
-
- getDefaultMapper() - Static method in class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
-
- 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
-
- getDefaultValue() - Method in class org.apache.drill.exec.server.rest.StatusResources.OptionWrapper
-
- getDefinition() - Method in class org.apache.drill.exec.expr.CodeGenerator
-
- getDefinitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ParquetTableMetadata_v1
-
- getDefinitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetTableMetadata_v2
-
- getDefinitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetTableMetadata_v3
-
- getDefinitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ParquetTableMetadataBase
-
- getDefinitions() - Method in class org.apache.drill.exec.server.BootStrapContext
-
- getDefinitions() - Method in class org.apache.drill.test.ConfigBuilder
-
- 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.
- getDescription() - Method in class org.apache.drill.exec.server.options.OptionValidator.OptionDescription
-
Get verbose description
- getDescription(int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDescriptor
-
- 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
-
- getDfsTestTmpDir() - Method in class org.apache.drill.test.BaseDirTestWatcher
-
Gets the temp directory that should be used by the dfs.tmp workspace.
- 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.physical.base.SchemalessScan
-
- 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.AbstractParquetGroupScan
-
- getDigest() - Method in class org.apache.drill.exec.store.sys.SystemTableScan
-
Example: SystemTableScan [table=OPTION, distributed=false, maxRecordsToRead=1]
- getDir() - Method in class org.apache.drill.exec.work.batch.SpoolingRawBatchBuffer
-
- getDirectories() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ParquetTableMetadata_v1
-
- getDirectories() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetTableMetadata_v2
-
- getDirectories() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetTableMetadata_v3
-
- getDirectories() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.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() - Static method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinWithSchemaChanges
-
- 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
-
- getDistinctRowCount(Join, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in class org.apache.drill.exec.planner.cost.DrillRelMdDistinctRowCount
-
We need to override this method since Calcite and Drill calculate
joined row count in different ways.
- getDistinctRowCount(DrillScanRel, RelMetadataQuery, ImmutableBitSet, RexNode) - Method in class org.apache.drill.exec.planner.cost.DrillRelMdDistinctRowCount
-
- getDistribution() - Method in class org.apache.drill.exec.planner.index.AbstractIndexStatistics
-
- getDistribution() - Method in interface org.apache.drill.exec.planner.index.IndexStatistics
-
Returns the distribution of the data in query result table.
- 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 class org.apache.drill.exec.planner.physical.DirectScanPrel
-
- 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(Sort) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- 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
-
- getDistributionFields() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getDistributionFields() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getDistributionFields() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- getDotDrills(DrillFileSystem, Path, DotDrillType...) - Static method in class org.apache.drill.exec.dotdrill.DotDrillUtil
-
Return list of DotDrillFile objects whose file name ends with .drill and matches the provided Drill Dot files types
in a given parent Path.
- getDotDrills(DrillFileSystem, Path, String, DotDrillType...) - Static method in class org.apache.drill.exec.dotdrill.DotDrillUtil
-
Return list of DotDrillFile objects whose file name matches the provided name pattern and Drill Dot files types
in a given parent Path.
- 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 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
-
- getDoubleStat(MetricDef) - Method in class org.apache.drill.exec.ops.OperatorStats
-
- getDoublingFactor() - Method in interface org.apache.drill.exec.physical.impl.join.HashTableSizeCalculator
-
- getDoublingFactor() - Method in class org.apache.drill.exec.physical.impl.join.HashTableSizeCalculatorConservativeImpl
-
- getDoublingFactor() - Method in class org.apache.drill.exec.physical.impl.join.HashTableSizeCalculatorLeanImpl
-
- getDoublingFactor() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl.MockHashTableSizeCalculator
-
- getDrillAclForPath(String) - Method in interface org.apache.drill.exec.coord.zk.ZKACLProvider
-
Returns the list of ZK ACLs ACL
to apply for a specific
Drill znode
- getDrillAclForPath(String) - Method in class org.apache.drill.exec.coord.zk.ZKDefaultACLProvider
-
- getDrillAclForPath(String) - Method in class org.apache.drill.exec.coord.zk.ZKSecureACLProvider
-
- getDrillbitContext() - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
-
Drillbit context.
- getDrillbitContext() - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
Useful for tests that require a DrillbitContext to get/add storage plugins, options etc.
- getDrillbits() - Method in class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
-
- getDrillbits() - Method in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- getDrillbits() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
-
- getDrillbitStatus() - Method in class org.apache.drill.exec.server.rest.DrillRoot
-
- getDrillbitStatusListener() - Method in class org.apache.drill.exec.work.foreman.QueryManager
-
- getDrillDefaultAcl() - Method in interface org.apache.drill.exec.coord.zk.ZKACLProvider
-
Returns the list of ZK ACLs ACL
to apply by default
on Drill znodes
- getDrillDefaultAcl() - Method in class org.apache.drill.exec.coord.zk.ZKDefaultACLProvider
-
- getDrillDefaultAcl() - Method in class org.apache.drill.exec.coord.zk.ZKSecureACLProvider
-
- getDrillFileGlobPattern(DotDrillType[]) - Static method in enum org.apache.drill.exec.dotdrill.DotDrillType
-
Return Glob pattern for given Dot Drill Types.
- getDrillFileSystemCreator(OperatorContext, OptionManager) - Method in class org.apache.drill.exec.store.parquet.AbstractParquetScanBatchCreator
-
- getDrillFileSystemCreator(OperatorContext, OptionManager) - Method in class org.apache.drill.exec.store.parquet.ParquetScanBatchCreator
-
- 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.index.DrillIndexDescriptor
-
Get the drill table corresponding to the index descriptor
- getDrillTable() - Method in class org.apache.drill.exec.planner.logical.DrillTranslatableTable
-
- getDrillTable(RelOptTable) - Static method in class org.apache.drill.exec.util.Utilities
-
Gets
DrillTable
, either wrapped in RelOptTable, or DrillTranslatableTable.
- getDrillTempDir() - Method in class org.apache.drill.test.ClusterFixture
-
- GetDrillType() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.GetDrillType
-
- 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.Metadata_V1.ParquetTableMetadata_v1
-
- getDrillVersion() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetTableMetadata_v2
-
- getDrillVersion() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetTableMetadata_v3
-
- getDrillVersion() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.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
-
- getElementCount() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
- 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.DirectScanPrel
-
- 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.LateralJoinPrel
-
- 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.OrderedMuxExchangePrel
-
- 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.RangePartitionExchangePrel
-
- getEncoding() - Method in class org.apache.drill.exec.planner.physical.RowKeyJoinPrel
-
- getEncoding() - Method in class org.apache.drill.exec.planner.physical.RuntimeFilterPrel
-
- 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.UnnestPrel
-
- 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
-
- getEnding() - Method in enum org.apache.drill.exec.dotdrill.DotDrillType
-
Return extension string of file type represented by this object.
- 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 interface org.apache.drill.exec.ops.ExecutorFragmentContext
-
- getEndpoint() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- 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
-
- getEndpoint() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- 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
-
- 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.AbstractParquetGroupScan
-
- getEqualOnCastChar() - Method in class org.apache.drill.exec.planner.index.IndexableExprMarker
-
- getError() - Method in class org.apache.drill.exec.rpc.AbstractDisposableUserClientConnection
-
- getError() - Method in class org.apache.drill.exec.server.rest.LogInLogOutResources.MainLoginPageModel
-
- getErrorList() - Method in class org.apache.drill.SingleRowListener
-
Get an immutable copy of the list of all errors received so far.
- 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
-
- getEstablished() - Method in class org.apache.drill.exec.rpc.user.UserServer.BitToUserConnectionConfig
-
- 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
-
- getException() - Method in class org.apache.drill.exec.work.foreman.Foreman.ForemanResult
-
Expose the current exception (if it exists).
- getExceptionWithContext(UserException.Builder, String) - Method in interface org.apache.drill.exec.store.easy.json.JsonProcessor
-
- getExceptionWithContext(Throwable, String) - Method in interface org.apache.drill.exec.store.easy.json.JsonProcessor
-
- getExceptionWithContext(UserException.Builder, String) - Method in class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
-
- getExceptionWithContext(Throwable, String) - Method in class org.apache.drill.exec.store.easy.json.reader.BaseJsonProcessor
-
- getExchange() - Method in class org.apache.drill.exec.planner.fragment.Fragment.ExchangeFragmentPair
-
- getExchange(RelOptCluster, boolean, boolean, RelTraitSet, DrillDistributionTrait, IndexCallContext, RelNode) - Static method in class org.apache.drill.exec.planner.index.generators.AbstractIndexPlanGenerator
-
- getExchange() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getExchange() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getExchange() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- getExcludedColumns() - Method in class org.apache.drill.exec.physical.config.LateralJoinPOP
-
- getExec(ExecutorFragmentContext, 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 interface org.apache.drill.exec.ops.FragmentContext
-
Return the set of execution controls used to inject faults into running
code for testing.
- getExecutionControls() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- 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
-
- getExecutionControls() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- 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 interface org.apache.drill.exec.ops.FragmentContext
-
- getExecutor() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- 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
-
- getExecutor() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- getExecutorState() - Method in interface org.apache.drill.exec.ops.FragmentContext
-
- getExecutorState() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getExecutorState() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- getExecutorThreadName(ExecProtos.FragmentHandle) - Static method in class org.apache.drill.exec.proto.helper.QueryIdHelper
-
- getExpected() - Method in class org.apache.drill.TestProjectPushDown.PushDownTestInstance
-
- getExpectedRecords() - Method in class org.apache.drill.exec.store.avro.AvroTestUtil.AvroTestRecordWriter
-
- getExpectedSchema() - Method in class org.apache.drill.test.TestBuilder
-
- getExpectedSchema() - Method in class org.apache.drill.test.TestBuilder.SchemaTestBuilder
-
- 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
-
- getExpressionsOnlyInEquality() - Method in class org.apache.drill.exec.planner.index.IndexableExprMarker
-
return the expressions that were only in equality condition _and_ only once.
- getExprMap() - Method in interface org.apache.drill.exec.planner.index.FunctionalIndexInfo
-
- 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
-
- getExprsFromRowType(RelDataType) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- getExtension() - Method in class org.apache.drill.exec.store.log.LogFormatConfig
-
- 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
-
- getExtensions() - Method in class org.apache.drill.exec.store.image.ImageFormatConfig
-
- getExtensions() - Method in class org.apache.drill.exec.store.pcapng.PcapngFormatConfig
-
- getExternalDrillTable(IndexDescriptor) - Method in class org.apache.drill.exec.planner.index.IndexDiscoverBase
-
When there is storageName in IndexDescriptor, get a DrillTable instance based on the
StorageName and other informaiton in idxDesc that helps identifying the table.
- 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.test.OperatorFixture.MockExecutorState
-
- getFailureMessage() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate.HashAggUpdater
-
- getFailureMessage() - Method in interface org.apache.drill.exec.physical.impl.common.SpilledState.Updater
-
Gets the failure message in the event that we spilled to far.
- getFailureMessage() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch.HashJoinUpdater
-
- getFamily() - Method in class org.apache.drill.exec.planner.types.RelDataTypeDrillImpl
-
- getFetch() - Method in class org.apache.drill.exec.planner.common.DrillLimitRelBase
-
- getFetch() - Method in interface org.apache.drill.exec.planner.common.OrderedRel
-
Fetch value represented in RexNode.
- getFetch(OrderedRel) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- getFetch() - Method in class org.apache.drill.exec.planner.logical.DrillSortRel
-
- getFetch() - Method in class org.apache.drill.exec.planner.physical.SortPrel
-
- getFetch() - Method in class org.apache.drill.exec.planner.physical.TopNPrel
-
- getField(RelDataTypeFactory, String) - Method in class org.apache.drill.exec.planner.types.AbstractRelDataTypeHolder
-
Returns RelDataTypeField field with specified name.
- getField(String, boolean, boolean) - Method in class org.apache.drill.exec.planner.types.DrillFixedRelDataTypeImpl
-
- getField(RelDataTypeFactory, String) - Method in class org.apache.drill.exec.planner.types.ExtendableRelDataTypeHolder
-
Returns RelDataTypeField field with specified name.
- 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(int) - Method in class org.apache.drill.exec.store.log.LogFormatConfig
-
- getField() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetColumnMetadata
-
- getField() - Method in class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
-
- getFieldAndPos() - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap.FieldsMarker
-
- getFieldCount() - Method in class org.apache.drill.exec.planner.types.AbstractRelDataTypeHolder
-
Returns count of RelDataTypeField fields in this holder.
- 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(RelDataTypeFactory) - Method in class org.apache.drill.exec.planner.types.AbstractRelDataTypeHolder
-
Returns list with all RelDataTypeField fields in this holder.
- 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
-
- getFieldName() - Method in class org.apache.drill.exec.store.log.LogFormatField
-
- getFieldNameFromItemStarField(RexCall, List<String>) - Static method in class org.apache.drill.exec.planner.logical.FieldsReWriterUtil
-
Checks if operator call is using item star field.
- 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.AbstractRelDataTypeHolder
-
Returns list with names of RelDataTypeField fields.
- 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.store.log.LogFormatConfig
-
- getFieldNames() - Method in class org.apache.drill.exec.store.pojo.PojoDataType
-
- getFieldNames() - Method in class org.apache.drill.exec.store.RecordDataType
-
- getFieldOverflowContainer(String) - Method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager
-
- getFieldOverflowDefs() - Method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchOverflow.RecordOverflowDefinition
-
- getFieldOverflowMap() - Method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager
-
- getFields() - Method in class org.apache.drill.exec.dotdrill.View
-
- getFields() - Method in class org.apache.drill.exec.planner.common.DrillRelOptUtil.ProjectPushInfo
-
- 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.planner.physical.RangePartitionExchangePrel
-
- 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.
- getFieldsInformation(RelDataType, List<RexNode>) - Static method in class org.apache.drill.exec.planner.common.DrillRelOptUtil
-
- 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
-
- getFieldType() - Method in class org.apache.drill.exec.store.log.LogFormatField
-
- 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
-
- getFile(String) - Static method in class org.apache.drill.PlanningBase
-
- getFile(String) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- getFile(String) - Method in class org.apache.drill.test.ClusterTest
-
Convenience method when converting classic tests to use the
cluster fixture.
- 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
-
- getFileName() - Method in class org.apache.drill.exec.store.avro.AvroTestUtil.AvroTestRecordWriter
-
- getFileNameForQueryFragment(FragmentContext, String, String) - Static method in class org.apache.drill.exec.util.Utilities
-
- getFilePath() - Method in class org.apache.drill.exec.store.avro.AvroTestUtil.AvroTestRecordWriter
-
- 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.AbstractParquetGroupScan
-
- getFiles() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ParquetTableMetadata_v1
-
- getFiles() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetTableMetadata_v2
-
- getFiles() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetTableMetadata_v3
-
- getFiles() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ParquetTableMetadataBase
-
- getFileSelection() - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
-
- getFileSet() - Method in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- getFileStatus(Path) - Method in class org.apache.drill.exec.store.CachedSingleFileSystem
-
- 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.physical.base.AbstractGroupScan
-
- getFilter() - Method in interface org.apache.drill.exec.physical.base.GroupScan
-
- getFilter() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getFilter() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getFilter() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- getFilter() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaSubScan
-
- getFilter() - Method in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- getFilter() - Method in class org.apache.drill.exec.store.parquet.AbstractParquetRowGroupScan
-
- getFilterCondition() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getFilterCondition() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getFilterCondition() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- 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
-
- getFilterRel() - Method in class org.apache.drill.exec.planner.logical.RowKeyJoinCallContext
-
- getFilterString() - Method in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- getFinalCondition() - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
-
- getFinalOutcome(boolean) - Method in class org.apache.drill.exec.physical.impl.limit.LimitRecordBatch
-
Gets the outcome to return from super implementation and then in case of EMIT outcome it refreshes the state of
operator.
- getFinalOutcome(boolean) - Method in class org.apache.drill.exec.physical.impl.limit.PartitionLimitRecordBatch
-
Gets the outcome to return from super implementation and then in case of EMIT outcome it refreshes the state of
operator.
- getFinalOutcome(boolean) - Method in class org.apache.drill.exec.record.AbstractSingleRecordBatch
-
Based on lastKnownOutcome and if there are more records to be output for current record boundary detected by
EMIT outcome, this method returns EMIT or OK outcome.
- 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.)
- getFirstKeyIndexConditionMap() - Method in class org.apache.drill.exec.planner.index.IndexConditionInfo.Builder
-
Get a map of Index=>IndexConditionInfo, each IndexConditionInfo has the separated condition and remainder condition.
- getFirstPath(DrillFileSystem) - Method in class org.apache.drill.exec.store.dfs.FileSelection
-
- getFixedColumnTypePrecision(ParquetColumnMetadata) - Static method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.BatchSizingMemoryUtil
-
- getFixedLenColumnReaders() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
-
- getFlags() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
-
- 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 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 interface org.apache.drill.exec.ops.ExecutorFragmentContext
-
- getForemanEndpoint() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getForemanEndpoint() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- getForemanForQueryId(UserBitShared.QueryId) - Method in class org.apache.drill.exec.work.WorkManager.WorkerBee
-
- getFormat() - Method in class org.apache.drill.exec.store.dfs.FormatSelection
-
- getFormat() - Method in class org.apache.drill.exec.store.log.LogFormatField
-
- 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(FormatPluginConfig) - Method in class org.apache.drill.exec.store.AbstractStoragePlugin
-
- 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(FormatPluginConfig) - Method in interface org.apache.drill.exec.store.StoragePlugin
-
Allows to get the format plugin for current storage plugin based on appropriate format plugin config usage.
- 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
-
- getFormats() - Method in class org.apache.drill.exec.store.dfs.FileSystemConfig
-
- 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 interface org.apache.drill.exec.ops.FragmentContext
-
- getFragIdString() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getFragIdString() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- 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.rpc.data.TestBitBitKerberos.MockFragmentManager
-
- getFragmentContext() - Method in class org.apache.drill.exec.rpc.data.TestBitRpc.MockFragmentManager
-
- 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
-
- getFragmentContext() - Method in class org.apache.drill.test.OperatorFixture
-
- getFragmentCount(Fragment) - Static method in class org.apache.drill.exec.pop.PopUnitTestBase
-
- 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 on.
- 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
-
- getFragmentParallelizer() - Method in enum org.apache.drill.exec.planner.fragment.DistributionAffinity
-
- getFragmentProfile() - Method in class org.apache.drill.test.ProfileParser
-
- 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
-
- getFreePortNumber(int, int) - Static method in class org.apache.drill.test.QueryTestUtil
-
Checks that port with specified number is free and returns it.
- 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(RowGroupReadEntry) - Method in class org.apache.drill.exec.store.parquet.AbstractParquetRowGroupScan
-
- getFsConf() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
-
- getFsConf(RowGroupReadEntry) - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
-
- getFsPartitionColumnLabel() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- getFullColumnPath(ColumnDescriptor) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
-
generate full path of the column in format `a`.`b`.`c`
- getFullFieldName() - Method in class org.apache.drill.exec.schema.Field
-
- getFullLog(String) - Method in class org.apache.drill.exec.server.rest.LogsResources
-
- getFullPath(PathSegment) - Static method in class org.apache.drill.exec.planner.index.SimpleRexRemap
-
- getFullRootSchema() - Method in interface org.apache.drill.exec.ops.FragmentContext
-
- getFullRootSchema() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getFullRootSchema(SchemaConfig) - Method in class org.apache.drill.exec.ops.QueryContext
-
Create and return a fully initialized SchemaTree with given schemaConfig.
- getFullRootSchema() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- 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.
- getFunctionalInfo() - Method in class org.apache.drill.exec.planner.index.DrillIndexDescriptor
-
- getFunctionalInfo() - Method in interface org.apache.drill.exec.planner.index.IndexDescriptor
-
Get the functional index information associated with this index (Functional indexes are
indexes involving expressions e.g CAST(a as INT).
- 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
-
- getFunctionRegistry() - Method in class org.apache.drill.exec.ops.BaseFragmentContext
-
- getFunctionRegistry() - Method in interface org.apache.drill.exec.ops.FragmentContext
-
Returns the UDF registry.
- 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
-
- getGeneratedCode() - Method in class org.apache.drill.exec.expr.CodeGenerator
-
- getGenerator() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
-
- getGracefulShutdownThread() - Method in class org.apache.drill.exec.server.Drillbit
-
- getGracePeriod() - Method in class org.apache.drill.exec.server.rest.DrillRoot
-
- getGrossRowWidth() - Method in class org.apache.drill.exec.record.RecordBatchSizer
-
- 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.common.DrillScanRelBase
-
- getGroupScan() - Method in class org.apache.drill.exec.planner.index.DrillIndexCollection
-
- getGroupScan() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getGroupScan() - Method in interface org.apache.drill.exec.planner.index.IndexCollection
-
If this IndexCollection exposes a single GroupScan, return the GroupScan instance.
- getGroupScan() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getGroupScan() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- getGroupScan(DrillScanRelBase) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- getGroupScan() - Method in class org.apache.drill.exec.planner.logical.DrillDirectScanRel
-
- getGroupScan() - Method in class org.apache.drill.exec.planner.logical.DrillTable
-
- getGroupScan() - Method in class org.apache.drill.exec.planner.physical.DirectScanPrel
-
- getGroupScan() - Method in interface org.apache.drill.exec.planner.physical.DrillScanPrel
-
- 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>, OptionManager) - 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
-
- getGroupScan(String, FileSelection, List<SchemaPath>, OptionManager) - 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 interface org.apache.drill.exec.ops.FragmentContext
-
- getHandle() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
The FragmentHandle for this Fragment
- getHandle() - Method in class org.apache.drill.exec.rpc.data.TestBitBitKerberos.MockFragmentManager
-
- getHandle() - Method in class org.apache.drill.exec.rpc.data.TestBitRpc.MockFragmentManager
-
- 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
-
- getHandle() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- 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
-
- getHash64(LogicalExpression[], TypedFieldId[]) - Method in class org.apache.drill.exec.expr.fn.impl.ValueVectorHashHelper
-
- getHash64Expression(LogicalExpression, LogicalExpression, boolean) - Static method in class org.apache.drill.exec.planner.physical.HashPrelUtil
-
Creates hash expression for input field and seed.
- getHashBuild(int, int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
-
- getHashExpression(LogicalExpression, LogicalExpression, boolean) - Static method in class org.apache.drill.exec.planner.physical.HashPrelUtil
-
Creates hash expression for input field and seed.
- 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, 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
-
- getHello() - Method in class org.apache.drill.exec.server.HelloResource
-
- 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
-
- getHolder() - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthExpression.FunctionCallExpr
-
- getHolders() - Method in class org.apache.drill.exec.work.filter.RuntimeFilterRouter.RuntimeFilterParallelismCollector
-
- getHoldersByFunctionName(String, AtomicInteger) - 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
-
- getHomeDirectory() - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
-
- getHostAffinity() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.RowGroupMetadata_v1
-
- getHostAffinity() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.RowGroupMetadata_v2
-
- getHostAffinity() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.RowGroupMetadata_v3
-
- getHostAffinity() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.RowGroupMetadata
-
- getHostName() - Method in class org.apache.drill.exec.server.BootStrapContext
-
- getHttpAuthMechanisms(DrillConfig) - Static method in class org.apache.drill.exec.server.rest.auth.DrillHttpSecurityHandlerProvider
-
Return's list of configured mechanisms for HTTP authentication.
- getHttpPort() - Method in class org.apache.drill.exec.server.rest.DrillRoot.DrillbitInfo
-
- 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
-
- getHyperVector() - Method in class org.apache.drill.exec.HyperVectorValueIterator
-
- 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.
- getIdentifier() - Method in class org.apache.drill.exec.physical.config.RuntimeFilterPOP
-
- 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
-
- 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
-
- 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.FragmentContext
-
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.FragmentContext
-
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.FragmentContext
-
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.FragmentContext
-
Generates code for a class given a
CodeGenerator
, and returns the
specified number of instances of the generated class.
- 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.
- getImplicitColumn() - Method in class org.apache.drill.exec.physical.config.UnnestPOP
-
- getImplicitColumnsNames(SchemaConfig) - Static method in class org.apache.drill.exec.store.ColumnExplorer
-
Returns list with implicit column names taken from specified
SchemaConfig
.
- getImplicitRIDColumn() - Method in class org.apache.drill.exec.physical.config.LateralJoinPOP
-
- getImplicitSubSchema(String, boolean) - Method in class org.apache.calcite.jdbc.DynamicRootSchema
-
- getImplicitSubSchema(String, boolean) - Method in class org.apache.calcite.jdbc.DynamicSchema
-
- getImplName() - Method in class org.apache.drill.exec.server.rest.auth.DrillHttpConstraintSecurityHandler
-
- getImplName() - Method in class org.apache.drill.exec.server.rest.auth.FormSecurityHanlder
-
- getImplName() - Method in class org.apache.drill.exec.server.rest.auth.SpnegoSecurityHandler
-
- 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 interface org.apache.drill.exec.physical.base.LateralContract
-
- getIncoming() - Method in class org.apache.drill.exec.physical.impl.join.LateralJoinBatch
-
Returns the left side incoming for the Lateral Join.
- getIncoming() - Method in class org.apache.drill.exec.physical.impl.SimpleRootExec
-
Deprecated.
- getIncoming() - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- getIncoming() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
-
- getIncoming() - Method in class org.apache.drill.exec.record.AbstractSingleRecordBatch
-
- getIncoming() - Method in class org.apache.drill.exec.record.AbstractTableFunctionRecordBatch
-
- getIncoming() - Method in class org.apache.drill.exec.record.AbstractUnaryRecordBatch
-
- getIncomingBatch() - Method in class org.apache.drill.exec.physical.impl.project.ProjectMemoryManager
-
- getIncomingCount() - Method in class org.apache.drill.exec.ops.OpProfileDef
-
- getIncomingProbeBatchReservedSpace() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.PostBuildCalculationsImpl
-
- 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
-
- getIndexableExpression() - Method in class org.apache.drill.exec.planner.index.IndexableExprMarker
-
- getIndexCollection(PlannerSettings, DrillScanRel) - Method in class org.apache.drill.exec.planner.index.rules.DbScanToIndexScanPrule
-
Return the index collection relevant for the underlying data source
- getIndexCollectionType() - Method in class org.apache.drill.exec.planner.index.DrillIndexCollection
-
- getIndexCollectionType() - Method in interface org.apache.drill.exec.planner.index.IndexCollection
-
- getIndexColumnOrdinal(LogicalExpression) - Method in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- getIndexColumnOrdinal(LogicalExpression) - Method in interface org.apache.drill.exec.planner.index.IndexDefinition
-
Check to see if the field name is an index column and if so return the ordinal position in the index
- getIndexColumns() - Method in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- getIndexColumns() - Method in interface org.apache.drill.exec.planner.index.IndexDefinition
-
Get the list of columns in the index key.
- getIndexConditionMap(List<IndexDescriptor>) - Method in class org.apache.drill.exec.planner.index.IndexConditionInfo.Builder
-
Get a map of Index=>IndexConditionInfo, each IndexConditionInfo has the separated condition and remainder condition.
- getIndexConditionMap() - Method in class org.apache.drill.exec.planner.index.IndexConditionInfo.Builder
-
Get a map of Index=>IndexConditionInfo, each IndexConditionInfo has the separated condition and remainder condition.
- getIndexCoveringSelThreshold() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- getIndexDesc() - Method in interface org.apache.drill.exec.planner.index.FunctionalIndexInfo
-
- getIndexDesc() - Method in interface org.apache.drill.exec.planner.index.IndexProperties
-
- getIndexDesc() - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- getIndexDiscover(StoragePluginConfig, GroupScan, RelNode, Class<? extends IndexDiscover>) - Static method in class org.apache.drill.exec.planner.index.IndexDiscoverFactory
-
- getIndexFromCollation(int, List<RelFieldCollation>) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- getIndexGroupScan() - Method in class org.apache.drill.exec.planner.index.AbstractIndexDescriptor
-
- getIndexGroupScan() - Method in class org.apache.drill.exec.planner.index.DrillIndexDescriptor
-
- getIndexGroupScan() - Method in interface org.apache.drill.exec.planner.index.IndexDescriptor
-
Get an instance of the group scan associated with this index descriptor
- getIndexHint() - Method in interface org.apache.drill.exec.physical.base.DbGroupScan
-
- getIndexMaxChosenIndexesPerTable() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- getIndexName() - Method in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- getIndexName() - Method in interface org.apache.drill.exec.planner.index.IndexDefinition
-
Get the name of the index
- getIndexNonCoveringSelThreshold() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- 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.
- getIndexProps() - Method in class org.apache.drill.exec.planner.index.IndexGroup
-
- getIndexRowKeyJoinCostFactor() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- getIndexStatsRowCountScalingFactor() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- getIndexType() - Method in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- getIndexType() - Method in interface org.apache.drill.exec.planner.index.IndexDefinition
-
- getInfo() - Method in class org.apache.drill.exec.planner.fragment.Materializer.IndexedFragmentNode
-
- getInfo() - Method in class org.apache.drill.exec.work.foreman.rm.DistributedQueryQueue
-
- getInfoMessage() - Method in class org.apache.drill.exec.client.DrillSqlLineApplication
-
- 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
-
- getInitialOutcome() - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
-
Return the initial outcome (from the first next() call )
- getInitialPlanningMemorySize() - Static method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- getInitialSizeIsFinal() - Method in class org.apache.drill.exec.physical.impl.common.HashTableConfig
-
- 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
-
- getInMemoryBatches() - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- getInMemoryBatches() - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PartitionStat
-
- getInMemoryBatches() - Method in class org.apache.drill.exec.physical.impl.join.PartitionStatImpl
-
- getInMemoryPartitions() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PartitionStatSet
-
- getInMemorySize() - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- getInMemorySize() - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PartitionStat
-
- getInMemorySize() - Method in class org.apache.drill.exec.physical.impl.join.PartitionStatImpl
-
- getInnerGenerator(String) - Method in class org.apache.drill.exec.expr.ClassGenerator
-
- getInnerRecordCount() - Method in class org.apache.drill.exec.record.RecordIterator
-
- getInnerSpilledBatches() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch.HashJoinSpilledPartition
-
- getInnerSpillFile() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch.HashJoinSpilledPartition
-
- 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
-
- getInputColumnName() - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthExpression.VarLenReadExpr
-
- 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.
- getInputRefs() - Method in class org.apache.drill.exec.planner.common.DrillRelOptUtil.InputRefVisitor
-
- getInputReWriter() - Method in class org.apache.drill.exec.planner.common.DrillRelOptUtil.ProjectPushInfo
-
- getInputRowCount() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
-
- getInputSize(int) - Method in class org.apache.drill.exec.planner.common.DrillLateralJoinRelBase
-
Returns number of fields in RelDataType
for
input rel node with specified ordinal considering value of
excludeCorrelateColumn
.
- 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.BoundCheckingAccessor
-
- getInt(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
-
- 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
-
- getIntersectCost(IndexGroup, IndexConditionInfo.Builder, RelOptPlanner) - Method in interface org.apache.drill.exec.planner.index.IndexProperties
-
- getIntersectCost(IndexGroup, IndexConditionInfo.Builder, RelOptPlanner) - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- getIntersectCost(IndexGroup, IndexConditionInfo.Builder, RelOptPlanner, PluginCost, DrillScanRelBase) - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- 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
-
- getIOTypeString() - Method in enum org.apache.drill.exec.util.record.RecordBatchStats.RecordBatchIOType
-
- 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(ExecutorFragmentContext, int) - 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
-
- 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
-
- getJoinCondition(Join, ConversionContext) - Static method in class org.apache.drill.exec.planner.logical.DrillJoinRel
-
- getJoinControl() - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
-
- getJoinControl() - Method in class org.apache.drill.exec.physical.impl.common.HashTableConfig
-
- 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.
- getJoinInputs(Join, ConversionContext) - Static method in class org.apache.drill.exec.planner.logical.DrillJoinRel
-
- getJoinRel() - Method in class org.apache.drill.exec.planner.logical.RowKeyJoinCallContext
-
- getJoinType() - Method in class org.apache.drill.exec.physical.base.AbstractJoinPop
-
- getJoinType() - Method in class org.apache.drill.exec.physical.impl.join.MergeJoinBatch
-
- getJoinType() - Method in interface org.apache.drill.exec.planner.logical.DrillJoin
-
- getJsonReadersFromBatchString(List<String>, FragmentContext, List<SchemaPath>) - Static method in class org.apache.drill.test.PhysicalOpUnitTestBase
-
- getJsonReadersFromInputFiles(DrillFileSystem, List<String>, FragmentContext, List<SchemaPath>) - Static method in class org.apache.drill.test.PhysicalOpUnitTestBase
-
Create JSONRecordReader from files on a file system.
- 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
-
- getLast() - Method in class org.apache.drill.exec.record.VectorContainer
-
- getLastKnownOutcome() - Method in class org.apache.drill.exec.record.AbstractUnaryRecordBatch
-
- 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
-
- getLateralInput(int, RelNode) - Method in class org.apache.drill.exec.planner.physical.LateralJoinPrel
-
Check to make sure that the fields of the inputs are the same as the output field names.
- getLeadingColumnsFilter(List<RexNode>, RexBuilder) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- getLeadingColumnsFilter() - Method in interface org.apache.drill.exec.planner.index.IndexProperties
-
- getLeadingColumnsFilter() - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- getLeadingFilters(Map<LogicalExpression, RexNode>, List<LogicalExpression>) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- getLeadingPrefixMap(Map<LogicalExpression, RexNode>, List<LogicalExpression>, IndexConditionInfo.Builder, RexNode) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- getLeadingRowCount(RexNode, String, DrillScanRelBase) - Method in interface org.apache.drill.exec.planner.index.Statistics
-
Returns the leading rowcount for the specified filter condition
Leading rowcount means rowcount for filter condition only on leading index columns.
- getLeadingRowCount() - Method in interface org.apache.drill.exec.planner.index.StatisticsPayload
-
- getLeadingSelectivity() - Method in interface org.apache.drill.exec.planner.index.IndexProperties
-
- getLeadingSelectivity() - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- 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.base.AbstractJoinPop
-
- getLeft() - Method in class org.apache.drill.exec.physical.config.RowKeyJoinPOP
-
- getLeft() - Method in interface org.apache.drill.exec.planner.logical.DrillJoin
-
- getLeftKeys() - Method in class org.apache.drill.exec.planner.common.DrillJoinRelBase
-
- getLeftKeys() - Method in interface org.apache.drill.exec.planner.logical.DrillJoin
-
- getLeftNDV() - Method in class org.apache.drill.exec.work.filter.BloomFilterDef
-
- getLeftOutcome() - Method in interface org.apache.drill.exec.physical.base.LateralContract
-
Get the current outcome of left incoming batch.
- getLeftOutcome() - Method in class org.apache.drill.exec.physical.impl.join.LateralJoinBatch
-
- getLeftOutcome() - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- getLeftOutPathsInFunctions() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getLeftOutPathsInFunctions() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getLeftOutPathsInFunctions() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- 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.Metadata_V1.ParquetFileMetadata_v1
-
- getLength() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.RowGroupMetadata_v1
-
- getLength() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetFileMetadata_v2
-
- getLength() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.RowGroupMetadata_v2
-
- getLength() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetFileMetadata_v3
-
- getLength() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.RowGroupMetadata_v3
-
- getLength() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ParquetFileMetadata
-
- getLength() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.RowGroupMetadata
-
- getLength() - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork.FileWorkImpl
-
- getLength() - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork
-
- 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
-
- getLimit() - Method in class org.apache.drill.exec.planner.physical.TopNPrel
-
- 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
-
- getLocalFileSystem() - Static method in class org.apache.drill.exec.ExecTest
-
Creates instance of local file system.
- getLocalFunctionRegistry() - Method in class org.apache.drill.exec.expr.fn.FunctionImplementationRegistry
-
- 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
-
- getLoggedInUgi() - Method in class org.apache.drill.exec.server.rest.auth.SpnegoConfig
-
- 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
-
- 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.BoundCheckingAccessor
-
- getLong(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
-
- 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
-
- getLongStat(MetricDef) - Method in class org.apache.drill.exec.ops.OperatorStats
-
- getLowerProject() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getLowerProject() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getLowerProject() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- getLowerProjectRel() - Method in class org.apache.drill.exec.planner.logical.RowKeyJoinCallContext
-
- getLpPersistence() - Method in class org.apache.drill.exec.ops.QueryContext
-
- getLpPersistence() - Method in class org.apache.drill.exec.server.DrillbitContext
-
- getMainLoginPage(HttpServletRequest, HttpServletResponse, SecurityContext, UriInfo, String) - Method in class org.apache.drill.exec.server.rest.LogInLogOutResources
-
- getMajor() - Method in class org.apache.drill.exec.store.parquet.metadata.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.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
-
- 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.FragmentContext
-
- getManagedBuffer(int) - Method in interface org.apache.drill.exec.ops.FragmentContext
-
- 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
-
- getManagedBuffer() - Method in class org.apache.drill.exec.store.TestOutputMutator
-
- getManager() - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthVisitorState
-
- getMap(DistributedCache.CacheConfig<K, V>) - Method in interface org.apache.drill.exec.cache.DistributedCache
-
- getMapExprToRex() - Method in class org.apache.drill.exec.planner.index.RexToExpression.RexToDrillExt
-
- 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.Metadata_V1.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
-
- getMaxAvgColumnSize() - Method in class org.apache.drill.exec.record.RecordBatchSizer
-
- 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
-
- getMaxErrors() - Method in class org.apache.drill.exec.store.log.LogFormatConfig
-
- 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
-
- getMaxIndexesToIntersect() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- getMaxLength() - Method in class org.apache.drill.exec.store.pcap.decoder.PacketDecoder
-
- getMaxLines() - Method in class org.apache.drill.exec.server.rest.LogsResources.LogContent
-
- getMaxMemoryUsage() - Method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager.ColumnMemoryQuota
-
- getMaxNumericPrecision() - Method in class org.apache.drill.exec.planner.types.DrillRelDataTypeSystem
-
- getMaxNumericScale() - Method in class org.apache.drill.exec.planner.types.DrillRelDataTypeSystem
-
- getMaxNumValues() - Method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager.ColumnMemoryQuota
-
- getMaxParallelizationWidth() - Method in interface org.apache.drill.exec.physical.base.GroupScan
-
- getMaxParallelizationWidth() - Method in class org.apache.drill.exec.physical.base.SchemalessScan
-
- 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.AbstractParquetGroupScan
-
- getMaxParallelizationWidth() - Method in class org.apache.drill.exec.store.sys.SystemTableScan
-
- getMaxRecordsToRead() - Method in class org.apache.drill.exec.store.sys.SystemTableScan
-
- getMaxReservedMemory() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMechanicalMemoryCalculator.MechanicalBuildSidePartitioning
-
- getMaxReservedMemory() - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.BuildSidePartitioning
-
- getMaxReservedMemory() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.BuildSidePartitioningImpl
-
- getMaxReservedMemory() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.NoopBuildSidePartitioningImpl
-
- getMaxValue() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ColumnMetadata_v1
-
- getMaxValue() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnMetadata_v2
-
- getMaxValue() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnMetadata_v3
-
- getMaxValue() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ColumnMetadata
-
- 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
-
- getMemLimit() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate.HashAggUpdater
-
- getMemLimit() - Method in interface org.apache.drill.exec.physical.impl.common.SpilledState.Updater
-
Gets the current memory limit.
- getMemLimit() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch.HashJoinUpdater
-
- getMemory() - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
-
- getMemoryLimit() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
-
- getMemoryUsage(ValueVector, int, BatchSizingMemoryUtil.VectorMemoryUsageInfo) - Static method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.BatchSizingMemoryUtil
-
Load memory usage information for a variable length value vector
- 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 interface org.apache.drill.exec.rpc.control.Controller.CustomResponse
-
The structured portion of the response.
- getMessage() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.CancelQuery
-
- getMessage() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.CustomMessageSender
-
- getMessage() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.ReceiverFinished
-
- getMessage() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.RequestProfile
-
- getMessage() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.SendFragment
-
- getMessage() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.SendFragmentStatus
-
- getMessage() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.SignalFragment
-
- getMessage() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.SyncCustomMessageSender
-
- getMessageHandler() - Method in class org.apache.drill.exec.rpc.control.ControlConnectionConfig
-
- getMetaContext() - Method in class org.apache.drill.exec.store.dfs.FileSelection
-
- getMetaData() - Method in class org.apache.drill.exec.server.options.OptionDefinition
-
- getMetadataVersion() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ParquetTableMetadata_v1
-
- getMetadataVersion() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetTableMetadata_v2
-
- getMetadataVersion() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetTableMetadata_v3
-
- getMetadataVersion() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ParquetTableMetadataBase
-
- getMetadataWidth(ValueVector) - Static method in class org.apache.drill.exec.physical.impl.project.ProjectMemoryManager
-
- 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
-
Creates a map with all method names and their modified bodies
from specified Java.CompilationUnit
.
- getMethods(String, AtomicInteger) - Method in class org.apache.drill.exec.expr.fn.registry.LocalFunctionRegistry
-
- getMethods(String) - Method in class org.apache.drill.exec.expr.fn.registry.LocalFunctionRegistry
-
- getMetric(int) - Method in class org.apache.drill.test.ProfileParser.OperatorProfile
-
- 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.Metadata_V1.ColumnMetadata_v1
-
- getMinor() - Method in class org.apache.drill.exec.store.parquet.metadata.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
-
- getMinorType() - Method in interface org.apache.drill.exec.store.pcapng.schema.Column
-
- getMinorType() - Method in class org.apache.drill.exec.store.pcapng.schema.DummyArrayImpl
-
- getMinorType() - Method in class org.apache.drill.exec.store.pcapng.schema.DummyImpl
-
- 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.Metadata_V1.ColumnMetadata_v1
-
- getMinValue() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnMetadata_v2
-
- getMinValue() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnMetadata_v3
-
- getMinValue() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ColumnMetadata
-
- getMinVersion() - Method in enum org.apache.drill.exec.client.ServerMethod
-
- getMinVLColumnMemorySize() - Static method in class org.apache.drill.exec.store.parquet.columnreaders.VarLenColumnBulkInput
-
- 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() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.GetMode
-
- 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 class org.apache.drill.exec.store.sys.CaseInsensitivePersistentStore
-
- getMode() - Method in class org.apache.drill.exec.store.sys.PersistentStoreConfig
-
- getMode() - Method in interface org.apache.drill.exec.store.sys.Store
-
Returns storage
mode
of this store.
- 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.UndefinedVersionDelegatingStore
-
- getMode() - Method in class org.apache.drill.exec.store.sys.store.VersionedDelegatingStore
-
- 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
-
- getMsPause() - Method in class org.apache.drill.exec.testing.Injection
-
- 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.logical.FieldsReWriterUtil.DesiredField
-
- getName() - Method in enum org.apache.drill.exec.planner.physical.AggPrelBase.OperatorPhase
-
- 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.rpc.control.ControlConnectionConfig
-
- 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.AbstractSchemaFactory
-
- getName() - Method in class org.apache.drill.exec.store.AbstractStoragePlugin
-
- 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.image.GenericMetadataDirectory
-
- 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.NamedStoragePluginConfig
-
- getName() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ColumnMetadata_v1
-
- getName() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnMetadata_v2
-
- getName() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnMetadata_v3
-
- getName() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ColumnMetadata
-
- getName() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatPlugin
-
- getName() - Method in interface org.apache.drill.exec.store.StoragePlugin
-
- getName() - Method in class org.apache.drill.exec.store.sys.PersistentStoreConfig
-
- getNativeDrillTable(IndexDescriptor) - Method in class org.apache.drill.exec.planner.index.IndexDiscoverBase
-
When it is native index(index provided by native storage plugin),
the actual IndexDiscover should provide the implementation to get the DrillTable object of index,
Otherwise, we call IndexDiscoverable interface exposed from external storage plugin's SchemaFactory
to get the desired DrillTable.
- getNestedLoopJoinFactor() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- getNetBatchSize() - Method in class org.apache.drill.exec.record.RecordBatchSizer
-
- getNetRowWidth() - Method in class org.apache.drill.exec.record.RecordBatchSizer
-
- getNetRowWidthCap50() - Method in class org.apache.drill.exec.record.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.
- getNetSizePerEntry() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
This is the average per entry size of just pure data plus
overhead of additional vectors we add on top like bits vector,
offset vector etc.
- 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
-
- getNewChildAllocator(String, int, long, long) - Method in interface org.apache.drill.exec.ops.FragmentContext
-
- getNewChildAllocator(String, int, long, long) - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getNewChildAllocator(String, int, long, long) - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- getNewClient() - Method in class org.apache.drill.exec.rpc.control.ControlConnectionManager
-
- getNewClient() - Method in class org.apache.drill.exec.rpc.control.LocalControlConnectionManager
-
- getNewClient() - Method in class org.apache.drill.exec.rpc.control.RemoteControlConnectionManager
-
- getNewClient() - Method in class org.apache.drill.exec.rpc.data.DataConnectionManager
-
- getNewDefaultSchema() - Method in class org.apache.drill.exec.ops.QueryContext
-
Return reference to default schema instance in a schema tree.
- 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")
- 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.easy.json.JsonRecordWriter
-
- getNewMapConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
-
- getNewMapConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.text.DrillTextRecordWriter
-
- getNewPath(SchemaPath) - Method in interface org.apache.drill.exec.planner.index.FunctionalIndexInfo
-
getNewPath: for an original path, return new rename '$N' path, notice there could be multiple renamed paths
if the there are multiple functional indexes refer original path.
- getNewPathFromExpr(LogicalExpression) - Method in interface org.apache.drill.exec.planner.index.FunctionalIndexInfo
-
return a plain field path if the incoming index expression 'expr' is replaced to be a plain field
- getNewRepeatedListConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter
-
- 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.easy.json.JsonRecordWriter
-
- getNewRepeatedMapConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
-
- getNewRepeatedMapConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.text.DrillTextRecordWriter
-
- 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
-
- getNewUnionConverter(int, String, FieldReader) - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter
-
- 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.OrderedMuxExchange
-
- 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.PartitionLimit
-
- 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.RangePartitionExchange
-
- getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.RangePartitionSender
-
- getNewWithChild(PhysicalOperator) - Method in class org.apache.drill.exec.physical.config.RuntimeFilterPOP
-
- 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.base.SchemalessScan
-
- 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.LateralJoinPOP
-
- 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.RowKeyJoinPOP
-
- 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.UnnestPOP
-
- 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
-
- getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.test.OperatorTestBuilderTest.MockPhysicalOperator
-
- getNewWithChildren(List<PhysicalOperator>) - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockPhysicalOperator
-
- 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.common.HashPartition
-
- getNextIndex(int) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelper
-
Takes a composite index for a key produced by
HashJoinHelper.getStartIndex(int)
, and returns the composite index for the
next record in the list of records that match a key.
- 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
-
- getNextSpilledPartition() - Method in class org.apache.drill.exec.physical.impl.common.SpilledState
-
Get the next spilled partition to process.
- 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
-
- getNextUnmatchedIndex() - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- 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
-
- getNoAlloc(EscapeTest1.Monkey) - Method in class org.apache.drill.exec.expr.EscapeTest1
-
- 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
-
- getNodes() - Method in class org.apache.drill.exec.planner.logical.FieldsReWriterUtil.DesiredField
-
- getNonIndexColumns() - Method in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- getNonIndexColumns() - Method in interface org.apache.drill.exec.planner.index.IndexDefinition
-
Get the list of columns that are in the 'included' or 'covered' fields.
- getNormalizedNewLine() - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
-
- getNullableColumnReader(ParquetRecordReader, 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.Metadata_V1.ColumnMetadata_v1
-
- getNulls() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnMetadata_v2
-
- getNulls() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnMetadata_v3
-
- getNulls() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ColumnMetadata
-
- getNullsOrderingDirection() - Method in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- getNullsOrderingDirection() - Method in interface org.apache.drill.exec.planner.index.IndexDefinition
-
Get the nulls ordering of this index
- 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.
- getNumBytes() - Method in class org.apache.drill.exec.work.filter.BloomFilterDef
-
- getNumericValue() - Method in enum org.apache.drill.exec.expr.BooleanType
-
- getNumIncomingBatches() - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getNumIncomingBatches(int) - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getNumInMemoryBatches() - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- getNumInMemoryBatches() - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PartitionStat
-
- getNumInMemoryBatches() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PartitionStatSet
-
- getNumInMemoryBatches() - Method in class org.apache.drill.exec.physical.impl.join.PartitionStatImpl
-
- getNumInMemoryPartitions() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PartitionStatSet
-
- getNumInMemoryRecords() - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- getNumInMemoryRecords() - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PartitionStat
-
- getNumInMemoryRecords() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PartitionStatSet
-
- getNumInMemoryRecords() - Method in class org.apache.drill.exec.physical.impl.join.PartitionStatImpl
-
- getNumOutgoingBatches() - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getNumPartitions() - Method in class org.apache.drill.exec.physical.impl.common.SpilledState
-
Gets the number of partitions.
- getNumPartitions() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMechanicalMemoryCalculator.MechanicalBuildSidePartitioning
-
- getNumPartitions() - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.BuildSidePartitioning
-
- getNumPartitions() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.BuildSidePartitioningImpl
-
- getNumPartitions() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.NoopBuildSidePartitioningImpl
-
- getNumRecords() - Method in interface org.apache.drill.exec.physical.impl.join.BatchSizePredictor
-
- getNumRecords() - Method in class org.apache.drill.exec.physical.impl.join.BatchSizePredictorImpl
-
- getNumRecords() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.BatchStat
-
- getNumRecords() - Method in class org.apache.drill.exec.physical.impl.join.TestBuildSidePartitioningImpl.MockBatchSizePredictor
-
- getNumRecords() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl.ConditionalMockBatchSizePredictor
-
- getNumRecordsToRead() - Method in class org.apache.drill.exec.store.parquet.RowGroupInfo
-
- getNumRecordsToRead() - Method in class org.apache.drill.exec.store.parquet.RowGroupReadEntry
-
- getNumSenders() - Method in class org.apache.drill.exec.physical.base.AbstractReceiver
-
- getNumSpilledPartitions() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PartitionStatSet
-
- 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.BoundCheckingAccessor
-
Returns an instance sitting at the given index if exists, null otherwise.
- getObject(int) - Method in class org.apache.drill.exec.vector.accessor.GenericAccessor
-
- getObject(int) - Method in interface org.apache.drill.exec.vector.accessor.SqlAccessor
-
- getObject(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
-
- getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
-
- getObjectClass() - Method in class org.apache.drill.exec.vector.accessor.GenericAccessor
-
- 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.UnionSqlAccessor
-
- 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 interface org.apache.drill.exec.planner.common.OrderedRel
-
Offset value represented in RexNode.
- getOffset(OrderedRel) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- getOffset() - Method in class org.apache.drill.exec.planner.logical.DrillSortRel
-
- getOffset() - Method in class org.apache.drill.exec.planner.physical.SortPrel
-
- getOffset() - Method in class org.apache.drill.exec.planner.physical.TopNPrel
-
- getOffset() - Method in class org.apache.drill.exec.store.dfs.MagicString
-
- getOffsetVectorWidth() - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- 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
-
- getOpCreatorReg() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase
-
- getOpDefn(String) - Method in class org.apache.drill.test.ProfileParser
-
- getOpDefsOfType(int) - Method in class org.apache.drill.test.ProfileParser
-
- getOperandList() - Method in class org.apache.drill.exec.planner.sql.parser.DrillSqlDescribeTable
-
- 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.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.DrillCalciteSqlBetweenOperatorWrapper
-
- 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.DrillSqlDescribeTable
-
- 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.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.AbstractParquetGroupScan
-
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 interface org.apache.drill.exec.ops.ExecutorFragmentContext
-
- getOperatorCreatorRegistry() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getOperatorCreatorRegistry() - Method in class org.apache.drill.exec.server.DrillbitContext
-
- getOperatorCreatorRegistry() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- 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
-
- getOperators() - Method in class org.apache.drill.test.ProfileParser
-
- 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.LateralJoinPOP
-
- 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.PartitionLimit
-
- 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.RangePartitionSender
-
- getOperatorType() - Method in class org.apache.drill.exec.physical.config.RowKeyJoinPOP
-
- getOperatorType() - Method in class org.apache.drill.exec.physical.config.RuntimeFilterPOP
-
- 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.UnnestPOP
-
- 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
-
- getOperatorType() - Method in class org.apache.drill.test.OperatorTestBuilderTest.MockPhysicalOperator
-
- getOperatorType() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockPhysicalOperator
-
- getOpId() - Method in class org.apache.drill.exec.planner.physical.explain.PrelSequencer.OpId
-
- getOpInfo() - Method in class org.apache.drill.test.ProfileParser
-
We often run test queries single threaded to make analysis of the profile
easier.
- 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
-
- getOppositeMajorFragmentId() - Method in interface org.apache.drill.exec.work.batch.DataCollector
-
- getOppositeMinorFragmentId() - Method in class org.apache.drill.exec.physical.config.SingleSender
-
- getOpsOfType(int) - Method in class org.apache.drill.test.ProfileParser
-
For a single-slice query, get all operators of a given numeric operator
type.
- 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
-
- 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
-
- getOptionDescription() - Method in class org.apache.drill.exec.server.options.OptionValidator
-
Get the option description (long and short)
- 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
-
- getOptionManager() - Method in class org.apache.drill.test.OperatorFixture
-
- getOptionName() - Method in class org.apache.drill.exec.server.options.OptionValidator
-
Gets the name of the option for this validator.
- getOptions() - Method in interface org.apache.drill.exec.ops.FragmentContext
-
Returns a read-only version of the session options.
- getOptions() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getOptions() - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
-
Returns the session options.
- 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
-
- getOptions() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- getOptionScope() - Method in class org.apache.drill.exec.server.rest.StatusResources.OptionWrapper
-
- getOpts(SqlLine) - Method in class org.apache.drill.exec.client.DrillSqlLineApplication
-
- 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
-
- 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
-
- 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
-
- 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
-
- getOrCreateVersionedStore(PersistentStoreConfig<V>) - Method in interface org.apache.drill.exec.store.sys.PersistentStoreProvider
-
Override this method if store supports versioning and return versioning instance.
- getOrCreateVersionedStore(PersistentStoreConfig<V>) - Method in class org.apache.drill.exec.store.sys.store.provider.CachingPersistentStoreProvider
-
- getOrCreateVersionedStore(PersistentStoreConfig<V>) - Method in class org.apache.drill.exec.store.sys.store.provider.InMemoryStoreProvider
-
- getOrCreateVersionedStore(PersistentStoreConfig<V>) - Method in class org.apache.drill.exec.store.sys.store.provider.LocalPersistentStoreProvider
-
- getOrCreateVersionedStore(PersistentStoreConfig<V>) - Method in class org.apache.drill.exec.store.sys.store.provider.ZookeeperPersistentStoreProvider
-
- 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, FunctionLookupContext) - 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
-
- getOrigCondition() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getOrigCondition() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getOrigCondition() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- getOriginalAccess() - Method in class org.apache.drill.exec.compile.InnerClassAccessStripper
-
Return the original class' access bits.
- getOriginalScan() - Method in class org.apache.drill.exec.planner.index.IndexDiscoverBase
-
- getOriginalScanRel() - Method in class org.apache.drill.exec.planner.index.IndexDiscoverBase
-
- getOriginalTableNameFromTemporaryTable(String) - Method in class org.apache.drill.exec.rpc.user.UserSession
-
- getOriginalType() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ColumnMetadata_v1
-
- getOriginalType(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ParquetTableMetadata_v1
-
- getOriginalType() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnMetadata_v2
-
- getOriginalType(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetTableMetadata_v2
-
- getOriginalType() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnMetadata_v3
-
- getOriginalType(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetTableMetadata_v3
-
- getOriginalType() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ColumnMetadata
-
- getOriginalType(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ParquetTableMetadataBase
-
- getOriginPartition() - Method in class org.apache.drill.exec.physical.impl.common.AbstractSpilledPartitionMetadata
-
- getOriginPartition() - Method in interface org.apache.drill.exec.physical.impl.common.SpilledPartitionMetadata
-
The parent partition.
- getOrigMarker() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getOrigMarker() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getOrigMarker() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- 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
-
- getOuterSpilledBatches() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch.HashJoinSpilledPartition
-
- getOuterSpillFile() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch.HashJoinSpilledPartition
-
- 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
-
- getOutgoingBatchSize() - Method in class org.apache.drill.exec.physical.config.HashPartitionSender
-
- getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.aggregate.SpilledRecordbatch
-
- getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggBatch
-
- getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenRecordBatch
-
- getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.MockRecordBatch
-
- getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.project.ProjectRecordBatch
-
- getOutgoingContainer() - Method in interface org.apache.drill.exec.physical.impl.protocol.BatchAccessor
-
- getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.protocol.OperatorRecordBatch
-
- getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor
-
- getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
-
- getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- getOutgoingContainer() - Method in class org.apache.drill.exec.physical.impl.unnest.UnnestRecordBatch
-
- 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.SchemalessBatch
-
- getOutgoingContainer() - Method in class org.apache.drill.exec.record.SimpleRecordBatch
-
- getOutgoingRowWidth() - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getOutgoingValueVector(TypedFieldId) - Method in class org.apache.drill.exec.physical.impl.project.ProjectMemoryManager
-
- getOutOfMemoryHandler() - Method in class org.apache.drill.exec.rpc.data.DataServer
-
- getOutPosition() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
-
- getOutputBatchSize() - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- 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 interface org.apache.drill.exec.physical.impl.join.HashJoinProbe
-
- getOutputCount() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinProbeTemplate
-
- 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
-
- getOutputFormats(SqlLine) - Method in class org.apache.drill.exec.client.DrillSqlLineApplication
-
- getOutputPrecision() - Method in class org.apache.drill.exec.planner.types.decimal.DrillBaseComputeScalePrecision
-
- getOutputRecords() - Method in interface org.apache.drill.exec.physical.impl.orderedpartitioner.SampleCopier
-
- getOutputRecords() - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.SampleCopierTemplate
-
- getOutputRowCount() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggBatch
-
- getOutputRowCount() - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getOutputScale() - Method in class org.apache.drill.exec.planner.types.decimal.DrillBaseComputeScalePrecision
-
- getOutputType(SqlNode) - Method in class org.apache.drill.exec.planner.sql.SqlConverter
-
- getOutputWidth(List<OutputWidthExpression.FixedLenExpr>) - Method in interface org.apache.drill.exec.expr.fn.output.OutputWidthCalculator
-
- getOutputWidth(List<OutputWidthExpression.FixedLenExpr>) - Method in class org.apache.drill.exec.expr.fn.output.OutputWidthCalculators.CloneOutputWidthCalculator
-
Defines a function's output size estimate as the same length as the first
argument.
- getOutputWidth(List<OutputWidthExpression.FixedLenExpr>) - Method in class org.apache.drill.exec.expr.fn.output.OutputWidthCalculators.ConcatOutputWidthCalculator
-
- getOutputWidth(List<OutputWidthExpression.FixedLenExpr>) - Method in class org.apache.drill.exec.expr.fn.output.OutputWidthCalculators.DefaultOutputWidthCalculator
-
- getOutputWidthCalculator() - Method in enum org.apache.drill.exec.expr.annotations.FunctionTemplate.OutputWidthCalculatorType
-
- getOutputWidthCalculator() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
-
- getOutputWidthCalculatorType() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
-
- 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
-
- getParamNames() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
-
- getParamNames() - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
-
- getParentClass() - Method in class org.apache.drill.exec.planner.physical.UnnestPrel
-
- getParmMajorType(int) - Method in class org.apache.drill.exec.expr.fn.AbstractFuncHolder
-
- getParmMajorType(int) - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
-
- getParquetFilterPredicate(LogicalExpression, UdfUtilities, FunctionImplementationRegistry, OptionManager, boolean) - Method in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
Returns parquet filter predicate built from specified filterExpr
.
- getParquetRowGroupFilterPushDownThreshold() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- getParquetTableMetadata(FileSystem, String, ParquetReaderConfig) - Static method in class org.apache.drill.exec.store.parquet.metadata.Metadata
-
Get the parquet metadata for the parquet files in the given directory, including those in subdirectories.
- getParquetTableMetadata(Map<FileStatus, FileSystem>, ParquetReaderConfig) - Static method in class org.apache.drill.exec.store.parquet.metadata.Metadata
-
Get the parquet metadata for a list of parquet files.
- getParsedFlags() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
-
- getPartitionBatchesCount() - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- getPartitionColumn() - Method in class org.apache.drill.exec.physical.config.PartitionLimit
-
- getPartitionColumnNames(FileSelection, SchemaConfig) - Static method in class org.apache.drill.exec.store.ColumnExplorer
-
Returns list with partition column names.
- 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.AbstractParquetGroupScan
-
- getPartitionColumns() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScanStatistics
-
- 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
-
- getPartitionExplorer() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- 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.
- getPartitionExplorer() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- getPartitionFieldRef() - Method in class org.apache.drill.exec.planner.physical.AbstractRangePartitionFunction
-
- getPartitionFieldRef() - Method in interface org.apache.drill.exec.planner.physical.PartitionFunction
-
Returns a FieldReference (LogicalExpression) for the partition function
- getPartitionFunction() - Method in class org.apache.drill.exec.physical.config.RangePartitionSender
-
- getPartitionFunction() - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
-
- 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
-
- getPartitionMask() - Method in class org.apache.drill.exec.physical.impl.common.SpilledState
-
- getPartitionNum() - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- getPartitionProbeBatchSize() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.PostBuildCalculationsImpl
-
- getPartitionRefList() - Method in class org.apache.drill.exec.planner.physical.AbstractRangePartitionFunction
-
- getPartitionRefList() - Method in interface org.apache.drill.exec.planner.physical.PartitionFunction
-
Return the list of FieldReferences that participate in the partitioning function
- getPartitions(boolean) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PartitionStatSet
-
- 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
- getPartitionValue(String, SchemaPath, Class<T>) - Method in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- getPartitionValue(String, SchemaPath) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScanStatistics
-
- getPartitionValues(RowGroupInfo) - Method in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- getPartitionValues(RowGroupReadEntry) - Method in class org.apache.drill.exec.store.parquet.AbstractParquetRowGroupScan
-
- getPartitionValues(RowGroupInfo) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
-
- getPartitionValues(RowGroupReadEntry) - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
-
- 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.physical.impl.xsort.managed.BatchGroup.SpilledRun
-
- getPath(TypedFieldId, RecordBatch) - Static method in class org.apache.drill.exec.record.TypedFieldId
-
Generates the full path to a field from the typefield ids
- 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.Metadata_V1.ParquetFileMetadata_v1
-
- getPath() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetFileMetadata_v2
-
- getPath() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetFileMetadata_v3
-
- getPath() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ParquetFileMetadata
-
- getPath() - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork.FileWorkImpl
-
- getPath() - Method in class org.apache.drill.exec.store.schedule.CompleteFileWork
-
- getPathsInFunctionExpr() - Method in interface org.apache.drill.exec.planner.index.FunctionalIndexInfo
-
- 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
-
- getPhysicalFileFromResource(String) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
Copy the resource (ex.
- 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.DirectScanPrel
-
- 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.LateralJoinPrel
-
- 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.OrderedMuxExchangePrel
-
- 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.RangePartitionExchangePrel
-
- getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.RowKeyJoinPrel
-
- getPhysicalOperator(PhysicalPlanCreator) - Method in class org.apache.drill.exec.planner.physical.RuntimeFilterPrel
-
- 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.UnnestPrel
-
- 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
-
- 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, SessionOptionManager) - Method in class org.apache.drill.exec.store.AbstractStoragePlugin
-
- getPhysicalScan(String, JSONOptions) - Method in class org.apache.drill.exec.store.AbstractStoragePlugin
-
- getPhysicalScan(String, JSONOptions, List<SchemaPath>, SessionOptionManager) - 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, SessionOptionManager) - Method in class org.apache.drill.exec.store.dfs.FileSystemPlugin
-
- getPhysicalScan(String, JSONOptions, List<SchemaPath>) - Method in class org.apache.drill.exec.store.dfs.FileSystemPlugin
-
- getPhysicalScan(String, JSONOptions, List<SchemaPath>, SessionOptionManager) - 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, SessionOptionManager) - 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>, SessionOptionManager) - 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.ShowFilesHandler
-
- 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
-
- getPlan() - Method in class org.apache.drill.test.ProfileParser
-
- getPlanForFile(String, String) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- getPlanInString(String, String) - Static method in class org.apache.drill.PlanTestBase
-
- 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 interface org.apache.drill.exec.ops.ExecutorFragmentContext
-
- getPlanReader() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getPlanReader() - Method in class org.apache.drill.exec.server.DrillbitContext
-
- getPlanReader() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- getPlans() - Method in class org.apache.drill.test.ProfileParser
-
- 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
-
- getPluginCostModel() - Method in class org.apache.drill.exec.physical.base.AbstractDbGroupScan
-
- getPluginCostModel() - Method in interface org.apache.drill.exec.physical.base.DbGroupScan
-
Get the format plugin cost model.
- getPluginCostModel() - Method in class org.apache.drill.exec.planner.index.DrillIndexDescriptor
-
- getPluginCostModel() - Method in interface org.apache.drill.exec.planner.index.IndexDescriptor
-
Get the costing factors associated with the storage/format plugin
- 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(WritableByteChannel) - 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.
- getPrevOriginPartition() - Method in class org.apache.drill.exec.physical.impl.common.AbstractSpilledPartitionMetadata
-
- getPrevOriginPartition() - Method in interface org.apache.drill.exec.physical.impl.common.SpilledPartitionMetadata
-
The parent of parent partition.
- getPrimaryTableScan() - Method in interface org.apache.drill.exec.planner.index.IndexProperties
-
- getPrimaryTableScan() - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- getPrimitiveType() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ColumnMetadata_v1
-
- getPrimitiveType(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ParquetTableMetadata_v1
-
- getPrimitiveType() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnMetadata_v2
-
- getPrimitiveType(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetTableMetadata_v2
-
- getPrimitiveType() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnMetadata_v3
-
- getPrimitiveType(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetTableMetadata_v3
-
- getPrimitiveType() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ColumnMetadata
-
- getPrimitiveType(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ParquetTableMetadataBase
-
- getPrimitiveType(MaterializedField) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
-
- getPriority() - Method in class org.apache.drill.exec.opt.BasicOptimizer.BasicOptimizationContext
-
- getPriority() - Method in interface org.apache.drill.exec.opt.Optimizer.OptimizationContext
-
- getProbeField() - Method in class org.apache.drill.exec.work.filter.BloomFilterDef
-
- getProbeHashCode(int) - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- getProbeHashCode(int) - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
-
Computes the hash code for the record at the given index in the probe side batch.
- getProbeHashCode(int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
-
Return the Hash Value for the row in the Probe incoming batch at index:
- getProbeRecordsPerBatch() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMechanicalMemoryCalculator.MechanicalPostBuildCalculations
-
- getProbeRecordsPerBatch() - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PostBuildCalculations
-
- getProbeRecordsPerBatch() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.NoopPostBuildCalculationsImpl
-
- getProbeRecordsPerBatch() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.PostBuildCalculationsImpl
-
- 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
-
- getProfileDir() - Method in class org.apache.drill.test.ClusterFixture
-
Returns the directory that holds query profiles.
- 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
-
- getProfiles(int, int) - Method in class org.apache.drill.exec.store.sys.ProfileInfoIterator
-
- getProfiles(int, int) - Method in class org.apache.drill.exec.store.sys.ProfileIterator
-
Returns profiles based of given range.
- getProfiles(int, int) - Method in class org.apache.drill.exec.store.sys.ProfileJsonIterator
-
- 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 interface org.apache.drill.exec.ops.ExecutorFragmentContext
-
- getProfileStoreContext() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getProfileStoreContext() - Method in class org.apache.drill.exec.ops.QueryContext
-
- getProfileStoreContext() - Method in class org.apache.drill.exec.server.DrillbitContext
-
- getProfileStoreContext() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- getProjectExpressions(DrillParseContext) - Method in class org.apache.drill.exec.planner.common.DrillProjectRelBase
-
- getProjectExpressions(DrillParseContext) - Method in class org.apache.drill.exec.planner.physical.ProjectAllowDupPrel
-
- getProjectExprs(List<RexNode>, DrillProjectRelBase, RelNode) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- getProjection(MessageType, Collection<SchemaPath>, List<SchemaPath>) - Static method in class org.apache.drill.exec.store.parquet2.DrillParquetReader
-
- getProjects(DrillProjectRelBase) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- 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.
- 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
-
- getQuery() - Method in class org.apache.drill.test.ProfileParser
-
- 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.server.rest.QueryResources.TabularResult
-
- getQueryId() - Method in class org.apache.drill.exec.server.rest.QueryWrapper.QueryResult
-
- getQueryId() - Method in class org.apache.drill.exec.work.foreman.Foreman
-
- getQueryId() - Method in class org.apache.drill.exec.work.foreman.LoggedQuery
-
- getQueryId() - Method in class org.apache.drill.test.BaseTestQuery.SilentListener
-
Deprecated.
- 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.
- getQueryOptions() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
-
- 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
-
- getQueryState() - Method in class org.apache.drill.SingleRowListener
-
Get the last known QueryState.
- getQueryStateDisplayName(UserBitShared.QueryResult.QueryState) - Static method in class org.apache.drill.exec.server.rest.profile.ProfileUtil
-
Utility method 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 interface org.apache.drill.exec.ops.FragmentContext
-
- getQueryUserName() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getQueryUserName() - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
-
- 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
-
- getQueryUserName() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- 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
-
- getRandomBlockReadCost(GroupScan) - Method in interface org.apache.drill.exec.planner.cost.PluginCost
-
- getRange(int, int) - Method in class org.apache.drill.exec.store.sys.CaseInsensitivePersistentStore
-
- getRange(int, int) - Method in interface org.apache.drill.exec.store.sys.Store
-
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.UndefinedVersionDelegatingStore
-
- getRange(int, int) - Method in class org.apache.drill.exec.store.sys.store.VersionedDelegatingStore
-
- 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
-
- getRangePartitionFunction(List<FieldReference>) - Method in class org.apache.drill.exec.physical.base.AbstractDbGroupScan
-
- getRangePartitionFunction(List<FieldReference>) - Method in interface org.apache.drill.exec.physical.base.DbGroupScan
-
Get a partition function instance for range based partitioning
- getReadBytes() - Method in class org.apache.drill.exec.physical.impl.spill.SpillSet
-
- getReadEntries() - Method in class org.apache.drill.exec.store.mock.MockGroupScanPOP
-
- getReadEntries() - Method in class org.apache.drill.exec.store.mock.MockSubScanPOP
-
- getReadEntries(int) - Method in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- 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 interface org.apache.drill.exec.vector.accessor.SqlAccessor
-
- getReaderConfig() - Method in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- getReaderConfig() - Method in class org.apache.drill.exec.store.parquet.AbstractParquetRowGroupScan
-
- getReaderConfigForSerialization() - Method in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- getReaderConfigForSerialization() - Method in class org.apache.drill.exec.store.parquet.AbstractParquetRowGroupScan
-
- getReaderListForJsonBatches(List<String>, FragmentContext) - Method in class org.apache.drill.test.PhysicalOpUnitTestBase
-
- 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.image.ImageFormatPlugin
-
- getReaderOperatorType() - Method in class org.apache.drill.exec.store.log.LogFormatPlugin
-
- getReaderOperatorType() - Method in class org.apache.drill.exec.store.pcap.PcapFormatPlugin
-
- getReaderOperatorType() - Method in class org.apache.drill.exec.store.pcapng.PcapngFormatPlugin
-
- getReadExpression() - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthExpression.VarLenReadExpr
-
- 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.OrderedMuxExchange
-
- getReceiver(int) - Method in class org.apache.drill.exec.physical.config.OrderedPartitionExchange
-
- getReceiver(int) - Method in class org.apache.drill.exec.physical.config.RangePartitionExchange
-
- 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, ExecutorFragmentContext) - Method in class org.apache.drill.exec.physical.impl.ImplCreator
-
Create a RecordBatch and its children for given PhysicalOperator
- getRecordBatchMemoryManager() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggBatch
-
- getRecordBatchSizer(int) - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getRecordBatchSizer() - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getRecordBatchStatsContext() - Method in class org.apache.drill.exec.record.AbstractRecordBatch
-
- 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.filter.RuntimeFilterRecordBatch
-
- 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.LateralJoinBatch
-
- 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.join.RowKeyJoinBatch
-
- getRecordCount() - Method in class org.apache.drill.exec.physical.impl.limit.LimitRecordBatch
-
- getRecordCount() - Method in class org.apache.drill.exec.physical.impl.limit.PartitionLimitRecordBatch
-
- getRecordCount() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
-
- getRecordCount() - Method in class org.apache.drill.exec.physical.impl.MockRecordBatch
-
- 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.protocol.OperatorRecordBatch
-
- getRecordCount() - Method in class org.apache.drill.exec.physical.impl.rangepartitioner.RangePartitionRecordBatch
-
- getRecordCount() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
-
- getRecordCount() - Method in class org.apache.drill.exec.physical.impl.SimpleRootExec
-
Deprecated.
- 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.unnest.MockLateralJoinBatch
-
- getRecordCount() - Method in class org.apache.drill.exec.physical.impl.unnest.UnnestRecordBatch
-
- 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 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.SchemalessBatch
-
- 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.Files
-
- 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() - Method in interface org.apache.drill.exec.physical.base.LateralContract
-
Get current record index in incoming to be processed.
- getRecordIndex() - Method in class org.apache.drill.exec.physical.impl.join.LateralJoinBatch
-
Returns the current row index which the calling operator should process in current incoming left record batch.
- getRecordIndex() - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- getRecordIndex(int) - Static method in class org.apache.drill.exec.record.selection.SelectionVector4
-
- getRecordOverflowDefinition() - Method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchOverflow
-
- 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(FragmentContext, DrillFileSystem, FileWork, List<SchemaPath>, String) - Method in class org.apache.drill.exec.store.image.ImageFormatPlugin
-
- 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.Files
-
- 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.log.LogFormatPlugin
-
- getRecordReader(FragmentContext, DrillFileSystem, FileWork, List<SchemaPath>, String) - Method in class org.apache.drill.exec.store.pcap.PcapFormatPlugin
-
- getRecordReader(FragmentContext, DrillFileSystem, FileWork, List<SchemaPath>, String) - Method in class org.apache.drill.exec.store.pcapng.PcapngFormatPlugin
-
- getRecords() - Method in class org.apache.drill.exec.store.mock.MockTableDef.MockScanEntry
-
- getRecordsReadInCurrentPass() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
-
- getRecordsReadInCurrentPass() - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
-
- 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, EasyWriter) - Method in class org.apache.drill.exec.store.image.ImageFormatPlugin
-
- getRecordWriter(FragmentContext, EasyWriter) - Method in class org.apache.drill.exec.store.log.LogFormatPlugin
-
- 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
-
- getRecordWriter(FragmentContext, EasyWriter) - Method in class org.apache.drill.exec.store.pcapng.PcapngFormatPlugin
-
- getRef() - Method in class org.apache.drill.exec.physical.config.OrderedPartitionSender
-
- getRef() - Method in class org.apache.drill.exec.planner.common.DrillUnnestRelBase
-
- getReferencedDirs() - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
-
- getRegex() - Method in class org.apache.drill.exec.store.log.LogFormatConfig
-
- 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.
- getRemainder() - Method in class org.apache.drill.exec.record.TypedFieldId
-
- getRemainderPaths() - Method in class org.apache.drill.exec.planner.index.PathInExpr
-
- getRemainderPathsInFunctions() - Method in class org.apache.drill.exec.planner.index.PathInExpr
-
- getRemainderSelectivity() - Method in interface org.apache.drill.exec.planner.index.IndexProperties
-
- getRemainderSelectivity() - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- 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
-
- getRemainingValuesToRead() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
-
- 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
-
- getRepetitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ParquetTableMetadata_v1
-
- getRepetitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetTableMetadata_v2
-
- getRepetitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetTableMetadata_v3
-
- getRepetitionLevel(String[]) - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.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
-
- getResource(String) - Static method in class org.apache.drill.test.ClusterFixture
-
- 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
-
- getRestrictedScan(List<SchemaPath>) - Method in class org.apache.drill.exec.physical.base.AbstractDbGroupScan
-
- getRestrictedScan(List<SchemaPath>) - Method in interface org.apache.drill.exec.physical.base.DbGroupScan
-
If this DbGroupScan supports restricted scan, create a restricted scan from this DbGroupScan.
- getResult() - Method in class org.apache.drill.exec.server.rest.StorageResources.JsonResult
-
- getResultList() - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- getResults() - Method in class org.apache.drill.exec.store.parquet.ParquetResultListener
-
- getResultString(List<QueryDataBatch>, String) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- getRetryAttempts() - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
-
- getReturnAlloc(EscapeTest1.Monkey) - Method in class org.apache.drill.exec.expr.EscapeTest1
-
- 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
-
- 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.index.RexToExpression.RexToDrillExt
-
- getRexBuilder() - Method in class org.apache.drill.exec.planner.logical.DrillOptiq.RexToDrill
-
- getRexBuilder() - Method in class org.apache.drill.exec.planner.torel.ConversionContext
-
- getRight() - Method in class org.apache.drill.exec.physical.base.AbstractJoinPop
-
- getRight() - Method in class org.apache.drill.exec.physical.config.RowKeyJoinPOP
-
- getRight() - Method in interface org.apache.drill.exec.planner.logical.DrillJoin
-
- getRightKeys() - Method in class org.apache.drill.exec.planner.common.DrillJoinRelBase
-
- getRightKeys() - Method in interface org.apache.drill.exec.planner.logical.DrillJoin
-
- getRightNDV() - Method in class org.apache.drill.exec.work.filter.BloomFilterDef
-
- 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(ExecutorFragmentContext, BroadcastSender, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.broadcastsender.BroadcastSenderCreator
-
- getRoot(ExecutorFragmentContext, OrderedPartitionSender, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionSenderCreator
-
- getRoot(ExecutorFragmentContext, HashPartitionSender, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderCreator
-
- getRoot(ExecutorFragmentContext, RangePartitionSender, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.rangepartitioner.RangePartitionSenderCreator
-
- getRoot(ExecutorFragmentContext, T, List<RecordBatch>) - Method in interface org.apache.drill.exec.physical.impl.RootCreator
-
- getRoot(ExecutorFragmentContext, Screen, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.ScreenCreator
-
- getRoot(ExecutorFragmentContext, SingleSender, List<RecordBatch>) - Method in class org.apache.drill.exec.physical.impl.SingleSenderCreator
-
- getRoot() - Method in class org.apache.drill.exec.planner.fragment.Fragment
-
- getRootAllocator() - Method in interface org.apache.drill.exec.ops.ExecutorFragmentContext
-
Returns the root allocator for the Drillbit.
- getRootAllocator() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getRootAllocator() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- getRootConverter() - Method in class org.apache.drill.exec.store.parquet2.DrillParquetRecordMaterializer
-
- getRootDir() - Method in class org.apache.drill.test.BaseDirTestWatcher
-
Gets the temp directory that should be used to hold the contents of the dfs.root workspace.
- getRootFragment(PhysicalPlanReader, String) - Static method in class org.apache.drill.exec.pop.PopUnitTestBase
-
- getRootFragment() - Method in class org.apache.drill.exec.work.QueryWorkUnit
-
- getRootFragmentDefn() - Method in class org.apache.drill.exec.work.QueryWorkUnit
-
- getRootFragmentFromPlanString(PhysicalPlanReader, String) - Static method in class org.apache.drill.exec.pop.PopUnitTestBase
-
- getRootFragmentTimeZone() - Method in class org.apache.drill.exec.ops.ContextInformation
-
- getRootOperator() - Method in class org.apache.drill.exec.work.QueryWorkUnit
-
- getRootOperator() - Method in class org.apache.drill.test.ProfileParser.FragInfo
-
- 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 SchemaPlus
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
-
- getRootWrapper() - Method in class org.apache.drill.exec.planner.fragment.PlanningSet
-
- getRootWrapper() - Method in class org.apache.drill.exec.work.QueryWorkUnit
-
- getRowAllocWidth() - Method in class org.apache.drill.exec.record.RecordBatchSizer
-
- getRowCount() - Method in class org.apache.drill.exec.expr.stat.RangeExprEvaluator
-
- getRowCount(RexNode, RelNode) - Method in interface org.apache.drill.exec.physical.base.DbGroupScan
-
Get the row count after applying the RexNode
condition
- getRowCount(RexNode, RelNode) - Method in interface org.apache.drill.exec.physical.base.IndexGroupScan
-
Get the row count after applying the RexNode
condition
- getRowCount() - Method in interface org.apache.drill.exec.physical.impl.protocol.BatchAccessor
-
- getRowCount() - Method in class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor
-
- 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.planner.index.AbstractIndexStatistics
-
- getRowCount() - Method in interface org.apache.drill.exec.planner.index.IndexStatistics
-
Returns the approximate number of rows in the table.
- getRowCount(RexNode, String, RelNode) - Method in interface org.apache.drill.exec.planner.index.Statistics
-
Returns the rowcount for the specified filter condition
- getRowCount() - Method in interface org.apache.drill.exec.planner.index.StatisticsPayload
-
- getRowCount() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.RowGroupMetadata_v1
-
- getRowCount() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.RowGroupMetadata_v2
-
- getRowCount() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.RowGroupMetadata_v3
-
- getRowCount() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.RowGroupMetadata
-
- getRowCount() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScanStatistics
-
- getRowCount() - Method in class org.apache.drill.exec.store.parquet.RowGroupInfo
-
- getRowCount() - Method in class org.apache.drill.test.BaseTestQuery.SilentListener
-
Deprecated.
- 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.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.AbstractParquetRowGroupScan
-
- getRowGroupReadEntry() - Method in class org.apache.drill.exec.store.parquet.RowGroupInfo
-
- getRowGroupReadEntry() - Method in class org.apache.drill.exec.store.parquet.RowGroupReadEntry
-
- getRowGroups() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ParquetFileMetadata_v1
-
- getRowGroups() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetFileMetadata_v2
-
- getRowGroups() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetFileMetadata_v3
-
- getRowGroups() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ParquetFileMetadata
-
- getRowKeyColumns() - Method in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- getRowKeyColumns() - Method in interface org.apache.drill.exec.planner.index.IndexDefinition
-
Get the list of columns (typically 1 column) that constitute the row key (primary key)
- getRowKeyIndex(RelDataType, DrillScanRelBase) - Static method in class org.apache.drill.exec.planner.index.generators.AbstractIndexPlanGenerator
-
- getRowKeyJoinConversionSelThreshold() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- getRowKeyJoinState() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
-
- getRowKeyJoinState() - Method in interface org.apache.drill.exec.physical.impl.join.RowKeyJoin
-
Get the current RowKeyJoinState.
- getRowKeyJoinState() - Method in class org.apache.drill.exec.physical.impl.join.RowKeyJoinBatch
-
- getRowKeyLocation() - Method in class org.apache.drill.exec.planner.logical.RowKeyJoinCallContext
-
- getRowKeyName() - Method in class org.apache.drill.exec.physical.base.AbstractDbGroupScan
-
- getRowKeyName() - Method in interface org.apache.drill.exec.physical.base.DbGroupScan
-
- getRowKeyOrdinal() - Method in interface org.apache.drill.exec.physical.base.IndexGroupScan
-
Get the column ordinal of the rowkey column from the output schema of the IndexGroupScan
- getRowKeyPath() - Method in class org.apache.drill.exec.physical.base.AbstractDbGroupScan
-
- getRowKeyPath() - Method in interface org.apache.drill.exec.physical.base.DbGroupScan
-
- getRowKeyPosition() - Method in class org.apache.drill.exec.planner.logical.RowKeyJoinCallContext
-
- getRows() - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
-
- getRows(RexNode) - Method in class org.apache.drill.exec.planner.index.AbstractIndexCollection
-
- getRows(RelNode, RexNode) - Method in class org.apache.drill.exec.planner.index.AbstractIndexDescriptor
-
- getRows(RexNode) - Method in class org.apache.drill.exec.planner.index.DrillIndexCollection
-
- getRows(RelNode, RexNode) - Method in class org.apache.drill.exec.planner.index.DrillIndexDescriptor
-
- getRows(RexNode) - Method in interface org.apache.drill.exec.planner.index.IndexCollection
-
Get the estimated row count for a single index condition
- getRows(RelNode, RexNode) - Method in interface org.apache.drill.exec.planner.index.IndexDescriptor
-
Get the estimated row count for a single index condition
- getRows() - Method in class org.apache.drill.exec.server.rest.QueryResources.TabularResult
-
- getRowType(RelDataTypeFactory) - Method in class org.apache.drill.exec.dotdrill.View
-
- getRowType() - Method in class org.apache.drill.exec.planner.index.RexToExpression.RexToDrillExt
-
- getRowType() - Method in class org.apache.drill.exec.planner.logical.DrillOptiq.RexToDrill
-
- 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.
- getRpcType() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.CancelQuery
-
- getRpcType() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.CustomMessageSender
-
- getRpcType() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.ReceiverFinished
-
- getRpcType() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.RequestProfile
-
- getRpcType() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.SendFragment
-
- getRpcType() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.SendFragmentStatus
-
- getRpcType() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.SignalFragment
-
- getRpcType() - Method in class org.apache.drill.exec.rpc.control.ControlTunnel.SyncCustomMessageSender
-
- 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.rpc.data.TestBitBitKerberos.MockFragmentManager
-
- getRunnable() - Method in class org.apache.drill.exec.rpc.data.TestBitRpc.MockFragmentManager
-
- 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
-
- getRunResult(SimpleRootExec) - Method in class org.apache.drill.exec.fn.impl.TestNewMathFunctions
-
- getRunResult(UserBitShared.QueryType, String) - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- getRunResult(SimpleRootExec) - Method in class org.apache.drill.exec.physical.impl.TestImplicitCastFunctions
-
- getRunResult(SimpleRootExec) - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- getRuntimeFilter(long) - Method in interface org.apache.drill.exec.ops.FragmentContext
-
- getRuntimeFilter(long, long, TimeUnit) - Method in interface org.apache.drill.exec.ops.FragmentContext
-
get the RuntimeFilter with a blocking wait, if the waiting option is enabled
- getRuntimeFilter(long) - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getRuntimeFilter(long, long, TimeUnit) - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getRuntimeFilter(long) - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- getRuntimeFilter(long, long, TimeUnit) - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- getRuntimeFilter(long) - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- getRuntimeFilter(long, long, TimeUnit) - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- getRuntimeFilterBDef() - Method in class org.apache.drill.exec.work.filter.RuntimeFilterWritable
-
- getRuntimeFilterDef() - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
-
- getRuntimeFilterDef() - Method in class org.apache.drill.exec.planner.physical.HashJoinPrel
-
- getRuntimeFilterIdentifier() - Method in class org.apache.drill.exec.work.filter.RuntimeFilterDef
-
- getRuntimeFilterRouter() - Method in class org.apache.drill.exec.work.foreman.Foreman
-
- 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
-
- 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
-
- getScan() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getScan() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getScan() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- getScanColumns() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getScanColumns() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getScanColumns() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- getScanDecodeExecutor() - Method in class org.apache.drill.exec.ops.BaseOperatorContext
-
- getScanDecodeExecutor() - Method in interface org.apache.drill.exec.ops.FragmentContext
-
- getScanDecodeExecutor() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- 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
-
- getScanDecodeExecutor() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- getScanExecutor() - Method in class org.apache.drill.exec.ops.BaseOperatorContext
-
- getScanExecutor() - Method in interface org.apache.drill.exec.ops.FragmentContext
-
- getScanExecutor() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- 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
-
- getScanExecutor() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- getScanRel() - Method in class org.apache.drill.exec.planner.logical.RowKeyJoinCallContext
-
- getScanResult() - Method in class org.apache.drill.exec.expr.fn.registry.JarScan
-
- getScans() - Method in class org.apache.drill.test.ProfileParser
-
- 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() - Method in class org.apache.drill.exec.physical.base.SchemalessScan
-
- 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.AbstractParquetGroupScan
-
- 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.MockRecordBatch
-
- getSchema() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
-
- getSchema() - Method in interface org.apache.drill.exec.physical.impl.protocol.BatchAccessor
-
- getSchema() - Method in class org.apache.drill.exec.physical.impl.protocol.OperatorRecordBatch
-
- getSchema() - Method in class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor
-
- getSchema() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
-
- getSchema() - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- 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.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.AbstractUnaryRecordBatch
-
- 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.SchemalessBatch
-
- 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.store.log.LogFormatConfig
-
- getSchema() - Method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager
-
- 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.calcite.jdbc.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
-
- getSchemaFilter() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaGroupScan
-
- 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(String) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
-
Utility method to get the list with schema path components for given schema path string.
- 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.OptionValue
-
- 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
-
- getSecondaryIndexCollection(RelNode) - Method in class org.apache.drill.exec.physical.base.AbstractDbGroupScan
-
- getSecondaryIndexCollection(RelNode) - Method in interface org.apache.drill.exec.physical.base.DbGroupScan
-
Get the index collection associated with this table if any
- 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.physical.base.SchemalessScan
-
- 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.filter.RuntimeFilterRecordBatch
-
- getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.join.RowKeyJoinBatch
-
- getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.limit.LimitRecordBatch
-
- getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.limit.PartitionLimitRecordBatch
-
- getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
-
- getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.MockRecordBatch
-
- getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
-
- getSelectionVector2() - Method in interface org.apache.drill.exec.physical.impl.protocol.BatchAccessor
-
- getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.protocol.OperatorRecordBatch
-
- getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor.ContainerAndSv2Accessor
-
- getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor
-
- getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
-
- getSelectionVector2() - Method in class org.apache.drill.exec.physical.impl.SimpleRootExec
-
Deprecated.
- 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.unnest.MockLateralJoinBatch
-
- 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.SchemalessBatch
-
- 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.filter.RuntimeFilterRecordBatch
-
- getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.join.RowKeyJoinBatch
-
- getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.MergingRecordBatch
-
- getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.MockRecordBatch
-
- getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
-
- getSelectionVector4() - Method in interface org.apache.drill.exec.physical.impl.protocol.BatchAccessor
-
- getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.protocol.OperatorRecordBatch
-
- getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor.ContainerAndSv4Accessor
-
- getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor
-
- getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
-
- getSelectionVector4() - Method in class org.apache.drill.exec.physical.impl.SimpleRootExec
-
Deprecated.
- 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.unnest.MockLateralJoinBatch
-
- 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.SchemalessBatch
-
- 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
-
- getSelectivity(RelNode, RexNode) - Method in class org.apache.drill.exec.planner.cost.DrillRelMdSelectivity
-
- 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
-
- getSelfCost(RelOptPlanner) - Method in interface org.apache.drill.exec.planner.index.IndexProperties
-
- getSelfCost(RelOptPlanner) - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- 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.RangePartitionExchange
-
- 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
-
- getSenders(int) - Method in class org.apache.drill.exec.physical.config.AbstractMuxExchange
-
- 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
-
- getSeparatedCondition(RexNode) - Method in class org.apache.drill.exec.planner.index.RexSeparator
-
- getSequenceNumber() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
-
- getSequentialBlockReadCost(GroupScan) - Method in interface org.apache.drill.exec.planner.cost.PluginCost
-
- 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
-
- 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
-
- getSessionOptions() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
-
- 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 interface org.apache.drill.exec.vector.accessor.SqlAccessor
-
- getShort(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
-
- getShortDescription() - Method in class org.apache.drill.exec.server.options.OptionValidator.OptionDescription
-
Get short description (typically for system tables)
- 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 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.physical.impl.join.HashJoinMemoryCalculator.PartitionStatSet
-
- 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
-
- getSort() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getSort() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getSort() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- getSortedOperators() - Method in class org.apache.drill.exec.physical.PhysicalPlan
-
- getSortedOperators(boolean) - Method in class org.apache.drill.exec.physical.PhysicalPlan
-
- getSortExprs() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getSortExprs() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getSortExprs() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- getSortNode(IndexCallContext, RelNode, boolean, boolean, boolean) - Static method in class org.apache.drill.exec.planner.index.generators.AbstractIndexPlanGenerator
-
- 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.physical.base.SchemalessScan
-
- 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
-
- getSpillDir() - Method in class org.apache.drill.test.BaseDirTestWatcher
-
- getSpilledBatches() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate.HashAggSpilledPartition
-
- getSpilledPartitions() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PartitionStatSet
-
- getSpillFile() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate.HashAggSpilledPartition
-
- getSpillFile() - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- 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
- getSpnegoLogin(HttpServletRequest, HttpServletResponse, SecurityContext, UriInfo, String) - Method in class org.apache.drill.exec.server.rest.LogInLogOutResources
-
- getSpnegoPrincipal() - Method in class org.apache.drill.exec.server.rest.auth.SpnegoConfig
-
- getSql() - Method in class org.apache.drill.exec.dotdrill.View
-
- getSql() - Method in class org.apache.drill.TestProjectPushDown.PushDownTestInstance
-
- 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.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
-
- GetSqlType() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.GetSqlType
-
- 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.Metadata_V1.RowGroupMetadata_v1
-
- getStart() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.RowGroupMetadata_v2
-
- getStart() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.RowGroupMetadata_v3
-
- getStart() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.RowGroupMetadata
-
- 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.common.HashPartition
-
- getStartIndex(int) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelper
-
Takes a composite index for a key produced by
HashTable.probeForKey(int, int)
, and uses it to look up the
index of the first original key in the original data.
- getStartIndex() - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLenColumnBulkInput
- 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.physical.impl.join.HashJoinMechanicalMemoryCalculator
-
- getState() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMechanicalMemoryCalculator.MechanicalBuildSidePartitioning
-
- getState() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMechanicalMemoryCalculator.MechanicalPostBuildCalculations
-
- getState() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.BuildSidePartitioningImpl
-
- getState() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl
-
- getState() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.NoopBuildSidePartitioningImpl
-
- getState() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.NoopPostBuildCalculationsImpl
-
- getState() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.PostBuildCalculationsImpl
-
- getState() - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinStateCalculator
-
- 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
-
- getState() - Method in class org.apache.drill.exec.work.foreman.QueryStateProcessor
-
- 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 interface org.apache.drill.exec.physical.base.DbGroupScan
-
- getStatistics() - Method in class org.apache.drill.exec.store.parquet.stat.ColumnStatistics
-
- getStats() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getStats() - Method in interface org.apache.drill.exec.ops.OperatorContext
-
Drill statistics mechanism.
- getStats() - Method in interface org.apache.drill.exec.ops.RootFragmentContext
-
- getStats(HashTableStats) - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- 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
-
- getStats() - Method in class org.apache.drill.test.OperatorFixture.MockOperatorContext
-
- getStats() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- 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
-
- getStatusInternalOption(String) - Method in class org.apache.drill.test.RestClientFixture
-
Gets the internal option corresponding to the given name.
- getStatusInternalOptions() - Method in class org.apache.drill.test.RestClientFixture
-
- getStatusJSON() - Method in class org.apache.drill.exec.server.rest.StatusResources
-
- getStatusOption(String) - Method in class org.apache.drill.test.RestClientFixture
-
Gets the external option corresponding to the given name.
- getStatusOptions() - Method in class org.apache.drill.test.RestClientFixture
-
Gets all the external options from the rest api.
- getStdDataSizePerEntry() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
std pure data size per entry from Drill metadata, based on type.
- getStdNetOrNetSizePerEntry() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
If there is an accurate std net size, that is returned.
- getStdNetSizePerEntry() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
std net size per entry taking into account additional metadata vectors
we add on top for variable length, cardinality etc.
- getStdNetSizePerEntryCommon(TypeProtos.MajorType, boolean, boolean, boolean, Map<String, RecordBatchSizer.ColumnSize>) - Static method in class org.apache.drill.exec.record.RecordBatchSizer
-
- getStdRowWidth() - Method in class org.apache.drill.exec.record.RecordBatchSizer
-
- 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.physical.base.AbstractDbGroupScan
-
- 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.ParquetRowGroupScan
-
- 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
-
- getStorageName() - Method in class org.apache.drill.exec.planner.index.DrillIndexDescriptor
-
Get storage plugin name for this index descriptor
- getStoragePlugin() - Method in class org.apache.drill.exec.physical.base.AbstractDbGroupScan
-
- 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
-
- getStoreDir() - Method in class org.apache.drill.test.BaseDirTestWatcher
-
- 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 interface org.apache.drill.exec.vector.accessor.SqlAccessor
-
- 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 interface org.apache.drill.exec.vector.accessor.SqlAccessor
-
- getString(int) - Method in class org.apache.drill.exec.vector.accessor.UnionSqlAccessor
-
- 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
-
- getSubScan() - Method in class org.apache.drill.exec.planner.fragment.Materializer.IndexedFragmentNode
-
- getSubScanForRowKeyJoin() - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
-
- getSubScanForRowKeyJoin() - Method in class org.apache.drill.exec.physical.config.RowKeyJoinPOP
-
- 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
-
- 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.DirectScanPrel
-
- 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.LateralJoinPrel
-
- 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.RangePartitionExchangePrel
-
- getSupportedEncodings() - Method in class org.apache.drill.exec.planner.physical.RowKeyJoinPrel
-
- 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.UnnestPrel
-
- 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
-
- getSv2() - Method in class org.apache.drill.test.rowSet.DirectRowSet
-
- getSv2() - Method in class org.apache.drill.test.rowSet.IndirectRowSet
-
- getSv2() - Method in interface org.apache.drill.test.rowSet.RowSet.SingleRowSet
-
- 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
-
- getSv4() - Method in class org.apache.drill.test.rowSet.HyperRowSetImpl
-
- getSv4() - Method in interface org.apache.drill.test.rowSet.RowSet.HyperRowSet
-
- 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.PartitionLimit
-
- getSVMode() - Method in class org.apache.drill.exec.physical.config.Project
-
- getSVMode() - Method in class org.apache.drill.exec.physical.config.RuntimeFilterPOP
-
- 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(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
-
- getTableIndex(String) - Method in interface org.apache.drill.exec.planner.index.IndexDiscover
-
- getTableIndex(String, String, Collection<DrillIndexDefinition>) - Method in class org.apache.drill.exec.planner.index.IndexDiscoverBase
-
- getTableName() - Method in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- getTableName() - Method in interface org.apache.drill.exec.planner.index.IndexDefinition
-
Get the name of the table this index is associated with
- getTableName() - Method in enum org.apache.drill.exec.store.sys.SystemTable
-
- 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).
- getTagNameMap() - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- getTargetBatchRowCount() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate.BatchHolder
-
- getTargetBatchRowCount() - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
-
- getTargetBatchRowCount() - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate.BatchHolder
-
- getTargetBatchRowCount() - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
-
- getTargetUserName() - Method in class org.apache.drill.exec.rpc.user.UserSession
-
- getTempDir(String) - Static method in class org.apache.drill.test.BaseFixture
-
Create a temp directory to store the given dirName.
- 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.
- getTestCompiler(DrillConfig) - Static method in class org.apache.drill.exec.compile.CodeCompilerTestFactory
-
- 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 interface org.apache.drill.exec.vector.accessor.SqlAccessor
-
- getTimeNs() - Method in class org.apache.drill.exec.cache.VectorAccessibleSerializable
-
- 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 interface org.apache.drill.exec.vector.accessor.SqlAccessor
-
- getTimestampFormat() - Method in class org.apache.drill.exec.store.httpd.HttpdLogFormatPlugin.HttpdLogFormatConfig
-
- getTimeZone() - Method in class org.apache.drill.exec.store.image.ImageFormatConfig
-
- getTmpArea() - Method in class org.apache.drill.exec.expr.fn.registry.RemoteFunctionRegistry
-
- getTmpDir() - Method in class org.apache.drill.test.BaseDirTestWatcher
-
Gets the temp directory that should be used as a Drillbit's tmp directory.
- getTmpJavaScriptDir() - Method in class org.apache.drill.exec.server.rest.WebServer
-
- getTotalBytes() - Method in class org.apache.drill.exec.store.parquet.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
-
- getTotalDataSize() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
This is the total data size for the column, including children for map
columns.
- getTotalFilter(RexNode, RexNode, RexBuilder) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- getTotalIncomingFragments() - Method in class org.apache.drill.exec.work.batch.AbstractDataCollector
-
- getTotalIncomingFragments() - Method in interface org.apache.drill.exec.work.batch.DataCollector
-
- getTotalInputRecords() - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getTotalInputRecords(int) - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getTotalNetSize() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
This is the total net size for the column, including children for map
columns.
- getTotalOutputRecords() - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- getTotalRecordCount() - Method in class org.apache.drill.exec.record.RecordIterator
-
- getTotalRecords() - Method in class org.apache.drill.exec.HyperVectorValueIterator
-
- 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
-
- getTotalRecordsToRead() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
-
- getTotalRemainderFilter(RexNode, RexNode, RexBuilder) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- getTotalRemainderFilter() - Method in interface org.apache.drill.exec.planner.index.IndexProperties
-
- getTotalRemainderFilter() - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- getTotalRows() - Method in interface org.apache.drill.exec.planner.index.IndexProperties
-
- getTotalRows() - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- 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() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.GetType
-
- 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.DecimalAvgAggReturnTypeInference
-
- 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 interface org.apache.drill.exec.physical.impl.join.HashTableSizeCalculator
-
- getType() - Method in class org.apache.drill.exec.physical.impl.join.HashTableSizeCalculatorConservativeImpl
-
- getType() - Method in class org.apache.drill.exec.physical.impl.join.HashTableSizeCalculatorLeanImpl
-
- getType() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl.MockHashTableSizeCalculator
-
- getType(String) - Method in class org.apache.drill.exec.physical.rowSet.impl.NullResultVectorCacheImpl
-
- getType(String) - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultVectorCacheImpl
-
- getType(String) - Method in interface org.apache.drill.exec.physical.rowSet.ResultVectorCache
-
- getType() - Method in class org.apache.drill.exec.planner.logical.FieldsReWriterUtil.DesiredField
-
- 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(String) - Method in class org.apache.drill.exec.store.AbstractSchema
-
- getType(PrimitiveType.PrimitiveTypeName, OriginalType, int, int) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
-
Builds major type using given OriginalType originalType
or PrimitiveTypeName type
.
- getType() - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
-
- getType() - Method in class org.apache.drill.exec.vector.accessor.GenericAccessor
-
- 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.UnionSqlAccessor
-
- 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.AbstractParquetGroupScan
-
- getTypeForColumn(SchemaPath) - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScanStatistics
-
- getTypeLengthInBits(PrimitiveType.PrimitiveTypeName) - Static method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetColumnMetadata
-
- getTypeMap() - Method in class org.apache.drill.exec.store.AbstractSchema
-
Returns a map of types in this schema by name.
- 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
-
- getTypeNames() - Method in class org.apache.drill.exec.store.AbstractSchema
-
- 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
-
- getUnnest() - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- getUnnest() - Method in class org.apache.drill.exec.planner.fragment.Materializer.IndexedFragmentNode
-
- getUnnestBatch() - Method in class org.apache.drill.exec.physical.config.UnnestPOP
-
- getUnnestField() - Method in interface org.apache.drill.exec.physical.impl.unnest.Unnest
-
- getUnnestField() - Method in class org.apache.drill.exec.physical.impl.unnest.UnnestImpl
-
- getUnnestForLateralJoin() - Method in class org.apache.drill.exec.physical.config.LateralJoinPOP
-
- 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
-
- getUpperProject() - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- getUpperProject() - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- getUpperProject() - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- getUpperProjectRel() - Method in class org.apache.drill.exec.planner.logical.RowKeyJoinCallContext
-
- getUri() - Method in class org.apache.drill.exec.store.CachedSingleFileSystem
-
- 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
-
- getUserConnections() - Method in interface org.apache.drill.exec.ops.ExecutorFragmentContext
-
- getUserConnections() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getUserConnections() - Static method in class org.apache.drill.exec.rpc.user.UserServer
-
Access to set of active connection details for this instance of the Drillbit
- getUserConnections() - Method in class org.apache.drill.exec.server.DrillbitContext
-
- getUserConnections() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- getUserDataTunnel() - Method in interface org.apache.drill.exec.ops.ExchangeFragmentContext
-
- getUserDataTunnel() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getUserDataTunnel() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- getUserHome(String) - Static method in class org.apache.drill.exec.impersonation.BaseTestImpersonation
-
- 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
-
- getUserPort() - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- 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
-
- getV1(int) - Method in class org.apache.drill.exec.expr.EscapeTest1.Monkey
-
- getV2(int) - Method in class org.apache.drill.exec.expr.EscapeTest1.Monkey
-
- getValidatedRowType() - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler.ConvertedRelNode
-
- getValidationQueryType() - Method in class org.apache.drill.test.TestBuilder.BaselineQueryTestBuilder
-
- getValidationQueryType() - Method in class org.apache.drill.test.TestBuilder.CSVTestBuilder
-
- getValidationQueryType() - Method in class org.apache.drill.test.TestBuilder
-
- getValidationQueryType() - Method in class org.apache.drill.test.TestBuilder.JSONTestBuilder
-
- getValidationQueryType() - Method in class org.apache.drill.test.TestBuilder.SchemaTestBuilder
-
- getValidator() - Method in class org.apache.drill.exec.server.options.OptionDefinition
-
- getValidJoinInput(RelNode) - Static method in class org.apache.drill.exec.planner.logical.DrillPushRowKeyJoinToScanRule
-
- 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(String) - Method in class org.apache.drill.exec.store.dfs.FileSystemConfig
-
- 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.MockRecordBatch
-
- getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
-
- getValueAccessorById(Class<?>, int...) - Method in interface org.apache.drill.exec.physical.impl.protocol.BatchAccessor
-
- getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.physical.impl.protocol.OperatorRecordBatch
-
- getValueAccessorById(Class<?>, int...) - Method in class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor
-
- 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.unnest.MockLateralJoinBatch
-
- 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.SchemalessBatch
-
- 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
-
- getValueCount() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
- 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
-
- getValuesReadInCurrentPass() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
-
- 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
-
- getValueVectorById(SchemaPath, Class<?>) - Method in class org.apache.drill.exec.physical.impl.SimpleRootExec
-
Deprecated.
- 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.MockRecordBatch
-
- getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
-
- getValueVectorId(SchemaPath) - Method in interface org.apache.drill.exec.physical.impl.protocol.BatchAccessor
-
- getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.physical.impl.protocol.OperatorRecordBatch
-
- getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor
-
- getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.physical.impl.ScanBatch
-
- getValueVectorId(SchemaPath) - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- 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.SchemalessBatch
-
- 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() - Method in class org.apache.drill.exec.client.DrillSqlLineApplication
-
- 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 interface org.apache.drill.exec.ops.ExecutorFragmentContext
-
- getWorkEventbus() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- getWorkEventbus() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- getWorkingDirectory() - Method in class org.apache.drill.exec.store.CachedSingleFileSystem
-
- 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
-
- getWorkspaces() - Method in class org.apache.drill.exec.store.dfs.FileSystemConfig
-
- 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.MockRecordBatch
-
- getWritableBatch() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
-
- getWritableBatch() - Method in interface org.apache.drill.exec.physical.impl.protocol.BatchAccessor
-
- getWritableBatch() - Method in class org.apache.drill.exec.physical.impl.protocol.OperatorRecordBatch
-
- getWritableBatch() - Method in class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor
-
- 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.unnest.MockLateralJoinBatch
-
- 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.SchemalessBatch
-
- 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.image.ImageFormatPlugin
-
- getWriterOperatorType() - Method in class org.apache.drill.exec.store.log.LogFormatPlugin
-
- getWriterOperatorType() - Method in class org.apache.drill.exec.store.pcap.PcapFormatPlugin
-
- getWriterOperatorType() - Method in class org.apache.drill.exec.store.pcapng.PcapngFormatPlugin
-
- getWSSchema(String) - Static method in class org.apache.drill.exec.impersonation.BaseTestImpersonation
-
- 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
-
- getZooKeeperServerNum() - Method in class org.apache.drill.exec.util.MiniZooKeeperCluster
-
- globalLevel - Variable in class org.apache.drill.test.ProfileParser.OperatorSummary
-
- 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
-
- go() - Method in class org.apache.drill.exec.physical.unit.MiniPlanUnitTestBase.MiniPlanTestBuilder
-
- go(RexNode) - Method in class org.apache.drill.exec.planner.common.DrillRelOptUtil.RexFieldsTransformer
-
- go() - Method in class org.apache.drill.exec.planner.index.generators.AbstractIndexPlanGenerator
-
- 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(T, RelNode) - Method in class org.apache.drill.exec.planner.physical.SubsetTransformer
-
- go() - Method in class org.apache.drill.test.LegacyOperatorTestBuilder
-
Deprecated.
- go() - Method in class org.apache.drill.test.OperatorTestBuilder
-
- go() - Method in class org.apache.drill.test.TestBuilder
-
- GRACE_PERIOD - Static variable in class org.apache.drill.exec.ExecConstants
-
Boot-time config option provided to modify duration of the grace period.
- gracefulShutdownThreadShouldBeInitializedBeforeClosingDrillbit() - Method in class org.apache.drill.test.TestGracefulShutdown
-
- graph() - Method in class org.apache.drill.exec.physical.PhysicalPlan
-
- greaterThanEquals(Integer) - Constructor for class org.apache.drill.exec.planner.cost.PluginCost.greaterThanEquals
-
- group - Variable in class org.apache.drill.exec.planner.sql.handlers.ShowFilesHandler.ShowFilesCommandResult
-
- GROUP - Variable in class org.apache.drill.exec.store.ischema.Records.File
-
- groupByQuery() - Method in class org.apache.drill.exec.work.prepare.TestPreparedStatementProvider
-
Create a prepared statement for a query that has GROUP BY clause in it
- 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.common.DrillScanRelBase
-
- GT - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
-
- GuavaPatcher - Class in org.apache.drill.exec.util
-
- GuavaPatcher() - Constructor for class org.apache.drill.exec.util.GuavaPatcher
-
- gzipIt(File) - Static method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- 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
-
- ID - Static variable in class org.apache.drill.exec.physical.impl.scan.project.ResolvedMapColumn
-
- ID - Static variable in class org.apache.drill.exec.physical.impl.scan.project.ResolvedNullColumn
-
- ID - Static variable in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTableColumn
-
- id - Variable in class org.apache.drill.test.ProfileParser.FragInfo
-
- id - Variable in class org.apache.drill.test.ProfileParser.MinorFragInfo
-
- id - Variable in class org.apache.drill.test.ProfileParser.OperatorSummary
-
- 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
-
- 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
-
- IfElseWidthExpr(OutputWidthExpression, OutputWidthExpression) - Constructor for class org.apache.drill.exec.physical.impl.project.OutputWidthExpression.IfElseWidthExpr
-
- ifExpression() - Method in class org.apache.drill.exec.work.prepare.TestLimit0VsRegularQueriesMetadata
-
- 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
-
- ILike() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.ILike
-
- ILikeWithEscape() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.ILikeWithEscape
-
- ImageFormatConfig - Class in org.apache.drill.exec.store.image
-
- ImageFormatConfig() - Constructor for class org.apache.drill.exec.store.image.ImageFormatConfig
-
- ImageFormatPlugin - Class in org.apache.drill.exec.store.image
-
- ImageFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig) - Constructor for class org.apache.drill.exec.store.image.ImageFormatPlugin
-
- ImageFormatPlugin(String, DrillbitContext, Configuration, StoragePluginConfig, ImageFormatConfig) - Constructor for class org.apache.drill.exec.store.image.ImageFormatPlugin
-
- ImageRecordReader - Class in org.apache.drill.exec.store.image
-
- ImageRecordReader(FragmentContext, DrillFileSystem, String, boolean, boolean, String) - Constructor for class org.apache.drill.exec.store.image.ImageRecordReader
-
- ImpalaTimestampConvertFrom() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.ConvertFromImpalaTimestamp.ImpalaTimestampConvertFrom
-
- 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.DrillLateralJoinRel
-
- 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.DrillSemiJoinRel
-
- 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.DrillUnnestRel
-
- 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
-
- implement(DrillImplementor) - Method in class org.apache.drill.exec.planner.logical.RowKeyJoinRel
-
- implementInput(DrillImplementor, int, int, RelNode, DrillRel, List<String>) - Static method in class org.apache.drill.exec.planner.logical.DrillJoinRel
-
Check to make sure that the fields of the inputs are the same as the output field names.
- IMPLICIT_COLUMN - Static variable in class org.apache.drill.exec.planner.common.DrillLateralJoinRelBase
-
- IMPLICIT_COLUMN - Static variable in class org.apache.drill.exec.planner.common.DrillRelOptUtil
-
- IMPLICIT_COLUMN - Static variable in class org.apache.drill.exec.planner.common.DrillUnnestRelBase
-
- 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
-
- ImpliedTupleRequest - Class in org.apache.drill.exec.physical.rowSet.project
-
Represents a wildcard: SELECT * when used at the root tuple.
- ImpliedTupleRequest(boolean) - Constructor for class org.apache.drill.exec.physical.rowSet.project.ImpliedTupleRequest
-
- ImportFinder() - Constructor for class org.apache.drill.exec.expr.fn.ImportGrabber.ImportFinder
-
- ImportGrabber - Class in org.apache.drill.exec.expr.fn
-
- ImportGrabber.ImportFinder - Class in org.apache.drill.exec.expr.fn
-
- 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.
- InboundImpersonationPolicyValidator(String) - Constructor for class org.apache.drill.exec.rpc.user.InboundImpersonationManager.InboundImpersonationPolicyValidator
-
- 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
-
- inCol - Variable in class org.apache.drill.exec.physical.impl.scan.project.UnresolvedColumn
-
The original physical plan column to which this output column
maps.
- incoming - Variable in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
-
- incoming - Variable in class org.apache.drill.exec.record.AbstractSingleRecordBatch
-
- incoming - Variable in class org.apache.drill.exec.record.AbstractTableFunctionRecordBatch
-
- 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.
- IncompatibleSchemaException() - Constructor for exception org.apache.drill.exec.physical.impl.scan.project.SchemaSmoother.IncompatibleSchemaException
-
- incOutputPos() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
-
- IncreasingBigInt() - Constructor for class org.apache.drill.exec.fn.impl.testing.GeneratorFunctions.IncreasingBigInt
-
- incRecordCount() - Method in class org.apache.drill.exec.record.VectorContainer
-
Increment the record count
- increment(UserSession) - Method in interface org.apache.drill.exec.rpc.user.UserSession.QueryCountIncrementer
-
- increment() - Method in class org.apache.drill.exec.store.parquet.WrapAroundCounter
-
- 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
-
- indentString(int, String) - Method in class org.apache.drill.test.ProfileParser.TreeVisitor
-
- indentString(int) - Method in class org.apache.drill.test.ProfileParser.TreeVisitor
-
- index(String) - Method in class org.apache.drill.exec.record.metadata.TupleSchema
-
- index - Variable in class org.apache.drill.test.rowSet.test.TestFixedWidthWriter.TestIndex
-
- INDEX_COVERING_SELECTIVITY_THRESHOLD - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- INDEX_FORCE_SORT_NONCOVERING - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- INDEX_MAX_CHOSEN_INDEXES_PER_TABLE - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- INDEX_MAX_INDEXES_TO_INTERSECT - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- INDEX_NONCOVERING_SELECTIVITY_THRESHOLD - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- INDEX_PLANNING - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- INDEX_PREFER_INTERSECT_PLANS - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- INDEX_ROWKEYJOIN_COST_FACTOR - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- INDEX_SORT_EXCHANGE_PROJ_SCAN - Static variable in class org.apache.drill.exec.planner.index.rules.DbScanSortRemovalRule
-
- INDEX_SORT_EXCHANGE_SCAN - Static variable in class org.apache.drill.exec.planner.index.rules.DbScanSortRemovalRule
-
- INDEX_SORT_PROJ_SCAN - Static variable in class org.apache.drill.exec.planner.index.rules.DbScanSortRemovalRule
-
- INDEX_SORT_SCAN - Static variable in class org.apache.drill.exec.planner.index.rules.DbScanSortRemovalRule
-
- INDEX_STATS_ROWCOUNT_SCALING_FACTOR - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- INDEX_USE_HASHJOIN_NONCOVERING - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- IndexableExprMarker - Class in org.apache.drill.exec.planner.index
-
The filter expressions that could be indexed
Other than SchemaPaths, which represent columns of a table and could be indexed,
we consider only function expressions, and specifically, CAST function.
- IndexableExprMarker(RelNode) - Constructor for class org.apache.drill.exec.planner.index.IndexableExprMarker
-
- IndexCallContext - Interface in org.apache.drill.exec.planner.index
-
- indexCollationContext - Variable in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- IndexCollection - Interface in org.apache.drill.exec.planner.index
-
Interface used to describe an index collection
- IndexCollection.IndexCollectionType - Enum in org.apache.drill.exec.planner.index
-
Types of an index collections: NATIVE_SECONDARY_INDEX_COLLECTION, EXTERNAL_SECONDARY_INDEX_COLLECTION
- indexColumns - Variable in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
The indexColumns is the list of column(s) on which this index is created.
- IndexComparator(RelOptPlanner, IndexConditionInfo.Builder) - Constructor for class org.apache.drill.exec.planner.index.IndexSelector.IndexComparator
-
- indexCondition - Variable in class org.apache.drill.exec.planner.index.generators.AbstractIndexPlanGenerator
-
- indexCondition - Variable in class org.apache.drill.exec.planner.index.IndexConditionInfo
-
- IndexConditionInfo - Class in org.apache.drill.exec.planner.index
-
- IndexConditionInfo(RexNode, RexNode, boolean) - Constructor for class org.apache.drill.exec.planner.index.IndexConditionInfo
-
- IndexConditionInfo.Builder - Class in org.apache.drill.exec.planner.index
-
- indexConditionRelatedToFields(List<LogicalExpression>, RexNode) - Method in class org.apache.drill.exec.planner.index.IndexConditionInfo.Builder
-
Given a list of Index Expressions(usually indexed fields/functions from one or a set of indexes),
separate a filter condition into
1), relevant subset of conditions (by relevant, it means at least one given index Expression was found) and,
2), the rest in remainderCondition
- indexContext - Variable in class org.apache.drill.exec.planner.index.generators.AbstractIndexPlanGenerator
-
- IndexDefinition - Interface in org.apache.drill.exec.planner.index
-
Top level interface used to define an index.
- IndexDefinition.IndexType - Enum in org.apache.drill.exec.planner.index
-
Types of an index: PRIMARY_KEY_INDEX, NATIVE_SECONDARY_INDEX, EXTERNAL_SECONDARY_INDEX
- indexDesc - Variable in class org.apache.drill.exec.planner.index.generators.CoveringIndexPlanGenerator
-
- indexDesc - Variable in class org.apache.drill.exec.planner.index.generators.CoveringPlanNoFilterGenerator
-
- IndexDescriptor - Interface in org.apache.drill.exec.planner.index
-
IndexDefinition + functions to access materialized index(index table/scan, etc)
- IndexDiscover - Interface in org.apache.drill.exec.planner.index
-
- IndexDiscoverable - Interface in org.apache.drill.exec.planner.index
-
SchemaFactory of a storage plugin that can used to store index tables should expose this interface to allow
IndexDiscovers discovering the index table without adding dependency to the storage plugin.
- IndexDiscoverBase - Class in org.apache.drill.exec.planner.index
-
IndexDiscoverBase is the layer to read index configurations of tables on storage plugins,
then based on the properties it collected, get the StoragePlugin from StoragePluginRegistry,
together with indexes information, build an IndexCollection
- IndexDiscoverBase(AbstractDbGroupScan, DrillScanRelBase) - Constructor for class org.apache.drill.exec.planner.index.IndexDiscoverBase
-
- IndexDiscoverBase(AbstractDbGroupScan, ScanPrel) - Constructor for class org.apache.drill.exec.planner.index.IndexDiscoverBase
-
- IndexDiscoverFactory - Class in org.apache.drill.exec.planner.index
-
With this factory, we allow user to load a different indexDiscover class to obtain index information
- IndexDiscoverFactory() - Constructor for class org.apache.drill.exec.planner.index.IndexDiscoverFactory
-
- IndexedFragmentNode(int, Wrapper) - Constructor for class org.apache.drill.exec.planner.fragment.Materializer.IndexedFragmentNode
-
- indexes() - Method in class org.apache.drill.exec.physical.rowSet.project.RequestedColumnImpl
-
- indexes() - Method in interface org.apache.drill.exec.physical.rowSet.project.RequestedTuple.RequestedColumn
-
- indexes - Variable in class org.apache.drill.exec.planner.index.AbstractIndexCollection
-
A set of indexes for a particular table
- IndexGroup - Class in org.apache.drill.exec.planner.index
-
Encapsulates one or more IndexProperties representing (non)covering or intersecting indexes.
- IndexGroup() - Constructor for class org.apache.drill.exec.planner.index.IndexGroup
-
- IndexGroupScan - Interface in org.apache.drill.exec.physical.base
-
An IndexGroupScan operator represents the scan associated with an Index.
- indexGroupScan - Variable in class org.apache.drill.exec.planner.index.generators.CoveringIndexPlanGenerator
-
- indexGroupScan - Variable in class org.apache.drill.exec.planner.index.generators.CoveringPlanNoFilterGenerator
-
- indexGroupScan - Variable in class org.apache.drill.exec.planner.index.generators.NonCoveringIndexPlanGenerator
-
- indexHint - Variable in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- indexHint - Variable in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- IndexIntersectPlanGenerator - Class in org.apache.drill.exec.planner.index.generators
-
IndexScanIntersectGenerator is to generate index plan against multiple index tables,
the input indexes are assumed to be ranked by selectivity(low to high) already.
- IndexIntersectPlanGenerator(IndexLogicalPlanCallContext, Map<IndexDescriptor, IndexConditionInfo>, RexBuilder, PlannerSettings) - Constructor for class org.apache.drill.exec.planner.index.generators.IndexIntersectPlanGenerator
-
- IndexLogicalPlanCallContext - Class in org.apache.drill.exec.planner.index
-
- IndexLogicalPlanCallContext(RelOptRuleCall, DrillProjectRel, DrillFilterRel, DrillProjectRel, DrillScanRel) - Constructor for class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- IndexLogicalPlanCallContext(RelOptRuleCall, DrillSortRel, DrillProjectRel, DrillFilterRel, DrillProjectRel, DrillScanRel) - Constructor for class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- IndexLogicalPlanCallContext(RelOptRuleCall, DrillSortRel, DrillProjectRel, DrillScanRel) - Constructor for class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- indexName - Variable in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
indexName: name of the index that should be unique within the scope of a table
- indexOf(int, int, byte) - Method in class org.apache.drill.exec.record.DeadBuf
-
- IndexPhysicalPlanCallContext - Class in org.apache.drill.exec.planner.index
-
- IndexPhysicalPlanCallContext(RelOptRuleCall, ProjectPrel, FilterPrel, ProjectPrel, ScanPrel) - Constructor for class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- IndexPhysicalPlanCallContext(RelOptRuleCall, OrderedRel, ProjectPrel, FilterPrel, ProjectPrel, ScanPrel, ExchangePrel) - Constructor for class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- IndexPhysicalPlanCallContext(RelOptRuleCall, OrderedRel, ProjectPrel, ScanPrel, ExchangePrel) - Constructor for class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- IndexPlanUtils - Class in org.apache.drill.exec.planner.index
-
- IndexPlanUtils() - Constructor for class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- IndexPlanUtils.ConditionIndexed - Enum in org.apache.drill.exec.planner.index
-
- IndexPointer - Class in org.apache.drill.exec.physical.impl.common
-
- IndexPointer() - Constructor for class org.apache.drill.exec.physical.impl.common.IndexPointer
-
- IndexProperties - Interface in org.apache.drill.exec.planner.index
-
IndexProperties encapsulates the various metrics of a single index that are related to
the current query.
- IndexSelector - Class in org.apache.drill.exec.planner.index
-
- IndexSelector(RexNode, RexNode, IndexCallContext, IndexCollection, RexBuilder, double) - Constructor for class org.apache.drill.exec.planner.index.IndexSelector
-
- IndexSelector(IndexCallContext) - Constructor for class org.apache.drill.exec.planner.index.IndexSelector
-
This constructor is to build selector for no index condition case (no filter)
- IndexSelector.DrillIndexProperties - Class in org.apache.drill.exec.planner.index
-
IndexProperties encapsulates the various metrics of a single index that are related to
the current query.
- IndexSelector.IndexComparator - Class in org.apache.drill.exec.planner.index
-
- IndexStatistics - Interface in org.apache.drill.exec.planner.index
-
- indexType - Variable in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- indirectionType() - Method in class org.apache.drill.test.rowSet.DirectRowSet
-
- indirectionType() - Method in class org.apache.drill.test.rowSet.HyperRowSetImpl
-
- indirectionType() - Method in class org.apache.drill.test.rowSet.IndirectRowSet
-
- indirectionType() - Method in interface org.apache.drill.test.rowSet.RowSet
-
- IndirectRowSet - Class in org.apache.drill.test.rowSet
-
Single row set coupled with an indirection (selection) vector,
specifically an SV2.
- IndirectRowSet(VectorContainer) - Constructor for class org.apache.drill.test.rowSet.IndirectRowSet
-
- IndirectRowSet(DirectRowSet, Set<Integer>) - Constructor for class org.apache.drill.test.rowSet.IndirectRowSet
-
- infer(VectorContainer) - Method in class org.apache.drill.exec.physical.rowSet.model.hyper.HyperSchemaInference
-
- infer(VectorContainer) - Method in class org.apache.drill.exec.physical.rowSet.model.single.SingleSchemaInference
-
- inferredParent - Variable in class org.apache.drill.test.ProfileParser.OperatorSummary
-
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.drill.exec.planner.sql.DrillSqlOperatorWithoutInference
-
- informReceiverFinished(RpcOutcomeListener<GeneralRPCProtos.Ack>, BitControl.FinishedReceiver) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel
-
- infoSchema() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- 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 - Interface 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.ExprNode - Class in org.apache.drill.exec.store.ischema
-
- InfoSchemaFilter.ExprNode.Type - Enum in org.apache.drill.exec.store.ischema
-
- InfoSchemaFilter.FieldExprNode - Class in org.apache.drill.exec.store.ischema
-
- InfoSchemaFilter.FunctionExprNode - Class in org.apache.drill.exec.store.ischema
-
- 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.Columns - Class in org.apache.drill.exec.store.ischema
-
- InfoSchemaRecordGenerator.Files - Class in org.apache.drill.exec.store.ischema
-
- InfoSchemaRecordGenerator.Schemata - Class in org.apache.drill.exec.store.ischema
-
- InfoSchemaRecordGenerator.Tables - Class in org.apache.drill.exec.store.ischema
-
- InfoSchemaRecordGenerator.Views - Class in org.apache.drill.exec.store.ischema
-
- InfoSchemaStoragePlugin - Class in org.apache.drill.exec.store.ischema
-
- InfoSchemaStoragePlugin(DrillbitContext) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaStoragePlugin
-
- 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(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.Field - Class in org.apache.drill.exec.store.ischema
-
- InfoSchemaTable.Files - Class in org.apache.drill.exec.store.ischema
-
Layout for the FILES table.
- InfoSchemaTable.Schemata - Class in org.apache.drill.exec.store.ischema
-
Layout for the SCHEMATA table.
- InfoSchemaTable.Tables - Class in org.apache.drill.exec.store.ischema
-
Layout for the TABLES table.
- InfoSchemaTable.Views - Class in org.apache.drill.exec.store.ischema
-
Layout for the VIEWS table.
- InfoSchemaTableType - Enum in org.apache.drill.exec.store.ischema
-
The set of tables/views in INFORMATION_SCHEMA.
- infoSchemaWithView() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- init() - Static method in class org.apache.drill.common.scanner.TestClassPathScanner
-
- init() - Static method in class org.apache.drill.exec.client.DrillSqlLineApplicationTest
-
- init() - Static method in class org.apache.drill.exec.expr.fn.FunctionInitializerTest
-
- init() - Static method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- 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() - Static method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- init(RecordBatch, ProjectRecordBatch) - Method in class org.apache.drill.exec.physical.impl.project.ProjectMemoryManager
-
- 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() - Static method in class org.apache.drill.exec.planner.TestDirectoryExplorerUDFs
-
- init() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- 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() - Static method in class org.apache.drill.exec.sql.TestCTTAS
-
- init(Map<String, String>) - Method in class org.apache.drill.exec.store.easy.json.JsonRecordWriter
-
- init() - Method in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- init(Map<String, String>) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordWriter
-
- init() - Static method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDownForDateTimeCasts
-
- 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() - 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() - Static method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- INIT_ALLOCATION - Static variable in class org.apache.drill.exec.physical.base.AbstractBase
-
- initCap(String) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionHelpers
-
Capitalizes first letter in each word.
- InitCap() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.InitCap
-
- initCluster() - Static method in class org.apache.drill.exec.server.TestTpcdsSf1Leaks
-
- initContext() - Method in class org.apache.drill.exec.ssl.SSLConfig
-
- initDrivers() - Method in class org.apache.drill.exec.client.DrillSqlLineApplication
-
- initFile() - Static method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- initFile(String) - Static method in class org.apache.drill.exec.store.parquet.ParquetSimpleTestFileGenerator
-
- initFragmentWrappers(Fragment, PlanningSet) - Method in class org.apache.drill.exec.planner.fragment.SimpleParallelizer
-
- initFs() - Static method in class org.apache.drill.exec.physical.impl.writer.TestCorruptParquetDateCorrection
-
- initFs() - Static method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- initFs() - Static method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriterEmptyFiles
-
- initFS() - Static method in class org.apache.drill.exec.physical.unit.TestMiniPlan
-
- initFS() - Static method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- initFSAndCreateFragContext() - Static method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- 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(int) - Method in class org.apache.drill.exec.physical.impl.common.SpilledState
-
Initializes the number of partitions to use for the spilled state.
- initialize(boolean) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMechanicalMemoryCalculator
-
- initialize(boolean, boolean, RecordBatch, RecordBatch, Set<String>, boolean, long, int, int, int, int, int, int, double) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMechanicalMemoryCalculator.MechanicalBuildSidePartitioning
-
- initialize(boolean) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMechanicalMemoryCalculator.MechanicalPostBuildCalculations
-
- initialize(boolean, boolean, RecordBatch, RecordBatch, Set<String>, boolean, long, int, int, int, int, int, int, double) - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.BuildSidePartitioning
-
- initialize(boolean) - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator
-
- initialize(boolean) - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PostBuildCalculations
-
Initializes the calculator with additional information needed.
- initialize(boolean, boolean, RecordBatch, RecordBatch, Set<String>, boolean, long, int, int, int, int, int, int, double) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.BuildSidePartitioningImpl
-
- initialize(boolean, boolean, CaseInsensitiveMap<Long>, long, int, boolean, BatchSizePredictor, BatchSizePredictor, int, int, int, int, int, double) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.BuildSidePartitioningImpl
-
- initialize(boolean) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl
-
- initialize(boolean, boolean, RecordBatch, RecordBatch, Set<String>, boolean, long, int, int, int, int, int, int, double) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.NoopBuildSidePartitioningImpl
-
- initialize(boolean) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.NoopPostBuildCalculationsImpl
-
- initialize(boolean) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.PostBuildCalculationsImpl
-
- 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(RexNode, DrillScanRelBase, IndexCallContext) - Method in interface org.apache.drill.exec.planner.index.Statistics
-
- initialize() - Method in class org.apache.drill.exec.record.TestMaterializedField
-
- 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() - Method in class org.apache.drill.exec.store.text.TestCsvHeader
-
- 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
-
- initialize() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- initializeBatch() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
-
Initialize the OutgoingBatch based on the current schema in incoming RecordBatch
- initializeFragment(BitControl.InitializeFragments) - Method in class org.apache.drill.exec.work.batch.ControlMessageHandler
-
- 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
-
- 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
- initInternal() - Method in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- initInternal() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
-
- 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
-
- initReservation - Variable in class org.apache.drill.exec.physical.unit.MiniPlanUnitTestBase.PopBuilder
-
- initReservation(long) - Method in class org.apache.drill.exec.physical.unit.MiniPlanUnitTestBase.PopBuilder
-
Set initial memory reservation used by this operator's allocator.
- initReservation(long) - Method in class org.apache.drill.test.LegacyOperatorTestBuilder
-
Deprecated.
- initReservation(long) - Method in class org.apache.drill.test.OperatorTestBuilder
-
- initSaslServer(String) - Method in class org.apache.drill.exec.rpc.AbstractServerConnection
-
- initWriter(MessageType, String, boolean) - Static method in class org.apache.drill.exec.store.parquet.ParquetSimpleTestFileGenerator
-
- 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, long) - 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
-
- InjectionMixIn() - Constructor for class org.apache.drill.exec.testing.ExecutionControls.InjectionMixIn
-
- injectionOnSpecificBit() - Method in class org.apache.drill.exec.testing.TestExceptionInjection
-
- 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.
- InjectionSiteKeyDeserializer() - Constructor for class org.apache.drill.exec.testing.InjectionSite.InjectionSiteKeyDeserializer
-
- injectMembers(ExampleTemplateWithInner.TheInnerClass) - Method in class org.apache.drill.exec.compile.ExampleTemplateWithInner
-
- injectMembers(ExampleTemplateWithInner.TheInnerClass.DoubleInner) - Method in class org.apache.drill.exec.compile.ExampleTemplateWithInner.TheInnerClass
-
- injectMembers(HashAggTemplate.BatchHolder) - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
-
- injectMembers(ClassGenerator<?>, Object, FragmentContext) - Static method in class org.apache.drill.exec.physical.impl.common.CodeGenMemberInjector
-
Generated code for a class may have several class members, they
are initialized by invoking this method when the instance created.
- injectMembers(HashTableTemplate.BatchHolder) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
-
- injectMembers(PartitionerTemplate.OutgoingRecordBatch) - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate
-
- 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(ExecutionControls, String) - Method in class org.apache.drill.exec.testing.ExecutionControlsInjector
-
- injectUnchecked(ExecutionControls, 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_CLASS_FIELD_NAME - Static variable in class org.apache.drill.exec.expr.ClassGenerator
-
- INNER_JOIN_TYPE - Static variable in class org.apache.drill.exec.physical.impl.join.JoinTestBase
-
- innerCardinality(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple
-
- innerCardinality(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedMapArray
-
- innerCardinality(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedRow
-
- innerCardinality(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedSingleMap
-
- innerCardinality() - Method in class org.apache.drill.exec.physical.rowSet.impl.ColumnState
-
- innerCardinality() - Method in class org.apache.drill.exec.physical.rowSet.impl.ContainerState
-
- innerCardinality() - Method in class org.apache.drill.exec.physical.rowSet.impl.ListState
-
- innerCardinality() - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedListState
-
- innerCardinality() - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState.MapState
-
- innerCardinality() - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState.RowState
-
- innerCardinality() - Method in class org.apache.drill.exec.physical.rowSet.impl.UnionState
-
- 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.LateralJoinBatch
-
Method that get's left and right incoming batch and produce the output batch.
- 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.join.RowKeyJoinBatch
-
- 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.TopN.TopNBatch
-
- innerNext() - Method in class org.apache.drill.exec.physical.impl.union.UnionAllRecordBatch
-
- innerNext() - Method in class org.apache.drill.exec.physical.impl.unnest.UnnestRecordBatch
-
- 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.AbstractUnaryRecordBatch
-
- input - Variable in class org.apache.drill.exec.planner.index.AbstractIndexStatistics
-
- input - Variable in class org.apache.drill.exec.store.parquet.ColumnDataReader
-
- InputBatch(VectorContainer, SelectionVector2, BufferAllocator, long) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.InputBatch
-
- inputContainer - Variable in class org.apache.drill.exec.physical.impl.BaseTestOpBatchEmitOutcome
-
- inputContainerSv2 - Variable in class org.apache.drill.exec.physical.impl.BaseTestOpBatchEmitOutcome
-
- inputDataStreamJson(List<String>) - Method in class org.apache.drill.test.LegacyOperatorTestBuilder
-
Deprecated.
- inputDataStreamsJson(List<List<String>>) - Method in class org.apache.drill.test.LegacyOperatorTestBuilder
-
Deprecated.
- inputMap - Variable in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedMap
-
- inputOutcomes - Variable in class org.apache.drill.exec.physical.impl.BaseTestOpBatchEmitOutcome
-
- inputPaths(List<String>) - Method in class org.apache.drill.exec.physical.unit.MiniPlanUnitTestBase.JsonScanBuilder
-
- inputPaths(List<String>) - Method in class org.apache.drill.exec.physical.unit.MiniPlanUnitTestBase.ParquetScanBuilder
-
- inputRefToPush(RexInputRef) - Method in class org.apache.drill.exec.planner.logical.partition.FindPartitionConditions
-
- InputRefVisitor() - Constructor for class org.apache.drill.exec.planner.common.DrillRelOptUtil.InputRefVisitor
-
- inputSchema - Static variable in class org.apache.drill.exec.physical.impl.BaseTestOpBatchEmitOutcome
-
- inScopeOf(OptionValue.OptionScope) - Method in enum org.apache.drill.exec.server.options.OptionValue.AccessibleScopes
-
- insert(long) - Method in class org.apache.drill.exec.work.filter.BloomFilter
-
Add an element's hash value to this bloom filter.
- 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(OptionManager) - Constructor for class org.apache.drill.exec.planner.physical.visitor.InsertLocalExchangeVisitor
-
- insertMockStorage(String, boolean) - Method in class org.apache.drill.test.ClusterMockStorageFixture
-
This should be called after bits are started
- insertRenameProject(Prel) - Static method in class org.apache.drill.exec.planner.physical.visitor.StarColumnConverter
-
- insertRowID(Prel) - Static method in class org.apache.drill.exec.planner.physical.visitor.LateralUnnestRowIDVisitor
-
- 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.DecimalAvgAggReturnTypeInference
-
- 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.OutputWidthCalculators.CloneOutputWidthCalculator
-
- INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.OutputWidthCalculators.ConcatOutputWidthCalculator
-
- INSTANCE - Static variable in class org.apache.drill.exec.expr.fn.output.OutputWidthCalculators.DefaultOutputWidthCalculator
-
- 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.physical.impl.join.BatchSizePredictorImpl.Factory
-
- INSTANCE - Static variable in class org.apache.drill.exec.physical.impl.join.HashJoinHelperSizeCalculatorImpl
-
- INSTANCE - Static variable in class org.apache.drill.exec.physical.impl.join.HashJoinHelperUnusedSizeImpl
-
- 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.DrillCorrelateRule
-
- 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.DrillProjectLateralJoinTransposeRule
-
- INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillProjectPushIntoLateralJoinRule
-
- INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillProjectRule
-
- INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillPushFilterPastProjectRule
-
- INSTANCE - Static variable in class org.apache.drill.exec.planner.logical.DrillPushProjectIntoScanRule
-
- 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.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.DrillUnnestRule
-
- 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.LateralJoinPrule
-
- INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.LimitExchangeTransposeRule
-
- INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.LimitPrule
-
- 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.RowKeyJoinPrule
-
- 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.UnnestPrule
-
- 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 class org.apache.drill.exec.store.ischema.InfoSchemaConfig
-
- 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 - Static variable in class org.apache.drill.test.rowSet.RowSetComparison.ObjectComparator
-
- 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
-
- 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 class org.apache.drill.exec.store.ischema.InfoSchemaTable
-
- Int32DecimalParquetValueWriter - Class in org.apache.drill.exec.store.parquet.decimal
-
Parquet value writer for passing decimal values
into RecordConsumer
to be stored as INT32 type.
- Int32DecimalParquetValueWriter() - Constructor for class org.apache.drill.exec.store.parquet.decimal.Int32DecimalParquetValueWriter
-
- Int64DecimalParquetValueWriter - Class in org.apache.drill.exec.store.parquet.decimal
-
Parquet value writer for passing decimal values
into RecordConsumer
to be stored as INT32 type.
- Int64DecimalParquetValueWriter() - Constructor for class org.apache.drill.exec.store.parquet.decimal.Int64DecimalParquetValueWriter
-
- INT_OUTPUT_SCHEMA - Static variable in class org.apache.drill.exec.physical.impl.agg.TestHashAggBatch
-
- INT_TYPE - Static variable in class org.apache.drill.exec.schema.json.jackson.JacksonHelper
-
- INT_VALUE_WIDTH - Static variable in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.BatchSizingMemoryUtil
-
INT in-memory width
- intArray(Integer...) - Static method in class org.apache.drill.test.rowSet.RowSetUtilities
-
- 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.vector.complex.fn.ExtendedTypeName
-
- IntegerValidator(String, OptionValidator.OptionDescription) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.IntegerValidator
-
- intermediateType(TypeProtos.MajorType) - Method in class org.apache.drill.exec.record.TypedFieldId.Builder
-
- internal - Variable in class org.apache.drill.exec.store.sys.FunctionsIterator.FunctionInfo
-
- 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
-
- interpreterCaseExpr() - Method in class org.apache.drill.exec.fn.interp.ExpressionInterpreterTest
-
- interpreterCastExpr() - Method in class org.apache.drill.exec.fn.interp.ExpressionInterpreterTest
-
- interpreterDateTest() - Method in class org.apache.drill.exec.fn.interp.ExpressionInterpreterTest
-
- 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.Trivalent - Enum in org.apache.drill.exec.expr.fn.interpreter
-
- interpreterLikeExpr() - Method in class org.apache.drill.exec.fn.interp.ExpressionInterpreterTest
-
- interpreterNullableBooleanExpr() - Method in class org.apache.drill.exec.fn.interp.ExpressionInterpreterTest
-
- interpreterNullableIntegerExpr() - Method in class org.apache.drill.exec.fn.interp.ExpressionInterpreterTest
-
- interpreterNullableStrExpr() - Method in class org.apache.drill.exec.fn.interp.ExpressionInterpreterTest
-
- interrupt(InterruptedException) - Method in interface org.apache.drill.exec.ops.Consumer
-
- interrupted(InterruptedException) - Method in class org.apache.drill.exec.ops.StatusHandler
-
- interruptiblePause() - Method in class org.apache.drill.exec.testing.PauseInjection
-
- interruptingBlockedMergingRecordBatch() - Method in class org.apache.drill.exec.server.TestDrillbitResilience
-
Test canceling query interrupts currently blocked FragmentExecutor threads waiting for some event to happen.
- interruptingBlockedUnorderedReceiverBatch() - Method in class org.apache.drill.exec.server.TestDrillbitResilience
-
Test canceling query interrupts currently blocked FragmentExecutor threads waiting for some event to happen.
- interruptingPartitionerThreadFragment() - Method in class org.apache.drill.exec.server.TestDrillbitResilience
-
Tests interrupting the fragment thread that is running PartitionSenderRootExec
.
- interruptingWhileFragmentIsBlockedInAcquiringSendingTicket() - Method in class org.apache.drill.exec.server.TestDrillbitResilience
-
- 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_ALL - Static variable in class org.apache.drill.exec.planner.common.JoinControl
-
- INTERSECT_DISTINCT - Static variable in class org.apache.drill.exec.planner.common.JoinControl
-
- INTERSECT_MASK - Static variable in class org.apache.drill.exec.planner.common.JoinControl
-
- 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
-
- IntervalDayType() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IntervalDayType
-
- IntervalType() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IntervalType
-
- IntervalYearType() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IntervalYearType
-
- 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
-
- IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.IntHash
-
- IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.IntHash
-
- IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.IntHash
-
- IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.IntHash
-
- IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.IntHash
-
- IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.IntHash
-
- IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.IntHash
-
- IntHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.IntHash
-
- 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
-
- IntWriter(String) - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters.IntWriter
-
- IntXor() - Constructor for class org.apache.drill.exec.expr.fn.impl.BitFunctions.IntXor
-
- 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
-
- InvalidIndexDefinitionException - Exception in org.apache.drill.exec.planner.index
-
An InvalidIndexDefinitionException may be thrown if Drill does not recognize the
type or expression of the index during the index discovery phase
- InvalidIndexDefinitionException(String) - Constructor for exception org.apache.drill.exec.planner.index.InvalidIndexDefinitionException
-
- invalidPolicy() - Method in class org.apache.drill.exec.impersonation.TestInboundImpersonation
-
- invalidProxy() - Method in class org.apache.drill.exec.impersonation.TestInboundImpersonation
-
- invalidQueryParserError() - Method in class org.apache.drill.exec.work.prepare.TestPreparedStatementProvider
-
Pass an invalid query to the create prepare statement request and expect a parser failure.
- invalidQueryValidationError() - Method in class org.apache.drill.exec.work.prepare.TestPreparedStatementProvider
-
Pass an invalid query to the create prepare statement request and expect a validation failure.
- 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
-
- ipOffset - Variable in class org.apache.drill.exec.store.pcap.decoder.Packet
-
- 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
-
- ipVersion() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
-
- is1st() - Method in enum org.apache.drill.exec.planner.physical.AggPrelBase.OperatorPhase
-
- is2nd() - Method in enum org.apache.drill.exec.planner.physical.AggPrelBase.OperatorPhase
-
- IS_CATALOG_CONNECT - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
Catalog connect string.
- IS_CATALOG_DESCRIPTION - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
Catalog description
- IS_CATALOG_NAME - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
Name of catalog containing information schema.
- IS_DIRECTORY - Variable in class org.apache.drill.exec.store.ischema.Records.File
-
- IS_FALSE - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
-
- IS_FILE - Variable in class org.apache.drill.exec.store.ischema.Records.File
-
- 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_NOT_FALSE - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
-
- IS_NOT_NULL - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
-
- IS_NOT_TRUE - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
-
- IS_NULL - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
-
- IS_NULLABLE - Variable in class org.apache.drill.exec.store.ischema.Records.Column
-
- IS_SCHEMA_NAME - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
Name of information schema.
- IS_TRUE - Static variable in class org.apache.drill.exec.expr.fn.FunctionGenerationHelper
-
- isAckSent() - Method in class org.apache.drill.exec.record.RawFragmentBatch
-
- isActive() - Method in class org.apache.drill.exec.rpc.control.ControlConnection
-
- isAdmin - Variable in class org.apache.drill.exec.store.sys.ProfileIterator
-
- 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
-
- isAlwaysValid() - Method in class org.apache.drill.exec.vector.complex.fn.FieldSelection
-
- isApplyAllowed() - Method in class org.apache.drill.exec.planner.sql.DrillConformance
-
Drill allows OUTER APPLY and CROSS APPLY to allow each row from left child of Join
to join with output of right side (sub-query or table function that will be invoked for each row).
- isArpPacket() - Method in class org.apache.drill.exec.store.pcap.decoder.Packet
-
- isArray() - Method in class org.apache.drill.exec.physical.rowSet.project.RequestedColumnImpl
-
- isArray() - Method in interface org.apache.drill.exec.physical.rowSet.project.RequestedTuple.RequestedColumn
-
- isArray() - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- isArray() - Method in class org.apache.drill.exec.record.metadata.VariantColumnMetadata
-
- 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?
- isAsyncIndex() - Method in class org.apache.drill.exec.planner.index.AbstractIndexDescriptor
-
- isAsyncIndex() - Method in interface org.apache.drill.exec.planner.index.IndexDescriptor
-
Whether this index is maintained synchronously (i.e primary table updates are propagated to the index
synchronously) or asynchronously with some delay.
- isAuthEnabled() - Method in class org.apache.drill.exec.rpc.user.UserServer.BitToUserConnectionConfig
-
- isAuthEnabled() - Method in class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
-
- isAuthenticated - Variable in class org.apache.drill.exec.store.sys.BitToUserConnectionIterator.ConnectionInfo
-
- 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.
- isBranchRoot - Variable in class org.apache.drill.test.ProfileParser.OperatorSummary
-
- isBroadcastJoinEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- isBufferedOperator(QueryContext) - Method in class org.apache.drill.exec.physical.base.AbstractBase
-
Any operator that supports spilling should override this method (and return true)
- isBufferedOperator(QueryContext) - Method in interface org.apache.drill.exec.physical.base.PhysicalOperator
-
- isBufferedOperator(QueryContext) - Method in class org.apache.drill.exec.physical.config.ExternalSort
-
The External Sort operator supports spilling
- isBufferedOperator(QueryContext) - Method in class org.apache.drill.exec.physical.config.HashAggregate
-
The Hash Aggregate operator supports spilling
- isBufferedOperator(QueryContext) - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
-
The Hash Aggregate operator supports spilling
- isBuffersDone() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- isCancelled() - Method in class org.apache.drill.exec.rpc.data.TestBitBitKerberos.MockFragmentManager
-
- isCancelled() - Method in class org.apache.drill.exec.rpc.data.TestBitRpc.MockFragmentManager
-
- isCancelled() - Method in class org.apache.drill.exec.util.concurrent.ExecutorServiceUtil.CallableTaskWrapper
- 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.
- isCancelled() - Method in class org.apache.drill.test.QueryBuilder.QuerySummaryFuture
-
Always returns false.
- 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
-
- isColumnIndexed(SchemaPath) - Method in class org.apache.drill.exec.planner.index.AbstractIndexCollection
-
- isColumnIndexed(SchemaPath) - Method in interface org.apache.drill.exec.planner.index.IndexCollection
-
Check if the field name is the leading key of any of the indexes in this collection
- isCompatible(boolean, boolean) - Method in class org.apache.drill.exec.planner.common.DrillUnionRelBase
-
- isCompleted() - Method in class org.apache.drill.exec.physical.impl.MockRecordBatch
-
- isCompleted() - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- isComplex(TypeProtos.MajorType) - Method in class org.apache.drill.exec.physical.impl.project.ProjectMemoryManager
-
- isComplex() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
- 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.DrillComplexWriterAggFuncHolder
-
- 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).
- isConditionPrefix(IndexDescriptor, RexNode) - Method in class org.apache.drill.exec.planner.index.IndexConditionInfo.Builder
-
Given a RexNode corresponding to the condition expression tree and the index descriptor,
check if one or more columns involved in the condition tree form a prefix of the columns in the
index keys.
- 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
-
- isCovering() - Method in interface org.apache.drill.exec.planner.index.IndexProperties
-
- isCovering() - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- isCoveringIndex(List<LogicalExpression>) - Method in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- isCoveringIndex(List<LogicalExpression>) - Method in interface org.apache.drill.exec.planner.index.IndexDefinition
-
Check if this index 'covers' all the columns specified in the supplied list of columns
- isCoveringIndex(IndexCallContext, FunctionalIndexInfo) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
For a particular table scan for table T1 and an index on that table, find out if it is a covering index
- 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
-
- IsDate() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IsDate
-
- IsDateRequiredInput() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.IsDateRequiredInput
-
- 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
- isDescriptive() - Method in class org.apache.drill.exec.store.image.ImageFormatConfig
-
- 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
-
- isDirectMemoryOOM(Throwable) - Static method in class org.apache.drill.exec.server.FailureUtils
-
- isDirectory - Variable in class org.apache.drill.exec.planner.sql.handlers.ShowFilesHandler.ShowFilesCommandResult
-
- isDirectory(Path) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
-
- isDisableFullTableScan() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- isDistinct() - Method in class org.apache.drill.exec.planner.common.DrillUnionRelBase
-
- isDistributed() - Method in class org.apache.drill.exec.physical.base.AbstractGroupScan
-
- isDistributed() - Method in interface org.apache.drill.exec.physical.base.GroupScan
-
- isDistributed() - Method in enum org.apache.drill.exec.store.sys.SystemTable
-
- isDone() - Method in interface org.apache.drill.exec.physical.impl.aggregate.StreamingAggregator
-
- isDone() - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
-
- isDone() - Method in class org.apache.drill.exec.physical.impl.window.Partition
-
- isDone() - Method in class org.apache.drill.exec.util.concurrent.ExecutorServiceUtil.CallableTaskWrapper
-
- isDone() - Method in class org.apache.drill.exec.work.batch.IncomingBuffers
-
- isDone() - Method in class org.apache.drill.test.QueryBuilder.QuerySummaryFuture
-
- 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
-
- isDynamicStruct() - Method in class org.apache.drill.exec.planner.logical.ExtendableRelDataType
-
- 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.common.SpilledState
-
True if there are no spilled partitions.
- 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.record.metadata.TupleSchema
-
- 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
-
- isEmptyDirectory() - Method in class org.apache.drill.exec.store.dfs.FileSelection
-
- isEnableBatchSzLogging() - Method in class org.apache.drill.exec.util.record.RecordBatchStats.RecordBatchStatsContext
-
- isEnabled() - Method in class org.apache.drill.exec.server.rest.DrillRoot.QueueInfo
-
- isEnableFgBatchSzLogging() - Method in class org.apache.drill.exec.util.record.RecordBatchStats.RecordBatchStatsContext
-
- isEncodedSchemaPath(SchemaPath) - Static method in class org.apache.drill.exec.util.EncodedSchemaPathSet
-
- isEncodedSchemaPath(String) - Static method in class org.apache.drill.exec.util.EncodedSchemaPathSet
-
- isEncrypted - Variable in class org.apache.drill.exec.store.sys.BitToUserConnectionIterator.ConnectionInfo
-
- isEncryptionEnabled() - Method in class org.apache.drill.exec.rpc.AbstractConnectionConfig
-
- isEncryptionEnabled() - Method in interface org.apache.drill.exec.rpc.ConnectionConfig
-
- isEncryptionEnabled() - Method in class org.apache.drill.exec.rpc.user.UserServer.BitToUserConnectionConfig
-
- 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
-
- isEquivalent(ColumnMetadata) - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- isEquivalent(TupleMetadata) - Method in class org.apache.drill.exec.record.metadata.TupleSchema
-
- isEqWithEpsilon(RelOptCost) - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
-
- isError() - Method in enum org.apache.drill.exec.record.RecordBatch.IterOutcome
-
- 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.AbstractParquetRowGroupScan
-
- isExpandedFully() - Method in class org.apache.drill.exec.store.dfs.FileSelection
-
- isExpandedPartial() - Method in class org.apache.drill.exec.store.dfs.FileSelection
-
- isExtendable() - Method in class org.apache.drill.test.rowSet.DirectRowSet
-
- isExtendable() - Method in class org.apache.drill.test.rowSet.HyperRowSetImpl
-
- isExtendable() - Method in class org.apache.drill.test.rowSet.IndirectRowSet
-
- isExtendable() - Method in interface org.apache.drill.test.rowSet.RowSet
-
- 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.test.OperatorFixture.MockExecutorState
-
- 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.Required - Class in org.apache.drill.exec.expr.fn.impl
-
- 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.ShowFilesHandler.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 interface org.apache.drill.exec.physical.base.DbGroupScan
-
- isFilterPushedDown() - Method in class org.apache.drill.exec.store.ischema.InfoSchemaGroupScan
-
- isFirstCycle() - Method in class org.apache.drill.exec.physical.impl.common.SpilledState
-
True if this is the first cycle (0).
- 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
-
- isFormEnabled() - Method in class org.apache.drill.exec.server.rest.auth.DrillHttpSecurityHandlerProvider
-
- isFormEnabled() - Method in class org.apache.drill.exec.server.rest.LogInLogOutResources.MainLoginPageModel
-
- isFrameDone() - Method in class org.apache.drill.exec.physical.impl.window.Partition
-
- isFrameUnitsRows() - Method in class org.apache.drill.exec.physical.config.WindowPOP
-
- isFull() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- isFull() - Method in class org.apache.drill.exec.physical.rowSet.impl.RowSetLoaderImpl
-
- isFull() - Method in interface org.apache.drill.exec.physical.rowSet.RowSetLoader
-
Indicates that no more rows fit into the current row batch and that the row
batch should be harvested and sent downstream.
- isFull() - Method in interface org.apache.drill.test.rowSet.RowSetWriter
-
Indicates if the current row position is valid for
writing.
- isFull() - Method in class org.apache.drill.test.rowSet.RowSetWriterImpl
-
- 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.
- isGenerateBloomFilter() - Method in class org.apache.drill.exec.work.filter.RuntimeFilterDef
-
- isGenerateMinMaxFilter() - Method in class org.apache.drill.exec.work.filter.RuntimeFilterDef
-
- isGroupByAlias() - Method in class org.apache.drill.exec.planner.sql.DrillConformance
-
- isGroupByOrdinal() - Method in class org.apache.drill.exec.planner.sql.DrillConformance
-
- 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
-
- isHavingAlias() - Method in class org.apache.drill.exec.planner.sql.DrillConformance
-
- 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
-
- isHeapOOM(Throwable) - Static method in class org.apache.drill.exec.server.FailureUtils
-
- 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 interface org.apache.drill.exec.ops.FragmentContext
-
- isImpersonationEnabled() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- isImpersonationEnabled() - Method in class org.apache.drill.exec.ops.QueryContext
-
- isImpersonationEnabled() - Method in class org.apache.drill.exec.ops.ViewExpansionContext
-
- isImpersonationEnabled() - Method in class org.apache.drill.test.OperatorFixture.MockFragmentContext
-
- isImpersonationOnlyEnabled(DrillConfig) - Static method in class org.apache.drill.exec.server.rest.WebServer
-
Checks if only impersonation is enabled.
- isIndexForceSortNonCovering() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- isIndexIntersectPlanPreferred() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- isIndexPlanningEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- isIndexScan() - Method in interface org.apache.drill.exec.physical.base.DbGroupScan
-
- isIndexUseHashJoinNonCovering() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- isInferred - Variable in class org.apache.drill.test.ProfileParser.OperatorSummary
-
- isInfinite() - Method in class org.apache.drill.exec.planner.cost.DrillCostBase
-
- isInitialized() - Method in interface org.apache.drill.exec.physical.impl.TopN.PriorityQueue
-
- isInitialized() - Method in class org.apache.drill.exec.physical.impl.TopN.PriorityQueueTemplate
-
When cleanup is called then heapSv4 is cleared and set to null and is only initialized during init call.
- isInject() - Method in class org.apache.drill.exec.expr.fn.WorkspaceReference
-
- isInternal() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
-
- isInternal() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
-
- isInternal() - Method in class org.apache.drill.exec.expr.fn.ValueReference
-
- isInternal() - Method in class org.apache.drill.exec.server.options.OptionMetaData
-
- isIntersect() - Method in class org.apache.drill.exec.planner.common.JoinControl
-
- isIntersectAll() - Method in class org.apache.drill.exec.planner.common.JoinControl
-
- isIntersectDistinct() - Method in class org.apache.drill.exec.planner.common.JoinControl
-
- isIntersectIndex() - Method in class org.apache.drill.exec.planner.index.IndexGroup
-
- 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?
- isLimit0(RexNode) - Static method in class org.apache.drill.exec.planner.common.DrillRelOptUtil
-
- 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.filter.BloomFilterDef
-
- isLocal() - Method in class org.apache.drill.exec.work.foreman.FragmentData
-
- isLocalControlServer(CoordinationProtos.DrillbitEndpoint, CoordinationProtos.DrillbitEndpoint) - Static method in class org.apache.drill.exec.rpc.BitRpcUtility
-
Verifies if local and remote Drillbit Endpoint has same control server by using address and control port
information.
- 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
-
- isMap() - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- isMap() - Method in class org.apache.drill.exec.record.metadata.MapColumnMetadata
-
- isMatchAllRowGroups() - Method in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- 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
-
- isMultiList() - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- isMultiList() - Method in class org.apache.drill.exec.record.metadata.RepeatedListColumnMetadata
-
- 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
-
- isNewSchema() - Method in class org.apache.drill.exec.store.TestOutputMutator
-
- 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.Required - Class in org.apache.drill.exec.expr.fn.impl
-
- IsNotNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.IsNotNull
-
- 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.Required - Class in org.apache.drill.exec.expr.fn.impl
-
- IsNull() - Constructor for class org.apache.drill.exec.expr.fn.impl.UnionFunctions.IsNull
-
- isNull(int) - Method in class org.apache.drill.exec.vector.accessor.AbstractSqlAccessor
-
- isNull(int) - Method in class org.apache.drill.exec.vector.accessor.BoundCheckingAccessor
-
- isNull(int) - Method in class org.apache.drill.exec.vector.accessor.GenericAccessor
-
- 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.UnionSqlAccessor
-
- isNullable() - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- isNullable() - Method in class org.apache.drill.exec.store.pcap.dto.ColumnDto
-
- isNumericType(TypeProtos.MinorType) - Static method in class org.apache.drill.exec.resolver.TypeCastRules
-
- isNumNullsSet() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ColumnMetadata
-
Number of nulls is considered to be valid if its value is not null and -1.
- isOnline(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.server.DrillbitContext
-
- isOnlyImpersonationEnabled() - Method in class org.apache.drill.exec.server.rest.profile.ProfileWrapper
-
- 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
-
- isOverflowDataFullyConsumed() - Method in interface org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager.FieldOverflowState
-
- isOverMemoryLimit() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- 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
- isPermissive() - Method in class org.apache.drill.exec.physical.rowSet.impl.NullResultVectorCacheImpl
-
- isPermissive() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultVectorCacheImpl
-
- isPermissive() - Method in interface org.apache.drill.exec.physical.rowSet.ResultVectorCache
-
- 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
-
- isProjected() - Method in class org.apache.drill.exec.physical.rowSet.impl.ColumnState
-
- isProjected() - Method in class org.apache.drill.exec.physical.rowSet.impl.ListState.ListVectorState
-
- isProjected() - Method in class org.apache.drill.exec.physical.rowSet.impl.NullableVectorState
-
- isProjected() - Method in class org.apache.drill.exec.physical.rowSet.impl.NullVectorState
-
- isProjected() - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedListState.RepeatedListVectorState
-
- isProjected() - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedVectorState
-
- isProjected() - Method in class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState
-
- isProjected() - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState.MapColumnState
-
- isProjected() - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState.MapVectorState
-
- isProjected() - Method in class org.apache.drill.exec.physical.rowSet.impl.UnionState.UnionColumnState
-
- isProjected() - Method in class org.apache.drill.exec.physical.rowSet.impl.UnionState.UnionVectorState
-
- isProjected() - Method in interface org.apache.drill.exec.physical.rowSet.impl.VectorState
-
Report whether this column is projected (has materialized vectors),
or is unprojected (has no materialized backing.)
- isProjected() - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- isProjectFlatten(RelNode) - Static method in class org.apache.drill.exec.planner.common.DrillRelOptUtil
-
- isProjectionEmpty() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- isProjectionEmpty() - Method in interface org.apache.drill.exec.physical.rowSet.ResultSetLoader
-
Reports if this is an empty projection such as occurs in a
SELECT COUNT(*) query.
- isProjectNone() - Method in class org.apache.drill.exec.physical.impl.scan.project.ScanSchemaOrchestrator
-
- isProjectOutputRowcountUnknown(Project) - Static method in class org.apache.drill.exec.planner.common.DrillRelOptUtil
-
Find whether the given project rel can produce non-scalar output (hence unknown rowcount).
- isProjectOutputSchemaUnknown(Project) - Static method in class org.apache.drill.exec.planner.common.DrillRelOptUtil
-
Find whether the given project rel has unknown output schema.
- 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, SchemaConfig) - Method in class org.apache.drill.exec.store.dfs.BasicFormatMatcher
-
- isReadable(DrillFileSystem, FileSelection, FileSystemPlugin, String, SchemaConfig) - 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
-
- isRecordBatchStatsLoggingEnabled() - Method in class org.apache.drill.exec.record.AbstractRecordBatch
-
- isRegularColumnOrExp(String) - Static method in class org.apache.drill.exec.planner.StarColumnHelper
-
- isRepeatable - Variable in class org.apache.drill.exec.physical.config.IteratorValidator
-
- isRepeated() - Method in class org.apache.drill.exec.expr.ClassGenerator.HoldingContainer
-
- isRepeated() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetColumnMetadata
-
- isRepeatedList() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
- isReplaceable() - Method in class org.apache.drill.exec.compile.bytecode.ReplacingBasicValue
-
Indicates whether or not this value is replaceable.
- isRestrictedScan() - Method in class org.apache.drill.exec.physical.base.AbstractDbGroupScan
-
- isRestrictedScan() - Method in interface org.apache.drill.exec.physical.base.DbGroupScan
-
Whether this DbGroupScan is itself a restricted scan
- isRestrictedSubScan() - Method in class org.apache.drill.exec.physical.base.AbstractDbSubScan
-
- isRestrictedSubScan() - Method in interface org.apache.drill.exec.physical.base.DbSubScan
-
Whether this subscan is a restricted (skip) subscan
- isReturnTrueOnOne() - Method in class org.apache.drill.exec.physical.impl.filter.ReturnValueExpression
-
- isRolledUp(String) - Method in class org.apache.drill.exec.planner.logical.DrillTable
-
- isRolledUp(String) - Method in class org.apache.drill.exec.planner.logical.DrillTranslatableTable
-
- isRolledUp(String) - Method in class org.apache.drill.exec.planner.logical.DrillViewTable
-
- isRoot() - Method in class org.apache.drill.exec.physical.rowSet.project.RequestedColumnImpl
-
- isRoot() - Method in class org.apache.drill.exec.record.metadata.TupleSchema
-
- isRootSchema(SchemaPlus) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
-
- isRoutingV6 - Variable in class org.apache.drill.exec.store.pcap.decoder.Packet
-
- isRowGroupPrunable() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ParquetTableMetadata_v1
-
- isRowGroupPrunable() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetTableMetadata_v2
-
- isRowGroupPrunable() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetTableMetadata_v3
-
- isRowGroupPrunable() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ParquetTableMetadataBase
-
- isRowKeyJoin() - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
-
- isRowKeyJoin - Variable in class org.apache.drill.exec.planner.physical.HashJoinPrel
-
- isRowKeyJoin() - Method in class org.apache.drill.exec.planner.physical.HashJoinPrel
-
- isRowKeyJoinConversionEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- isRowKeyJoinConversionUsingHashJoin() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- isRunning() - Method in class org.apache.drill.exec.server.rest.WebServer
-
- isRuntimeFilterEnabled() - Method in class org.apache.drill.exec.ops.QueryContext
-
- 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
-
- isSemiJoin() - Method in class org.apache.drill.exec.physical.base.AbstractJoinPop
-
- isSemiJoin() - Method in interface org.apache.drill.exec.planner.logical.DrillJoin
-
- isSemiJoin() - Method in class org.apache.drill.exec.planner.logical.DrillJoinRel
-
- isSemiJoin() - Method in class org.apache.drill.exec.planner.logical.DrillSemiJoinRel
-
- isSemiJoin() - Method in class org.apache.drill.exec.planner.logical.RowKeyJoinRel
-
Returns whether this RowKeyJoin represents a SemiJoin
- isSemiJoin - Variable in class org.apache.drill.exec.planner.physical.JoinPrel
-
- isSemiJoin() - Method in class org.apache.drill.exec.planner.physical.JoinPrel
-
- isSemiJoinEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- isSendToForeman() - Method in class org.apache.drill.exec.work.filter.RuntimeFilterDef
-
- 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
-
- IsSetVectorState(WriterPosition, ValueVector) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState.IsSetVectorState
-
- 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
-
- isSimple() - Method in class org.apache.drill.exec.physical.rowSet.project.RequestedColumnImpl
-
- isSimple() - Method in interface org.apache.drill.exec.physical.rowSet.project.RequestedTuple.RequestedColumn
-
- isSimple() - Method in class org.apache.drill.exec.record.metadata.VariantSchema
-
- isSimpleProjection() - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple
-
- isSingleMode() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- isSingleMode(RelOptRuleCall) - Static method in class org.apache.drill.exec.planner.physical.Prule
-
- isSingleType() - Method in class org.apache.drill.exec.record.metadata.VariantSchema
-
- 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
-
- isSpilled() - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- isSpilled() - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PartitionStat
-
- isSpilled() - Method in class org.apache.drill.exec.physical.impl.join.PartitionStatImpl
-
- isSpilledInner(int) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
-
- isSpillNeeded(long, long) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortMemoryManager
-
- isSpnegoEnabled() - Method in class org.apache.drill.exec.server.rest.auth.DrillHttpSecurityHandlerProvider
-
- isSpnegoEnabled() - Method in class org.apache.drill.exec.server.rest.LogInLogOutResources.MainLoginPageModel
-
- 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.BitToUserConnectionConfig
-
- 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.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.
- isStatisticsEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- isStatsAvailable() - Method in interface org.apache.drill.exec.planner.index.Statistics
-
Returns whether statistics are available.
- isStreamAggEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- isStringsSignedMinMaxEnabled() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatConfig
-
Parquet statistics for UTF-8 data for files created prior to 1.9.1 parquet library version was stored incorrectly.
- 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.
- isTree - Variable in class org.apache.drill.test.ProfileParser.Aggregator
-
- 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.Required - Class in org.apache.drill.exec.expr.fn.impl
-
- isTuple() - Method in class org.apache.drill.exec.physical.rowSet.project.RequestedColumnImpl
-
- isTuple() - Method in interface org.apache.drill.exec.physical.rowSet.project.RequestedTuple.RequestedColumn
-
- 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
-
- isUnnestLateralEnabled() - Method in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- isUserAuthenticationEnabled() - Method in interface org.apache.drill.exec.ops.ExecutorFragmentContext
-
- isUserAuthenticationEnabled() - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- isUserAuthenticationEnabled() - Method in class org.apache.drill.exec.ops.QueryContext
-
- isUserAuthenticationEnabled() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- 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
-
- isValid(T) - Method in interface org.apache.drill.exec.planner.cost.PluginCost.CheckValid
-
- isValid(Integer) - Method in class org.apache.drill.exec.planner.cost.PluginCost.greaterThanEquals
-
- isValid(Litmus, RelNode.Context) - Method in class org.apache.drill.exec.planner.logical.RowKeyJoinRel
-
The parent method relies the class being an instance of SemiJoin
in deciding row-type validity.
- isValid(Litmus, RelNode.Context) - Method in class org.apache.drill.exec.planner.physical.JoinPrel
-
- isValidForBit(CoordinationProtos.DrillbitEndpoint) - Method in class org.apache.drill.exec.testing.Injection
-
- isValidIndexHint(IndexLogicalPlanCallContext) - Method in class org.apache.drill.exec.planner.index.IndexConditionInfo.Builder
-
- isVariableWidth() - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- isVariableWidth() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
- isVariant() - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- isVariant() - Method in class org.apache.drill.exec.record.metadata.VariantColumnMetadata
-
- isVersioned() - Method in class org.apache.drill.exec.physical.rowSet.impl.ContainerState
-
Reports whether this container is subject to version management.
- isVersioned() - Method in class org.apache.drill.exec.physical.rowSet.impl.ListState
-
- isVersioned() - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedListState
-
The repeated list vector does not support versioning
of maps within the list.
- isVersioned - Variable in class org.apache.drill.exec.physical.rowSet.impl.TupleState.MapColumnState
-
- isVersioned() - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState.MapColumnState
-
Indicate if this map is versioned.
- isVersioned() - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState.MapState
-
A map is within a union if the map vector has been materialized.
- isVersioned() - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState.RowState
-
The row as a whole is versioned.
- isVersioned() - Method in class org.apache.drill.exec.physical.rowSet.impl.UnionState
-
- isVersionMatch() - Method in class org.apache.drill.exec.server.rest.DrillRoot.DrillbitInfo
-
- isVersionSupported(String) - Static method in class org.apache.drill.exec.store.parquet.metadata.MetadataVersion.Constants
-
- isWaiting() - Method in class org.apache.drill.exec.rpc.data.TestBitBitKerberos.MockFragmentManager
-
- isWaiting() - Method in class org.apache.drill.exec.rpc.data.TestBitRpc.MockFragmentManager
-
- isWaiting() - Method in class org.apache.drill.exec.work.fragment.AbstractFragmentManager
-
- isWaiting() - Method in interface org.apache.drill.exec.work.fragment.FragmentManager
-
- isWildcard() - Method in class org.apache.drill.exec.physical.rowSet.project.RequestedColumnImpl
-
- isWildcard() - Method in interface org.apache.drill.exec.physical.rowSet.project.RequestedTuple.RequestedColumn
-
- 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
-
- isWritable() - Method in class org.apache.drill.test.rowSet.DirectRowSet
-
- isWritable() - Method in class org.apache.drill.test.rowSet.HyperRowSetImpl
-
- isWritable() - Method in class org.apache.drill.test.rowSet.IndirectRowSet
-
- isWritable() - Method in interface org.apache.drill.test.rowSet.RowSet
-
- 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
-
- Iter(DrillConfig) - Constructor for class org.apache.drill.exec.server.options.DrillConfigIterator.Iter
-
- ITERATIONS - Static variable in class org.apache.drill.test.rowSet.test.PerformanceTool
-
- 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.ParquetComparisonPredicate
-
- iterator() - Method in class org.apache.drill.exec.expr.stat.ParquetIsPredicate
-
- 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.AbstractJoinPop
-
- 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.RowKeyJoinPOP
-
- iterator() - Method in class org.apache.drill.exec.physical.config.UnnestPOP
-
- 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.MockRecordBatch
-
- iterator() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
-
- iterator() - Method in interface org.apache.drill.exec.physical.impl.protocol.BatchAccessor
-
- iterator() - Method in class org.apache.drill.exec.physical.impl.protocol.OperatorRecordBatch
-
- iterator() - Method in class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor
-
- iterator() - Method in class org.apache.drill.exec.physical.impl.ScanBatch
-
- iterator() - Method in class org.apache.drill.exec.physical.impl.SimpleRootExec
-
Deprecated.
- iterator() - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- 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.index.AbstractIndexCollection
-
- 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.DirectScanPrel
-
- 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.LateralJoinPrel
-
- 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.RowKeyJoinPrel
-
- 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.UnnestPrel
-
- 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.metadata.TupleSchema
-
- 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.SchemalessBatch
-
- 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.AbstractParquetRowGroupScan
-
- 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
-
- iterator() - Method in class org.apache.drill.exec.store.TestOutputMutator
-
- iterator() - Method in class org.apache.drill.test.OperatorTestBuilderTest.MockPhysicalOperator
-
- iterator() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.BatchIterator
-
- iterator() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockPhysicalOperator
-
- iterator() - Method in class org.apache.drill.test.QueryRowSetIterator
-
- IteratorValidator - Class in org.apache.drill.exec.physical.config
-
- IteratorValidator(PhysicalOperator, boolean) - Constructor for class org.apache.drill.exec.physical.config.IteratorValidator
-
- IteratorValidator(PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.config.IteratorValidator
-
- IteratorValidatorBatchIterator - Class in org.apache.drill.exec.physical.impl.validate
-
- IteratorValidatorBatchIterator(RecordBatch, boolean) - Constructor for class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
-
- 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
-
- IteratorValidatorInjector(boolean) - Constructor for class org.apache.drill.exec.physical.impl.validate.IteratorValidatorInjector
-
- Random() - Constructor for class org.apache.drill.exec.expr.fn.impl.MathFunctions.Random
-
- random - Static variable in class org.apache.drill.exec.fn.impl.testing.GeneratorFunctions
-
- RANDOM_DISTRIBUTED - Static variable in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
-
- RandomBigInt() - Constructor for class org.apache.drill.exec.fn.impl.testing.GeneratorFunctions.RandomBigInt
-
- RandomBigIntGauss() - Constructor for class org.apache.drill.exec.fn.impl.testing.GeneratorFunctions.RandomBigIntGauss
-
- RandomFloat8() - Constructor for class org.apache.drill.exec.fn.impl.testing.GeneratorFunctions.RandomFloat8
-
- RandomFloat8Gauss() - Constructor for class org.apache.drill.exec.fn.impl.testing.GeneratorFunctions.RandomFloat8Gauss
-
- RANGE_PARTITION_CPU_COST - Static variable in class org.apache.drill.exec.planner.cost.DrillCostBase
-
- RANGE_PARTITION_EXPR_NAME - Static variable in class org.apache.drill.exec.planner.physical.AbstractRangePartitionFunction
-
- RANGE_PARTITION_OUTGOING_BATCH_SIZE - Static variable in class org.apache.drill.exec.physical.config.RangePartitionSender
-
- RangeDoubleValidator(String, double, double, OptionValidator.OptionDescription) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.RangeDoubleValidator
-
- RangeExprEvaluator<T extends Comparable<T>> - Class in org.apache.drill.exec.expr.stat
-
- RangeExprEvaluator(Map<SchemaPath, ColumnStatistics<T>>, long) - Constructor for class org.apache.drill.exec.expr.stat.RangeExprEvaluator
-
- RangeLongValidator(String, long, long, OptionValidator.OptionDescription) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.RangeLongValidator
-
- RangePartitionExchange - Class in org.apache.drill.exec.physical.config
-
- RangePartitionExchange(PhysicalOperator, PartitionFunction) - Constructor for class org.apache.drill.exec.physical.config.RangePartitionExchange
-
- RangePartitionExchangePrel - Class in org.apache.drill.exec.planner.physical
-
A RangePartitionExchange provides the ability to divide up the rows into separate ranges or 'buckets'
based on the values of a set of columns (the range partitioning columns).
- RangePartitionExchangePrel(RelOptCluster, RelTraitSet, RelNode, List<DrillDistributionTrait.DistributionField>, PartitionFunction) - Constructor for class org.apache.drill.exec.planner.physical.RangePartitionExchangePrel
-
- RangePartitionRecordBatch - Class in org.apache.drill.exec.physical.impl.rangepartitioner
-
A RangePartitionRecordBatch is a run-time operator that provides the ability to divide up the input rows
into a fixed number of separate ranges or 'buckets' based on the values of a set of columns (the range
partitioning columns).
- RangePartitionRecordBatch(RangePartitionSender, RecordBatch, FragmentContext) - Constructor for class org.apache.drill.exec.physical.impl.rangepartitioner.RangePartitionRecordBatch
-
- RangePartitionSender - Class in org.apache.drill.exec.physical.config
-
- RangePartitionSender(int, PhysicalOperator, List<MinorFragmentEndpoint>, PartitionFunction) - Constructor for class org.apache.drill.exec.physical.config.RangePartitionSender
-
- RangePartitionSenderCreator - Class in org.apache.drill.exec.physical.impl.rangepartitioner
-
- RangePartitionSenderCreator() - Constructor for class org.apache.drill.exec.physical.impl.rangepartitioner.RangePartitionSenderCreator
-
- rank() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- rank - Variable in class org.apache.drill.exec.physical.impl.window.Partition
-
- raw - Variable in class org.apache.drill.exec.store.pcap.decoder.Packet
-
- 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
-
- 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(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(FileType, FileStatus, Metadata) - Method in class org.apache.drill.exec.store.image.GenericMetadataReader
-
- 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
-
- 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, ParquetReaderConfig) - Static method in class org.apache.drill.exec.store.parquet.metadata.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.record.DeadBuf
-
- readComplexWithStar() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- 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(BufferAllocator, InputStream) - Constructor for class org.apache.drill.exec.cache.VectorSerializer.Reader
-
- reader - Variable in class org.apache.drill.exec.store.direct.DirectGroupScan
-
- reader() - Method in class org.apache.drill.test.rowSet.DirectRowSet
-
- reader() - Method in class org.apache.drill.test.rowSet.HyperRowSetImpl
-
- reader() - Method in class org.apache.drill.test.rowSet.IndirectRowSet
-
- reader() - Method in interface org.apache.drill.test.rowSet.RowSet
-
- READER_BASE_ID - Static variable in interface org.apache.drill.exec.physical.impl.scan.project.ColumnProjection
-
- readerConfig - Variable in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- readerConfig - Variable in class org.apache.drill.exec.store.parquet.AbstractParquetRowGroupScan
-
- ReaderIndex - Class in org.apache.drill.exec.physical.rowSet.model
-
Row set index base class used when indexing rows within a row
set for a row set reader.
- ReaderIndex(int) - Constructor for class org.apache.drill.exec.physical.rowSet.model.ReaderIndex
-
- readerIndex() - Method in class org.apache.drill.exec.record.DeadBuf
-
- readerIndex(int) - Method in class org.apache.drill.exec.record.DeadBuf
-
- readerIndex - Variable in class org.apache.drill.test.rowSet.RowSetReaderImpl
-
- ReaderSchemaOrchestrator() - Constructor for class org.apache.drill.exec.physical.impl.scan.project.ScanSchemaOrchestrator.ReaderSchemaOrchestrator
-
- 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, ParquetReaderConfig) - Static method in class org.apache.drill.exec.store.parquet.metadata.Metadata
-
Get the parquet metadata for all subdirectories by reading the metadata file
- readNumbersAsDouble(boolean) - Method in class org.apache.drill.exec.vector.complex.fn.JsonReader.Builder
-
- 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
-
- readPcapng(byte[]) - Method in class org.apache.drill.exec.store.pcapng.decoder.PacketDecoder
-
- 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
-
- readRecordsInBulk(int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
-
- readRecordsInBulk(int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthValuesColumn
- readShort() - Method in class org.apache.drill.exec.record.DeadBuf
-
- readSlice(int) - Method in class org.apache.drill.exec.record.DeadBuf
-
- ReadState() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderTorture.ReadState
-
- 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, RecordBatchSizerManager, 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.
- Receiver - Interface in org.apache.drill.exec.physical.base
-
A receiver is one half of an exchange operator.
- ReceiverFinished(RpcOutcomeListener<GeneralRPCProtos.Ack>, BitControl.FinishedReceiver) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.ReceiverFinished
-
- 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
-
- receiveRuntimeFilter(RuntimeFilterWritable) - Method in class org.apache.drill.exec.work.WorkManager.WorkerBee
-
receive the RuntimeFilter thorough the wire
- 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.SimpleRootExec
-
Deprecated.
- receivingFragmentFinished(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.physical.impl.SingleSenderCreator.SingleSenderRootExec
-
- receivingFragmentFinished(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.rpc.data.TestBitBitKerberos.MockFragmentManager
-
- receivingFragmentFinished(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.rpc.data.TestBitRpc.MockFragmentManager
-
- receivingFragmentFinished(BitControl.FinishedReceiver) - Method in class org.apache.drill.exec.work.batch.ControlMessageHandler
-
- 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_COUNT - Static variable in class org.apache.drill.exec.store.avro.AvroTestUtil
-
- 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.
- RecordBatchMemoryManager - Class in org.apache.drill.exec.record
-
- RecordBatchMemoryManager(int, int) - Constructor for class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- RecordBatchMemoryManager(int) - Constructor for class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- RecordBatchOverflow - Class in org.apache.drill.exec.store.parquet.columnreaders.batchsizing
-
Logic for handling batch record overflow; this class essentially serializes overflow vector data in a
compact manner so that it is reused for building the next record batch.
- RecordBatchOverflow.Builder - Class in org.apache.drill.exec.store.parquet.columnreaders.batchsizing
-
- RecordBatchOverflow.FieldOverflowDefinition - Class in org.apache.drill.exec.store.parquet.columnreaders.batchsizing
-
Field overflow definition
- RecordBatchOverflow.RecordOverflowDefinition - Class in org.apache.drill.exec.store.parquet.columnreaders.batchsizing
-
Record batch definition
- RecordBatchSizer - Class in org.apache.drill.exec.record
-
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.record.RecordBatchSizer
-
- RecordBatchSizer(VectorAccessible) - Constructor for class org.apache.drill.exec.record.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.record.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.record
-
Column size information.
- RecordBatchSizerManager - Class in org.apache.drill.exec.store.parquet.columnreaders.batchsizing
-
This class is tasked with managing all aspects of flat Parquet reader record batch sizing logic.
- RecordBatchSizerManager(OptionManager, ParquetSchema, long, RecordBatchStats.RecordBatchStatsContext) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager
-
Constructor.
- RecordBatchSizerManager.ColumnMemoryQuota - Class in org.apache.drill.exec.store.parquet.columnreaders.batchsizing
-
Field memory quota
- RecordBatchSizerManager.FieldOverflowState - Interface in org.apache.drill.exec.store.parquet.columnreaders.batchsizing
-
An abstraction to allow column readers attach custom field overflow state
- RecordBatchSizerManager.FieldOverflowStateContainer - Class in org.apache.drill.exec.store.parquet.columnreaders.batchsizing
-
Container object to hold current field overflow state
- RecordBatchSizerManager.VarLenColumnBatchStats - Class in org.apache.drill.exec.store.parquet.columnreaders.batchsizing
-
Container object to supply variable columns statistics to the batch sizer
- RecordBatchStats - Class in org.apache.drill.exec.util.record
-
Utility class to capture key record batch statistics.
- RecordBatchStats.RecordBatchIOType - Enum in org.apache.drill.exec.util.record
-
Indicates whether a record batch is Input or Output
- RecordBatchStats.RecordBatchStatsContext - Class in org.apache.drill.exec.util.record
-
Helper class which loads contextual record batch logging options
- RecordBatchStatsContext(FragmentContext, OperatorContext) - Constructor for class org.apache.drill.exec.util.record.RecordBatchStats.RecordBatchStatsContext
-
- recordCount() - Method in class org.apache.drill.test.QueryBuilder.QuerySummary
-
- recordCount() - Method in class org.apache.drill.test.QueryResultSet
-
- 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, RecordBatchMemoryManager) - Constructor for class org.apache.drill.exec.record.RecordIterator
-
- RecordIterator(RecordBatch, AbstractRecordBatch<?>, OperatorContext, int, boolean, RecordBatchMemoryManager) - 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
-
- recordNewState(UserBitShared.QueryResult.QueryState) - Method in class org.apache.drill.exec.work.foreman.QueryStateProcessor
-
Directly moves query from one state to another and updates ephemeral query store.
- RecordOverflowDefinition() - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchOverflow.RecordOverflowDefinition
-
- 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 - Variable in class org.apache.drill.test.ProfileParser.OperatorProfile
-
- Records.Catalog - Class in org.apache.drill.exec.store.ischema
-
Pojo object for a record in INFORMATION_SCHEMA.CATALOGS
- Records.Column - Class in org.apache.drill.exec.store.ischema
-
Pojo object for a record in INFORMATION_SCHEMA.COLUMNS
- Records.File - Class in org.apache.drill.exec.store.ischema
-
Pojo object for a record in INFORMATION_SCHEMA.FILES
- Records.Schema - Class in org.apache.drill.exec.store.ischema
-
Pojo object for a record in INFORMATION_SCHEMA.SCHEMATA
- Records.Table - Class in org.apache.drill.exec.store.ischema
-
Pojo object for a record in INFORMATION_SCHEMA.TABLES
- Records.View - Class in org.apache.drill.exec.store.ischema
-
Pojo object for a record in INFORMATION_SCHEMA.VIEWS
- 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
-
- REDIRECT_QUERY_PARM - Static variable in class org.apache.drill.exec.server.rest.WebServerConstants
-
- reduce(RexBuilder, List<RexNode>, List<RexNode>) - Method in class org.apache.drill.exec.planner.logical.DrillConstExecutor
-
- ref - Variable in class org.apache.drill.exec.planner.common.DrillUnnestRelBase
-
- refCnt() - Method in class org.apache.drill.exec.record.DeadBuf
-
- referToSchemaInsideAndOutsideView() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- RefreshMetadataHandler - Class in org.apache.drill.exec.planner.sql.handlers
-
- RefreshMetadataHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.RefreshMetadataHandler
-
- RegexpMatches() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.RegexpMatches
-
- RegexpReplace() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.RegexpReplace
-
- 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.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>, int) - 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
-
- register(RuntimeFilterWritable) - Method in class org.apache.drill.exec.work.filter.RuntimeFilterRouter
-
This method is passively invoked by receiving a runtime filter from the network
- 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.
- REL_FILTER_SCAN - Static variable in class org.apache.drill.exec.planner.index.rules.DbScanToIndexScanPrule
-
- RELATIVE_PATH - Variable in class org.apache.drill.exec.store.ischema.Records.File
-
- relativize(String, String) - Static method in class org.apache.drill.exec.store.parquet.metadata.MetadataPathUtils
-
Constructs relative path from child full path and base path.
- RelDataTypeDrillImpl - Class in org.apache.drill.exec.planner.types
-
- RelDataTypeDrillImpl(AbstractRelDataTypeHolder, 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
-
- RelDataTypeReader(List<String>, List<TypeProtos.MajorType>) - Constructor for class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor.RelDataTypeReader
-
- release() - Method in class org.apache.drill.exec.ops.ViewExpansionContext.ViewExpansionToken
-
Release the token.
- release() - Method in interface org.apache.drill.exec.physical.impl.protocol.BatchAccessor
-
- release() - Method in class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor
-
- 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
-
- releaseFieldOverflowContainer(String) - Method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager
-
Releases the overflow data resources associated with this field; also removes the overflow
container from the overflow containers map.
- relFieldCollations - Variable in class org.apache.drill.exec.planner.index.CollationContext
-
- 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
-
- remainderCondition - Variable in class org.apache.drill.exec.planner.index.generators.AbstractIndexPlanGenerator
-
- remainderCondition - Variable in class org.apache.drill.exec.planner.index.IndexConditionInfo
-
- remainderCondition(IndexDescriptor, IndexConditionInfo.Builder, RexNode) - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- remapGroupSet(ImmutableBitSet) - Static method in class org.apache.drill.exec.planner.physical.AggPruleBase
-
Returns group-by keys with the remapped arguments for specified aggregate.
- REMAPPING_FLAG - Static variable in class org.apache.drill.exec.store.httpd.HttpdParser
-
- RemoteControlConnectionManager - Class in org.apache.drill.exec.rpc.control
-
- RemoteControlConnectionManager(ControlConnectionConfig, CoordinationProtos.DrillbitEndpoint, CoordinationProtos.DrillbitEndpoint) - Constructor for class org.apache.drill.exec.rpc.control.RemoteControlConnectionManager
-
- 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 - Static variable in class org.apache.drill.exec.client.ConnectTriesPropertyTestClusterBits
-
- 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() - Method in class org.apache.drill.exec.HyperVectorValueIterator
-
- 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.parquet.columnreaders.VarLenColumnBulkInput
- remove() - Method in class org.apache.drill.exec.store.sys.BitToUserConnectionIterator
-
- 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.ProfileInfoIterator
-
- remove() - Method in class org.apache.drill.exec.store.sys.ProfileJsonIterator
-
- remove() - Method in class org.apache.drill.exec.store.sys.ThreadsIterator
-
- remove() - Method in class org.apache.drill.exec.store.sys.VersionIterator
-
- remove() - Method in class org.apache.drill.test.QueryRowSetIterator
-
- REMOVE_IS_NOT_DISTINCT_FROM_RULE - Static variable in interface org.apache.drill.exec.planner.RuleInstance
-
- 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
-
- removeAll() - Method in class org.apache.drill.exec.record.VectorContainer
-
- removeChild(ResolvedTuple) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple
-
- removeCollation(RelTraitSet, RelOptRuleCall) - Static method in class org.apache.drill.exec.planner.physical.PrelUtil
-
- 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
-
- removeField(MaterializedField) - Method in class org.apache.drill.exec.store.TestOutputMutator
-
- removeFileFromRoot(Path) - Method in class org.apache.drill.test.BaseDirTestWatcher
-
Removes a file or directory copied at relativePath inside the root directory
- removeFragmentManager(ExecProtos.FragmentHandle, boolean) - Method in class org.apache.drill.exec.rpc.control.WorkEventBus
-
Optionally cancels and 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
-
- removeImplicitField(RelDataType) - Method in class org.apache.drill.exec.planner.common.DrillLateralJoinRelBase
-
- removeIndex(IndexDescriptor) - Method in class org.apache.drill.exec.planner.index.AbstractIndexCollection
-
- removeIndex(IndexDescriptor) - Method in interface org.apache.drill.exec.planner.index.IndexCollection
-
Remove an index (identified by table name and index name) from the collection.
- removeIndexProp(IndexProperties) - Method in class org.apache.drill.exec.planner.index.IndexGroup
-
- removeJar(String) - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolder
-
- 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.
- removeMiniDfsBasedStorage() - Static method in class org.apache.drill.exec.impersonation.TestImpersonationDisabledWithMiniDFS
-
- removeMiniDfsBasedStorage() - Static method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- removeMiniDfsBasedStorage() - Static method in class org.apache.drill.exec.impersonation.TestImpersonationQueries
-
- 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.CachedSingleFileSystem
-
- 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.DrillComplexWriterAggFuncHolder
-
- 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
-
- renderMiddle(ClassGenerator<?>, ClassGenerator.HoldingContainer[], JVar[]) - Method in class org.apache.drill.exec.expr.fn.DrillComplexWriterAggFuncHolder
-
- renderStart(ClassGenerator<?>, ClassGenerator.HoldingContainer[], FieldReference) - Method in class org.apache.drill.exec.expr.fn.AbstractFuncHolder
-
- renderStart(ClassGenerator<?>, ClassGenerator.HoldingContainer[], FieldReference) - Method in class org.apache.drill.exec.expr.fn.DrillComplexWriterAggFuncHolder
-
- renderStart(ClassGenerator<?>, ClassGenerator.HoldingContainer[], FieldReference) - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
-
- repeat - Variable in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- repeat - Variable in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
-
Some tests want to create a very wide row with many columns.
- 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
-
- RepeatedLengthBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthBigInt
-
- RepeatedLengthBit() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthBit
-
- RepeatedLengthFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthFloat4
-
- RepeatedLengthFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthFloat8
-
- RepeatedLengthInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthInt
-
- RepeatedLengthTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthTinyInt
-
- RepeatedLengthVarChar() - Constructor for class org.apache.drill.exec.expr.fn.impl.SimpleRepeatedFunctions.RepeatedLengthVarChar
-
- RepeatedListBuilder - Class in org.apache.drill.test.rowSet.schema
-
Builder for a repeated list.
- RepeatedListBuilder(SchemaContainer, String) - Constructor for class org.apache.drill.test.rowSet.schema.RepeatedListBuilder
-
- RepeatedListColumnMetadata - Class in org.apache.drill.exec.record.metadata
-
- RepeatedListColumnMetadata(MaterializedField) - Constructor for class org.apache.drill.exec.record.metadata.RepeatedListColumnMetadata
-
- RepeatedListColumnMetadata(String, AbstractColumnMetadata) - Constructor for class org.apache.drill.exec.record.metadata.RepeatedListColumnMetadata
-
- RepeatedListColumnState(LoaderInternals, AbstractObjectWriter, RepeatedListState.RepeatedListVectorState, RepeatedListState) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.RepeatedListState.RepeatedListColumnState
-
- RepeatedListJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.easy.json.JsonRecordWriter.RepeatedListJsonConverter
-
- RepeatedListState - Class in org.apache.drill.exec.physical.rowSet.impl
-
Represents the internal state of a RepeatedList vector.
- RepeatedListState(LoaderInternals, ResultVectorCache) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.RepeatedListState
-
- RepeatedListState.RepeatedListColumnState - Class in org.apache.drill.exec.physical.rowSet.impl
-
Repeated list column state.
- RepeatedListState.RepeatedListVectorState - Class in org.apache.drill.exec.physical.rowSet.impl
-
Track the repeated list vector.
- RepeatedListVectorState(ArrayWriter, RepeatedListVector) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.RepeatedListState.RepeatedListVectorState
-
- RepeatedMapJsonConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.easy.json.JsonRecordWriter.RepeatedMapJsonConverter
-
- RepeatedMapParquetConverter(int, String, FieldReader) - Constructor for class org.apache.drill.exec.store.parquet.ParquetRecordWriter.RepeatedMapParquetConverter
-
- RepeatedVectorState - Class in org.apache.drill.exec.physical.rowSet.impl
-
Vector state for a scalar array (repeated scalar) vector.
- RepeatedVectorState(ArrayWriter, RepeatedValueVector) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.RepeatedVectorState
-
- RepeatedVectorTester(OperatorFixture) - Constructor for class org.apache.drill.test.rowSet.test.PerformanceTool.RepeatedVectorTester
-
- RepeatString() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.RepeatString
-
- repetitionLevel - Variable in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnTypeMetadata_v3
-
- Replace() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Replace
-
- 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.FragmentContext
-
- 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(Project, Project) - Static method in class org.apache.drill.exec.planner.logical.DrillMergeProjectRule
-
The purpose of the replace() method is to allow the caller to replace a 'top' and 'bottom' project with
a single merged project with the assumption that caller knows exactly the semantics/correctness of merging
the two projects.
- 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
-
- replaceMetaDataContents(File, File, String) - Method in class org.apache.drill.test.BaseDirTestWatcher
-
This is a convenience method that replaces placeholders in test parquet metadata files.
- ReplaceMethodInvoke - Class in org.apache.drill.exec.compile.bytecode
-
- ReplaceMethodInvoke() - Constructor for class org.apache.drill.exec.compile.bytecode.ReplaceMethodInvoke
-
- 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
-
- requestedCols() - Method in class org.apache.drill.exec.physical.impl.scan.project.ScanLevelProjection
-
Return the set of columns from the SELECT list
- RequestedColumnImpl - Class in org.apache.drill.exec.physical.rowSet.project
-
Represents one name element.
- RequestedColumnImpl(RequestedTuple, String) - Constructor for class org.apache.drill.exec.physical.rowSet.project.RequestedColumnImpl
-
- RequestedTuple - Interface in org.apache.drill.exec.physical.rowSet.project
-
Represents the set of columns projected for a tuple (row or map.)
The projected columns might themselves be columns, so returns a
projection set for such columns.
- RequestedTuple.RequestedColumn - Interface in org.apache.drill.exec.physical.rowSet.project
-
Plan-time properties of a requested column.
- RequestedTupleImpl - Class in org.apache.drill.exec.physical.rowSet.project
-
Represents an explicit projection at some tuple level.
- RequestedTupleImpl() - Constructor for class org.apache.drill.exec.physical.rowSet.project.RequestedTupleImpl
-
- RequestedTupleImpl(RequestedColumnImpl) - Constructor for class org.apache.drill.exec.physical.rowSet.project.RequestedTupleImpl
-
- requestFragmentStatus(BitControl.FragmentStatus) - Method in class org.apache.drill.exec.work.batch.ControlMessageHandler
-
- RequestProfile(UserBitShared.QueryId) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.RequestProfile
-
- requestQueryCancel(UserBitShared.QueryId) - Method in class org.apache.drill.exec.work.batch.ControlMessageHandler
-
- requestQueryProfile(UserBitShared.QueryId) - Method in class org.apache.drill.exec.rpc.control.ControlTunnel
-
- requestQueryStatus(UserBitShared.QueryId) - Method in class org.apache.drill.exec.work.batch.ControlMessageHandler
-
- Required() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsFalse.Required
-
- Required() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNotFalse.Required
-
- Required() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsNotTrue.Required
-
- Required() - Constructor for class org.apache.drill.exec.expr.fn.impl.IsTrue.Required
-
- Required() - Constructor for class org.apache.drill.exec.expr.fn.impl.Not.Required
-
- RequiredVectorTester(OperatorFixture) - Constructor for class org.apache.drill.test.rowSet.test.PerformanceTool.RequiredVectorTester
-
- RequiredWriterTester(OperatorFixture) - Constructor for class org.apache.drill.test.rowSet.test.PerformanceTool.RequiredWriterTester
-
- 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
-
- 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 interface org.apache.drill.exec.physical.impl.common.HashTable
-
Clears all the memory used by the
HashTable
and re-initializes it.
- 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() - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple
-
During planning, discard a partial plan to allow reusing the same (root) tuple
for multiple projection plans.
- reset() - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- 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.batchsizing.BatchSizingMemoryUtil.VectorMemoryUsageInfo
-
- 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.store.parquet.TestPushDownAndPruningForDecimal
-
- reset() - Method in class org.apache.drill.exec.store.parquet.WrapAroundCounter
-
- reset() - Method in class org.apache.drill.exec.util.filereader.BufferedDirectBufInputStream
-
- reset() - Method in class org.apache.drill.exec.vector.complex.impl.VectorContainerWriter
-
- reset() - Method in class org.apache.drill.test.TestBuilder.CSVTestBuilder
-
- reset() - Method in class org.apache.drill.test.TestBuilder
-
- RESET_HJ - Static variable in class org.apache.drill.exec.physical.impl.join.JoinTestBase
-
- RESET_JOIN_OPTIMIZATION - Static variable in class org.apache.drill.exec.physical.impl.join.JoinTestBase
-
- resetAllocation() - Method in class org.apache.drill.exec.planner.fragment.Wrapper
-
- resetAllSessionOptions() - Method in class org.apache.drill.exec.server.TestOptions
-
- 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
-
- resetDrillbitCount() - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- resetGroupIndex() - Method in interface org.apache.drill.exec.physical.impl.flatten.Flattener
-
- resetGroupIndex() - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenTemplate
-
- resetGroupIndex() - Method in interface org.apache.drill.exec.physical.impl.unnest.Unnest
-
Reset the index at which the incoming vector is being processed.
- resetGroupIndex() - Method in class org.apache.drill.exec.physical.impl.unnest.UnnestImpl
-
- resetJoinOptions() - Static method in class org.apache.drill.exec.physical.impl.join.JoinTestBase
-
Allows to reset session options of custom join operators
- 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
-
- resetOption() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- 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
-
Cleanup the old state of queue and recreate a new one with HyperContainer containing vectors in input container
and the corresponding indexes (in SV4 format) from input SelectionVector4
- 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
-
- resetSession(String) - Method in class org.apache.drill.test.ClientFixture
-
Reset a system option
- resetSessionOption(String) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- resetSliceCount() - Static method in class org.apache.drill.exec.expr.TestLogicalExprSerDe
-
- resetSystem(String) - Method in class org.apache.drill.test.ClientFixture
-
- resetUgi() - Static method in class org.apache.hadoop.security.UgiTestUtil
-
- 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
-
- resolve(TupleMetadata, ResolvedTuple) - Method in class org.apache.drill.exec.physical.impl.scan.project.SchemaSmoother
-
- resolveColumn(ColumnProjection, ResolvedTuple, TupleMetadata) - Method in interface org.apache.drill.exec.physical.impl.scan.project.SchemaLevelProjection.SchemaProjectionResolver
-
- ResolvedColumn - Class in org.apache.drill.exec.physical.impl.scan.project
-
A resolved column has a name, and a specification for how to project
data from a source vector to a vector in the final output container.
- ResolvedColumn(VectorSource, int) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.ResolvedColumn
-
- ResolvedMap(ResolvedMapColumn) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedMap
-
- ResolvedMapArray(ResolvedMapColumn) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedMapArray
-
- ResolvedMapColumn - Class in org.apache.drill.exec.physical.impl.scan.project
-
Represents a column which is implicitly a map (because it has children
in the project list), but which does not match any column in the table.
- ResolvedMapColumn(ResolvedTuple, String) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.ResolvedMapColumn
-
- ResolvedMapColumn(ResolvedTuple, MaterializedField, int) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.ResolvedMapColumn
-
- ResolvedNullColumn - Class in org.apache.drill.exec.physical.impl.scan.project
-
Projected column that serves as both a resolved column (provides projection
mapping) and a null column spec (provides the information needed to create
the required null vectors.)
- ResolvedNullColumn(String, TypeProtos.MajorType, VectorSource, int) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.ResolvedNullColumn
-
- resolveDrillType(Map<String, SchemaElement>, OptionManager) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetColumnMetadata
-
- ResolvedRow(NullColumnBuilder) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedRow
-
- ResolvedSingleMap(ResolvedMapColumn) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedSingleMap
-
- ResolvedTableColumn - Class in org.apache.drill.exec.physical.impl.scan.project
-
Column that matches one provided by the table.
- ResolvedTableColumn(String, MaterializedField, VectorSource, int) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.ResolvedTableColumn
-
- ResolvedTuple - Class in org.apache.drill.exec.physical.impl.scan.project
-
Drill rows are made up of a tree of tuples, with the row being the root
tuple.
- ResolvedTuple(NullColumnBuilder) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple
-
- ResolvedTuple.ResolvedMap - Class in org.apache.drill.exec.physical.impl.scan.project
-
Represents a map implied by the project list, whether or not the map
actually appears in the table schema.
- ResolvedTuple.ResolvedMapArray - Class in org.apache.drill.exec.physical.impl.scan.project
-
Represents a map tuple (not the map column, rather the value of the
map column.) When projecting, we create a new repeated map vector,
but share the offsets vector from input to output.
- ResolvedTuple.ResolvedRow - Class in org.apache.drill.exec.physical.impl.scan.project
-
Represents the top-level tuple which is projected to a
vector container.
- ResolvedTuple.ResolvedSingleMap - Class in org.apache.drill.exec.physical.impl.scan.project
-
- resolveHash(LogicalExpression, TypeProtos.DataMode, FunctionImplementationRegistry) - Method in class org.apache.drill.exec.physical.impl.TestSimpleFunctions
-
- 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
-
- resolver() - Method in interface org.apache.drill.exec.physical.impl.scan.project.MetadataManager
-
- resolver() - Method in class org.apache.drill.exec.physical.impl.scan.project.NoOpMetadataManager
-
- resolvers - Variable in class org.apache.drill.exec.physical.impl.scan.project.SchemaLevelProjection
-
- resolvers(SchemaLevelProjection.SchemaProjectionResolver...) - Static method in class org.apache.drill.exec.physical.impl.scan.ScanTestUtils
-
- ResolverTypePrecedence - Class in org.apache.drill.exec.resolver
-
- ResolverTypePrecedence() - Constructor for class org.apache.drill.exec.resolver.ResolverTypePrecedence
-
- resolveSpecial(ResolvedTuple, ColumnProjection, TupleMetadata) - Method in class org.apache.drill.exec.physical.impl.scan.project.SchemaLevelProjection
-
- 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.
- resource(String) - Method in class org.apache.drill.test.ConfigBuilder
-
Use the given configuration file, stored as a resource, to initialize
the Drill config.
- 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
-
- restClientBuilder() - Method in class org.apache.drill.test.ClusterFixture
-
- restClientFixture - Variable in class org.apache.drill.test.ClusterFixture
-
- restClientFixture() - Method in class org.apache.drill.test.ClusterFixture
-
- RestClientFixture - Class in org.apache.drill.test
-
Represents a client for the Drill Rest API.
- RestClientFixture.Builder - Class in org.apache.drill.test
-
A builder for the rest client.
- restore() - Static method in class org.apache.drill.exec.store.store.TestDisabledPlugin
-
- restoreScalarReplacementOption(Drillbit, String) - Static method in class org.apache.drill.test.QueryTestUtil
-
Restore the original scalar replacement option returned from
setupScalarReplacementOption().
- resultArrived(ByteBuf) - Method in class org.apache.drill.exec.rpc.user.QueryResultHandler
-
- results - Variable in class org.apache.drill.exec.server.rest.WebUserConnection
-
- results() - Method in class org.apache.drill.test.QueryBuilder
-
Run the query and return a list of the result batches.
- resultSchema - Static variable in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
- resultSchemaNoGroupBy - Static variable in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
- resultSet() - Method in class org.apache.drill.test.QueryBuilder
-
- ResultSetLoader - Interface in org.apache.drill.exec.physical.rowSet
-
Builds a result set (series of zero or more row sets) based on a defined
schema which may
evolve (expand) over time.
- ResultSetLoaderImpl - Class in org.apache.drill.exec.physical.rowSet.impl
-
Implementation of the result set loader.
- ResultSetLoaderImpl(BufferAllocator, ResultSetLoaderImpl.ResultSetOptions) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- ResultSetLoaderImpl(BufferAllocator) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- ResultSetLoaderImpl.ResultSetOptions - Class in org.apache.drill.exec.physical.rowSet.impl
-
Read-only set of options for the result set loader.
- ResultSetOptions() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl.ResultSetOptions
-
- ResultSetOptions(OptionBuilder) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl.ResultSetOptions
-
- ResultVectorCache - Interface in org.apache.drill.exec.physical.rowSet
-
Interface for a cache that implements "vector persistence" across
multiple result set loaders.
- ResultVectorCacheImpl - Class in org.apache.drill.exec.physical.rowSet.impl
-
Manages an inventory of value vectors used across row batch readers.
- ResultVectorCacheImpl(BufferAllocator) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.ResultVectorCacheImpl
-
- ResultVectorCacheImpl(BufferAllocator, boolean) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.ResultVectorCacheImpl
-
- resume() - Method in class org.apache.drill.exec.work.foreman.Foreman
-
Resume the query.
- resumeFragment(ExecProtos.FragmentHandle) - Method in class org.apache.drill.exec.work.batch.ControlMessageHandler
-
- resumeList() - Method in class org.apache.drill.test.rowSet.schema.MapBuilder
-
- resumeList() - Method in class org.apache.drill.test.rowSet.schema.RepeatedListBuilder
-
- resumeMap() - Method in class org.apache.drill.test.rowSet.schema.MapBuilder
-
- resumeMap() - Method in class org.apache.drill.test.rowSet.schema.RepeatedListBuilder
-
- resumeMap() - Method in class org.apache.drill.test.rowSet.schema.UnionBuilder
-
- 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
-
- resumeSchema() - Method in class org.apache.drill.test.rowSet.schema.MapBuilder
-
- resumeSchema() - Method in class org.apache.drill.test.rowSet.schema.RepeatedListBuilder
-
- resumeSchema() - Method in class org.apache.drill.test.rowSet.schema.UnionBuilder
-
- resumeUnion() - Method in class org.apache.drill.test.rowSet.schema.MapBuilder
-
- resumeUnion() - Method in class org.apache.drill.test.rowSet.schema.RepeatedListBuilder
-
- resumeUnion() - Method in class org.apache.drill.test.rowSet.schema.UnionBuilder
-
- 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
-
- retainBuffers(int) - Method in class org.apache.drill.exec.work.filter.RuntimeFilterWritable
-
- 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_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.
- RETURN_RESULT_SET_FOR_DDL - Static variable in class org.apache.drill.exec.ExecConstants
-
- RETURN_RESULT_SET_FOR_DDL_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
-
- returnType - Variable in class org.apache.drill.exec.store.sys.FunctionsIterator.FunctionInfo
-
- ReturnTypeInference - Interface in org.apache.drill.exec.expr.fn.output
-
- 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
-
- reverse(SelectionVector2) - Static method in class org.apache.drill.test.rowSet.RowSetUtilities
-
Reverse a row set by reversing the entries in an SV2.
- ReverseString() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.ReverseString
-
- revisedTableSchema() - Method in class org.apache.drill.exec.physical.impl.scan.project.SmoothingProjection
-
- rewrite(RexNode) - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap
-
- 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
-
- rewriteEqualOnCharToLike(RexNode, Map<RexNode, LogicalExpression>) - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap
-
- rewriteFunctionalRex(IndexCallContext, DrillParseContext, DrillProjectRelBase, RelNode, RexNode, RelDataType, FunctionalIndexInfo) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
A RexNode forest with three RexNodes for expressions "cast(a.q as int) * 2, b+c, concat(a.q, " world")"
on Scan RowType('a', 'b', 'c') will be like this:
(0)Call:"*" Call:"concat"
/ \ / \
(1)Call:CAST 2 Call:"+" (5)Call:ITEM ' world'
/ \ / \ / \
(2)Call:ITEM TYPE:INT (3)$1 (4)$2 $0 'q'
/ \
$0 'q'
So for above expressions, when visiting the RexNode trees using PathInExpr, we could mark indexed expressions in the trees,
as shown in the diagram above are the node (1),
then collect the schema paths in the indexed expression but found out of the indexed expression -- node (5),
and other regular schema paths (3) (4)
- rewriteFunctionalRowType(RelNode, IndexCallContext, FunctionalIndexInfo) - Static method in class org.apache.drill.exec.planner.index.FunctionalIndexHelper
-
- rewriteFunctionalRowType(RelNode, IndexCallContext, FunctionalIndexInfo, Collection<SchemaPath>) - Static method in class org.apache.drill.exec.planner.index.FunctionalIndexHelper
-
if a field in rowType serves only the to-be-replaced column(s), we should replace it with new name "$1",
otherwise we should keep this dataTypeField and add a new one for "$1"
- rewriteFunctionColumn(List<SchemaPath>, FunctionalIndexInfo, List<SchemaPath>) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
For IndexGroupScan, if a column is only appeared in the should-be-renamed function,
this column is to-be-replaced column, we replace that column(schemaPath) from 'a.b'
to '$1' in the list of SchemaPath.
- 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
-
- rewriteUnnestWithComplexExprs(RelNode) - Static method in class org.apache.drill.exec.planner.sql.handlers.ComplexUnnestVisitor
-
Rewrites rel node tree and moves non-RexFieldAccess
rex node from the project
below Uncollect
to the left side of the Correlate
.
- rewriteWithMap(RexNode, Map<RexNode, LogicalExpression>) - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap
-
- rewrittenFields - Variable in class org.apache.drill.exec.physical.impl.scan.project.SmoothingProjection
-
- RexFieldsTransformer(RexBuilder, Map<Integer, Integer>) - Constructor for class org.apache.drill.exec.planner.common.DrillRelOptUtil.RexFieldsTransformer
-
- RexNodeBasedHashExpressionCreatorHelper(RexBuilder) - Constructor for class org.apache.drill.exec.planner.physical.HashPrelUtil.RexNodeBasedHashExpressionCreatorHelper
-
- RexReplace(Map<RexNode, RexNode>) - Constructor for class org.apache.drill.exec.planner.index.SimpleRexRemap.RexReplace
-
- RexSeparator - Class in org.apache.drill.exec.planner.index
-
- RexSeparator(List<LogicalExpression>, RelNode, RexBuilder) - Constructor for class org.apache.drill.exec.planner.index.RexSeparator
-
- RexToDrill(DrillParseContext, RelNode) - Constructor for class org.apache.drill.exec.planner.logical.DrillOptiq.RexToDrill
-
- RexToDrill(DrillParseContext, RelDataType, RexBuilder) - Constructor for class org.apache.drill.exec.planner.logical.DrillOptiq.RexToDrill
-
- RexToDrillExt(DrillParseContext, DrillProjectRelBase, RelNode) - Constructor for class org.apache.drill.exec.planner.index.RexToExpression.RexToDrillExt
-
- RexToExpression - Class in org.apache.drill.exec.planner.index
-
This class is an enhanced version for DrillOptiq,
1, it can convert expressions in one more layer(project that have expression) above project-scan,
while DrillOptiq can only convert expressions directly reference scan's row type,
2, it can record the generated LogicalExpression of each rexNode in the rexNode tree for future reference
this result can serve future rewrite that need to locate particular LogicalExpressions
- RexToExpression() - Constructor for class org.apache.drill.exec.planner.index.RexToExpression
-
- RexToExpression.RexToDrillExt - Class in org.apache.drill.exec.planner.index
-
- rexVisitor - Variable in class org.apache.drill.exec.planner.physical.visitor.LateralUnnestRowIDVisitor.CorrelateVarReplacer
-
- 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() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Right
-
- right - Variable in class org.apache.drill.exec.physical.base.AbstractJoinPop
-
- right - Variable in class org.apache.drill.exec.physical.impl.join.JoinStatus
-
- right - Variable in class org.apache.drill.exec.record.AbstractBinaryRecordBatch
-
- RIGHT_DIR - Static variable in class org.apache.drill.exec.physical.impl.join.TestMergeJoinWithSchemaChanges
-
- RIGHT_INDEX - Static variable in class org.apache.drill.exec.record.AbstractBinaryRecordBatch
-
- RIGHT_INDEX - Static variable in class org.apache.drill.exec.record.JoinBatchMemoryManager
-
- 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_JOIN_TYPE - Static variable in class org.apache.drill.exec.physical.impl.join.JoinTestBase
-
- RIGHT_MAPPING - Variable in class org.apache.drill.exec.physical.impl.xsort.managed.BaseSortWrapper
-
- rightKeys - Variable in class org.apache.drill.exec.planner.common.DrillJoinRelBase
-
- rightShiftColsInRowType(RelDataType) - Static method in class org.apache.drill.exec.planner.common.DrillRelOptUtil
-
For a given row type return a map between old field indices and one index right shifted fields.
- rightUpstream - Variable in class org.apache.drill.exec.record.AbstractBinaryRecordBatch
-
- rm - Variable in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedResourceAllocator
-
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.drill.exec.planner.logical.DrillTable
-
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.drill.exec.planner.logical.DrillTranslatableTable
-
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.drill.exec.planner.logical.DrillViewTable
-
- rollover() - Method in class org.apache.drill.exec.physical.rowSet.impl.ColumnState.BaseContainerColumnState
-
- rollover() - Method in class org.apache.drill.exec.physical.rowSet.impl.ColumnState
-
A column within the row batch overflowed.
- rollover() - Method in class org.apache.drill.exec.physical.rowSet.impl.ContainerState
-
A column within the row batch overflowed.
- rollover(int) - Method in class org.apache.drill.exec.physical.rowSet.impl.ListState.ListVectorState
-
- rollover(int) - Method in class org.apache.drill.exec.physical.rowSet.impl.NullableVectorState
-
- rollover(int) - Method in class org.apache.drill.exec.physical.rowSet.impl.NullVectorState
-
- rollover(int) - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedListState.RepeatedListVectorState
-
- rollover(int) - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedVectorState
-
The column is a scalar or an array of scalars.
- rollover(int) - Method in class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState
-
A column within the row batch overflowed.
- rollover(int) - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState.MapVectorState
-
- rollover(int) - Method in class org.apache.drill.exec.physical.rowSet.impl.UnionState.UnionVectorState
-
- rollover(int) - Method in interface org.apache.drill.exec.physical.rowSet.impl.VectorState
-
A vector has overflowed.
- rollover() - Method in class org.apache.drill.test.rowSet.test.TestFixedWidthWriter.TestIndex
-
- 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.physical.unit.MiniPlanUnitTestBase.MiniPlanTestBuilder
-
- root(RecordBatch) - Method in class org.apache.drill.exec.physical.unit.MiniPlanUnitTestBase.MiniPlanTestBuilder
-
Specify the root operator for a MiniPlan.
- root - Static variable in class org.apache.drill.exec.store.parquet.ParquetSimpleTestFileGenerator
-
- root() - Method in class org.apache.drill.exec.work.QueryWorkUnit.MinorFragmentDefn
-
- ROOT_SCHEMA - Static variable in class org.apache.drill.exec.util.StoragePluginTestUtils
-
- ROOT_SCHEMA_NAME - Variable in class org.apache.drill.exec.store.ischema.Records.File
-
- 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
-
Functionality
- RootFragmentContext - Interface in org.apache.drill.exec.ops
-
- 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
-
- rootLogger(Level) - Method in class org.apache.drill.test.LogFixture.LogFixtureBuilder
-
Set the desired log level on the root logger.
- rootProjection() - Method in class org.apache.drill.exec.physical.impl.scan.project.ScanLevelProjection
-
- rootState() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- rootWriter() - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState.RowState
-
- RootWriterFixture(TupleMetadata, List<AbstractObjectWriter>) - Constructor for class org.apache.drill.test.rowSet.test.DummyWriterTest.RootWriterFixture
-
- rotateBlock() - Method in class org.apache.drill.exec.expr.ClassGenerator
-
- RoundBigInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundBigInt
-
- RoundFloat4() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundFloat4
-
- RoundFloat8() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundFloat8
-
- 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.RoundFloat4 - Class in org.apache.drill.exec.expr.fn.impl.conv
-
- RoundFunctions.RoundFloat8 - Class in org.apache.drill.exec.expr.fn.impl.conv
-
- RoundFunctions.RoundInt - Class in org.apache.drill.exec.expr.fn.impl.conv
-
- RoundFunctions.RoundSmallInt - Class in org.apache.drill.exec.expr.fn.impl.conv
-
- RoundFunctions.RoundTinyInt - Class in org.apache.drill.exec.expr.fn.impl.conv
-
- RoundFunctions.RoundUInt1 - Class in org.apache.drill.exec.expr.fn.impl.conv
-
- RoundFunctions.RoundUInt2 - Class in org.apache.drill.exec.expr.fn.impl.conv
-
- RoundFunctions.RoundUInt4 - Class in org.apache.drill.exec.expr.fn.impl.conv
-
- RoundFunctions.RoundUInt8 - Class in org.apache.drill.exec.expr.fn.impl.conv
-
- RoundInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundInt
-
- RoundSmallInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundSmallInt
-
- RoundTinyInt() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundTinyInt
-
- RoundUInt1() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt1
-
- RoundUInt2() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt2
-
- RoundUInt4() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt4
-
- RoundUInt8() - Constructor for class org.apache.drill.exec.expr.fn.impl.conv.RoundFunctions.RoundUInt8
-
- roundUpToPowerOf2(long) - Static method in class org.apache.drill.exec.physical.impl.join.BatchSizePredictorImpl
-
- ROUTING_V6 - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
-
- row1() - Static method in class org.apache.drill.exec.physical.impl.svremover.AbstractGenericCopierTest
-
- row2() - Static method in class org.apache.drill.exec.physical.impl.svremover.AbstractGenericCopierTest
-
- row3() - Static method in class org.apache.drill.exec.physical.impl.svremover.AbstractGenericCopierTest
-
- row4() - Static method in class org.apache.drill.exec.physical.impl.svremover.AbstractGenericCopierTest
-
- row5() - Static method in class org.apache.drill.exec.physical.impl.svremover.AbstractGenericCopierTest
-
- ROW_COUNT - Static variable in class org.apache.drill.test.rowSet.test.PerformanceTool
-
- ROW_COUNT - Static variable in class org.apache.drill.test.rowSet.test.TestFillEmpties
-
- row_number - Variable in class org.apache.drill.exec.physical.impl.window.Partition
-
- rowAggregated() - Method in class org.apache.drill.exec.physical.impl.window.Partition
-
- rowArrived(QueryDataBatch) - Method in class org.apache.drill.SingleRowListener
-
A record has arrived and is ready for access.
- rowCount() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- rowCount() - Method in class org.apache.drill.exec.physical.rowSet.impl.RowSetLoaderImpl
-
- rowCount - Variable in class org.apache.drill.exec.physical.rowSet.model.ReaderIndex
-
- rowCount() - Method in interface org.apache.drill.exec.physical.rowSet.RowSetLoader
-
The number of rows in the current row set.
- rowCount() - Method in class org.apache.drill.exec.record.RecordBatchSizer
-
- rowCount - Variable in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.RowGroupMetadata_v1
-
- rowCount - Variable in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.RowGroupMetadata_v2
-
- rowCount - Variable in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.RowGroupMetadata_v3
-
- rowCount() - Method in class org.apache.drill.test.QueryRowSetIterator
-
- rowCount() - Method in class org.apache.drill.test.rowSet.AbstractRowSet
-
- rowCount() - Method in class org.apache.drill.test.rowSet.HyperRowSetImpl
-
- rowCount() - Method in interface org.apache.drill.test.rowSet.RowSet
-
- rowCount() - Method in interface org.apache.drill.test.rowSet.RowSetReader
-
Total number of rows in the row set.
- rowCount() - Method in class org.apache.drill.test.rowSet.RowSetReaderImpl
-
- ROWCOUNT_HUGE - Static variable in interface org.apache.drill.exec.planner.index.Statistics
-
- ROWCOUNT_UNKNOWN - Static variable in interface org.apache.drill.exec.planner.index.Statistics
-
- rowCountLimit - Variable in class org.apache.drill.exec.physical.rowSet.impl.OptionBuilder
-
- rowCountLimit - Variable in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl.ResultSetOptions
-
- RowGroupInfo - Class in org.apache.drill.exec.store.parquet
-
- RowGroupInfo(String, long, long, int, long) - Constructor for class org.apache.drill.exec.store.parquet.RowGroupInfo
-
- rowGroupInfos - Variable in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- RowGroupMetadata() - Constructor for class org.apache.drill.exec.store.parquet.metadata.MetadataBase.RowGroupMetadata
-
- RowGroupMetadata_v1() - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.RowGroupMetadata_v1
-
- RowGroupMetadata_v1(Long, Long, Long, Map<String, Float>, List<Metadata_V1.ColumnMetadata_v1>) - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.RowGroupMetadata_v1
-
- RowGroupMetadata_v2() - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.RowGroupMetadata_v2
-
- RowGroupMetadata_v2(Long, Long, Long, Map<String, Float>, List<Metadata_V2.ColumnMetadata_v2>) - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.RowGroupMetadata_v2
-
- RowGroupMetadata_v3() - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.RowGroupMetadata_v3
-
- RowGroupMetadata_v3(Long, Long, Long, Map<String, Float>, List<Metadata_V3.ColumnMetadata_v3>) - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.RowGroupMetadata_v3
-
- rowGroupReadEntries - Variable in class org.apache.drill.exec.store.parquet.AbstractParquetRowGroupScan
-
- 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.Metadata_V1.ParquetFileMetadata_v1
-
- rowGroups - Variable in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetFileMetadata_v2
-
- rowGroups - Variable in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetFileMetadata_v3
-
- rowHasData() - Method in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
-
- rowIndex() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- rowIndex() - Method in class org.apache.drill.exec.physical.rowSet.impl.RowSetLoaderImpl
-
- rowIndex() - Method in interface org.apache.drill.exec.physical.rowSet.RowSetLoader
-
The index of the current row.
- rowIndex() - Method in interface org.apache.drill.test.rowSet.RowSetWriter
-
- rowIndex() - Method in class org.apache.drill.test.rowSet.RowSetWriterImpl
-
- rowKeyColumns - Variable in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- RowKeyJoin - Interface in org.apache.drill.exec.physical.impl.join
-
Interface for a row key join
- RowKeyJoin.RowKeyJoinState - Enum in org.apache.drill.exec.physical.impl.join
-
Enum for RowKeyJoin internal state.
- ROWKEYJOIN_CONVERSION - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- ROWKEYJOIN_CONVERSION_SELECTIVITY_THRESHOLD - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- ROWKEYJOIN_CONVERSION_USING_HASHJOIN - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- RowKeyJoinBatch - Class in org.apache.drill.exec.physical.impl.join
-
- RowKeyJoinBatch(RowKeyJoinPOP, FragmentContext, RecordBatch, RecordBatch) - Constructor for class org.apache.drill.exec.physical.impl.join.RowKeyJoinBatch
-
- RowKeyJoinBatchCreator - Class in org.apache.drill.exec.physical.impl.join
-
- RowKeyJoinBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.join.RowKeyJoinBatchCreator
-
- RowKeyJoinCallContext - Class in org.apache.drill.exec.planner.logical
-
- RowKeyJoinCallContext(RelOptRuleCall, RowKeyJoinCallContext.RowKey, int, boolean, DrillJoin, DrillProjectRel, DrillFilterRel, DrillProjectRel, DrillScanRel) - Constructor for class org.apache.drill.exec.planner.logical.RowKeyJoinCallContext
-
- RowKeyJoinCallContext.RowKey - Enum in org.apache.drill.exec.planner.logical
-
- RowKeyJoinPOP - Class in org.apache.drill.exec.physical.config
-
- RowKeyJoinPOP(PhysicalOperator, PhysicalOperator) - Constructor for class org.apache.drill.exec.physical.config.RowKeyJoinPOP
-
- RowKeyJoinPrel - Class in org.apache.drill.exec.planner.physical
-
- RowKeyJoinPrel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType) - Constructor for class org.apache.drill.exec.planner.physical.RowKeyJoinPrel
-
- RowKeyJoinPrel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, boolean) - Constructor for class org.apache.drill.exec.planner.physical.RowKeyJoinPrel
-
- RowKeyJoinPrule - Class in org.apache.drill.exec.planner.physical
-
- RowKeyJoinRel - Class in org.apache.drill.exec.planner.logical
-
- RowKeyJoinRel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType) - Constructor for class org.apache.drill.exec.planner.logical.RowKeyJoinRel
-
- RowKeyJoinRel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, boolean) - Constructor for class org.apache.drill.exec.planner.logical.RowKeyJoinRel
-
- RowKeyJoinRel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, int) - Constructor for class org.apache.drill.exec.planner.logical.RowKeyJoinRel
-
- RowKeyJoinRel(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType, List<Integer>, List<Integer>) - Constructor for class org.apache.drill.exec.planner.logical.RowKeyJoinRel
-
- rows - Variable in class org.apache.drill.exec.server.rest.QueryWrapper.QueryResult
-
- rowSet() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestRowBatchMerger.RowSetSource
-
- rowSet(BatchSchema) - Method in class org.apache.drill.test.OperatorFixture
-
- rowSet(TupleMetadata) - Method in class org.apache.drill.test.OperatorFixture
-
- rowSet() - Method in class org.apache.drill.test.QueryBuilder
-
Run the query and return the first non-empty batch as a
DirectRowSet
object that can be inspected directly
by the code using a
RowSetReader
.
- RowSet - Interface in org.apache.drill.test.rowSet
-
A row set is a collection of rows stored as value vectors.
- RowSet.ExtendableRowSet - Interface in org.apache.drill.test.rowSet
-
Single row set which is empty and allows writing.
- RowSet.HyperRowSet - Interface in org.apache.drill.test.rowSet
-
Row set comprised of multiple single row sets, along with
an indirection vector (SV4).
- RowSet.HyperRowSetBuilder - Interface in org.apache.drill.test.rowSet
-
- RowSet.SingleRowSet - Interface in org.apache.drill.test.rowSet
-
Row set that manages a single batch of rows.
- rowSetBuilder(BatchSchema) - Method in class org.apache.drill.test.ClientFixture
-
- rowSetBuilder(BatchSchema) - Method in class org.apache.drill.test.OperatorFixture
-
- rowSetBuilder(TupleMetadata) - Method in class org.apache.drill.test.OperatorFixture
-
- RowSetBuilder - Class in org.apache.drill.test.rowSet
-
Fluent builder to quickly build up an row set (record batch)
programmatically.
- RowSetBuilder(BufferAllocator, BatchSchema) - Constructor for class org.apache.drill.test.rowSet.RowSetBuilder
-
- RowSetBuilder(BufferAllocator, TupleMetadata) - Constructor for class org.apache.drill.test.rowSet.RowSetBuilder
-
- RowSetBuilder(BufferAllocator, TupleMetadata, int) - Constructor for class org.apache.drill.test.rowSet.RowSetBuilder
-
- RowSetComparison - Class in org.apache.drill.test.rowSet
-
For testing, compare the contents of two row sets (record batches)
to verify that they are identical.
- RowSetComparison(RowSet) - Constructor for class org.apache.drill.test.rowSet.RowSetComparison
-
- RowSetComparison.ObjectComparator - Class in org.apache.drill.test.rowSet
-
- rowSetIterator() - Method in class org.apache.drill.test.QueryBuilder
-
- RowSetLoader - Interface in org.apache.drill.exec.physical.rowSet
-
Interface for writing values to a row set.
- RowSetLoaderImpl - Class in org.apache.drill.exec.physical.rowSet.impl
-
Implementation of the row set loader.
- RowSetLoaderImpl(ResultSetLoaderImpl, TupleMetadata) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.RowSetLoaderImpl
-
- RowSetPrinter - Class in org.apache.drill.test.rowSet
-
Print a row set in CSV-like format.
- RowSetPrinter(RowSet) - Constructor for class org.apache.drill.test.rowSet.RowSetPrinter
-
- RowSetReader - Interface in org.apache.drill.test.rowSet
-
Reader for all types of row sets.
- RowSetReaderBuilder() - Constructor for class org.apache.drill.test.rowSet.AbstractSingleRowSet.RowSetReaderBuilder
-
- RowSetReaderBuilder() - Constructor for class org.apache.drill.test.rowSet.HyperRowSetImpl.RowSetReaderBuilder
-
- RowSetReaderImpl - Class in org.apache.drill.test.rowSet
-
Reader implementation for a row set.
- RowSetReaderImpl(TupleMetadata, ReaderIndex, AbstractObjectReader[]) - Constructor for class org.apache.drill.test.rowSet.RowSetReaderImpl
-
- RowSetReaderImpl(TupleMetadata, ReaderIndex, List<AbstractObjectReader>) - Constructor for class org.apache.drill.test.rowSet.RowSetReaderImpl
-
- RowSetSource(RowSet.SingleRowSet) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.TestRowBatchMerger.RowSetSource
-
- RowSetTest - Class in org.apache.drill.test.rowSet.test
-
Test row sets.
- RowSetTest() - Constructor for class org.apache.drill.test.rowSet.test.RowSetTest
-
- RowSetTestUtils - Class in org.apache.drill.exec.physical.rowSet.impl
-
- RowSetUtilities - Class in org.apache.drill.test.rowSet
-
Various utilities useful for working with row sets, especially for testing.
- RowSetWriter - Interface in org.apache.drill.test.rowSet
-
Interface for writing values to a row set.
- RowSetWriterBuilder() - Constructor for class org.apache.drill.test.rowSet.DirectRowSet.RowSetWriterBuilder
-
- RowSetWriterImpl - Class in org.apache.drill.test.rowSet
-
Implementation of a row set writer.
- RowSetWriterImpl(RowSet.ExtendableRowSet, TupleMetadata, RowSetWriterImpl.WriterIndexImpl, List<AbstractObjectWriter>) - Constructor for class org.apache.drill.test.rowSet.RowSetWriterImpl
-
- rowStartIndex() - Method in class org.apache.drill.test.rowSet.test.TestFixedWidthWriter.TestIndex
-
- rowStartOffset() - Method in class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState.OffsetVectorState
-
- RowState(ResultSetLoaderImpl, ResultVectorCache) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TupleState.RowState
-
- Rpad() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Rpad
-
- RpadTwoArg() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.RpadTwoArg
-
- 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
-
- RR() - Constructor for class org.apache.drill.exec.expr.EscapeTest1.RR
-
- RR(int, int) - Constructor for class org.apache.drill.exec.expr.EscapeTest1.RR
-
- Rtrim() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Rtrim
-
- RtrimOneArg() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.RtrimOneArg
-
- RuleInstance - Interface in org.apache.drill.exec.planner
-
Contains rule instances which use custom RelBuilder.
- run() - Method in interface org.apache.drill.exec.cache.DistributedCache
-
- run(HashPartitionTest.HashPartitionTestCase) - Method in class org.apache.drill.exec.physical.impl.common.HashPartitionTest.HashPartitionFixture
-
- run() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortTestUtilities.CopierTester
-
- run() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl.SortTestFixture
-
- run() - Method in class org.apache.drill.exec.server.Drillbit
-
- run(WorkManager, WebUserConnection) - Method in class org.apache.drill.exec.server.rest.QueryWrapper
-
- run(String, Logger, List<TimedCallable<V>>, int) - Static method in class org.apache.drill.exec.store.TimedCallable
-
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
-
- run(String, Object...) - Static method in class org.apache.drill.test.ClusterTest
-
- run() - Method in class org.apache.drill.test.DrillTestWrapper
-
- run() - Method in class org.apache.drill.test.QueryBuilder
-
Run the query returning just a summary of the results: record count,
batch count and run time.
- RUN_ADVANCED_TESTS - Static variable in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
enable this if you have the following files:
- /tmp/yelp_academic_dataset_business.json
- /tmp/mapkv.json
- /tmp/drill1665.json
- /tmp/bigfile.json
- runAndLog(String) - Method in class org.apache.drill.test.ClusterTest
-
- runAndPrint(String) - Method in class org.apache.drill.test.ClusterTest
-
- runAndWait(UserResultsListener) - Method in class org.apache.drill.test.QueryBuilder
-
- runCallableAs(UserGroupInformation, Callable<RESULT>) - Method in interface org.apache.drill.exec.ops.OperatorContext
-
Run the callable as the given proxy user.
- runCallableAs(UserGroupInformation, Callable<RESULT>) - Method in class org.apache.drill.test.OperatorFixture.MockOperatorContext
-
- runCommand(RpcCommand) - Method in class org.apache.drill.exec.rpc.control.LocalControlConnectionManager
-
- runInner() - Method in class org.apache.drill.exec.store.TimedCallable
-
- runJSONScanPopFragment() - Method in class org.apache.drill.exec.physical.impl.TestSimpleFragmentRun
-
- runJumboBatchTest(OperatorFixture, int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl
-
Set up and run a test for "jumbo" batches, and time the run.
- runLargeSortTest(OperatorFixture, TestSortImpl.DataGenerator, TestSortImpl.DataValidator) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl
-
Run a full-blown sort test with multiple input batches.
- runNoExchangeFragment() - Method in class org.apache.drill.exec.physical.impl.TestSimpleFragmentRun
-
- runQueriesAndLog(String) - Method in class org.apache.drill.test.ClientFixture
-
Run zero or more queries and log the output in TSV format.
- runQueriesAndPrint(String) - Method in class org.apache.drill.test.ClientFixture
-
Run zero or more queries and print the output in TSV format.
- 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)
- RunRootExec - Class in org.apache.drill.exec
-
- RunRootExec() - Constructor for class org.apache.drill.exec.RunRootExec
-
- runSorterTest(RowSet.SingleRowSet, RowSet.SingleRowSet) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
- runSorterTest(Sort, RowSet.SingleRowSet, RowSet.SingleRowSet) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
- runSQL(String) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- runSqlSilently(String) - Method in class org.apache.drill.test.ClientFixture
-
Run SQL silently (discard results.)
- runTest(Object[], String, String) - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunction
-
- runTest(String, String, Object[]) - Method in class org.apache.drill.exec.fn.impl.TestNewAggregateFunctions
-
- runTest(Object[], String) - Method in class org.apache.drill.exec.fn.impl.TestNewMathFunctions
-
- runTest(String, int) - Method in class org.apache.drill.exec.physical.impl.TestComparisonFunctions
-
- runTest(Object[], String) - Method in class org.apache.drill.exec.physical.impl.TestImplicitCastFunctions
-
- runTest(Object[], String) - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- runTest() - Method in class org.apache.drill.test.rowSet.test.PerformanceTool.PerfTester
-
- runTestAndValidate(String, String, String, String) - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- runTestsOnFile(String, UserBitShared.QueryType, String[], long[]) - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- RuntimeFilterBatchCreator - Class in org.apache.drill.exec.physical.impl.filter
-
- RuntimeFilterBatchCreator() - Constructor for class org.apache.drill.exec.physical.impl.filter.RuntimeFilterBatchCreator
-
- RuntimeFilterDef - Class in org.apache.drill.exec.work.filter
-
- RuntimeFilterDef(boolean, boolean, List<BloomFilterDef>, boolean, long) - Constructor for class org.apache.drill.exec.work.filter.RuntimeFilterDef
-
- RuntimeFilterParallelismCollector() - Constructor for class org.apache.drill.exec.work.filter.RuntimeFilterRouter.RuntimeFilterParallelismCollector
-
- RuntimeFilterPOP - Class in org.apache.drill.exec.physical.config
-
- RuntimeFilterPOP(PhysicalOperator, long) - Constructor for class org.apache.drill.exec.physical.config.RuntimeFilterPOP
-
- RuntimeFilterPrel - Class in org.apache.drill.exec.planner.physical
-
- RuntimeFilterPrel(Prel, long) - Constructor for class org.apache.drill.exec.planner.physical.RuntimeFilterPrel
-
- RuntimeFilterPrel(RelOptCluster, RelTraitSet, RelNode, long) - Constructor for class org.apache.drill.exec.planner.physical.RuntimeFilterPrel
-
- RuntimeFilterRecordBatch - Class in org.apache.drill.exec.physical.impl.filter
-
A RuntimeFilterRecordBatch steps over the ScanBatch.
- RuntimeFilterRecordBatch(RuntimeFilterPOP, RecordBatch, FragmentContext) - Constructor for class org.apache.drill.exec.physical.impl.filter.RuntimeFilterRecordBatch
-
- RuntimeFilterRecordBatch.Metric - Enum in org.apache.drill.exec.physical.impl.filter
-
- RuntimeFilterReporter - Class in org.apache.drill.exec.work.filter
-
A reporter to send out the bloom filters to their receivers.
- RuntimeFilterReporter(ExecutorFragmentContext) - Constructor for class org.apache.drill.exec.work.filter.RuntimeFilterReporter
-
- RuntimeFilterRouter - Class in org.apache.drill.exec.work.filter
-
This class manages the RuntimeFilter routing information of the pushed down join predicate
of the partitioned exchange HashJoin.
- RuntimeFilterRouter(QueryWorkUnit, DrillbitContext) - Constructor for class org.apache.drill.exec.work.filter.RuntimeFilterRouter
-
This class maintains context for the runtime join push down's filter management.
- RuntimeFilterRouter.RuntimeFilterParallelismCollector - Class in org.apache.drill.exec.work.filter
-
Collect the runtime filter parallelism related information such as join node major/minor fragment id , probe side scan node's
major/minor fragment id, probe side node's endpoints.
- RuntimeFilterSink - Class in org.apache.drill.exec.work.filter
-
This sink receives the RuntimeFilters from the netty thread,
aggregates them in an async thread, broadcast the final aggregated
one to the RuntimeFilterRecordBatch.
- RuntimeFilterSink(DrillbitContext, SendingAccountor) - Constructor for class org.apache.drill.exec.work.filter.RuntimeFilterSink
-
- RuntimeFilterVisitor - Class in org.apache.drill.exec.planner.physical.visitor
-
This visitor does two major things:
1) Find the possible HashJoinPrel to add a RuntimeFilterDef to it.
- RuntimeFilterWritable - Class in org.apache.drill.exec.work.filter
-
A binary wire transferable representation of the RuntimeFilter which contains
the runtime filter definition and its corresponding data.
- RuntimeFilterWritable(BitData.RuntimeFilterBDef, DrillBuf...) - Constructor for class org.apache.drill.exec.work.filter.RuntimeFilterWritable
-
- runTimeMs() - Method in class org.apache.drill.test.QueryBuilder.QuerySummary
-
- RuntimeOption(String, Object) - Constructor for class org.apache.drill.test.ClusterFixtureBuilder.RuntimeOption
-
- RuntimeOverridden - Annotation Type in org.apache.drill.exec.compile.sig
-
Describes the field will provide output from the given function.
- runTypeTest(OperatorFixture, TypeProtos.MinorType) - Static method in class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- runWideRowsTest(OperatorFixture, int, int) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl
-
Run a test using wide rows.
- 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.record.RecordBatchSizer
-
- safeDivide(int, int) - Static method in class org.apache.drill.exec.record.RecordBatchSizer
-
- safeDivide(int, float) - Static method in class org.apache.drill.exec.record.RecordBatchSizer
-
- safeDivide(int, double) - Static method in class org.apache.drill.exec.record.RecordBatchSizer
-
- SameInOutLengthReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
-
- 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
-
- satisfies(RelTrait) - Method in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
-
- satisfiesCollation() - Method in interface org.apache.drill.exec.planner.index.IndexProperties
-
- satisfiesCollation() - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- save() - Method in class org.apache.drill.exec.physical.rowSet.impl.RowSetLoaderImpl
-
- save() - Method in interface org.apache.drill.exec.physical.rowSet.RowSetLoader
-
Saves the current row and moves to the next row.
- save() - Method in interface org.apache.drill.test.rowSet.RowSetWriter
-
Saves the current row and moves to the next row.
- save() - Method in class org.apache.drill.test.rowSet.RowSetWriterImpl
-
- 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
-
- saveProfiles() - Method in class org.apache.drill.test.ClusterFixtureBuilder
-
Enable saving of query profiles.
- saveRow() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
Finalize the current row.
- sawWildcard - Variable in class org.apache.drill.exec.physical.impl.scan.project.ScanLevelProjection
-
- SCALAR_REPLACEMENT_OPTION - Static variable in class org.apache.drill.exec.ExecConstants
-
- SCALAR_REPLACEMENT_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
-
- 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 - Variable in class org.apache.drill.exec.record.MajorTypeSerDe.MajorTypeHolder
-
- scale - Variable in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- scale() - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- scale() - Method in class org.apache.drill.exec.record.metadata.PrimitiveColumnMetadata
-
- scale - Variable in class org.apache.drill.exec.store.mock.MockTableDef.MockColumn
-
- scale - Variable in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnTypeMetadata_v3
-
- Scan - Interface in org.apache.drill.exec.physical.base
-
- scan - Variable in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- scan - Variable in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- 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(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(PhysicalOperator, FragmentContext, List<RecordReader>, boolean) - 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.
- scanDecodeExecutor - Variable in class org.apache.drill.test.PhysicalOpUnitTestBase
-
- scanDecoderExecutor - Variable in class org.apache.drill.test.OperatorFixture.Builder
-
- scanExecutor - Variable in class org.apache.drill.test.OperatorFixture.Builder
-
- scanExecutor - Variable in class org.apache.drill.test.PhysicalOpUnitTestBase
-
- 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
-
- scanIsPartition(GroupScan) - Static method in class org.apache.drill.exec.planner.index.IndexPlanUtils
-
- ScanLevelProjection - Class in org.apache.drill.exec.physical.impl.scan.project
-
Parses and analyzes the projection list passed to the scanner.
- ScanLevelProjection(List<SchemaPath>, List<ScanLevelProjection.ScanProjectionParser>, boolean) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.ScanLevelProjection
-
Specify the set of columns in the SELECT list.
- ScanLevelProjection(List<SchemaPath>, List<ScanLevelProjection.ScanProjectionParser>) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.ScanLevelProjection
-
- ScanLevelProjection.ScanProjectionParser - Interface in org.apache.drill.exec.physical.impl.scan.project
-
Interface for add-on parsers, avoids the need to create
a single, tightly-coupled parser for all types of columns.
- ScanPopBuider() - Constructor for class org.apache.drill.exec.physical.unit.MiniPlanUnitTestBase.ScanPopBuider
-
- ScanPopBuider(MiniPlanUnitTestBase.PopBuilder) - Constructor for class org.apache.drill.exec.physical.unit.MiniPlanUnitTestBase.ScanPopBuider
-
- ScanPrel - Class in org.apache.drill.exec.planner.physical
-
- ScanPrel(RelOptCluster, RelTraitSet, GroupScan, RelDataType, RelOptTable) - 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
-
- ScanSchemaOrchestrator - Class in org.apache.drill.exec.physical.impl.scan.project
-
Performs projection of a record reader, along with a set of static
columns, to produce the final "public" result set (record batch)
for the scan operator.
- ScanSchemaOrchestrator(BufferAllocator) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.ScanSchemaOrchestrator
-
- ScanSchemaOrchestrator.ReaderSchemaOrchestrator - Class in org.apache.drill.exec.physical.impl.scan.project
-
Orchestrates projection tasks for a single reader with the set that the
scan operator manages.
- ScanStats - Class in org.apache.drill.exec.physical.base
-
- ScanStats(ScanStats.GroupScanProperty, double, double, double) - Constructor for class org.apache.drill.exec.physical.base.ScanStats
-
- ScanStats.GroupScanProperty - Enum in org.apache.drill.exec.physical.base
-
- ScanTestUtils - Class in org.apache.drill.exec.physical.impl.scan
-
- ScanTestUtils() - Constructor for class org.apache.drill.exec.physical.impl.scan.ScanTestUtils
-
- schema() - Method in class org.apache.drill.exec.physical.impl.protocol.SchemaTracker
-
- schema() - Method in interface org.apache.drill.exec.physical.impl.scan.project.ConstantColumnLoader.ConstantColumnSpec
-
- schema() - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedColumn
-
Return the type of this column.
- schema() - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedMapColumn
-
- schema() - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedNullColumn
-
- schema - Variable in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTableColumn
-
- schema() - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTableColumn
-
- schema() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestRowBatchMerger.TestProjection
-
- schema(ResolvedTuple) - Static method in class org.apache.drill.exec.physical.impl.scan.ScanTestUtils
-
- schema - Variable in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup
-
- schema() - Method in class org.apache.drill.exec.physical.rowSet.impl.ColumnState
-
- schema - Variable in class org.apache.drill.exec.physical.rowSet.impl.OptionBuilder
-
- schema - Variable in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl.ResultSetOptions
-
- schema() - Method in class org.apache.drill.exec.physical.rowSet.impl.RowSetLoaderImpl
-
- schema - Variable in class org.apache.drill.exec.physical.rowSet.impl.TupleState
-
Internal writer schema that matches the column list.
- schema() - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState
-
- schema - Variable in class org.apache.drill.exec.physical.rowSet.model.BaseTupleModel.BaseColumnModel
-
Extended schema associated with a column.
- schema() - Method in class org.apache.drill.exec.physical.rowSet.model.BaseTupleModel.BaseColumnModel
-
- schema - Variable in class org.apache.drill.exec.physical.rowSet.model.BaseTupleModel
-
Descriptive schema associated with the columns above.
- schema() - Method in class org.apache.drill.exec.physical.rowSet.model.BaseTupleModel
-
- schema() - Method in interface org.apache.drill.exec.physical.rowSet.model.TupleModel.ColumnModel
-
- schema() - Method in interface org.apache.drill.exec.physical.rowSet.model.TupleModel
-
- schema - Variable in class org.apache.drill.exec.planner.sql.handlers.DescribeSchemaHandler.DescribeSchemaResult
-
- schema() - Method in class org.apache.drill.exec.record.metadata.MapColumnMetadata
-
- schema() - Method in class org.apache.drill.exec.record.metadata.PrimitiveColumnMetadata
-
- schema() - Method in class org.apache.drill.exec.record.metadata.RepeatedListColumnMetadata
-
- schema() - Method in class org.apache.drill.exec.record.metadata.VariantColumnMetadata
-
- Schema(String, String, String, String, boolean) - Constructor for class org.apache.drill.exec.store.ischema.Records.Schema
-
- 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 - Class in org.apache.drill.exec.store.pcapng.schema
-
- Schema() - Constructor for class org.apache.drill.exec.store.pcapng.schema.Schema
-
- schema - Variable in class org.apache.drill.test.rowSet.AbstractRowSet
-
- schema() - Method in class org.apache.drill.test.rowSet.AbstractRowSet
-
- schema() - Method in interface org.apache.drill.test.rowSet.RowSet
-
- schema() - Method in class org.apache.drill.test.rowSet.RowSetReaderImpl
-
- schema() - Method in class org.apache.drill.test.rowSet.RowSetWriterImpl
-
- schema() - Method in class org.apache.drill.test.rowSet.test.DummyWriterTest.RootWriterFixture
-
- SCHEMA_LENGTH - Static variable in class org.apache.drill.exec.physical.impl.project.OutputSizeEstimateConstants
-
- SCHEMA_NAME - Variable in class org.apache.drill.exec.store.ischema.Records.File
-
- 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
-
- schemaBaseLine(BatchSchema) - Method in class org.apache.drill.test.TestBuilder
-
- schemaBaseLine(List<Pair<SchemaPath, TypeProtos.MajorType>>) - Method in class org.apache.drill.test.TestBuilder
-
- SchemaBuilder - Class in org.apache.drill.exec.record
-
A reusable builder that supports the creation of BatchSchemas.
- SchemaBuilder - Class in org.apache.drill.test.rowSet.schema
-
Builder of a row set schema expressed as a list of materialized
fields.
- SchemaBuilder() - Constructor for class org.apache.drill.test.rowSet.schema.SchemaBuilder
-
- SchemaBuilder(BatchSchema) - Constructor for class org.apache.drill.test.rowSet.schema.SchemaBuilder
-
Create a new schema starting with the base schema.
- schemaChange() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- 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
-
- schemaChangeValidate() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- schemaConfig - Variable in class org.apache.calcite.jdbc.DynamicRootSchema
-
- SchemaConfig - Class in org.apache.drill.exec.store
-
- 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
-
- SchemalessBatch - Class in org.apache.drill.exec.record
-
Empty batch without schema and data.
- SchemalessBatch() - Constructor for class org.apache.drill.exec.record.SchemalessBatch
-
- SchemalessBatchCreator - Class in org.apache.drill.exec.physical.base
-
- SchemalessBatchCreator() - Constructor for class org.apache.drill.exec.physical.base.SchemalessBatchCreator
-
- SchemalessScan - Class in org.apache.drill.exec.physical.base
-
The type of scan operator, which allows to scan schemaless tables (
DynamicDrillTable
with null selection)
- SchemalessScan(String, String) - Constructor for class org.apache.drill.exec.physical.base.SchemalessScan
-
- SchemalessScan(SchemalessScan) - Constructor for class org.apache.drill.exec.physical.base.SchemalessScan
-
- SchemaLevelProjection - Class in org.apache.drill.exec.physical.impl.scan.project
-
Computes the full output schema given a table (or batch)
schema.
- SchemaLevelProjection(List<SchemaLevelProjection.SchemaProjectionResolver>) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.SchemaLevelProjection
-
- SchemaLevelProjection.SchemaProjectionResolver - Interface in org.apache.drill.exec.physical.impl.scan.project
-
Schema-level projection is customizable.
- 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
-
- schemaPathColumns(List<SchemaPath>) - Method in class org.apache.drill.exec.vector.complex.fn.JsonReader.Builder
-
- schemas(UserSession, DrillbitContext, UserProtos.GetSchemasReq, ResponseSender) - Static method in class org.apache.drill.exec.work.metadata.MetadataProvider
-
- schemas() - Method in class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- schemas - Variable in class org.apache.drill.test.ProfileParser.OperatorProfile
-
- SchemaSmoother - Class in org.apache.drill.exec.physical.impl.scan.project
-
Implements a "schema smoothing" algorithm.
- SchemaSmoother(ScanLevelProjection, List<SchemaLevelProjection.SchemaProjectionResolver>) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.SchemaSmoother
-
- SchemaSmoother.IncompatibleSchemaException - Exception in org.apache.drill.exec.physical.impl.scan.project
-
Exception thrown if the prior schema is not compatible with the
new table schema.
- schemasWithCatalogNameFilterAndSchemaNameFilter() - Method in class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- schemasWithSchemaNameFilter() - Method in class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- Schemata(OptionManager) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Schemata
-
- Schemata() - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaTable.Schemata
-
- SchemaTracker - Class in org.apache.drill.exec.physical.impl.protocol
-
Tracks changes to schemas via "snapshots" over time.
- SchemaTracker() - Constructor for class org.apache.drill.exec.physical.impl.protocol.SchemaTracker
-
- 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
-
- schemaVersion() - Method in interface org.apache.drill.exec.physical.impl.protocol.BatchAccessor
-
- schemaVersion() - Method in class org.apache.drill.exec.physical.impl.protocol.SchemaTracker
-
- schemaVersion() - Method in class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor
-
- schemaVersion() - Method in class org.apache.drill.exec.physical.impl.scan.project.SchemaSmoother
-
- schemaVersion() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- schemaVersion() - Method in interface org.apache.drill.exec.physical.rowSet.ResultSetLoader
-
Current schema version.
- SCHS_COL_CATALOG_NAME - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- SCHS_COL_IS_MUTABLE - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- SCHS_COL_SCHEMA_NAME - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- SCHS_COL_SCHEMA_OWNER - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- SCHS_COL_TYPE - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- scope - Variable in class org.apache.drill.exec.server.options.OptionValue
-
- 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.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
-
- ScreenRoot(RootFragmentContext, RecordBatch, Screen) - Constructor for class org.apache.drill.exec.physical.impl.ScreenCreator.ScreenRoot
-
- Se() - Constructor for class org.apache.drill.exec.coord.DrillbitEndpointSerDe.Se
-
- Se() - Constructor for class org.apache.drill.exec.record.MajorTypeSerDe.Se
-
- secondaryFinal(TypeProtos.MajorType) - Method in class org.apache.drill.exec.record.TypedFieldId.Builder
-
- secondaryImplicitCastRules - Static variable in class org.apache.drill.exec.resolver.ResolverTypePrecedence
-
- secondElementInMap() - Method in class org.apache.drill.exec.store.parquet.TestParquetComplex
-
- secondTest() - Method in class org.apache.drill.test.ExampleTest
-
Example that uses the fixture builder to build a cluster fixture.
- 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
-
- selectAllColumns() - Method in class org.apache.drill.exec.store.parquet.TestParquetComplex
-
- selectChainedView() - Method in class org.apache.drill.exec.impersonation.TestInboundImpersonation
-
- selectFromAllTables() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- selectFromViewCreatedOnCalcite1_4() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- 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, 64K values.
- 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
-
Create a selection vector with the given buffer.
- SelectionVector2(BufferAllocator, DrillBuf, int, 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
-
- SelectionVector4(BufferAllocator, 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
-
- selectMap() - Method in class org.apache.drill.exec.store.parquet.TestParquetComplex
-
- selectMapAndElements() - Method in class org.apache.drill.exec.store.parquet.TestParquetComplex
-
- selectMultiElements() - Method in class org.apache.drill.exec.store.parquet.TestParquetComplex
-
- SEMI_BROADCAST_INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.HashJoinPrule
-
- SEMI_DIST_INSTANCE - Static variable in class org.apache.drill.exec.planner.physical.HashJoinPrule
-
- SEMI_JOIN_PROJECT_RULE - Static variable in interface org.apache.drill.exec.planner.RuleInstance
-
- semiJoin - Variable in class org.apache.drill.exec.physical.base.AbstractJoinPop
-
- SEMIJOIN - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- 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(RowSet) - Method in class org.apache.drill.exec.physical.impl.MockRecordBatch.Builder
-
- 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
-
- sendDataAndEmit(RowSet) - Method in class org.apache.drill.exec.physical.impl.MockRecordBatch.Builder
-
- sendDataWithNewSchema(RowSet) - Method in class org.apache.drill.exec.physical.impl.MockRecordBatch.Builder
-
- 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
-
- SendFragment(RpcOutcomeListener<GeneralRPCProtos.Ack>, BitControl.InitializeFragments) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.SendFragment
-
- 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
-
- SendFragmentStatus(BitControl.FragmentStatus) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.SendFragmentStatus
-
- SendingAccountor - Class in org.apache.drill.exec.ops
-
Account for whether all messages sent have been completed.
- SendingAccountor() - Constructor for class org.apache.drill.exec.ops.SendingAccountor
-
- 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.
- sendOut(List<BloomFilter>, List<String>, RuntimeFilterDef, int) - Method in class org.apache.drill.exec.work.filter.RuntimeFilterReporter
-
- 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
-
- 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.
- sendRuntimeFilter(RuntimeFilterWritable) - Method in class org.apache.drill.exec.ops.AccountingDataTunnel
-
- sendRuntimeFilter(RpcOutcomeListener<GeneralRPCProtos.Ack>, RuntimeFilterWritable) - Method in class org.apache.drill.exec.rpc.data.DataTunnel
-
- sendUnsafe(RpcOutcomeListener<RECEIVE>, BitControl.RpcType, SEND, Class<RECEIVE>, ByteBuf...) - Method in class org.apache.drill.exec.rpc.control.ControlConnection
-
- sequenceFileChainedImpersonationWithView() - Method in class org.apache.drill.exec.impersonation.TestImpersonationQueries
-
- 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
-
- 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_V2.ColumnMetadata_v2, JsonGenerator, SerializerProvider) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnMetadata_v2.Serializer
-
- serialize(Metadata_V3.ColumnMetadata_v3, JsonGenerator, SerializerProvider) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.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
-
- Serializer() - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnMetadata_v2.Serializer
-
- Serializer() - Constructor for class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnMetadata_v3.Serializer
-
- 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(BufferAllocator, OutOfMemoryHandler) - Constructor for class org.apache.drill.exec.rpc.data.DataProtobufLengthDecoder.Server
-
- SERVER_PRINCIPAL - Variable in class org.apache.drill.exec.rpc.security.KerberosHelper
-
- 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
-
- serverKeytab - Variable in class org.apache.drill.exec.rpc.security.KerberosHelper
-
- 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.
- 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.ExecConstants
-
- SERVICE_NAME - Static variable in class org.apache.drill.exec.ExecConstants
-
- SERVICE_PRINCIPAL - Static variable in class org.apache.drill.exec.ExecConstants
-
- ServiceEngine - Class in org.apache.drill.exec.service
-
- ServiceEngine(WorkManager, BootStrapContext, boolean, boolean) - Constructor for class org.apache.drill.exec.service.ServiceEngine
-
- serviceSet - Static variable in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- serviceSet() - Method in class org.apache.drill.test.ClusterFixture
-
- session - Variable in class org.apache.drill.exec.store.sys.BitToUserConnectionIterator.ConnectionInfo
-
- SessionId() - Constructor for class org.apache.drill.exec.expr.fn.impl.ContextFunctions.SessionId
-
- sessionIdUDFWithinSameSession() - Method in class org.apache.drill.exec.fn.impl.TestContextFunctions
-
- sessionOption(String, Object) - Method in class org.apache.drill.test.ClusterFixtureBuilder
-
Provide a session option to be set once the Drillbit
is started.
- SessionOptionManager - Class in org.apache.drill.exec.server.options
-
- SessionOptionManager(OptionManager, UserSession) - Constructor for class org.apache.drill.exec.server.options.SessionOptionManager
-
- sessionOptions - Variable in class org.apache.drill.test.ClusterFixtureBuilder
-
- set(int, int) - Method in class org.apache.drill.exec.expr.EscapeTest1.Monkey
-
- set(EscapeTest1.EH) - Method in class org.apache.drill.exec.expr.EscapeTest1.Monkey
-
- set(int) - Method in class org.apache.drill.exec.physical.rowSet.model.ReaderIndex
-
- 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(String, String, String) - Method in class org.apache.drill.exec.rpc.control.TestCustomTunnel.MesgB
-
- 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
-
- setAlloc(EscapeTest1.Monkey) - Method in class org.apache.drill.exec.expr.EscapeTest1
-
- setAllocator(BufferAllocator) - Method in class org.apache.drill.exec.work.batch.AbstractDataCollector
-
Enables caller (e.g., receiver) to attach its buffer allocator to this Data Collector in order
to claim ownership of incoming batches; by default, the fragment allocator owns these batches.
- setAllocator(BufferAllocator) - Method in interface org.apache.drill.exec.work.batch.DataCollector
-
Enables caller (e.g., receiver) to attach its buffer allocator to this Data Collector in order
to claim ownership of incoming batches; by default, the fragment allocator owns these batches.
- setAlpha(boolean) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setAlpha(Directory, int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setAndResetSessionOption() - Method in class org.apache.drill.exec.server.TestOptions
-
- setAndResetSystemOption() - Method in class org.apache.drill.exec.server.TestOptions
-
- 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.
- setAudioCodec(String) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setAudioCodec(Directory, int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setAudioSampleRate(double) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setAudioSampleRate(Directory, int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setAudioSampleSize(int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setAudioSampleSize(Directory, int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- 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
-
- setBatchActualRecordCount(int) - Method in class org.apache.drill.exec.record.selection.SelectionVector2
-
- setBatchByteLimit(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.ScanSchemaOrchestrator
-
- setBatchRecordLimit(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.ScanSchemaOrchestrator
-
Specify a custom batch record count.
- setBatchSize(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.ScanSchemaOrchestrator.ReaderSchemaOrchestrator
-
- setBatchSize(long) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.SpilledRun
-
- setBatchSizeLimit(int) - Method in class org.apache.drill.exec.physical.rowSet.impl.OptionBuilder
-
- setBatchState(AbstractRecordBatch.BatchState) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
-
- setBatchState(AbstractRecordBatch.BatchState) - Method in interface org.apache.drill.exec.physical.impl.join.RowKeyJoin
-
Set the BatchState (this is useful when performing row key join)
- setBatchState(AbstractRecordBatch.BatchState) - Method in class org.apache.drill.exec.physical.impl.join.RowKeyJoinBatch
-
- setBitPerPixel(int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setBitPerPixel(Directory, int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setBitPerPixel(Directory, int, int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setBloomFilterDefs(List<BloomFilterDef>) - Method in class org.apache.drill.exec.work.filter.RuntimeFilterDef
-
- 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 interface org.apache.drill.exec.ops.ExecutorFragmentContext
-
- setBuffers(IncomingBuffers) - Method in class org.apache.drill.exec.ops.FragmentContextImpl
-
- setBuffers(IncomingBuffers) - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- 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
-
- setChild(ArrayWriter, ColumnMetadata) - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedListState
-
- setChild(ArrayWriter, MaterializedField) - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedListState
-
- setChildWriter(WriterPosition) - Method in class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState.OffsetVectorState
-
- 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.
- setColorMode(String) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setColorMode(Directory, int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setColumns(List<SchemaPath>) - Method in interface org.apache.drill.exec.physical.base.IndexGroupScan
-
- setColumns(Collection<SchemaPath>) - Method in class org.apache.drill.exec.store.AbstractRecordReader
-
- setColumns(List<? extends MetadataBase.ColumnMetadata>) - Method in class org.apache.drill.exec.store.parquet.RowGroupInfo
-
- setColumnWidth(int) - Method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- setColumnWidths(int[]) - Method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- setComment(byte) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
-
- setCompleted(UserBitShared.QueryResult.QueryState) - Method in class org.apache.drill.exec.work.foreman.Foreman.ForemanResult
-
Set up the result for a COMPLETED or CANCELED state.
- 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
-
- setContainer(VectorContainer) - Method in class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor
-
Set the vector container.
- setControls(DrillClient, String) - Static method in class org.apache.drill.exec.testing.ControlsInjectionUtil
-
- setControls(UserSession, String) - Static method in class org.apache.drill.exec.testing.ControlsInjectionUtil
-
- setControls(String) - Method in class org.apache.drill.test.ClientFixture
-
Set a set of injection controls that apply on the next query
only.
- 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
-
- setCostFactor(double) - Method in interface org.apache.drill.exec.physical.base.DbGroupScan
-
- 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
-
- setCustomFormatter(String, String) - Method in class org.apache.drill.test.rowSet.file.JsonFileBuilder
-
- setData(DrillBuf...) - Method in class org.apache.drill.exec.work.filter.RuntimeFilterWritable
-
- setDefaultClientPort(int) - Method in class org.apache.drill.exec.util.MiniZooKeeperCluster
-
- 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
-
Set a stat to the specified double value.
- setDPIHeight(double) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setDPIHeight(Directory, int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setDPIHeight(Directory, int, double) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setDPIWidth(double) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setDPIWidth(Directory, int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setDPIWidth(Directory, int, double) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setDrillTable(DrillTable) - Method in class org.apache.drill.exec.planner.index.DrillIndexDescriptor
-
Set the drill table corresponding to the index
- setDropBehind(Boolean) - Method in class org.apache.drill.exec.store.dfs.DrillFSDataInputStream
-
- setDuration(long) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setDuration(Directory, int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setEmptyDirectoryStatus() - Method in class org.apache.drill.exec.store.dfs.FileSelection
-
- 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.RowGroupInfo
-
- setEstimatedRowCount(double) - Method in class org.apache.drill.exec.planner.physical.RowKeyJoinPrel
-
- 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.FragmentContextImpl
-
- setExecutorState(FragmentContext.ExecutorState) - Method in interface org.apache.drill.exec.ops.RootFragmentContext
-
- setExecutorState(FragmentContext.ExecutorState) - Method in class org.apache.drill.test.PhysicalOpUnitTestBase.MockExecutorFragmentContext
-
- setExpandedFully() - Method in class org.apache.drill.exec.store.dfs.FileSelection
-
- setExpandedPartial() - Method in class org.apache.drill.exec.store.dfs.FileSelection
-
- setExpectedElementCount(int) - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- setExpectedWidth(int) - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- setExpectedWidth(int) - Method in class org.apache.drill.exec.record.metadata.PrimitiveColumnMetadata
-
- setExpressionMap(Map<LogicalExpression, LogicalExpression>) - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap
-
Set the map of src expression to target expression, expressions not in the map do not have assigned destinations
- setExtendedClass(Class<?>) - Method in class org.apache.drill.exec.compile.ClassBodyBuilder
-
- setExtension(String) - Method in class org.apache.drill.exec.store.log.LogFormatConfig
-
- setFailed(Exception) - Method in class org.apache.drill.exec.work.foreman.Foreman.ForemanResult
-
Set up the result for a FAILED state.
- 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.AbstractParquetGroupScan
-
- 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
-
- setForceFailure(Exception) - Method in class org.apache.drill.exec.work.foreman.Foreman.ForemanResult
-
Ignore the current status and force the given failure as current status.
- setForcefulShutdown(boolean) - Method in class org.apache.drill.exec.server.Drillbit
-
- setFragmentsInfo(List<BitControl.PlanFragment>, BitControl.PlanFragment, FragmentRoot) - Method in class org.apache.drill.exec.work.foreman.FragmentsRunner
-
- setFrameRate(double) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setFrameRate(Directory, int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- 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
-
- setFromInt(RowSetWriter, int, int) - Static method in class org.apache.drill.test.rowSet.RowSetUtilities
-
Set a test data value from an int.
- 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(int) - Method in class org.apache.drill.exec.planner.sql.DrillOperatorTable
-
Set function registry version based on which operator table was loaded.
- setFuture(Future<T>) - Method in class org.apache.drill.exec.util.concurrent.ExecutorServiceUtil.CallableTaskWrapper
-
- setGenerateBloomFilter(boolean) - Method in class org.apache.drill.exec.work.filter.RuntimeFilterDef
-
- setGenerateMinMaxFilter(boolean) - Method in class org.apache.drill.exec.work.filter.RuntimeFilterDef
-
- setGroupScan(GroupScan) - Method in class org.apache.drill.exec.planner.logical.DrillTable
-
- setHadWildcard(boolean) - Method in class org.apache.drill.exec.store.dfs.FileSelection
-
- setHandler(Handler) - Method in class org.apache.drill.exec.server.rest.auth.DrillHttpSecurityHandlerProvider
-
- 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
- setIdentifier(long) - Method in class org.apache.drill.exec.physical.config.RuntimeFilterPOP
-
- 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
-
- setIncoming(RecordBatch) - Method in class org.apache.drill.exec.record.AbstractTableFunctionRecordBatch
-
- setIncoming(LateralContract) - Method in class org.apache.drill.exec.record.AbstractTableFunctionRecordBatch
-
- setIncoming(RecordBatch) - Method in interface org.apache.drill.exec.record.TableFunctionContract
-
sets the incoming record batch for the operator.
- setIncoming(LateralContract) - Method in interface org.apache.drill.exec.record.TableFunctionContract
-
sets the incoming Lateral Contract for the operator.
- 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
-
- setInternal(boolean) - Method in class org.apache.drill.exec.expr.fn.ValueReference
-
- setInterpreter(DrillSimpleFunc) - Method in class org.apache.drill.exec.expr.DrillFuncHolderExpr
-
- setIsLast() - Method in class org.apache.drill.exec.physical.impl.partitionsender.PartitionerTemplate.OutgoingRecordBatch
-
- setJaasTestConfigFile() - Static method in class org.apache.drill.exec.ZookeeperTestUtil
-
Specifies JAAS configuration file.
- setJoinMjId2probeScanEps(Map<Integer, List<CoordinationProtos.DrillbitEndpoint>>) - Method in class org.apache.drill.exec.work.filter.RuntimeFilterSink
-
- setJoinMjId2rfNumber(Map<Integer, Integer>) - Method in class org.apache.drill.exec.work.filter.RuntimeFilterSink
-
- setJoinMjId2ScanMjId(Map<Integer, Integer>) - Method in class org.apache.drill.exec.work.filter.RuntimeFilterSink
-
- setLastKnownOutcome(RecordBatch.IterOutcome) - Method in class org.apache.drill.exec.record.AbstractUnaryRecordBatch
-
Set's the outcome received with current input batch in processing
- setLeftNDV(Double) - Method in class org.apache.drill.exec.work.filter.BloomFilterDef
-
- setLeftOutPathsInFunctions(Set<LogicalExpression>) - Method in interface org.apache.drill.exec.planner.index.IndexCallContext
-
- setLeftOutPathsInFunctions(Set<LogicalExpression>) - Method in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- setLeftOutPathsInFunctions(Set<LogicalExpression>) - Method in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- setLength(int) - Method in class org.apache.drill.exec.expr.fn.impl.DrillByteArray
-
- setLocal(boolean) - Method in class org.apache.drill.exec.work.filter.BloomFilterDef
-
- 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
-
- setLocalOption(String, long) - Method in interface org.apache.drill.exec.server.options.OptionManager
-
- setLocalOption(String, double) - Method in interface org.apache.drill.exec.server.options.OptionManager
-
- setLocalOption(String, String) - Method in interface org.apache.drill.exec.server.options.OptionManager
-
- setLocalOption(String, Object) - Method in interface org.apache.drill.exec.server.options.OptionManager
-
- setLocalOption(OptionValue.Kind, String, String) - Method in interface org.apache.drill.exec.server.options.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
-
Add a long value to the existing value.
- 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.Metadata_V1.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.Metadata_V2.ColumnMetadata_v2
-
- setMax(Object) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnMetadata_v3
-
- setMax(Object) - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ColumnMetadata
-
Set the max value recorded in the parquet metadata statistics.
- 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
-
- setMaxAllocation(long) - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
-
- setMaxCharsPerColumn(long) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
-
- setMaxErrors(int) - Method in class org.apache.drill.exec.store.log.LogFormatConfig
-
- setMaxOutputRowCount(int) - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggBatch
-
- setMaxOutputRowCount(int) - Method in class org.apache.drill.exec.physical.impl.join.LateralJoinBatch
-
Used only for testing for cases when multiple output batches are produced for same input set
- 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.Metadata_V1.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.Metadata_V2.ColumnMetadata_v2
-
- setMin(Object) - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnMetadata_v3
-
- setMin(Object) - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataBase.ColumnMetadata
-
Set the min value recorded in the parquet metadata statistics.
- 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
-
- setMode(TypeProtos.DataMode) - Method in class org.apache.drill.test.rowSet.schema.ColumnBuilder
-
- 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
-
- setNoAlloc(EscapeTest1.Monkey) - Method in class org.apache.drill.exec.expr.EscapeTest1
-
- setNormalizedNewLine(byte) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
-
- setNullType(TypeProtos.MajorType) - Method in class org.apache.drill.exec.physical.impl.scan.project.ScanSchemaOrchestrator
-
Specify the type to use for null columns in place of the standard
nullable int.
- 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.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
-
- setOption() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- setOptionDefault(String, Object) - Method in class org.apache.drill.test.ClusterFixtureBuilder
-
- 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
-
- setOptions(SessionOptionManager) - Method in class org.apache.drill.exec.planner.logical.DrillTable
-
- setOrientation(int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setOrientation(Directory, int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setOutgoingRowWidth(int) - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- setOutputCount(int) - Method in interface org.apache.drill.exec.physical.impl.flatten.Flattener
-
- setOutputCount(int) - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenTemplate
-
- setOutputCount(int) - Method in interface org.apache.drill.exec.physical.impl.unnest.Unnest
-
Set the maximum number of values allowed in the output.
- setOutputCount(int) - Method in class org.apache.drill.exec.physical.impl.unnest.UnnestImpl
-
- setOutputRowCount(int, int) - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
Given batchSize and rowWidth, this will set output rowCount taking into account
the min and max that is allowed.
- setOutputRowCount(int) - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- setOwner(Path, String, String) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
-
- setParallelizationWidth(int) - Method in interface org.apache.drill.exec.physical.base.IndexGroupScan
-
- setParseUnescapedQuotes(boolean) - Method in class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
-
Configures how to handle unescaped quotes inside quoted values.
- setPartitionStatSet(HashJoinMemoryCalculator.PartitionStatSet) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMechanicalMemoryCalculator.MechanicalBuildSidePartitioning
-
- setPartitionStatSet(HashJoinMemoryCalculator.PartitionStatSet) - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.BuildSidePartitioning
-
- setPartitionStatSet(HashJoinMemoryCalculator.PartitionStatSet) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.BuildSidePartitioningImpl
-
- setPartitionStatSet(HashJoinMemoryCalculator.PartitionStatSet) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.NoopBuildSidePartitioningImpl
-
- setPermission(Path, FsPermission) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
-
- setPixelHeight(int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setPixelHeight(Directory, int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setPixelWidth(int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setPixelWidth(Directory, int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- 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
-
- setPosn(int) - Method in interface org.apache.drill.test.rowSet.RowSetReader
-
- setPosn(int) - Method in class org.apache.drill.test.rowSet.RowSetReaderImpl
-
- setPrecision(int) - Method in class org.apache.drill.test.rowSet.schema.ColumnBuilder
-
- setProjected(boolean) - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- setProjection(Collection<SchemaPath>) - Method in class org.apache.drill.exec.physical.rowSet.impl.OptionBuilder
-
Record (batch) readers often read a subset of available table columns,
but want to use a writer schema that includes all columns for ease of
writing.
- setProjectionSet(RequestedTuple) - Method in class org.apache.drill.exec.physical.rowSet.impl.OptionBuilder
-
- setProperties(Map<LogicalExpression, RexNode>, boolean, RexNode, Statistics) - Method in interface org.apache.drill.exec.planner.index.IndexProperties
-
- setProperties(Map<LogicalExpression, RexNode>, boolean, RexNode, Statistics) - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- 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.
- 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
-
- setRecord(String) - Method in class org.apache.drill.exec.fn.interp.TestConstantFolding.SmallFileCreator
-
- setRecordBatchSizer(int, RecordBatchSizer) - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- setRecordBatchSizer(RecordBatchSizer) - Method in class org.apache.drill.exec.record.RecordBatchMemoryManager
-
- setRecordCount(int) - Method in class org.apache.drill.exec.record.selection.SelectionVector2
-
- setRecordCount(int) - Method in class org.apache.drill.exec.record.VectorContainer
-
- setRecordLimit(long) - Method in class org.apache.drill.exec.HyperVectorValueIterator
-
- setRecordMatched(int) - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- setRecordMatched(int) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinHelper
-
- setRegex(String) - Method in class org.apache.drill.exec.store.log.LogFormatConfig
-
- setRelDataTypeFactory(RelDataTypeFactory) - Method in class org.apache.drill.exec.planner.types.AbstractRelDataTypeHolder
-
- setReplication(Path, short) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
-
- setRightNDV(Double) - Method in class org.apache.drill.exec.work.filter.BloomFilterDef
-
- setRow(Object...) - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- setRow(Object...) - Method in interface org.apache.drill.exec.physical.rowSet.ResultSetLoader
-
Load a row using column values passed as variable-length arguments.
- setRowCount(RexNode, double, double) - Method in interface org.apache.drill.exec.physical.base.DbGroupScan
-
Set the artificial row count after applying the RexNode
condition
- setRowCount(RexNode, double, double) - Method in interface org.apache.drill.exec.physical.base.IndexGroupScan
-
Set the artificial row count after applying the RexNode
condition
Mainly used for debugging
- setRowCount(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedMapArray
-
- setRowCount(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedRow
-
- setRowCount(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedSingleMap
-
- setRowCount(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple
-
- setRowCountLimit(int) - Method in class org.apache.drill.exec.physical.rowSet.impl.OptionBuilder
-
Specify the maximum number of rows per batch.
- setRowIdVector(IntVector) - Method in interface org.apache.drill.exec.physical.impl.unnest.Unnest
-
Set the vector for the rowId implicit column
- setRowIdVector(IntVector) - Method in class org.apache.drill.exec.physical.impl.unnest.UnnestImpl
-
- setRowKeyJoinState(RowKeyJoin.RowKeyJoinState) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
-
- setRowKeyJoinState(RowKeyJoin.RowKeyJoinState) - Method in interface org.apache.drill.exec.physical.impl.join.RowKeyJoin
-
Set the RowKeyJoinState (this is useful for maintaining state for row key join algorithm)
- setRowKeyJoinState(RowKeyJoin.RowKeyJoinState) - Method in class org.apache.drill.exec.physical.impl.join.RowKeyJoinBatch
-
- setRowType() - Method in class org.apache.drill.exec.planner.common.DrillWriterRelBase
-
- setRuntimeFilterDef(RuntimeFilterDef) - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
-
- setRuntimeFilterDef(RuntimeFilterDef) - Method in class org.apache.drill.exec.planner.physical.HashJoinPrel
-
- setRuntimeFilterIdentifier(long) - Method in class org.apache.drill.exec.work.filter.RuntimeFilterDef
-
- 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.NullableVarBinaryColumn
-
- setSafe(VarLenBulkInput<VarLenBulkEntry>) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.NullableVarBinaryColumn
-
Store a set of variable entries in bulk; this method will automatically extend the underlying
value vector if needed.
- setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.NullableVarCharColumn
-
- setSafe(VarLenBulkInput<VarLenBulkEntry>) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.NullableVarCharColumn
-
Store a set of variable entries in bulk; this method will automatically extend the underlying
value vector if needed.
- setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.NullableVarDecimalColumn
-
- setSafe(VarLenBulkInput<VarLenBulkEntry>) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.NullableVarDecimalColumn
-
Store a set of variable entries in bulk; this method will automatically extend the underlying
value vector if needed.
- setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.VarBinaryColumn
-
- setSafe(VarLenBulkInput<VarLenBulkEntry>) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.VarBinaryColumn
-
Store a set of variable entries in bulk; this method will automatically extend the underlying
value vector if needed.
- setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.VarCharColumn
-
- setSafe(VarLenBulkInput<VarLenBulkEntry>) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.VarCharColumn
-
Store a set of variable entries in bulk; this method will automatically extend the underlying
value vector if needed.
- setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.VarDecimalColumn
-
- setSafe(VarLenBulkInput<VarLenBulkEntry>) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.VarDecimalColumn
-
Store a set of variable entries in bulk; this method will automatically extend the underlying
value vector if needed.
- setSafe(int, DrillBuf, int, int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthValuesColumn
-
Store a variable length entry if there is enough memory.
- setSafe(VarLenBulkInput<VarLenBulkEntry>) - Method in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthValuesColumn
-
Store a set of variable entries in bulk; this method will automatically extend the underlying
value vector if needed.
- setSaslClient(SaslClient) - Method in class org.apache.drill.exec.rpc.AbstractClientConnection
-
- setSaslClient(SaslClient) - Method in class org.apache.drill.exec.rpc.control.ControlConnection
-
- setSatisfiesCollation(boolean) - Method in interface org.apache.drill.exec.planner.index.IndexProperties
-
- setSatisfiesCollation(boolean) - Method in class org.apache.drill.exec.planner.index.IndexSelector.DrillIndexProperties
-
- setScale(int, int) - Method in class org.apache.drill.test.rowSet.schema.ColumnBuilder
-
- setScanDecoderExecutor(ExecutorService) - Method in class org.apache.drill.test.OperatorFixture.Builder
-
- setScanExecutor(ExecutorService) - Method in class org.apache.drill.test.OperatorFixture.Builder
-
- setSchema(BatchSchema) - Method in class org.apache.drill.exec.physical.impl.MockRecordBatch.Builder
-
- 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
-
- setSchema(TupleMetadata) - Method in class org.apache.drill.exec.physical.rowSet.impl.OptionBuilder
-
Clients can use the row set builder in several ways:
Provide the schema up front, when known, by using this method to
provide the schema.
Discover the schema on the fly, adding columns during the write
operation.
- setSchema() - Method in class org.apache.drill.exec.store.log.LogFormatConfig
-
- setSelectionVector(SelectionVector2) - Method in class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor.ContainerAndSv2Accessor
-
- setSelectionVectorMode(BatchSchema.SelectionVectorMode) - Method in class org.apache.drill.exec.record.SchemaBuilder
-
- setSendToForeman(boolean) - Method in class org.apache.drill.exec.work.filter.RuntimeFilterDef
-
- setSessionOption(String, String) - Method in class org.apache.drill.exec.rpc.user.UserSession
-
Set the option of a session level.
- setSessionOption(DrillClient, String, String) - Static method in class org.apache.drill.exec.testing.ControlsInjectionUtil
-
- setSessionOption(String, boolean) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- setSessionOption(String, long) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- setSessionOption(String, double) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- setSessionOption(String, String) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- 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
-
- setSliceCount() - Static method in class org.apache.drill.exec.expr.TestLogicalExprSerDe
-
- 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
-
- setStatistics(Statistics) - Method in interface org.apache.drill.exec.physical.base.IndexGroupScan
-
- 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.
- setStorageName(String) - Method in class org.apache.drill.exec.planner.index.DrillIndexDescriptor
-
Set the storage plugin name
- setStorageStrategy(StorageStrategy) - Method in class org.apache.drill.exec.physical.base.AbstractWriter
-
- setSubColumn(ColumnState) - Method in class org.apache.drill.exec.physical.rowSet.impl.ListState
-
Set the one and only type when building a single-type list.
- setSubScanForRowKeyJoin(SubScan) - Method in class org.apache.drill.exec.physical.config.HashJoinPOP
-
- setSubScanForRowKeyJoin(SubScan) - Method in class org.apache.drill.exec.physical.config.RowKeyJoinPOP
-
- 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
-
- setTargetBatchRowCount(int) - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate.BatchHolder
-
- setTargetBatchRowCount(int) - Method in interface org.apache.drill.exec.physical.impl.common.HashTable
-
- setTargetBatchRowCount(int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate.BatchHolder
-
- setTargetBatchRowCount(int) - Method in class org.apache.drill.exec.physical.impl.common.HashTableTemplate
-
- setTargetOutputCount(int) - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinProbe
-
- setTargetOutputCount(int) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinProbeTemplate
-
- setTargetOutputCount(int) - Method in interface org.apache.drill.exec.physical.impl.join.NestedLoopJoin
-
- setTargetOutputCount(int) - Method in class org.apache.drill.exec.physical.impl.join.NestedLoopJoinTemplate
-
- setTargetOutputRowCount(int) - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
-
- setTargetRowCount(int) - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- setTargetRowCount(int) - Method in interface org.apache.drill.exec.physical.rowSet.ResultSetLoader
-
Adjust the number of rows to produce in the next batch.
- 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.
- setTickTime(int) - Method in class org.apache.drill.exec.util.MiniZooKeeperCluster
-
- setTimes(Path, long, long) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
-
- settingNoOpInjectionsAndQuery() - Method in class org.apache.drill.exec.server.TestDrillbitResilience
-
- settings - Variable in class org.apache.drill.exec.planner.index.generators.AbstractIndexPlanGenerator
-
- setTotalCost(double) - Method in class org.apache.drill.exec.work.foreman.QueryManager
-
- setType(TypeProtos.MajorType) - Method in interface org.apache.drill.exec.physical.impl.scan.project.NullColumnLoader.NullColumnSpec
-
- setType(TypeProtos.MajorType) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedNullColumn
-
- setUnnest(RecordBatch) - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- setUnnestField(RepeatedValueVector) - Method in interface org.apache.drill.exec.physical.impl.unnest.Unnest
-
Set the field to be unnested
- setUnnestField(RepeatedValueVector) - Method in class org.apache.drill.exec.physical.impl.unnest.UnnestImpl
-
- setUnnestForLateralJoin(UnnestPOP) - Method in class org.apache.drill.exec.physical.config.LateralJoinPOP
-
- setUnnestLimit(int) - Method in class org.apache.drill.exec.physical.impl.unnest.MockLateralJoinBatch
-
- setUp() - Method in class org.apache.drill.exec.client.DrillClientSystemTest
-
- setUp() - Method in class org.apache.drill.exec.coord.zk.TestEphemeralStore
-
- setUp() - Method in class org.apache.drill.exec.coord.zk.TestEventDispatcher
-
- setUp() - Method in class org.apache.drill.exec.coord.zk.TestZKACL
-
- setUp() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- setup() - Static method in class org.apache.drill.exec.dotdrill.TestDotDrillUtil
-
- 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.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.CompareUntypedNull.CompareUntypedNullHigh
-
- setup() - Method in class org.apache.drill.exec.expr.fn.impl.CompareUntypedNull.CompareUntypedNullLow
-
- 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.ConvertFromJsonNullableInput
-
- 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.JsonConvertFrom.ConvertFromJsonVarcharNullableInput
-
- 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.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.CastDateToTime
-
- 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.Hash32AsDouble.BigIntHash
-
- 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.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.Hash32AsDouble.NullableVarDecimalHash
-
- setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.VarDecimalHash
-
- 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.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.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.NullableVarDecimalHash
-
- 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.Hash32Functions.VarDecimalHash
-
- 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.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.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.NullableVarDecimalHash
-
- 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.Hash32FunctionsWithSeed.VarDecimalHash
-
- 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.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.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.Hash32WithSeedAsDouble.NullableVarDecimalHash
-
- setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.VarDecimalHash
-
- 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.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.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.Hash64AsDouble.NullableVarDecimalHash
-
- setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.VarDecimalHash
-
- 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.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.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.NullableVarDecimalHash
-
- 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.Hash64Functions.VarDecimalHash
-
- 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.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.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.NullableVarDecimalHash
-
- 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.Hash64FunctionsWithSeed.VarDecimalHash
-
- 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.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.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.Hash64WithSeedAsDouble.NullableVarDecimalHash
-
- setup() - Method in class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.VarDecimalHash
-
- 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.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.ToNullableNumber
-
- setup() - Method in class org.apache.drill.exec.expr.fn.impl.MathFunctions.ToNullableNumberNullableInput
-
- setup() - Method in class org.apache.drill.exec.expr.fn.impl.MathFunctions.ToNumber
-
- 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.ParseQuery
-
- setup() - Method in class org.apache.drill.exec.expr.fn.impl.ParseQueryFunction.ParseQueryNullableInput
-
- setup() - Method in class org.apache.drill.exec.expr.fn.impl.ParseUrlFunction.ParseUrl
-
- setup() - Method in class org.apache.drill.exec.expr.fn.impl.ParseUrlFunction.ParseUrlNullableInput
-
- 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.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.SplitNullableInput
-
- 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.TestSqlPatterns
-
- setup() - Static method in class org.apache.drill.exec.expr.fn.impl.TestTypeFns
-
- 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.GetDrillType
-
- setup() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.GetMode
-
- setup() - Method in class org.apache.drill.exec.expr.fn.impl.UnionFunctions.GetSqlType
-
- 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() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- setup() - Static method in class org.apache.drill.exec.fn.impl.TestByteComparisonFunctions
-
- setup() - Static method in class org.apache.drill.exec.fn.impl.TestCastEmptyStrings
-
- setup() - Method in class org.apache.drill.exec.fn.impl.testing.GeneratorFunctions.IncreasingBigInt
-
- setup() - Method in class org.apache.drill.exec.fn.impl.testing.GeneratorFunctions.RandomBigInt
-
- setup() - Method in class org.apache.drill.exec.fn.impl.testing.GeneratorFunctions.RandomBigIntGauss
-
- setup() - Method in class org.apache.drill.exec.fn.impl.testing.GeneratorFunctions.RandomFloat8
-
- setup() - Method in class org.apache.drill.exec.fn.impl.testing.GeneratorFunctions.RandomFloat8Gauss
-
- setup() - Static method in class org.apache.drill.exec.fn.impl.TestParseFunctions
-
- setup() - Static method in class org.apache.drill.exec.fn.impl.TestTimestampAddDiffFunctions
-
- setup() - Static method in class org.apache.drill.exec.impersonation.TestImpersonationDisabledWithMiniDFS
-
- setup() - Static method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- setup() - Static method in class org.apache.drill.exec.impersonation.TestImpersonationQueries
-
- setup() - Static method in class org.apache.drill.exec.impersonation.TestInboundImpersonation
-
- setup(HashAggregate, HashTableConfig, FragmentContext, OperatorContext, RecordBatch, HashAggBatch, LogicalExpression[], List<TypedFieldId>, ClassGenerator<?>, TypedFieldId[], VectorContainer, int) - Method in interface org.apache.drill.exec.physical.impl.aggregate.HashAggregator
-
- setup(HashAggregate, HashTableConfig, FragmentContext, OperatorContext, RecordBatch, HashAggBatch, LogicalExpression[], List<TypedFieldId>, ClassGenerator<?>, TypedFieldId[], VectorContainer, int) - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
-
- setup(OperatorContext, RecordBatch, StreamingAggBatch, int) - Method in interface org.apache.drill.exec.physical.impl.aggregate.StreamingAggregator
-
- setup(OperatorContext, RecordBatch, StreamingAggBatch, int) - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
-
- setup(HashTableConfig, BufferAllocator, VectorContainer, RecordBatch, RecordBatch, VectorContainer, FragmentContext, ClassGenerator<?>) - 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, BufferAllocator, VectorContainer, RecordBatch, RecordBatch, VectorContainer, FragmentContext, ClassGenerator<?>) - 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(ExchangeFragmentContext, RecordBatch, HashPartitionSender, OperatorStats, OperatorContext, ClassGenerator<?>, int, int) - Method in interface org.apache.drill.exec.physical.impl.partitionsender.Partitioner
-
- setup(ExchangeFragmentContext, RecordBatch, HashPartitionSender, OperatorStats, OperatorContext, ClassGenerator<?>, 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() - Static method in class org.apache.drill.exec.physical.impl.scan.project.TestRowBatchMerger
-
- 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(VectorAccessible, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.svremover.AbstractCopier
-
- setup(VectorAccessible, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.svremover.AbstractSV2Copier
-
- setup(VectorAccessible, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.svremover.AbstractSV4Copier
-
- setup(VectorAccessible, VectorContainer) - Method in interface org.apache.drill.exec.physical.impl.svremover.Copier
-
- setup(VectorAccessible, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.svremover.GenericCopier
-
- setup(VectorAccessible, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.svremover.StraightCopier
-
- setup() - Static method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- setup() - Static method in class org.apache.drill.exec.physical.impl.TestSchema
-
- 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(FragmentContext, RecordBatch, RecordBatch, List<TransferPair>) - Method in interface org.apache.drill.exec.physical.impl.unnest.Unnest
-
- setup(FragmentContext, RecordBatch, RecordBatch, List<TransferPair>) - Method in class org.apache.drill.exec.physical.impl.unnest.UnnestImpl
-
- 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(FragmentContext, BufferAllocator, SelectionVector4, VectorContainer, int, int) - Method in interface org.apache.drill.exec.physical.impl.xsort.managed.MSorter
-
- setup(FragmentContext, 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(FragmentContext, SelectionVector2, VectorAccessible) - Method in interface org.apache.drill.exec.physical.impl.xsort.SingleBatchSorter
-
- setup(FragmentContext, SelectionVector2, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.xsort.SingleBatchSorterTemplate
-
- setup() - Static method in class org.apache.drill.exec.physical.impl.xsort.TestSortSpillWithException
-
- setup(List<VectorWrapper<?>>) - Method in class org.apache.drill.exec.planner.physical.AbstractRangePartitionFunction
-
- setup(List<VectorWrapper<?>>) - Method in interface org.apache.drill.exec.planner.physical.PartitionFunction
-
Setup method for the partitioning function
- setUp() - Static method in class org.apache.drill.exec.planner.sql.CrossJoinTest
-
- setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.planner.sql.handlers.FindLimit0Visitor.RelDataTypeReader
-
- setup() - Static method in class org.apache.drill.exec.pop.PopUnitTestBase
-
- setup() - Static method in class org.apache.drill.exec.pop.TestInjectionValue
-
- setup() - Static method in class org.apache.drill.exec.rpc.control.ConnectionManagerRegistryTest
-
- setup() - Static method in class org.apache.drill.exec.rpc.control.TestLocalControlConnectionManager
-
- 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 class org.apache.drill.exec.rpc.user.security.testing.UserAuthenticatorTestImpl
-
- setup() - Static method in class org.apache.drill.exec.rpc.user.security.TestUserBitSaslCompatibility
-
- setup(DrillConfig) - Method in interface org.apache.drill.exec.rpc.user.security.UserAuthenticator
-
Setup for authenticating user credentials.
- setup() - Method in class org.apache.drill.exec.rpc.user.TemporaryTablesAutomaticDropTest
-
- setup(LoginAuthenticator, LoginService) - Method in class org.apache.drill.exec.server.rest.auth.DrillHttpConstraintSecurityHandler
-
- setup() - Method in class org.apache.drill.exec.server.rest.TestMainLoginPageModel
-
- setup() - Static method in class org.apache.drill.exec.sql.TestConformance
-
- setup() - Static method in class org.apache.drill.exec.sql.TestSchemaCaseInsensitivity
-
- setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.avro.AvroRecordReader
-
- setUp() - Method in class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- 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() - Static method in class org.apache.drill.exec.store.easy.text.compliant.TestCsv
-
- setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.image.ImageRecordReader
-
- setUp() - Static method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- setup() - Static method in class org.apache.drill.exec.store.ischema.TestFilesTable
-
- setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.log.LogRecordReader
-
- setup() - Static method in class org.apache.drill.exec.store.log.TestLogReader
-
- 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() - Method in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager
-
Tunes record batch parameters based on configuration and schema.
- setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
-
Prepare the Parquet reader.
- setup() - Static method in class org.apache.drill.exec.store.parquet.ParquetInternalsTest
-
- setup() - Static method in class org.apache.drill.exec.store.parquet.TestComplexColumnInSchema
-
- setup() - Static method in class org.apache.drill.exec.store.parquet.TestParquetBulkReader
-
- setup() - Static method in class org.apache.drill.exec.store.parquet.TestParquetLimitPushDown
-
- setup() - Static method in class org.apache.drill.exec.store.parquet.TestParquetReaderUtility
-
- setup() - Static method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
- setup() - Static method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForVarchar
-
- setup() - Static method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.parquet2.DrillParquetReader
-
- setup() - Static method in class org.apache.drill.exec.store.parquet2.TestDrillParquetReader
-
- setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.pcap.PcapRecordReader
-
- setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.pcapng.PcapngRecordReader
-
- 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() - Static method in class org.apache.drill.exec.store.StorageStrategyTest
-
- setup() - Static method in class org.apache.drill.exec.store.store.TestAssignment
-
- setup() - Static method in class org.apache.drill.exec.store.store.TestDisabledPlugin
-
- setup() - Static method in class org.apache.drill.exec.store.TestImplicitFileColumns
-
- setup(OperatorContext, OutputMutator) - Method in class org.apache.drill.exec.store.text.DrillTextRecordReader
-
- setup() - Method in class org.apache.drill.exec.testing.TestResourceLeak.Leak
-
- setUp() - Method in class org.apache.drill.exec.TestOpSerialization
-
- setUp() - Method in class org.apache.drill.exec.TestWithZookeeper
-
- setup() - Static method in class org.apache.drill.exec.util.FileSystemUtilTestBase
-
- setup() - Method in class org.apache.drill.exec.util.TestValueVectorElementFormatter
-
- setUp() - Method in class org.apache.drill.exec.vector.accessor.GenericAccessorTest
-
- setUp() - Method in class org.apache.drill.exec.work.fragment.FragmentStatusReporterTest
-
- setup() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase
-
- setup() - Static method in class org.apache.drill.test.rowSet.test.TestOffsetVectorWriter
-
Party over enough memory that the uninitialized nature of
vectors under the new writers will cause test to fail if
the writer's don't correctly fill in all values.
- setup() - Method in class org.apache.drill.test.rowSet.TestRowSetComparison
-
- setup() - Static method in class org.apache.drill.TestDropTable
-
- setup() - Static method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- setup() - Method in class org.apache.drill.TestOperatorDump
-
- setup() - Method in class org.apache.drill.TestProjectWithFunctions
-
- setup() - Static method in class org.apache.drill.TestUntypedNull
-
- setup() - Method in class org.apache.drill.udf.dynamic.CustomAbsFunction
-
- setup() - Method in class org.apache.drill.udf.dynamic.CustomLogFunction
-
- setup() - Method in class org.apache.drill.udf.dynamic.CustomLowerDummyFunction
-
- setup() - Method in class org.apache.drill.udf.dynamic.CustomLowerFunction
-
- setup() - Method in class org.apache.drill.udf.dynamic.CustomLowerFunctionV2
-
- setup() - Method in class org.apache.drill.udf.dynamic.CustomUpperFunction
-
- setup() - Method in class org.apache.drill.udf.dynamic.LowerFunction
-
- setupAllocator() - Static method in class org.apache.drill.exec.vector.complex.writer.TestRepeated
-
- setUpBeforeClass() - Static method in class org.apache.drill.exec.cache.TestBatchSerialization
-
- setUpBeforeClass() - Static method in class org.apache.drill.exec.physical.impl.BaseTestOpBatchEmitOutcome
-
- setUpBeforeClass() - Static method in class org.apache.drill.exec.physical.impl.join.TestHashJoinOutcome
-
- setUpBeforeClass() - Static method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
- setUpBeforeClass() - Static method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- setUpBeforeClass() - Static method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestCorrectness
-
- setUpBeforeClass() - Static method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestWithLateralCorrectness
-
- setUpBeforeClass() - Static method in class org.apache.drill.exec.physical.impl.validate.TestBatchValidator
-
- setUpBeforeClass() - Static method in class org.apache.drill.exec.physical.impl.validate.TestValidationOptions
-
- setUpBeforeClass() - Static method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
- setUpBeforeClass() - Static method in class org.apache.drill.exec.record.TestVectorContainer
-
- setUpBeforeClass() - Static method in class org.apache.drill.exec.store.parquet.columnreaders.TestBatchSizingMemoryUtil
-
- setUpBeforeClass2() - Static method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
- setupBufferedOpsMemoryAllocations(PhysicalPlan, QueryContext) - Static method in class org.apache.drill.exec.util.MemoryAllocationUtilities
-
Helper method to setup Memory Allocations
- setupCluster() - Static method in class org.apache.drill.exec.rpc.user.security.TestCustomUserAuthenticator
-
- setupCluster() - Static method in class org.apache.drill.exec.server.TestOptionsAuthEnabled
-
- setupClusterSize() - Static method in class org.apache.drill.exec.physical.impl.TestLocalExchange
-
- 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
-
- setupDefaultTestCluster() - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- 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
-
- setupFiles() - Static method in class org.apache.drill.exec.DrillSeparatePlanningTest
-
- setupFiles() - Static method in class org.apache.drill.exec.expr.TestSchemaPathMaterialization
-
- setupFiles() - Static method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- setupFiles() - Static method in class org.apache.drill.exec.physical.impl.broadcastsender.TestBroadcast
-
- setupFiles() - Static method in class org.apache.drill.exec.sql.TestInfoSchema
-
- setupFiles() - Static method in class org.apache.drill.TestOperatorDump
-
- setupFiles() - Static method in class org.apache.drill.TestProjectWithFunctions
-
- setupFiles() - Static method in class org.apache.drill.TestSchemaChange
-
- setupFiles() - Static method in class org.apache.drill.TestUnionDistinct
-
- setupForTest() - Method in class org.apache.drill.exec.rpc.control.TestLocalControlConnectionManager
-
- setupHashJoinProbe() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinBatch
-
- setupHashJoinProbe(RecordBatch, HashJoinBatch, JoinRelType, boolean, RecordBatch.IterOutcome, HashPartition[], int, VectorContainer, HashJoinBatch.HashJoinSpilledPartition[], boolean, int, int) - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinProbe
-
- setupHashJoinProbe(RecordBatch, HashJoinBatch, JoinRelType, boolean, RecordBatch.IterOutcome, HashPartition[], int, VectorContainer, HashJoinBatch.HashJoinSpilledPartition[], boolean, int, int) - Method in class org.apache.drill.exec.physical.impl.join.HashJoinProbeTemplate
-
Setup the Hash Join Probe object
- setupHelper(boolean, boolean) - Static method in class org.apache.drill.exec.physical.impl.TestLocalExchange
-
- 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(VectorContainer, 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
-
- setupKdc(File) - Method in class org.apache.drill.exec.rpc.security.KerberosHelper
-
- setupMs - Variable in class org.apache.drill.test.ProfileParser.OperatorProfile
-
- setupMs - Variable in class org.apache.drill.test.ProfileParser.OperatorSummary
-
- setupMSortBatchSize() - Static method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- setupMultiNodeCluster() - Static method in class org.apache.drill.exec.store.sys.TestSystemTable
-
- 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.
- setupNewDrillbit() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- setupNewSchema() - Method in class org.apache.drill.exec.physical.impl.filter.FilterRecordBatch
-
- setupNewSchema() - Method in class org.apache.drill.exec.physical.impl.filter.RuntimeFilterRecordBatch
-
- 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() - Method in class org.apache.drill.exec.physical.impl.limit.PartitionLimitRecordBatch
-
- 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.rangepartitioner.RangePartitionRecordBatch
-
Sets up projection that will transfer all of the columns in batch, and also setup
the partition column based on which partition a record falls into
- 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.unnest.UnnestRecordBatch
-
- setupNewSchema() - Method in class org.apache.drill.exec.physical.impl.WriterRecordBatch
-
- setupNewSchema() - Method in class org.apache.drill.exec.record.AbstractUnaryRecordBatch
-
- setupOptionManager() - Static method in class org.apache.drill.exec.ExecTest
-
- 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
-
- setupSaveFirstValue(VectorAccessible, VectorAccessible) - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
-
- setupScalarReplacementOption(Drillbit, ClassTransformer.ScalarReplacementOption) - Static method in class org.apache.drill.test.QueryTestUtil
-
Set up the options to test the scalar replacement retry option (see
ClassTransformer.java).
- 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
-
- setupSimpleSingleBatchSumTestPhase1of2() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggBatch
-
- 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
-
- setupTest() - Static method in class org.apache.drill.exec.rpc.data.TestBitBitKerberos
-
- setupTest() - Static method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberos
-
- setupTest() - Static method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberosEncryption
-
- setupTest() - Static method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSL
-
- setupTest() - Static method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSLServer
-
- setupTest() - Static method in class org.apache.drill.exec.server.rest.spnego.TestDrillSpnegoAuthenticator
-
- setupTest() - Static method in class org.apache.drill.exec.server.rest.spnego.TestSpnegoAuthentication
-
- setupTest() - Static method in class org.apache.drill.exec.server.rest.spnego.TestSpnegoConfig
-
- setUpTestData() - Static method in class org.apache.drill.test.TestGracefulShutdown
-
- setupTestFiles() - Static method in class org.apache.drill.exec.physical.impl.join.TestHashJoinJPPDPlan
-
- setupTestFiles() - Static method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- setupTestFiles() - Static method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- setupTestFiles() - Static method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- setupTestFiles() - Static method in class org.apache.drill.exec.physical.impl.limit.TestLimitWithExchanges
-
- setupTestFiles() - Static method in class org.apache.drill.exec.physical.impl.TopN.TestTopNSchemaChanges
-
- setupTestFiles() - Static method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- setupTestFiles() - Static method in class org.apache.drill.exec.planner.logical.TestConvertCountToDirectScan
-
- setupTestFiles() - Static method in class org.apache.drill.exec.sql.TestViewSupport
-
- setupTestFiles() - Static method in class org.apache.drill.exec.store.dfs.TestGlob
-
- setupTestFiles() - Static method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- setupTestFiles() - Static method in class org.apache.drill.exec.store.pcap.TestPcapRecordReader
-
- setupTestFiles() - Static method in class org.apache.drill.exec.store.pcapng.TestPcapngHeaders
-
- setupTestFiles() - Static method in class org.apache.drill.exec.store.pcapng.TestPcapngRecordReader
-
- setupTestFiles() - Static method in class org.apache.drill.exec.TestEmptyInputSql
-
- setupTestFiles() - Static method in class org.apache.drill.exec.TestWindowFunctions
-
- setupTestFiles() - Static method in class org.apache.drill.exec.vector.complex.writer.TestExtendedTypes
-
- setupTestFiles() - Static method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- setupTestFiles() - Static method in class org.apache.drill.TestAltSortQueries
-
- setupTestFiles() - Static method in class org.apache.drill.TestBugFixes
-
- setupTestFiles() - Static method in class org.apache.drill.TestCTASPartitionFilter
-
- setupTestFiles() - Static method in class org.apache.drill.TestExampleQueries
-
- setupTestFiles() - Static method in class org.apache.drill.TestProjectPushDown
-
- setupTestFiles() - Static method in class org.apache.drill.TestStarQueries
-
- setupTestFiles() - Static method in class org.apache.drill.TestUnionAll
-
- 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
-
- setUseMemoryManager(boolean) - Method in class org.apache.drill.exec.physical.impl.join.LateralJoinBatch
-
- 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.parquet2.DrillParquetRecordMaterializer
-
- 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
-
- setValuesReadInCurrentPass(int) - Method in class org.apache.drill.exec.store.parquet.columnreaders.ReadState
-
- setVectorCache(ResultVectorCache) - Method in class org.apache.drill.exec.physical.rowSet.impl.OptionBuilder
-
Downstream operators require "vector persistence": the same vector
must represent the same column in every batch.
- 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
-
- setVideoCodec(String) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setVideoCodec(Directory, int) - Method in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- setWidth(int) - Method in class org.apache.drill.exec.planner.fragment.Wrapper
-
- setWidth(int) - Method in class org.apache.drill.test.rowSet.schema.ColumnBuilder
-
- 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.CachedSingleFileSystem
-
- 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
-
- setZookeeperSaslTestConfigProps() - Static method in class org.apache.drill.exec.ZookeeperTestUtil
-
Sets zookeeper server and client SASL test config properties.
- seventhTest() - Method in class org.apache.drill.test.ExampleTest
-
This example shows how to define a workspace that points to test files in the sample-data folder.
- shouldContinue() - Method in interface org.apache.drill.exec.ops.FragmentContext.ExecutorState
-
Tells individual operations whether they should continue.
- shouldContinue() - Method in interface org.apache.drill.exec.ops.FragmentContextInterface
-
Determine if fragment execution has been interrupted.
- shouldContinue() - Method in class org.apache.drill.test.OperatorFixture.MockExecutorState
-
- shouldMark() - Method in class org.apache.drill.exec.physical.impl.join.JoinStatus
-
- shouldShowAdminInfo() - Method in class org.apache.drill.exec.server.rest.DrillRoot.ClusterInfo
-
- shouldSpill() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMechanicalMemoryCalculator.MechanicalBuildSidePartitioning
-
- shouldSpill() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMechanicalMemoryCalculator.MechanicalPostBuildCalculations
-
- shouldSpill() - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.BuildSidePartitioning
-
- shouldSpill() - Method in interface org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculator.PostBuildCalculations
-
- shouldSpill() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.BuildSidePartitioningImpl
-
- shouldSpill() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.NoopBuildSidePartitioningImpl
-
- shouldSpill() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.NoopPostBuildCalculationsImpl
-
- shouldSpill() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinMemoryCalculatorImpl.PostBuildCalculationsImpl
-
- 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
-
- shouldVisitFiles(String, SchemaPlus) - 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
-
- showDatabases() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- showDatabasesLike() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- showDatabasesWhere() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- ShowFilesCommandResult(Records.File) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ShowFilesHandler.ShowFilesCommandResult
-
- ShowFilesHandler - Class in org.apache.drill.exec.planner.sql.handlers
-
- ShowFilesHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ShowFilesHandler
-
- ShowFilesHandler.ShowFilesCommandResult - Class in org.apache.drill.exec.planner.sql.handlers
-
Original show files command result holder is used as wrapper over new Records.File
holder
to maintain backward compatibility with ODBC driver etc.
- 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
-
- showProperMsgWhenDroppingNonExistentView() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- showProperMsgWhenTryingToDropANonViewTable() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- showProperMsgWhenTryingToDropAViewInImmutableSchema() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- ShowSchemasHandler - Class in org.apache.drill.exec.planner.sql.handlers
-
- ShowSchemasHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ShowSchemasHandler
-
- showTablesFromDb() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- showTablesFromDbWhere() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- ShowTablesHandler - Class in org.apache.drill.exec.planner.sql.handlers
-
- ShowTablesHandler(SqlHandlerConfig) - Constructor for class org.apache.drill.exec.planner.sql.handlers.ShowTablesHandler
-
- showTablesLike() - Method in class org.apache.drill.exec.sql.TestInfoSchema
-
- SHRD_COL_TABLE_CATALOG - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- SHRD_COL_TABLE_NAME - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- SHRD_COL_TABLE_SCHEMA - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- shutdown() - Method in class org.apache.drill.exec.server.Drillbit
-
- shutdown() - Method in class org.apache.drill.exec.util.MiniZooKeeperCluster
-
- shutdown() - Static method in class org.apache.drill.test.ClusterTest
-
- shutdownAllDrillbits() - Static method in class org.apache.drill.exec.server.TestDrillbitResilience
-
- shutdownDrillbit() - Method in class org.apache.drill.exec.server.rest.DrillRoot
-
- shutdownForcefully() - Method in class org.apache.drill.exec.server.rest.DrillRoot
-
- SignalFragment(RpcOutcomeListener<GeneralRPCProtos.Ack>, ExecProtos.FragmentHandle, BitControl.RpcType) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.SignalFragment
-
- Signature - Annotation Type in org.apache.drill.exec.compile.sig
-
Describes the field will provide output from the given function.
- signature - Variable in class org.apache.drill.exec.store.sys.FunctionsIterator.FunctionInfo
-
- SignatureHolder - Class in org.apache.drill.exec.compile.sig
-
- SilentListener() - Constructor for class org.apache.drill.test.BaseTestQuery.SilentListener
-
Deprecated.
- Similar() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Similar
-
- SimilarWithEscape() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.SimilarWithEscape
-
- simple() - Method in class org.apache.drill.exec.work.prepare.TestPreparedStatementProvider
-
Simple query.
- SIMPLE_NAME - Static variable in class org.apache.drill.exec.rpc.security.plain.PlainFactory
-
- simpleAddBatchTest() - Method in class org.apache.drill.exec.physical.impl.join.TestPartitionStat
-
- simpleCalculateSize() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinHelperSizeCalculatorImpl
-
- simpleCase1() - Method in class org.apache.drill.exec.planner.fragment.TestHardAffinityFragmentParallelizer
-
- simpleCase2() - Method in class org.apache.drill.exec.planner.fragment.TestHardAffinityFragmentParallelizer
-
- 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.CastVarCharBoolean - Class in org.apache.drill.exec.expr.fn.impl
-
- SimpleCommandResult - Class in org.apache.drill.exec.planner.sql.handlers
-
- SimpleCommandResult(boolean, String) - Constructor for class org.apache.drill.exec.planner.sql.handlers.SimpleCommandResult
-
- simpleCompound() - Method in class org.apache.drill.exec.planner.logical.FilterSplitTest
-
- simpleCsv() - Method in class org.apache.drill.exec.physical.impl.writer.TestWriter
-
- simpleCTAS() - Method in class org.apache.drill.exec.physical.impl.writer.TestWriter
-
- simpleCTASWithSchemaInTableName() - Method in class org.apache.drill.exec.physical.impl.writer.TestWriter
-
- simpleDoubleUnorderedComparisonMatchTest() - Method in class org.apache.drill.test.rowSet.TestRowSetComparison
-
- simpleDoubleUnorderedComparisonNoMatchTest() - Method in class org.apache.drill.test.rowSet.TestRowSetComparison
-
- 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.
- simpleEqualityJoin() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoin
-
- simpleEqualityJoin() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoin
-
- simpleMultiBatchSumTestPhase1of1() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggBatch
-
- simpleMultiBatchSumTestPhase1of2() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggBatch
-
- simpleMultiBatchSumTestPhase2of2() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggBatch
-
- simpleNullableSchema - Static variable in class org.apache.drill.exec.store.parquet.ParquetSimpleTestFileGenerator
-
- simpleNullableSchemaMsg - Static variable in class org.apache.drill.exec.store.parquet.ParquetSimpleTestFileGenerator
-
- 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.
- simpleParquetDecimal() - Method in class org.apache.drill.exec.physical.impl.writer.TestWriter
-
- SimplePartitionLocation - Class in org.apache.drill.exec.planner
-
Abstract class for simple partition.
- SimplePartitionLocation() - Constructor for class org.apache.drill.exec.planner.SimplePartitionLocation
-
- simplePrint() - Method in class org.apache.drill.test.ProfileParser
-
- 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.ContainsBit - Class in org.apache.drill.exec.expr.fn.impl
-
- SimpleRepeatedFunctions.ContainsFloat4 - Class in org.apache.drill.exec.expr.fn.impl
-
- SimpleRepeatedFunctions.ContainsFloat8 - Class in org.apache.drill.exec.expr.fn.impl
-
- SimpleRepeatedFunctions.ContainsInt - Class in org.apache.drill.exec.expr.fn.impl
-
- SimpleRepeatedFunctions.ContainsTinyInt - Class in org.apache.drill.exec.expr.fn.impl
-
- SimpleRepeatedFunctions.ContainsVarChar - Class in org.apache.drill.exec.expr.fn.impl
-
- SimpleRepeatedFunctions.RepeatedLengthBigInt - Class in org.apache.drill.exec.expr.fn.impl
-
- SimpleRepeatedFunctions.RepeatedLengthBit - Class in org.apache.drill.exec.expr.fn.impl
-
- SimpleRepeatedFunctions.RepeatedLengthFloat4 - Class in org.apache.drill.exec.expr.fn.impl
-
- SimpleRepeatedFunctions.RepeatedLengthFloat8 - Class in org.apache.drill.exec.expr.fn.impl
-
- SimpleRepeatedFunctions.RepeatedLengthInt - Class in org.apache.drill.exec.expr.fn.impl
-
- SimpleRepeatedFunctions.RepeatedLengthTinyInt - Class in org.apache.drill.exec.expr.fn.impl
-
- SimpleRepeatedFunctions.RepeatedLengthVarChar - Class in org.apache.drill.exec.expr.fn.impl
-
- SimpleRexRemap - Class in org.apache.drill.exec.planner.index
-
Rewrite RexNode with these policies:
1) field renamed.
- SimpleRexRemap(RelNode, RelDataType, RexBuilder) - Constructor for class org.apache.drill.exec.planner.index.SimpleRexRemap
-
- SimpleRexRemap.FieldsMarker - Class in org.apache.drill.exec.planner.index
-
This class go through the RexNode, collect all the fieldNames, mark starting positions(RexNode) of fields
so this information can be used later e,.g.
- SimpleRexRemap.RexReplace - Class in org.apache.drill.exec.planner.index
-
- SimpleRootExec - Class in org.apache.drill.exec.physical.impl
-
Deprecated.
- SimpleRootExec(RootExec) - Constructor for class org.apache.drill.exec.physical.impl.SimpleRootExec
-
Deprecated.
- simpleSchema - Static variable in class org.apache.drill.exec.store.parquet.ParquetSimpleTestFileGenerator
-
- simpleSchemaMsg - Static variable in class org.apache.drill.exec.store.parquet.ParquetSimpleTestFileGenerator
-
- simpleSelect() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- simpleSelectLimit0() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- simpleSingleBatchSumTestPhase1of1() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggBatch
-
- simpleSingleBatchSumTestPhase1of2() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggBatch
-
- simpleSingleBatchSumTestPhase2of2() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggBatch
-
- simpleSpillTest() - Method in class org.apache.drill.exec.physical.impl.join.TestPartitionStat
-
- SimpleSV4RecordBatch(VectorContainer, SelectionVector4, FragmentContext) - Constructor for class org.apache.drill.exec.physical.impl.TopN.TopNBatch.SimpleSV4RecordBatch
-
- simpleUnorderedComparisonMatchTest() - Method in class org.apache.drill.test.rowSet.TestRowSetComparison
-
- simpleUnorderedComparisonNoMatchTest() - Method in class org.apache.drill.test.rowSet.TestRowSetComparison
-
- simpleVarcharUnorderedComparisonMatchTest() - Method in class org.apache.drill.test.rowSet.TestRowSetComparison
-
- simpleVarcharUnorderedComparisonNoMatchTest() - Method in class org.apache.drill.test.rowSet.TestRowSetComparison
-
- SimpleVectorState(WriterPosition, ValueVector) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState.SimpleVectorState
-
- SimpleVectorWrapper<T extends ValueVector> - Class in org.apache.drill.exec.record
-
- SimpleVectorWrapper(T) - Constructor for class org.apache.drill.exec.record.SimpleVectorWrapper
-
- simplifyCast(List<RexNode>) - Static method in class org.apache.drill.exec.planner.logical.DrillMergeProjectRule
-
- SINGLE_CACHE_CONFIG - Static variable in class org.apache.drill.exec.physical.impl.orderedpartitioner.OrderedPartitionRecordBatch
-
- SINGLE_EMPTY_JSON - Variable in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- SINGLE_EMPTY_JSON2 - Variable in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- SINGLE_JSON - Variable in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- SINGLE_JSON2 - Variable in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- SingleBatchResults(BatchGroup.InputBatch, VectorContainer) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl.SingleBatchResults
-
- 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
-
- singleList(Object) - Static method in class org.apache.drill.test.rowSet.RowSetUtilities
-
- singleMap(Object) - Static method in class org.apache.drill.test.rowSet.RowSetUtilities
-
- SingleMapState(LoaderInternals, ResultVectorCache, RequestedTuple) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TupleState.SingleMapState
-
- 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
-
- singleObjArray(Object) - Static method in class org.apache.drill.test.rowSet.RowSetUtilities
-
- SinglePrel - Class in org.apache.drill.exec.planner.physical
-
- SinglePrel(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.drill.exec.planner.physical.SinglePrel
-
- SingleRowListener - Class in org.apache.drill
-
Result listener that is set up to receive a single row.
- SingleRowListener() - Constructor for class org.apache.drill.SingleRowListener
-
- SingleSchemaInference - Class in org.apache.drill.exec.physical.rowSet.model.single
-
Produce a metadata schema from a vector container.
- SingleSchemaInference() - Constructor for class org.apache.drill.exec.physical.rowSet.model.single.SingleSchemaInference
-
- 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.Metric - Enum in org.apache.drill.exec.physical.impl
-
- SingleSenderRootExec(RootFragmentContext, RecordBatch, SingleSender) - Constructor for class org.apache.drill.exec.physical.impl.SingleSenderCreator.SingleSenderRootExec
-
- SINGLETON - Static variable in class org.apache.drill.exec.planner.physical.DrillDistributionTrait
-
- singletonDouble() - Method in class org.apache.drill.test.QueryBuilder
-
Run the query that is expected to return (at least) one row
with the only (or first) column returning a double value.
- singletonInt() - Method in class org.apache.drill.test.QueryBuilder
-
Run the query that is expected to return (at least) one row
with the only (or first) column returning a int value.
- singletonLong() - Method in class org.apache.drill.test.QueryBuilder
-
Run the query that is expected to return (at least) one row
with the only (or first) column returning a long value.
- singletonString() - Method in class org.apache.drill.test.QueryBuilder
-
Run the query that is expected to return (at least) one row
with the only (or first) column returning a string value.
- SingleVectorState - Class in org.apache.drill.exec.physical.rowSet.impl
-
Base class for a single vector.
- SingleVectorState(WriterPosition, ValueVector) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState
-
- SingleVectorState.FixedWidthVectorState - Class in org.apache.drill.exec.physical.rowSet.impl
-
State for a scalar value vector.
- SingleVectorState.IsSetVectorState - Class in org.apache.drill.exec.physical.rowSet.impl
-
- SingleVectorState.OffsetVectorState - Class in org.apache.drill.exec.physical.rowSet.impl
-
Special case for an offset vector.
- SingleVectorState.SimpleVectorState - Class in org.apache.drill.exec.physical.rowSet.impl
-
- SingleVectorState.VariableWidthVectorState - Class in org.apache.drill.exec.physical.rowSet.impl
-
State for a scalar value vector.
- siteClass - Variable in class org.apache.drill.exec.testing.Injection
-
- sixthTest() - Method in class org.apache.drill.test.ExampleTest
-
This example shows how to define a workspace that points to test files in src/main/resources.
- 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.physical.rowSet.model.BaseTupleModel
-
- size() - Method in class org.apache.drill.exec.physical.rowSet.model.ReaderIndex
-
- size() - Method in interface org.apache.drill.exec.physical.rowSet.model.TupleModel
-
- size() - Method in class org.apache.drill.exec.planner.sql.ExpandingConcurrentMap
-
- size - Variable in enum org.apache.drill.exec.record.BatchSchema.SelectionVectorMode
-
- size() - Method in class org.apache.drill.exec.record.metadata.TupleSchema
-
- size() - Method in class org.apache.drill.exec.record.metadata.VariantSchema
-
- size() - Method in class org.apache.drill.exec.store.parquet.ColumnDataReader.HadoopBytesInput
-
- size() - Method in interface org.apache.drill.exec.work.batch.BaseRawBatchBuffer.BufferQueue
-
- size() - Method in class org.apache.drill.test.BaseTestQuery.TestResultSet
-
Deprecated.
- size() - Method in class org.apache.drill.test.rowSet.AbstractRowSet
-
- size() - Method in class org.apache.drill.test.rowSet.AbstractSingleRowSet
-
- size() - Method in class org.apache.drill.test.rowSet.IndirectRowSet
-
- size() - Method in interface org.apache.drill.test.rowSet.RowSet
-
Return the size in memory of this record set, including indirection
vectors, null vectors, offset vectors and the entire (used and unused)
data vectors.
- 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
-
- skipAndLimit() - Method in class org.apache.drill.exec.testing.TestExceptionInjection
-
- skipBytes(int) - Method in class org.apache.drill.exec.record.DeadBuf
-
- skipFirstLine - Variable in class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
-
- skipOuterList(boolean) - Method in class org.apache.drill.exec.vector.complex.fn.JsonReader.Builder
-
- 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
-
- skipRows(int) - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- skipRows(int) - Method in interface org.apache.drill.exec.physical.rowSet.ResultSetLoader
-
Requests to skip the given number of rows.
- SLAB_SIZE - Static variable in class org.apache.drill.exec.physical.impl.scan.project.TestRowBatchMerger
-
- slash - Variable in class org.apache.drill.exec.compile.ClassTransformer.ClassNames
-
- 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
-
- SmallFileCreator(File) - Constructor for class org.apache.drill.exec.fn.interp.TestConstantFolding.SmallFileCreator
-
- 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
-
- SmoothingProjection - Class in org.apache.drill.exec.physical.impl.scan.project
-
Resolve a table schema against the prior schema.
- SmoothingProjection(ScanLevelProjection, TupleMetadata, ResolvedTuple, ResolvedTuple, List<SchemaLevelProjection.SchemaProjectionResolver>) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.SmoothingProjection
-
- snapshot(SchemaVersion) - Method in class org.apache.drill.exec.store.AbstractSchema
-
- SoftAffinityFragmentParallelizer - Class in org.apache.drill.exec.planner.fragment
-
- 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
-
- someColumnsIndexed(Collection<LogicalExpression>) - Method in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- someColumnsIndexed(Collection<LogicalExpression>) - Method in interface org.apache.drill.exec.planner.index.IndexDefinition
-
Check if this index has some columns specified in the supplied list of columns indexed
- someColumnsInIndexFields(Collection<LogicalExpression>, Collection<LogicalExpression>) - Method in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- someTargetUsers() - Method in class org.apache.drill.exec.impersonation.TestInboundImpersonationPrivileges
-
- someTargetUsersAndGroups() - Method in class org.apache.drill.exec.impersonation.TestInboundImpersonationPrivileges
-
- 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
-
- sort - Variable in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- sort - Variable in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- sort() - Method in class org.apache.drill.exec.store.parquet.TestParquetComplex
-
- SORT_FILTER_PROJECT_SCAN - Static variable in class org.apache.drill.exec.planner.index.rules.DbScanToIndexScanPrule
-
- SORT_PROJECT_FILTER_PROJECT_SCAN - Static variable in class org.apache.drill.exec.planner.index.rules.DbScanToIndexScanPrule
-
- SORT_PROJECT_FILTER_SCAN - Static variable in class org.apache.drill.exec.planner.index.rules.DbScanToIndexScanPrule
-
- SORT_REMOVE_RULE - Static variable in interface org.apache.drill.exec.planner.RuleInstance
-
- 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, OptionManager) - 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
-
- sortExprs - Variable in class org.apache.drill.exec.planner.index.IndexLogicalPlanCallContext
-
- sortExprs - Variable in class org.apache.drill.exec.planner.index.IndexPhysicalPlanCallContext
-
- 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.SingleBatchResults - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
Return results for a single input batch.
- 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.MergeAction - Enum in org.apache.drill.exec.physical.impl.xsort.managed
-
- SortMemoryManager.MergeTask - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
- SortMetrics - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
- SortMetrics(OperatorStats) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.SortMetrics
-
- sortOneKeyAscending() - Method in class org.apache.drill.exec.physical.impl.sort.TestSimpleSort
-
- sortOneKeyAscending() - Method in class org.apache.drill.exec.physical.impl.TopN.TopNBatchTest
-
End to end test of the TopN operator.
- sortOneKeyDescendingExternalSortLegacy() - Method in class org.apache.drill.exec.physical.impl.xsort.TestSimpleExternalSort
-
- sortOneKeyDescendingExternalSortManaged() - Method in class org.apache.drill.exec.physical.impl.xsort.TestSimpleExternalSort
-
- sortOneKeyDescendingMergeSortLegacy() - Method in class org.apache.drill.exec.physical.impl.xsort.TestSimpleExternalSort
-
- sortOneKeyDescendingMergeSortManaged() - Method in class org.apache.drill.exec.physical.impl.xsort.TestSimpleExternalSort
-
- 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.
- SortPrel(RelOptCluster, RelTraitSet, RelNode, RelCollation, boolean) - Constructor for class org.apache.drill.exec.planner.physical.SortPrel
-
Creates a DrillSortRel.
- 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
-
- SortTest - Class in org.apache.drill.exec
-
- SortTestFixture(OperatorFixture) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl.SortTestFixture
-
- SortTestFixture(OperatorFixture, String, String) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl.SortTestFixture
-
- SortTestUtilities - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
- SortTestUtilities.CopierTester - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
- sortTwoKeysOneAscendingOneDescending() - Method in class org.apache.drill.exec.physical.impl.sort.TestSimpleSort
-
- source - Variable in class org.apache.drill.exec.physical.impl.scan.project.ResolvedColumn
-
- source() - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedColumn
-
- 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 class org.apache.drill.exec.planner.cost.DrillRelMdSelectivity
-
- source - Variable in class org.apache.drill.exec.store.sys.FunctionsIterator.FunctionInfo
-
- sourceIndex - Variable in class org.apache.drill.exec.physical.impl.scan.project.ResolvedColumn
-
- sourceIndex() - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedColumn
-
- span(int) - Method in class org.apache.drill.test.rowSet.RowSetComparison
-
Specify a subset of rows to compare.
- SPENGO_LOGIN_RESOURCE_NAME - Static variable in class org.apache.drill.exec.server.rest.WebServerConstants
-
- SPENGO_LOGIN_RESOURCE_PATH - Static variable in class org.apache.drill.exec.server.rest.WebServerConstants
-
- spill() - Method in class org.apache.drill.exec.physical.impl.join.PartitionStatImpl
-
- 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
-
- SpilledPartitionMetadata - Interface in org.apache.drill.exec.physical.impl.common
-
This interface represents the metadata for a spilled partition.
- 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
-
- SpilledRun(SpillSet, String, BufferAllocator) - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.BatchGroup.SpilledRun
-
- 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
-
- SpilledState<T extends SpilledPartitionMetadata> - Class in org.apache.drill.exec.physical.impl.common
-
Manages the spilling information for an operator.
- SpilledState() - Constructor for class org.apache.drill.exec.physical.impl.common.SpilledState
-
- SpilledState.Updater - Interface in org.apache.drill.exec.physical.impl.common
-
This is a class that is used to do updates of the spilled state.
- 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.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.
- spillSingleIncompleteBatchBuildSideTest() - Method in class org.apache.drill.exec.physical.impl.common.HashPartitionTest
-
- spillThisPartition() - Method in class org.apache.drill.exec.physical.impl.common.HashPartition
-
- Split() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Split
-
- SplitNullableInput() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.SplitNullableInput
-
- SplitPart() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.SplitPart
-
- 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
-
- SpnegoConfig - Class in org.apache.drill.exec.server.rest.auth
-
- SpnegoConfig(DrillConfig) - Constructor for class org.apache.drill.exec.server.rest.auth.SpnegoConfig
-
- SpnegoSecurityHandler - Class in org.apache.drill.exec.server.rest.auth
-
- SpnegoSecurityHandler() - Constructor for class org.apache.drill.exec.server.rest.auth.SpnegoSecurityHandler
-
- 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(String) - Method in class org.apache.drill.test.QueryBuilder
-
- sql(String, Object...) - Method in class org.apache.drill.test.QueryBuilder
-
- sql(File) - Method in class org.apache.drill.test.QueryBuilder
-
Parse a single SQL statement (with optional ending semi-colon) from
the file provided.
- SqlAccessor - Interface in org.apache.drill.exec.vector.accessor
-
Column-data accessor that implements JDBC's Java-null--when--SQL-NULL mapping.
- sqlBaselineQuery(Object) - Method in class org.apache.drill.test.TestBuilder
-
Provide a SQL query to validate against.
- sqlBaselineQuery(String, String...) - Method in class org.apache.drill.test.TestBuilder
-
- sqlBaselineQueryFromFile(String) - Method in class org.apache.drill.test.TestBuilder
-
- 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 - Class in org.apache.drill.exec.planner.sql.parser
-
- SqlCreateFunction(SqlParserPos, SqlNode) - Constructor for class org.apache.drill.exec.planner.sql.parser.SqlCreateFunction
-
- 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
-
- 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 - 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 - 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
-
- 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
-
- 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
-
SQL Pattern Contains implementation
- 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
-
- SqlPatternInfo(RegexpUtil.SqlPatternType, String, String) - Constructor for class org.apache.drill.exec.expr.fn.impl.RegexpUtil.SqlPatternInfo
-
- 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
-
- sqlQuery(String) - Method in class org.apache.drill.test.TestBuilder
-
- sqlQuery(String, Object...) - Method in class org.apache.drill.test.TestBuilder
-
- sqlQueryFromFile(String) - Method in class org.apache.drill.test.TestBuilder
-
- 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
-
- sqlResource(String) - Method in class org.apache.drill.test.QueryBuilder
-
Run a query contained in a resource file.
- sqlResource(String, Object...) - Method in class org.apache.drill.test.QueryBuilder
-
- 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 - 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 - 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
-
- SqlSumCountAggFunction(RelDataType) - Constructor for class org.apache.drill.exec.planner.physical.AggPrelBase.SqlSumCountAggFunction
-
- 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.
- 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
-
- 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
-
- 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
-
- standardCluster(BaseDirTestWatcher) - Static method in class org.apache.drill.test.ClusterFixture
-
Return a cluster fixture built with standard options.
- standardFixture(BaseDirTestWatcher) - Static method in class org.apache.drill.test.OperatorFixture
-
- 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() - Method in class org.apache.drill.exec.physical.rowSet.impl.RowSetLoaderImpl
-
- start() - Method in interface org.apache.drill.exec.physical.rowSet.RowSetLoader
-
Prepare a new row for writing.
- 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.Metadata_V1.RowGroupMetadata_v1
-
- start - Variable in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.RowGroupMetadata_v2
-
- start - Variable in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.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.physical.impl.scan.project.ScanSchemaOrchestrator.ReaderSchemaOrchestrator
-
- startBatch(boolean) - Method in class org.apache.drill.exec.physical.rowSet.impl.ColumnState.BaseContainerColumnState
-
- startBatch(boolean) - Method in class org.apache.drill.exec.physical.rowSet.impl.ColumnState
-
Prepare the column for a new row batch after overflow on the previous
batch.
- startBatch(boolean) - Method in class org.apache.drill.exec.physical.rowSet.impl.ContainerState
-
Start a new batch by shifting the overflow buffers back into the main
write vectors and updating the writers.
- startBatch() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- startBatch(boolean) - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- startBatch() - Method in interface org.apache.drill.exec.physical.rowSet.ResultSetLoader
-
Start a new row batch.
- startBatch() - Method in class org.apache.drill.exec.store.easy.text.compliant.HeaderBuilder
-
- startBatchWithLookAhead() - Method in class org.apache.drill.exec.physical.rowSet.impl.ListState.ListVectorState
-
- startBatchWithLookAhead() - Method in class org.apache.drill.exec.physical.rowSet.impl.NullableVectorState
-
- startBatchWithLookAhead() - Method in class org.apache.drill.exec.physical.rowSet.impl.NullVectorState
-
- startBatchWithLookAhead() - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedListState.RepeatedListVectorState
-
- startBatchWithLookAhead() - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedVectorState
-
- startBatchWithLookAhead() - Method in class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState
-
The previous full batch has been sent downstream and the client is
now ready to start writing to the next batch.
- startBatchWithLookAhead() - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState.MapVectorState
-
- startBatchWithLookAhead() - Method in class org.apache.drill.exec.physical.rowSet.impl.UnionState.UnionVectorState
-
- startBatchWithLookAhead() - Method in interface org.apache.drill.exec.physical.rowSet.impl.VectorState
-
A new batch is starting while an look-ahead vector exists.
- startBitMasks - Static variable in class org.apache.drill.exec.store.parquet.columnreaders.ParquetRecordReader
-
- startCluster(int) - Method in class org.apache.drill.exec.DrillSystemTestBase
-
- startCluster(ClusterFixtureBuilder) - Static method in class org.apache.drill.test.ClusterTest
-
- startDrillCluster(boolean) - Static method in class org.apache.drill.exec.impersonation.BaseTestImpersonation
-
- startDrillCluster(Properties) - Static method in class org.apache.drill.exec.impersonation.BaseTestImpersonation
-
- startEmptyBatch() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- 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
-
- 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.
- starting(Description) - Method in class org.apache.drill.test.BaseDirTestWatcher
-
- 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
-
- startMiniDfsCluster(String) - Static method in class org.apache.drill.exec.impersonation.BaseTestImpersonation
-
Start a MiniDFS cluster backed Drillbit cluster with impersonation enabled.
- startMiniDfsCluster(String, boolean) - Static method in class org.apache.drill.exec.impersonation.BaseTestImpersonation
-
Start a MiniDFS cluster backed Drillbit cluster
- startNewFragment(BitControl.PlanFragment, DrillbitContext) - Method in class org.apache.drill.exec.work.batch.ControlMessageHandler
-
Start a new fragment on this node.
- 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
-
- startProcessingEvents() - Method in class org.apache.drill.exec.work.foreman.Foreman
-
While one fragments where sanding out, other might have been completed.
- startProcessingEvents() - Method in class org.apache.drill.exec.work.foreman.QueryStateProcessor
-
Starts processing all events that were enqueued while all fragments were sending out.
- startReader() - Method in class org.apache.drill.exec.physical.impl.scan.project.ScanSchemaOrchestrator
-
- startRecord() - Method in class org.apache.drill.exec.store.avro.AvroTestUtil.AvroTestRecordWriter
-
- 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 class org.apache.drill.exec.store.text.DrillTextRecordWriter
-
- startResolution() - Method in interface org.apache.drill.exec.physical.impl.scan.project.SchemaLevelProjection.SchemaProjectionResolver
-
- startRM() - Method in class org.apache.drill.exec.server.DrillbitContext
-
Starts the resource manager.
- startRow() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
Called before writing a new row.
- startSetup() - Method in class org.apache.drill.exec.ops.OperatorStats
-
- startSomeDrillbits() - Static method in class org.apache.drill.exec.server.TestDrillbitResilience
-
- startTime - Variable in class org.apache.drill.exec.store.sys.ProfileInfoIterator.ProfileInfo
-
- startup(File) - Method in class org.apache.drill.exec.util.MiniZooKeeperCluster
-
- startup(File, int) - Method in class org.apache.drill.exec.util.MiniZooKeeperCluster
-
- 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
-
- startZookeeper(int) - Method in class org.apache.drill.exec.ZookeeperHelper
-
Start the Zookeeper instance.
- state - Variable in class org.apache.drill.exec.physical.rowSet.impl.ColumnState
-
- state - Variable in class org.apache.drill.exec.record.AbstractRecordBatch
-
- state - Variable in class org.apache.drill.exec.store.sys.DrillbitIterator.DrillbitInstance
-
- state - Variable in class org.apache.drill.exec.store.sys.ProfileInfoIterator.ProfileInfo
-
- state - Variable in class org.apache.drill.test.BufferingQueryEventListener.QueryEvent
-
- StatementParser(Reader) - Constructor for class org.apache.drill.test.ClientFixture.StatementParser
-
- 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
-
- StaticColumnLoader - Class in org.apache.drill.exec.physical.impl.scan.project
-
Base class for columns that take values based on the
reader, not individual rows.
- StaticColumnLoader(ResultVectorCache) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.StaticColumnLoader
-
- StaticDrillTable - Class in org.apache.drill.exec.store.sys
-
- StaticDrillTable(String, StoragePlugin, Schema.TableType, Object, RecordDataType) - Constructor for class org.apache.drill.exec.store.sys.StaticDrillTable
-
- Statistics - Interface in org.apache.drill.exec.planner.index
-
- StatisticsPayload - Interface in org.apache.drill.exec.planner.index
-
- 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
-
- STATS_LOGGING_BATCH_FG_SIZE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
-
- STATS_LOGGING_BATCH_OPERATOR_OPTION - Static variable in class org.apache.drill.exec.ExecConstants
-
Controls the list of operators for which batch sizing stats should be enabled
- STATS_LOGGING_BATCH_OPERATOR_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
-
- STATS_LOGGING_BATCH_SIZE_OPTION - Static variable in class org.apache.drill.exec.ExecConstants
-
Enables batch size statistics logging
- STATS_LOGGING_BATCH_SIZE_VALIDATOR - Static variable in class org.apache.drill.exec.ExecConstants
-
- STATS_LOGGING_FG_BATCH_SIZE_OPTION - Static variable in class org.apache.drill.exec.ExecConstants
-
Enables fine-grained batch size statistics logging
- 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.ExtendedOptionIterator.ExtendedOptionValueWrapper
-
- 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
-
- StatusResourcesTest - Class in org.apache.drill.exec.server.rest
-
- StatusResourcesTest() - Constructor for class org.apache.drill.exec.server.rest.StatusResourcesTest
-
- 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
-
- stddevEmptyNonexistentNullableInput() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- stepId - Variable in class org.apache.drill.test.ProfileParser.OperatorSummary
-
- stopCluster() - Method in class org.apache.drill.exec.DrillSystemTestBase
-
- stopKdc() - Method in class org.apache.drill.exec.rpc.security.KerberosHelper
-
Workspace is owned by test using this helper
- stopMiniDfsCluster() - Static method in class org.apache.drill.exec.impersonation.BaseTestImpersonation
-
- 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
-
- stopZookeeper() - Method in class org.apache.drill.exec.ZookeeperHelper
-
Shut down the Zookeeper instance.
- 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
-
- StoragePlugins - Class in org.apache.drill.exec.planner.logical
-
- StoragePlugins(Map<String, StoragePluginConfig>) - Constructor for class org.apache.drill.exec.planner.logical.StoragePlugins
-
- StoragePluginsHandler - Interface in org.apache.drill.exec.store
-
Storage plugins handler is an additional service for updating storage plugins configs from the file
- StoragePluginsHandlerService - Class in org.apache.drill.exec.store
-
- StoragePluginsHandlerService(DrillbitContext) - Constructor for class org.apache.drill.exec.store.StoragePluginsHandlerService
-
- 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
-
- storages - Variable in class org.apache.calcite.jdbc.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
-
- StorageStrategyTest - Class in org.apache.drill.exec.store
-
- StorageStrategyTest() - Constructor for class org.apache.drill.exec.store.StorageStrategyTest
-
- Store - Interface in org.apache.drill.exec.physical.base
-
An interface which supports storing a record stream.
- Store<V> - Interface in org.apache.drill.exec.store.sys
-
A Store interface used to store and retrieve instances of given value type.
- StoreConfigBuilder(InstanceSerializer<V>) - Constructor for class org.apache.drill.exec.store.sys.PersistentStoreConfig.StoreConfigBuilder
-
- 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
-
- StraightCopier - Class in org.apache.drill.exec.physical.impl.svremover
-
- StraightCopier(RecordBatch, VectorContainer, SchemaChangeCallBack) - Constructor for class org.apache.drill.exec.physical.impl.svremover.StraightCopier
-
- strArray(String...) - Static method in class org.apache.drill.test.rowSet.RowSetUtilities
-
- 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
-
The Aggregator can return one of the following outcomes:
- StreamingAggTemplate - Class in org.apache.drill.exec.physical.impl.aggregate
-
- StreamingAggTemplate() - Constructor for class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
-
- STRICT_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 strict EQUAL or IS_DISTINCT_FROM conditions (without any mathematical operations) over RexInputRef in INNER join.
- 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.server.options.PersistedOptionValueTest.MockPersistedOptionValue
-
- string_val - Variable in class org.apache.drill.exec.store.sys.OptionIterator.OptionValueWrapper
-
- StringBinary() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.StringBinary
-
- stringCastForDecimal() - Method in class org.apache.drill.exec.work.prepare.TestLimit0VsRegularQueriesMetadata
-
- StringCastReturnTypeInference - Class in org.apache.drill.exec.expr.fn.output
-
- StringCastReturnTypeInference() - Constructor for class org.apache.drill.exec.expr.fn.output.StringCastReturnTypeInference
-
- stringCasts() - Method in class org.apache.drill.exec.work.prepare.TestLimit0VsRegularQueriesMetadata
-
- 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.AsciiString - Class in org.apache.drill.exec.expr.fn.impl
-
Returns the ASCII code of the first character of input string
- StringFunctions.AsciiToChar - Class in org.apache.drill.exec.expr.fn.impl
-
Returns the char corresponding to ASCII code input.
- StringFunctions.BinaryString - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.BitLength - Class in org.apache.drill.exec.expr.fn.impl
-
- 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.BtrimOneArg - Class in org.apache.drill.exec.expr.fn.impl
-
Remove the longest string containing only character " " from the start of "text"
- StringFunctions.ByteLength - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.CharLength - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.Concat - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.ConcatBothNullInput - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.ConcatLeftNullInput - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.ConcatOperator - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.ConcatRightNullInput - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.ILike - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.ILikeWithEscape - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.InitCap - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.Left - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.Like - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.LikeWithEscape - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.LowerCase - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.Lpad - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.LpadTwoArg - Class in org.apache.drill.exec.expr.fn.impl
-
- 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.LtrimOneArg - Class in org.apache.drill.exec.expr.fn.impl
-
Remove the longest string containing only character " " from the start of "text"
- StringFunctions.OctetLength - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.Position - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.RegexpMatches - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.RegexpReplace - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.RepeatString - Class in org.apache.drill.exec.expr.fn.impl
-
Returns the input char sequences repeated nTimes.
- StringFunctions.Replace - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.ReverseString - Class in org.apache.drill.exec.expr.fn.impl
-
Returns the reverse string for given input.
- StringFunctions.Right - Class in org.apache.drill.exec.expr.fn.impl
-
- 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.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.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.RtrimOneArg - Class in org.apache.drill.exec.expr.fn.impl
-
Remove the longest string containing only character " " from the end of "text"
- StringFunctions.Similar - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.SimilarWithEscape - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.Split - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.SplitNullableInput - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.SplitPart - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.StringBinary - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.Strpos - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.Substring - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.SubstringOffset - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.SubstringRegex - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.SubstringRegexNullable - Class in org.apache.drill.exec.expr.fn.impl
-
- StringFunctions.UpperCase - Class in org.apache.drill.exec.expr.fn.impl
-
- 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
-
- stringify(Object) - Static method in class org.apache.drill.test.ClusterFixture
-
Convert a Java object (typically a boxed scalar) to a string
for use in SQL.
- stringifyFragments() - Method in class org.apache.drill.exec.work.QueryWorkUnit
-
Converts list of stored fragments into their string representation,
in case of exception returns text indicating that string was malformed.
- stringLeftMatchUTF8(ByteBuf, int, int, ByteBuf, int, int) - Static method in class org.apache.drill.exec.expr.fn.impl.StringFunctionUtil
-
- StringValidator(String, OptionValidator.OptionDescription) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.StringValidator
-
- StringWriter(String, DrillBuf) - Constructor for class org.apache.drill.exec.store.pojo.PojoWriters.StringWriter
-
- Strpos() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Strpos
-
- structureType() - Method in class org.apache.drill.exec.record.metadata.MapColumnMetadata
-
- structureType() - Method in class org.apache.drill.exec.record.metadata.PrimitiveColumnMetadata
-
- structureType() - Method in class org.apache.drill.exec.record.metadata.RepeatedListColumnMetadata
-
- structureType() - Method in class org.apache.drill.exec.record.metadata.VariantColumnMetadata
-
- STUFF_COL - Static variable in class org.apache.drill.exec.physical.impl.agg.TestHashAggBatch
-
- SUB_QUERY_FILTER_REMOVE_RULE - Static variable in interface org.apache.drill.exec.planner.RuleInstance
-
- SUB_QUERY_JOIN_REMOVE_RULE - Static variable in interface org.apache.drill.exec.planner.RuleInstance
-
- SUB_QUERY_PROJECT_REMOVE_RULE - Static variable in interface org.apache.drill.exec.planner.RuleInstance
-
- SubDirectoryList - Class in org.apache.drill.exec.store.dfs
-
- subDirTestWatcher - Variable in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- subDirTestWatcher - Variable in class org.apache.drill.exec.physical.impl.join.TestMergeJoinWithSchemaChanges
-
- 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.LoggingResultsListener
-
- 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.
- submissionFailed(UserException) - Method in class org.apache.drill.exec.store.parquet.ParquetResultListener
-
- submissionFailed(UserException) - Method in class org.apache.drill.SingleRowListener
-
- submissionFailed(UserException) - Method in class org.apache.drill.test.BaseTestQuery.SilentListener
-
Deprecated.
- submissionFailed(UserException) - Method in class org.apache.drill.test.BufferingQueryEventListener
-
- submissionFailed(UserException) - Method in class org.apache.drill.test.PrintingResultsListener
-
- submissionFailed(UserException) - Method in class org.apache.drill.test.QueryBuilder.SummaryOnlyQueryEventListener
-
- submit(ExecutorService, Callable<T>) - Static method in class org.apache.drill.exec.util.concurrent.ExecutorServiceUtil
-
Helper method to submit the callabale task, gets the original future object, and wrap it
in another future object with the ability to decorate the
Future.cancel(boolean)
method;
this decorator will block when future cancellation is invoked (and the "mayInterruptIfRunning"
parameter is set to true).
- submit() - Method in class org.apache.drill.exec.work.foreman.FragmentsRunner
-
Submits root and non-root fragments fragments for running.
- 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
-
- SubOperatorTest - Class in org.apache.drill.test
-
- SubOperatorTest() - Constructor for class org.apache.drill.test.SubOperatorTest
-
- 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
-
- substr() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- Substring() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.Substring
-
- substring() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- SubstringOffset() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.SubstringOffset
-
- SubstringRegex() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.SubstringRegex
-
- SubstringRegexNullable() - Constructor for class org.apache.drill.exec.expr.fn.impl.StringFunctions.SubstringRegexNullable
-
- substringTest(String, int) - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- subsumeColumn(Map<String, String>, String) - Static method in class org.apache.drill.exec.planner.StarColumnHelper
-
- subtreeLabel(ProfileParser.OperatorSummary, int) - Method in class org.apache.drill.test.ProfileParser.TreeVisitor
-
- succeeded() - Method in class org.apache.drill.test.QueryBuilder.QuerySummary
-
- success(GeneralRPCProtos.Ack, ByteBuf) - Method in class org.apache.drill.exec.ops.StatusHandler
-
- success() - Method in class org.apache.drill.exec.rpc.data.TestBitBitKerberos
-
- successEncryption() - Method in class org.apache.drill.exec.rpc.data.TestBitBitKerberos
-
- successEncryptionAllChannel() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberosEncryption
-
This test will not cover the data channel since we are using only 1 Drillbit and the query doesn't involve
any exchange operator.
- successEncryptionAllChannelChunkMode() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberosEncryption
-
This test will not cover the data channel since we are using only 1 Drillbit and the query doesn't involve
any exchange operator.
- successEncryptionChunkMode() - Method in class org.apache.drill.exec.rpc.data.TestBitBitKerberos
-
- successfullyCompletes() - Method in class org.apache.drill.exec.server.TestDrillbitResilience
-
- successKeytab() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberos
-
- successKeytabWithChunking() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberosEncryption
-
- successKeytabWithChunkingDefaultChunkSize() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberosEncryption
-
- successKeytabWithoutChunking() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberosEncryption
-
- successOldClientEncryptionDisabled() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberosEncryption
-
Test to validate that older clients are successfully connecting to secure cluster
with encryption disabled.
- successTicket() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberos
-
- successTicketWithoutChunking() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberosEncryption
-
- SUM - Static variable in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
-
- sumCast() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- sumEmptyNonexistentNullableInput() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- summary() - Method in class org.apache.drill.exec.physical.rowSet.project.RequestedColumnImpl
-
- summary() - Method in interface org.apache.drill.exec.physical.rowSet.project.RequestedTuple.RequestedColumn
-
- summary - Variable in class org.apache.drill.exec.planner.sql.handlers.SimpleCommandResult
-
- SummaryOnlyQueryEventListener(QueryBuilder.QuerySummaryFuture) - Constructor for class org.apache.drill.test.QueryBuilder.SummaryOnlyQueryEventListener
-
- sums() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- sumsAndCounts1() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- sumsAndCounts2() - Method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- 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.metadata.MetadataVersion.Constants
-
All historical versions of the Drill metadata cache files.
- supportEqualCharConvertToLike() - Method in interface org.apache.drill.exec.planner.index.FunctionalIndexInfo
-
Whether this implementation( may be different per storage) support rewrite rewriting varchar equality expression,
e.g.
- 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
-
- supportsFileImplicitColumns() - Method in class org.apache.drill.exec.store.parquet.AbstractParquetGroupScan
-
- supportsFileImplicitColumns() - Method in class org.apache.drill.exec.store.parquet.AbstractParquetRowGroupScan
-
- supportsFileImplicitColumns() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
-
- supportsFileImplicitColumns() - Method in class org.apache.drill.exec.store.parquet.ParquetRowGroupScan
-
- supportsFullTextSearch() - Method in class org.apache.drill.exec.planner.index.AbstractIndexCollection
-
- supportsFullTextSearch() - Method in class org.apache.drill.exec.planner.index.AbstractIndexDescriptor
-
- supportsFullTextSearch() - Method in class org.apache.drill.exec.planner.index.DrillIndexCollection
-
- supportsFullTextSearch() - Method in interface org.apache.drill.exec.planner.index.IndexCollection
-
Whether or not the index supports full-text search (to allow pushing down such filters)
- supportsFullTextSearch() - Method in interface org.apache.drill.exec.planner.index.IndexDescriptor
-
Whether or not the index supports full-text search (to allow pushing down such filters)
- supportsIndexSelection() - Method in class org.apache.drill.exec.planner.index.AbstractIndexCollection
-
- supportsIndexSelection() - Method in class org.apache.drill.exec.planner.index.DrillIndexCollection
-
- supportsIndexSelection() - Method in interface org.apache.drill.exec.planner.index.IndexCollection
-
Whether or not this index collection supports index selection (selecting an
appropriate index out of multiple candidates).
- 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.AbstractParquetGroupScan
-
- supportsLimitPushdown() - Method in class org.apache.drill.exec.store.sys.SystemTableScan
-
- 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)
- supportsPartitionFilterPushdown() - Method in class org.apache.drill.exec.physical.base.SchemalessScan
-
- 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.image.ImageFormatPlugin
-
- supportsPushDown() - Method in class org.apache.drill.exec.store.log.LogFormatPlugin
-
- supportsPushDown() - Method in class org.apache.drill.exec.store.pcap.PcapFormatPlugin
-
- supportsPushDown() - Method in class org.apache.drill.exec.store.pcapng.PcapngFormatPlugin
-
- 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.
- supportsRestrictedScan() - Method in class org.apache.drill.exec.physical.base.AbstractDbGroupScan
-
- supportsRestrictedScan() - Method in interface org.apache.drill.exec.physical.base.DbGroupScan
-
Whether this DbGroupScan supports creating a restricted (skip) scan
- supportsRowCountStats() - Method in class org.apache.drill.exec.planner.index.AbstractIndexCollection
-
- supportsRowCountStats() - Method in class org.apache.drill.exec.planner.index.AbstractIndexDescriptor
-
- supportsRowCountStats() - Method in class org.apache.drill.exec.planner.index.DrillIndexCollection
-
- supportsRowCountStats() - Method in interface org.apache.drill.exec.planner.index.IndexCollection
-
Whether or not the index supports getting row count statistics
- supportsRowCountStats() - Method in interface org.apache.drill.exec.planner.index.IndexDescriptor
-
Whether or not the index supports getting row count statistics
- supportsSecondaryIndex() - Method in class org.apache.drill.exec.physical.base.AbstractDbGroupScan
-
- supportsSecondaryIndex() - Method in interface org.apache.drill.exec.physical.base.DbGroupScan
-
- 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
-
- sv2 - Variable in class org.apache.drill.exec.physical.impl.MockRecordBatch
-
- sv2 - Variable in class org.apache.drill.exec.record.RecordBatchSizer
-
- sv4 - Variable in class org.apache.drill.exec.physical.impl.MockRecordBatch
-
- 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.
- sync() - Method in class org.apache.drill.exec.store.LocalSyncableFileSystem.LocalSyncableOutputStream
-
- SyncCustomMessageSender(BitControl.CustomMessage, ByteBuf[]) - Constructor for class org.apache.drill.exec.rpc.control.ControlTunnel.SyncCustomMessageSender
-
- syncWithRemoteRegistry(int) - 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_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_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
- systemOption(String, Object) - Method in class org.apache.drill.test.ClusterFixtureBuilder
-
Provide a system option to be set once the Drillbit
is started.
- systemOption(String, Object) - Method in class org.apache.drill.test.OperatorFixture.Builder
-
- SystemOptionManager - Class in org.apache.drill.exec.server.options
-
- 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.
- systemOptions - Variable in class org.apache.drill.test.ClusterFixtureBuilder
-
- systemOptions - Variable in class org.apache.drill.test.OperatorFixture.Builder
-
- SystemPlugin - Annotation Type in org.apache.drill.exec.store
-
Is used to indicated system plugins which will be dynamically initialized during storage plugin registry init stage.
- 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(DrillbitContext) - Constructor for class org.apache.drill.exec.store.sys.SystemTablePlugin
-
- 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, int, StoragePluginRegistry) - Constructor for class org.apache.drill.exec.store.sys.SystemTableScan
-
- SystemTableScan(SystemTable, SystemTablePlugin) - Constructor for class org.apache.drill.exec.store.sys.SystemTableScan
-
- SystemTableScan(SystemTable, int, SystemTablePlugin) - Constructor for class org.apache.drill.exec.store.sys.SystemTableScan
-
- t10_1_testStreamingAggr_InputSplitToMultipleOutputBatch() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
- t10_testStreamingAggrWithEmptyDataSet() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
- t11_testStreamingAggrEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Repeats t1_testStreamingAggrEmptyBatchEmitOutcome with no group by
- t12_testStreamingAggrNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Repeats t2_testStreamingAggrNonEmptyBatchEmitOutcome with no group by
- t13_testStreamingAggrEmptyBatchFollowedByNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Repeats t3_testStreamingAggrEmptyBatchFollowedByNonEmptyBatchEmitOutcome with no group by
- t14_testStreamingAggrMultipleEmptyBatchFollowedByNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Repeats t4_testStreamingAggrMultipleEmptyBatchFollowedByNonEmptyBatchEmitOutcome with no group by
- t15_testStreamingAgrResetsAfterFirstEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Repeats t5_testStreamingAgrResetsAfterFirstEmitOutcome with no group by
- t16_testStreamingAggrOkFollowedByNone() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Repeats t6_testStreamingAggrOkFollowedByNone with no group by
- t17_testStreamingAggrMultipleEMITOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Repeats t7_testStreamingAggrMultipleEMITOutcome with no group by
- t18_testStreamingAggrMultipleInputToSingleOutputBatch() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Repeats t8_testStreamingAggrMultipleInputToSingleOutputBatch with no group by
- t19_testStreamingAgr_WithEmptyNonEmptyBatchesAndOKOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Repeats t9_testStreamingAgr_WithEmptyNonEmptyBatchesAndOKOutcome with no group by
- t1_testStreamingAggrEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Verifies that if StreamingAggBatch receives empty batches with OK_NEW_SCHEMA and EMIT outcome then it correctly produces
empty batches as output.
- t20_testStreamingAggrWithEmptyDataSet() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Repeats t10_testStreamingAggrWithEmptyDataSet with no group by
- t21_testStreamingAggrRunsofEmpty_NonEmpty_Sv2() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Repeats t21_testStreamingAggrRunsofEmpty_NonEmpty_Sv2 with no group by
- t22_testStreamingAggrRunsOfEmpty_NonEmpty() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Repeats t22_testStreamingAggrRunsOfEmpty_NonEmpty with no group by
- t2_testStreamingAggrNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Verifies that if StreamingAgg receives a RecordBatch with EMIT outcome post build schema phase then it produces
output for those input batch correctly.
- t3_testStreamingAggrEmptyBatchFollowedByNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
- t4_testStreamingAggrMultipleEmptyBatchFollowedByNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
- t5_testStreamingAgrResetsAfterFirstEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Verifies that if StreamingAggr receives multiple non-empty record batch with EMIT outcome in between then it produces
output for those input batch correctly.
- t6_testStreamingAggrOkFollowedByNone() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Verifies that if StreamingAggr receives multiple non-empty record batch with EMIT outcome in between then it produces
output for those input batch correctly.
- t7_testStreamingAggrMultipleEMITOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Normal case
- t8_1_testStreamingAggr_InputSplitToMultipleOutputBatch() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Verifies scenario where multiple incoming batches received with OK_NEW_SCHEMA, OK, OK, EMIT whose output is split
into multiple output batches is handled correctly such that first output is produced with OK_NEW_SCHEMA and then
followed by EMIT outcome
- t8_2_testStreamingAggr_Inputs_OK_EMIT_SplitToMultipleOutputBatch() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Verifies scenario where multiple incoming batches received with OK_NEW_SCHEMA, OK, OK, EMIT whose output is split
into multiple output batches and incoming batches received with OK,OK,EMIT whose output is also split across
multiple output batches is handled correctly.
- t8_testStreamingAggrMultipleInputToSingleOutputBatch() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
- t9_testStreamingAgr_WithEmptyNonEmptyBatchesAndOKOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
Tests for validating regular StreamingAggr behavior with no EMIT outcome
- table - Variable in class org.apache.drill.exec.planner.index.AbstractIndexStatistics
-
- Table(String, String, String, String) - Constructor for class org.apache.drill.exec.store.ischema.Records.Table
-
- 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 - 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
-
- TableFunctionContract - Interface in org.apache.drill.exec.record
-
- tableName - Variable in class org.apache.drill.exec.planner.index.DrillIndexDefinition
-
- Tables(OptionManager) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Tables
-
- Tables() - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaTable.Tables
-
- tables(UserSession, DrillbitContext, UserProtos.GetTablesReq, ResponseSender) - Static method in class org.apache.drill.exec.work.metadata.MetadataProvider
-
- tables() - Method in class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- tableSchemaWhenSelectFieldsInDef_SelectFieldsInView() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- tablesWithSystemTableFilter() - Method in class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- tablesWithTableFilter() - Method in class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- tablesWithTableNameFilter() - Method in class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- tablesWithTableNameFilterAndSchemaNameFilter() - Method in class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- TabularResult(QueryWrapper.QueryResult) - Constructor for class org.apache.drill.exec.server.rest.QueryResources.TabularResult
-
- TAG_AUDIO_CODEC - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_AUDIO_SAMPLE_RATE - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_AUDIO_SAMPLE_SIZE - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_BITS_PER_PIXEL - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_COLOR_MODE - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_DPI_HEIGHT - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_DPI_WIDTH - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_DURATION - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_FILE_DATE_TIME - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_FILE_SIZE - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_FORMAT - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_FRAME_RATE - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_HAS_ALPHA - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_ORIENTATION - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_PIXEL_HEIGHT - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_PIXEL_WIDTH - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- TAG_VIDEO_CODEC - Static variable in class org.apache.drill.exec.store.image.GenericMetadataDirectory
-
- take() - Method in interface org.apache.drill.exec.work.batch.BaseRawBatchBuffer.BufferQueue
-
- tallyAllocations(int) - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- 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
-
- TARGET_NAME - Static variable in class org.apache.drill.exec.impersonation.TestInboundImpersonation
-
- TARGET_PASSWORD - Static variable in class org.apache.drill.exec.impersonation.TestInboundImpersonation
-
- targetRowCount() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- targetRowCount() - Method in interface org.apache.drill.exec.physical.rowSet.ResultSetLoader
-
The number of rows produced by this loader (as configured in the loader
options.)
- targetVectorSize() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- targetVectorSize() - Method in interface org.apache.drill.exec.physical.rowSet.ResultSetLoader
-
The largest vector size produced by this loader (as specified by
the value vector limit.)
- TBLS_COL_TABLE_TYPE - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- TCP_ACK_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
-
- TCP_FLAG_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
-
- TCP_PROTOCOL - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
-
- TCP_SEQUENCE_OFFSET - Static variable in class org.apache.drill.exec.store.pcap.decoder.PacketConstants
-
- tearDown() - Method in class org.apache.drill.exec.coord.zk.TestEphemeralStore
-
- tearDown() - Method in class org.apache.drill.exec.coord.zk.TestZKACL
-
- tearDown() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- teardown() - Static method in class org.apache.drill.exec.fn.impl.TestByteComparisonFunctions
-
- tearDown() - Static method in class org.apache.drill.exec.impersonation.TestInboundImpersonation
-
- tearDown() - Method in class org.apache.drill.exec.planner.sql.CrossJoinTest
-
- teardown() - Static method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- tearDown() - Static method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDownForDateTimeCasts
-
- tearDown() - Static method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- tearDown() - Method in class org.apache.drill.exec.TestWithZookeeper
-
- teardown() - Method in class org.apache.drill.test.PhysicalOpUnitTestBase
-
- teardown() - Method in class org.apache.drill.test.rowSet.TestRowSetComparison
-
- tearDown() - Static method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- tearDown() - Method in class org.apache.drill.TestOperatorDump
-
- tearDownAfterClass() - Static method in class org.apache.drill.exec.cache.TestBatchSerialization
-
- tearDownAfterClass() - Static method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
- tearDownAfterClass() - Static method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- tearDownAfterClass() - Static method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestCorrectness
-
- tearDownAfterClass() - Static method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestWithLateralCorrectness
-
- tearDownAfterClass() - Static method in class org.apache.drill.exec.physical.impl.validate.TestBatchValidator
-
- tearDownAfterClass() - Static method in class org.apache.drill.exec.physical.impl.validate.TestValidationOptions
-
- tearDownAfterClass() - Static method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
- tearDownAfterClass() - Static method in class org.apache.drill.exec.record.TestVectorContainer
-
- tearDownTest() - Method in class org.apache.drill.exec.client.DrillClientSystemTest
-
- tearDownView() - Static method in class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- 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_DEFINITION4 - Static variable in interface org.apache.drill.exec.physical.impl.filter.Filterer
-
- 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 class org.apache.drill.exec.store.StorageStrategy
-
Primary is used for temporary tables.
- temporaryFolder - Static variable in class org.apache.drill.exec.expr.fn.FunctionInitializerTest
-
- TemporaryTablesAutomaticDropTest - Class in org.apache.drill.exec.rpc.user
-
- TemporaryTablesAutomaticDropTest() - Constructor for class org.apache.drill.exec.rpc.user.TemporaryTablesAutomaticDropTest
-
- 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
-
- terminate() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- terminateWithError(RecordBatch.IterOutcome) - Method in class org.apache.drill.exec.physical.impl.MockRecordBatch.Builder
-
- tesGreaterThanFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- tesGreaterThanOrEqualToFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- test() - Method in class org.apache.drill.exec.cache.TestWriteToDisk
-
- test() - Method in class org.apache.drill.exec.fn.impl.TestDateTruncFunctions
-
- test() - Method in class org.apache.drill.exec.nested.TestFastComplexSchema
-
- test() - Method in class org.apache.drill.exec.server.TestTpcdsSf1Leaks
-
- test() - Method in class org.apache.drill.exec.store.dfs.TestFormatPluginOptionExtractor
-
- test(PersistentStoreProvider) - Static method in class org.apache.drill.exec.store.sys.PStoreTestUtil
-
- test() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexToJson
-
- test() - Method in class org.apache.drill.exec.vector.TestSplitAndTransfer
-
- test(String) - Method in class org.apache.drill.test.BaseTestQuery.ClassicTestServices
-
Deprecated.
- test(String, Object...) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- test(String) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- test(String) - Method in class org.apache.drill.test.ClusterFixture.FixtureTestServices
-
- test(String) - Method in interface org.apache.drill.test.DrillTestWrapper.TestServices
-
- test1RecordLeftBatchTo1RightRecordBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test to show correct IterOutcome produced by LATERAL when one record in left batch produces only 1 right batch
with EMIT outcome.
- test1RecordLeftBatchTo2RightRecordBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test to show correct IterOutcome & output produced by LATERAL when one record in left batch produces 2 right
batches with OK and EMIT outcome respectively.
- test1RecordLeftBatchToEmptyRightBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test to show that if the result of cross join between left batch and empty right batch is an empty
batch and next batch on left side result in NONE outcome, then there is no output produced and result
returned to downstream is NONE.
- test2() - Method in class org.apache.drill.exec.nested.TestFastComplexSchema
-
- test2DEarlySchema() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderRepeatedList
-
- test2DLateSchema() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderRepeatedList
-
- test2DLateSchemaIncremental() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderRepeatedList
-
- test2DOverflow() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderRepeatedList
-
- test2PhaseAggAfterOrderBy() - Method in class org.apache.drill.TestExampleQueries
-
- test3() - Method in class org.apache.drill.exec.nested.TestFastComplexSchema
-
- test3643Fix() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- test3648Fix() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- test3654Fix() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- test3668Fix() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- test3DEarlySchema() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderRepeatedList
-
- test4() - Method in class org.apache.drill.exec.nested.TestFastComplexSchema
-
- test4349() - Method in class org.apache.drill.exec.store.parquet2.TestDrillParquetReader
-
- test4443() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- test4457() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- test4657() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- test5() - Method in class org.apache.drill.exec.nested.TestFastComplexSchema
-
- test8() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggr
-
- test958_sql() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- test958_sql() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- test958_sql_all_columns() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- test_array() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- TEST_CONFIGURATIONS - Static variable in class org.apache.drill.test.ClusterFixture
-
- test_JSON_convertTo_empty_list_drill_1416() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- test_OK_NEW_SCHEMAFromLeft_EmitFromRight_PostBuildSchema() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test to verify if OK_NEW_SCHEMA is received from left side of LATERAL post build schema phase and EMIT is
received from right side of LATERAL for each row on left side, then Lateral sends OK_NEW_SCHEMA downstream with
the output batch.
- test_repeatedList() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- test_SimpleContainer_NoSchemaChange() - Method in class org.apache.drill.exec.physical.impl.svremover.TestSVRemoverIterOutcome
-
- test_SimpleContainer_SchemaChange() - Method in class org.apache.drill.exec.physical.impl.svremover.TestSVRemoverIterOutcome
-
- TEST_SUB_DIR - Static variable in class org.apache.drill.exec.sql.TestInfoSchema
-
- test_SV2Container_NoSchemaChange() - Method in class org.apache.drill.exec.physical.impl.svremover.TestSVRemoverIterOutcome
-
- test_SV2Container_SchemaChange() - Method in class org.apache.drill.exec.physical.impl.svremover.TestSVRemoverIterOutcome
-
- TEST_USER_1 - Static variable in class org.apache.drill.exec.rpc.user.security.testing.UserAuthenticatorTestImpl
-
- TEST_USER_1_PASSWORD - Static variable in class org.apache.drill.exec.rpc.user.security.testing.UserAuthenticatorTestImpl
-
- TEST_USER_2 - Static variable in class org.apache.drill.exec.rpc.user.security.testing.UserAuthenticatorTestImpl
-
- TEST_USER_2_PASSWORD - Static variable in class org.apache.drill.exec.rpc.user.security.testing.UserAuthenticatorTestImpl
-
- testA0() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testA0() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeWriter
-
- testA1() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testA1() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeWriter
-
- testA10() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeWriter
-
- testA100() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeWriter
-
- testA11() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeWriter
-
- testA2() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testA2() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeWriter
-
- testA3() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testA3() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeWriter
-
- testA4() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testA4() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeWriter
-
- testA5() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeWriter
-
- testA6() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeWriter
-
- testA7() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeWriter
-
- testA8() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeWriter
-
- testA9() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeWriter
-
- testAbsDecimalFunction() - Method in class org.apache.drill.TestFunctionsQuery
-
- testAbsentBinaryInStaging() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testAbsentPluginOrWorkspaceError() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testAbsentSourceInStaging() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testAbsentTable() - Method in class org.apache.drill.TestSelectWithOption
-
- testAbsFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testAcosFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testAddConfigToConf() - Method in class org.apache.drill.exec.store.parquet.TestParquetReaderConfig
-
- testAddFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testAddJars() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- testAddTheSameJars() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- testAddTypes() - Method in class org.apache.drill.test.rowSet.test.TestVariantAccessors
-
Test a variant (AKA "union vector") at the top level, using
just scalar values.
- testAdjustInitialPartitions() - Method in class org.apache.drill.exec.physical.impl.join.TestBuildSidePartitioningImpl
-
- testAdminUserOptions() - Method in class org.apache.drill.exec.server.TestOptionsAuthEnabled
-
- TestAffinityCalculator - Class in org.apache.drill.exec.store
-
- TestAffinityCalculator() - Constructor for class org.apache.drill.exec.store.TestAffinityCalculator
-
- testAfter() - Method in class org.apache.drill.exec.fn.impl.TestByteComparisonFunctions
-
- testAfterLong() - Method in class org.apache.drill.exec.fn.impl.TestByteComparisonFunctions
-
- testAge() - Method in class org.apache.drill.exec.fn.impl.TestDateFunctions
-
- TestAgg - Class in org.apache.drill.exec.physical.impl.agg
-
- TestAgg() - Constructor for class org.apache.drill.exec.physical.impl.agg.TestAgg
-
- testAggExpressionWithGroupBy() - Method in class org.apache.drill.TestExampleQueries
-
- testAggExpressionWithGroupByHaving() - Method in class org.apache.drill.TestExampleQueries
-
- testAggGroupByWithNullDecimal() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- TestAggNullable - Class in org.apache.drill
-
- TestAggNullable() - Constructor for class org.apache.drill.TestAggNullable
-
- TestAggregateFunction - Class in org.apache.drill.exec.fn.impl
-
- TestAggregateFunction() - Constructor for class org.apache.drill.exec.fn.impl.TestAggregateFunction
-
- TestAggregateFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestAggregateFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testAggregateRangeCurrentAndCurrent() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testAggregateRowsUnboundedAndCurrentRow() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testAggregationOnUnionAllOperator() - Method in class org.apache.drill.TestUnionAll
-
- testAggregationOnUnionDistinctOperator() - Method in class org.apache.drill.TestUnionDistinct
-
- TestAggWithAnyValue - Class in org.apache.drill.exec.physical.impl.agg
-
- TestAggWithAnyValue() - Constructor for class org.apache.drill.exec.physical.impl.agg.TestAggWithAnyValue
-
- TestAggWithAnyValue.TestAggWithAnyValueMultipleBatches - Class in org.apache.drill.exec.physical.impl.agg
-
- TestAggWithAnyValue.TestAggWithAnyValueSingleBatch - Class in org.apache.drill.exec.physical.impl.agg
-
- TestAggWithAnyValueMultipleBatches() - Constructor for class org.apache.drill.exec.physical.impl.agg.TestAggWithAnyValue.TestAggWithAnyValueMultipleBatches
-
- TestAggWithAnyValueSingleBatch() - Constructor for class org.apache.drill.exec.physical.impl.agg.TestAggWithAnyValue.TestAggWithAnyValueSingleBatch
-
- testAlgorithm() - Method in class org.apache.drill.exec.physical.impl.partitionsender.TestPartitionSender
-
- testAllFieldsQueryNoSchema() - Method in class org.apache.drill.exec.store.log.TestLogReader
-
- testAllNulls() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- TestAllocators - Class in org.apache.drill.exec.memory
-
- TestAllocators() - Constructor for class org.apache.drill.exec.memory.TestAllocators
-
- testAllocators() - Method in class org.apache.drill.exec.memory.TestAllocators
-
- testAllScalarTypes() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testAllScalarTypesDictionary() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testAllTextMode() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testAllTypes(OperatorFixture) - Static method in class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- testAlterInternalSystemOption() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testAlterSystem() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- TestAltSortQueries - Class in org.apache.drill
-
- TestAltSortQueries() - Constructor for class org.apache.drill.TestAltSortQueries
-
- testAppendRecords() - Method in class org.apache.drill.exec.physical.impl.svremover.AbstractGenericCopierTest
-
- testApply() - Method in class org.apache.drill.exec.sql.TestConformance
-
- TestApproximateStringMatcher - Class in org.apache.drill.exec.util
-
- TestApproximateStringMatcher() - Constructor for class org.apache.drill.exec.util.TestApproximateStringMatcher
-
- testArray() - Method in class org.apache.drill.exec.cache.TestBatchSerialization
-
- testArray() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestScanLevelProjection
-
Similar to maps, if the project list contains "a[1]" then we've learned that
a is an array, but we don't know what type.
- testArray() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
- testArray() - Method in class org.apache.drill.test.rowSet.test.TestIndirectReaders
-
More complex case with two levels of offset vector (one for the
array, another for the Varchar values.) Only the top level goes
through the indirection.
- testArrayAndSimple() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
- testArrayDups() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
- testArrayMismatch() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaLevelProjection
-
Project of a non-array as an array
- testArrayOfDocumentType() - Method in class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- testArrayOverflowWithOtherArrays() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderOverflow
-
Test the complete set of array overflow cases:
Array a is written before the column that has overflow,
and must be copied, in its entirety, to the overflow row.
Column b causes the overflow.
Column c is written after the overflow, and should go
to the look-ahead row.
Column d is written for a while, then has empties before
the overflow row, but is written in the overflow row.
Column e is like d, but is not written in the overflow
row.
- testArrayProject() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaLevelProjection
-
Test project of an array.
- testArrayType() - Method in class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- TestArrayWrappedIntIntMap - Class in org.apache.drill.exec.util
-
- TestArrayWrappedIntIntMap() - Constructor for class org.apache.drill.exec.util.TestArrayWrappedIntIntMap
-
- testAscNullsFirst() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- testAscNullsLast() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- testAsinFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- TestAssignment - Class in org.apache.drill.exec.store.store
-
- TestAssignment() - Constructor for class org.apache.drill.exec.store.store.TestAssignment
-
- testAtanFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testAuthClientRequestForLogOut() - Method in class org.apache.drill.exec.server.rest.spnego.TestDrillSpnegoAuthenticator
-
- testAuthClientRequestForOtherPage() - Method in class org.apache.drill.exec.server.rest.spnego.TestDrillSpnegoAuthenticator
-
- testAuthClientRequestForSpnegoLoginResource() - Method in class org.apache.drill.exec.server.rest.spnego.TestDrillSpnegoAuthenticator
-
- testAuthDisabled() - Method in class org.apache.drill.exec.server.rest.TestMainLoginPageModel
-
Test when auth is disabled then both Form and Spnego authentication is disabled.
- testAuthEnabledWithForm() - Method in class org.apache.drill.exec.server.rest.TestMainLoginPageModel
-
Test when auth is enabled with http.auth.mechanisms configured as Form then only Form authentication is
enabled but Spnego is disabled.
- testAuthEnabledWithFormSpnego() - Method in class org.apache.drill.exec.server.rest.TestMainLoginPageModel
-
Test when auth is enabled with http.auth.mechanisms configured as Form, Spnego then both Form and Spnego
authentication are enabled.
- testAuthEnabledWithNoMech() - Method in class org.apache.drill.exec.server.rest.TestMainLoginPageModel
-
Test when auth is enabled with no http.auth.mechanisms configured then by default Form authentication is
enabled but Spnego is disabled.
- testAuthEnabledWithSpnego() - Method in class org.apache.drill.exec.server.rest.TestMainLoginPageModel
-
Test when auth is enabled with http.auth.mechanisms configured as Spnego then only Spnego authentication is
enabled but Form is disabled.
- testAutomaticDropOfSeveralSessionTemporaryLocations() - Method in class org.apache.drill.exec.rpc.user.TemporaryTablesAutomaticDropTest
-
- testAutomaticDropWhenClientIsClosed() - Method in class org.apache.drill.exec.rpc.user.TemporaryTablesAutomaticDropTest
-
- testAutomaticDropWhenDrillbitIsClosed() - Method in class org.apache.drill.exec.rpc.user.TemporaryTablesAutomaticDropTest
-
- testAvgAndSUM() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testAvgCountStar() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testAvgDecimal() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testAvgFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testAvgOnKnownType() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testAvgVarianceWindowFunctions() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testAvgWithNullableScalarFunction() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testAviImage() - Method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- testAvro() - Method in class org.apache.drill.exec.store.FormatPluginSerDeTest
-
- testAvroTableWithLogicalTypesDecimal() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testAvroWithDisabledDecimalType() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testB1() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testB1P1() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
Single batch with a single partition (position_id column)
- testB1P2() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
Single batch with 2 partitions (position_id column)
- testB2() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testB2P2() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
2 batches with 2 partitions (position_id column), each batch contains a different partition
- testB2P4() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
2 batches with 4 partitions, one partition has rows in both batches
- testB3() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testB3P2() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
3 batches with 2 partitions, one partition has rows in all 3 batches
- testB4P4() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
4 batches with 4 partitions.
- testBackPathBad() - Method in class org.apache.drill.exec.store.dfs.TestFileSelection
-
- testBackPathGood() - Method in class org.apache.drill.exec.store.dfs.TestFileSelection
-
- testBalanceAcrossNodes() - Method in class org.apache.drill.exec.store.store.TestAssignment
-
- testBaselineValsVerification() - Method in class org.apache.drill.TestFrameworkTest
-
- testBaselineValsVerificationWithComplexAndNulls() - Method in class org.apache.drill.TestFrameworkTest
-
- testBaselineValsVerificationWithNulls() - Method in class org.apache.drill.TestFrameworkTest
-
- TestBaseViewSupport - Class in org.apache.drill.exec.sql
-
Base class for view tests.
- TestBaseViewSupport() - Constructor for class org.apache.drill.exec.sql.TestBaseViewSupport
-
- testBasicExpression() - Method in class org.apache.drill.exec.expr.ExpressionTest
-
- testBasicJSON() - Method in class org.apache.drill.TestFrameworkTest
-
- testBasicLeftLateralJoin() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test to check basic left lateral join is working correctly or not.
- testBasicMathFunctions() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctions
-
- testBasicQueryWithIncorrectFileName() - Method in class org.apache.drill.exec.store.pcapng.TestPcapngRecordReader
-
- testBasicRepeatedMap() - Method in class org.apache.drill.test.rowSet.test.TestMapAccessors
-
- testBasics() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestNullColumnLoader
-
Test the simplest case: default null type, nothing in the vector
cache.
- testBasics() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestScanLevelProjection
-
Basic test: select a set of columns (a, b, c) when the
data source has an early schema of (a, c, d).
- testBasics() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMapArray
-
- testBasics() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMaps
-
- testBasics() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderProtocol
-
- testBasics() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultVectorCache
-
- testBasics() - Method in class org.apache.drill.exec.store.pcap.TestPcapDecoder
-
- testBasics() - Method in class org.apache.drill.test.rowSet.test.TestMapAccessors
-
- testBatchAccessor() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
The record batch abstraction has a bunch of methods to work with a vector container.
- testBatchCutoff() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- TestBatchSerialization - Class in org.apache.drill.exec.cache
-
- TestBatchSerialization() - Constructor for class org.apache.drill.exec.cache.TestBatchSerialization
-
- testBatchSizeLimit() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderOverflow
-
Test that the writer detects a vector overflow.
- TestBatchSizePredictorImpl - Class in org.apache.drill.exec.physical.impl.join
-
- TestBatchSizePredictorImpl() - Constructor for class org.apache.drill.exec.physical.impl.join.TestBatchSizePredictorImpl
-
- TestBatchSizingMemoryUtil - Class in org.apache.drill.exec.store.parquet.columnreaders
-
- TestBatchSizingMemoryUtil() - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.TestBatchSizingMemoryUtil
-
- TestBatchValidator - Class in org.apache.drill.exec.physical.impl.validate
-
- TestBatchValidator() - Constructor for class org.apache.drill.exec.physical.impl.validate.TestBatchValidator
-
- testBefore() - Method in class org.apache.drill.exec.fn.impl.TestByteComparisonFunctions
-
- testBeforeLong() - Method in class org.apache.drill.exec.fn.impl.TestByteComparisonFunctions
-
- testBetweenDateAndTimeStamp() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testBetweenDecimalAndDouble() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testBigInt() - Method in class org.apache.drill.exec.physical.impl.TestComparisonFunctions
-
- testBigIntNullable() - Method in class org.apache.drill.exec.physical.impl.TestComparisonFunctions
-
- testBigIntVarCharReturnTripConvertLogical() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testBigIntVarCharReturnTripConvertLogical_ScalarReplaceOFF() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testBigIntVarCharReturnTripConvertLogical_ScalarReplaceON() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testBigIntVarCharReturnTripConvertLogical_ScalarReplaceTRY() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testBigIntWithDictionary() - Method in class org.apache.drill.exec.store.parquet.columnreaders.TestColumnReaderFactory
-
check if BigInt is read correctly with dictionary encoding.
- testBinaryDecimalPruning() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check partition pruning for binary decimal with and without
using Drill metadata file.
- testBinaryDecimalPushDown() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check filter push down for binary decimal with and without
using Drill metadata file.
- testBinaryString() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testBinaryTypes() - Method in class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- TestBitBitKerberos - Class in org.apache.drill.exec.rpc.data
-
- TestBitBitKerberos() - Constructor for class org.apache.drill.exec.rpc.data.TestBitBitKerberos
-
- TestBitBitKerberos.MockFragmentManager - Class in org.apache.drill.exec.rpc.data
-
- testBitError_Drill_2031() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- TestBitRpc - Class in org.apache.drill.exec.rpc.data
-
- TestBitRpc() - Constructor for class org.apache.drill.exec.rpc.data.TestBitRpc
-
- TestBitRpc.MockFragmentManager - Class in org.apache.drill.exec.rpc.data
-
- testBitVector() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- testBitVectorAlignedStart() - Method in class org.apache.drill.exec.vector.TestSplitAndTransfer
-
- testBitVectorImpl(int, int[][], TestSplitAndTransfer.TestBitPattern) - Method in class org.apache.drill.exec.vector.TestSplitAndTransfer
-
- testBitVectorReallocation() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- testBitVectorUnalignedStart() - Method in class org.apache.drill.exec.vector.TestSplitAndTransfer
-
- testBitwiseAggrFuncs() - Method in class org.apache.drill.exec.fn.impl.TestNewAggregateFunctions
-
- testBmpImage() - Method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- testBool1() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testBool2() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testBool3() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testBool4() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testBoolean() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testBooleanAND() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testBooleanConditionsMode() - Method in class org.apache.drill.TestFunctionsQuery
-
- testBooleanORWhereClause() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testBooleanPartitionPruning() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testBooleanPredicate() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testBooleanType() - Method in class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- testBracketsForQuotingIdentifiers() - Method in class org.apache.drill.exec.planner.sql.TestDrillSQLWorker
-
- TestBroadcast - Class in org.apache.drill.exec.physical.impl.broadcastsender
-
- TestBroadcast() - Constructor for class org.apache.drill.exec.physical.impl.broadcastsender.TestBroadcast
-
- TestBroadcastExchange - Class in org.apache.drill.exec.physical.impl
-
- TestBroadcastExchange() - Constructor for class org.apache.drill.exec.physical.impl.TestBroadcastExchange
-
- testBroadcastHashJoin1Cond() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinJPPD
-
- testBroadcastHashJoin2Cond() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinJPPD
-
- TestBsonRecordReader - Class in org.apache.drill.exec.store.bson
-
- TestBsonRecordReader() - Constructor for class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- testBtrimOneArgConvergeToBtrim() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testBufferBounds() - Method in class org.apache.drill.test.rowSet.test.RowSetTest
-
Test filling a row set up to the maximum vector size.
- TestBugFixes - Class in org.apache.drill
-
- TestBugFixes() - Constructor for class org.apache.drill.TestBugFixes
-
- testBuilder() - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- testBuilder() - Method in class org.apache.drill.test.ClientFixture
-
- testBuilder() - Method in class org.apache.drill.test.ClusterTest
-
Convenience method when converting classic tests to use the
cluster fixture.
- TestBuilder - Class in org.apache.drill.test
-
- TestBuilder(DrillTestWrapper.TestServices) - Constructor for class org.apache.drill.test.TestBuilder
-
- TestBuilder(DrillTestWrapper.TestServices, Object, UserBitShared.QueryType, Boolean, boolean, Map<SchemaPath, TypeProtos.MajorType>, String, String, boolean, int) - Constructor for class org.apache.drill.test.TestBuilder
-
- TestBuilder.BaselineQueryTestBuilder - Class in org.apache.drill.test
-
- TestBuilder.CSVTestBuilder - Class in org.apache.drill.test
-
- TestBuilder.JSONTestBuilder - Class in org.apache.drill.test
-
- TestBuilder.SchemaTestBuilder - Class in org.apache.drill.test
-
- testBuildRangeMap() - Method in class org.apache.drill.exec.store.TestAffinityCalculator
-
- testBuildRowSetScalarList() - Method in class org.apache.drill.test.rowSet.test.TestVariantAccessors
-
- testBuildRowSetUnion() - Method in class org.apache.drill.test.rowSet.test.TestVariantAccessors
-
- testBuildRowSetUnionArray() - Method in class org.apache.drill.test.rowSet.test.TestVariantAccessors
-
- testBuildSchemaEmptyLNonEmptyRBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
- testBuildSchemaEmptyLRBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
With both left and right batch being empty, the
LateralJoinBatch.buildSchema()
phase
should still build the output container schema and return empty batch
- testBuildSchemaNonEmptyLEmptyRBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
With non-empty left and empty right batch, the
LateralJoinBatch.buildSchema()
phase
should still build the output container schema and return empty batch
- testBuildSchemaNonEmptyLRBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
- testBuildSchemaWithEMITOutcome() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test for receiving unexpected EMIT outcome during build phase on left side.
- TestBuildSidePartitioningImpl - Class in org.apache.drill.exec.physical.impl.join
-
- TestBuildSidePartitioningImpl() - Constructor for class org.apache.drill.exec.physical.impl.join.TestBuildSidePartitioningImpl
-
- TestBuildSidePartitioningImpl.MockBatchSizePredictor - Class in org.apache.drill.exec.physical.impl.join
-
- TestByteComparisonFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestByteComparisonFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestByteComparisonFunctions
-
- testByteOrdering() - Method in class org.apache.drill.exec.store.pcap.TestPcapDecoder
-
- testByteSubstring() - Method in class org.apache.drill.exec.physical.impl.TestSimpleFunctions
-
- testCache() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testCachedTypesAllowRequired() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestNullColumnLoader
-
Suppose, in the previous test, that one of the columns that
goes missing is a required column.
- testCachedTypesMapToNullable() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestNullColumnLoader
-
Drill requires "schema persistence": if a scan operator
reads two files, F1 and F2, then the scan operator must
provide the same vectors from both readers.
- testCacheWithSubschema() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testCalculateHashTableSize() - Method in class org.apache.drill.exec.physical.impl.join.TestHashTableSizeCalculatorConservativeImpl
-
- testCalculateHashTableSize() - Method in class org.apache.drill.exec.physical.impl.join.TestHashTableSizeCalculatorLeanImpl
-
- testCanAddNewData() - Method in class org.apache.drill.exec.store.parquet.columnreaders.TestBatchSizingMemoryUtil
-
- testCanAddNewNullabalData() - Method in class org.apache.drill.exec.store.parquet.columnreaders.TestBatchSizingMemoryUtil
-
- testCancelExecution() - Method in class org.apache.drill.exec.util.ExecutorServiceUtilTest
-
- testCancelNonRunningFragments() - Method in class org.apache.drill.exec.work.fragment.TestFragmentExecutorCancel
-
- testCancelQuery_NegativeAck() - Method in class org.apache.drill.exec.rpc.control.TestLocalControlConnectionManager
-
Verify that CancelQuery with negative ack is handled correctly using ControlTunnel with
LocalControlConnectionManager
- testCancelQuery_PositiveAck() - Method in class org.apache.drill.exec.rpc.control.TestLocalControlConnectionManager
-
Verify that CancelQuery with positive ack is handled correctly using ControlTunnel with
LocalControlConnectionManager
- testCase() - Method in class org.apache.drill.TestExampleQueries
-
- testCaseInsensitiveJoin() - Method in class org.apache.drill.TestExampleQueries
-
- testCaseInsensitiveSchema() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderProtocol
-
Schemas are case insensitive by default.
- testCaseInsensitiveSubQuery() - Method in class org.apache.drill.TestExampleQueries
-
- testCaseNullableTimestamp() - Method in class org.apache.drill.exec.planner.logical.TestCaseNullableTypes
-
- TestCaseNullableTypes - Class in org.apache.drill.exec.planner.logical
-
DRILL-4906
Tests for handling nullable types in CASE function
- TestCaseNullableTypes() - Constructor for class org.apache.drill.exec.planner.logical.TestCaseNullableTypes
-
- testCaseNullableTypesBigint() - Method in class org.apache.drill.exec.planner.logical.TestCaseNullableTypes
-
- testCaseNullableTypesBoolean() - Method in class org.apache.drill.exec.planner.logical.TestCaseNullableTypes
-
- testCaseNullableTypesDate() - Method in class org.apache.drill.exec.planner.logical.TestCaseNullableTypes
-
- testCaseNullableTypesDecimal() - Method in class org.apache.drill.exec.planner.logical.TestCaseNullableTypes
-
- testCaseNullableTypesDouble() - Method in class org.apache.drill.exec.planner.logical.TestCaseNullableTypes
-
- testCaseNullableTypesFloat() - Method in class org.apache.drill.exec.planner.logical.TestCaseNullableTypes
-
- testCaseNullableTypesInt() - Method in class org.apache.drill.exec.planner.logical.TestCaseNullableTypes
-
- testCaseNullableTypesTimestamp() - Method in class org.apache.drill.exec.planner.logical.TestCaseNullableTypes
-
- testCaseNullableTypesVarchar() - Method in class org.apache.drill.exec.planner.logical.TestCaseNullableTypes
-
- testCaseReturnValueBigInt() - Method in class org.apache.drill.TestExampleQueries
-
- testCaseReturnValueVarChar() - Method in class org.apache.drill.TestExampleQueries
-
- testCaseSenJoinCTEWithRegTab() - Method in class org.apache.drill.TestStarQueries
-
- TestCaseSensitivity - Class in org.apache.drill
-
- TestCaseSensitivity() - Constructor for class org.apache.drill.TestCaseSensitivity
-
- testCaseSenWhenQueryTwoDiffCols() - Method in class org.apache.drill.TestCaseSensitivity
-
- testCaseWithDecimalExpressions() - Method in class org.apache.drill.TestFunctionsQuery
-
- testCastBigInt() - Method in class org.apache.drill.exec.physical.impl.TestCastFunctions
-
- testCastBigIntDecimal() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testCastBigIntDecimalOverflow() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastBigIntToFloatAndDouble() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastByConstantFolding() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastDateTimestamp() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDownForDateTimeCasts
-
- testCastDateVarchar() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDownForDateTimeCasts
-
- testCastDecimalBigInt() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testCastDecimalDivide() - Method in class org.apache.drill.TestFunctionsQuery
-
- testCastDecimalDouble() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testCastDecimalDouble() - Method in class org.apache.drill.TestFunctionsQuery
-
- testCastDecimalFloat() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testCastDecimalGreaterScaleThanPrecision() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastDecimalInt() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testCastDecimalLiteral() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastDecimalToFloatAndDouble() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastDecimalToIntAndBigInt() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastDecimalToVarDecimal() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastDecimalVarchar() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testCastDecimalZeroPrecision() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastDoubleDecimal() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testCastDoubleDecimalOverflow() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastDoubleToBigInt() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastDoubleToInt() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- TestCastEmptyStrings - Class in org.apache.drill.exec.fn.impl
-
- TestCastEmptyStrings() - Constructor for class org.apache.drill.exec.fn.impl.TestCastEmptyStrings
-
- testCastFloat4() - Method in class org.apache.drill.exec.physical.impl.TestCastFunctions
-
- testCastfloat4Function() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testCastFloat8() - Method in class org.apache.drill.exec.physical.impl.TestCastFunctions
-
- testCastFloatAndDouble() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastFloatDecimal() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testCastFloatDecimalOverflow() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastFloatToBigInt() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastFloatToInt() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastFromBooleanToString() - Method in class org.apache.drill.exec.sql.TestSimpleCastFunctions
-
- testCastFromFloat() - Method in class org.apache.drill.exec.physical.impl.TestDecimal
-
- testCastFromNullablCol() - Method in class org.apache.drill.exec.physical.impl.TestCastFunctions
-
- TestCastFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestCastFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- TestCastFunctions - Class in org.apache.drill.exec.physical.impl
-
- TestCastFunctions() - Constructor for class org.apache.drill.exec.physical.impl.TestCastFunctions
-
- testCastFunctions() - Method in class org.apache.drill.TestProjectWithFunctions
-
- testCasthighFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testCastInt() - Method in class org.apache.drill.exec.physical.impl.TestCastFunctions
-
- testCastIntAndBigInt() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastIntAndBigIntToDecimal() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastIntDecimal() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testCastIntDecimalOverflow() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastIntToFloatAndDouble() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastNegativeDecimalToVarChar() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastNegativeFloatToInt() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastNested() - Method in class org.apache.drill.exec.physical.impl.TestCastFunctions
-
- testCastNullToBoolean() - Method in class org.apache.drill.exec.sql.TestSimpleCastFunctions
-
- testCastNumericToBooleanFalseValue() - Method in class org.apache.drill.exec.sql.TestSimpleCastFunctions
-
- testCastNumericToBooleanTrueValue() - Method in class org.apache.drill.exec.sql.TestSimpleCastFunctions
-
- testCastNumException() - Method in class org.apache.drill.exec.physical.impl.TestCastFunctions
-
- testCastOptionalVarCharToDateTime() - Method in class org.apache.drill.exec.fn.impl.TestCastEmptyStrings
-
- testCastOptionalVarCharToDecimal() - Method in class org.apache.drill.exec.fn.impl.TestCastEmptyStrings
-
- testCastOptionalVarCharToNumber() - Method in class org.apache.drill.exec.fn.impl.TestCastEmptyStrings
-
- testCastOptionalVarCharToNumeric() - Method in class org.apache.drill.exec.fn.impl.TestCastEmptyStrings
-
- testCastProjectBug_Drill_929() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testCastRequiredVarCharToDateTime() - Method in class org.apache.drill.exec.fn.impl.TestCastEmptyStrings
-
- testCastRequiredVarCharToDecimal() - Method in class org.apache.drill.exec.fn.impl.TestCastEmptyStrings
-
- testCastRequiredVarCharToInterval() - Method in class org.apache.drill.exec.fn.impl.TestCastEmptyStrings
-
- testCastRequiredVarCharToNumber() - Method in class org.apache.drill.exec.fn.impl.TestCastEmptyStrings
-
- testCastRequiredVarCharToNumeric() - Method in class org.apache.drill.exec.fn.impl.TestCastEmptyStrings
-
- testCastStringToBooleanFalseValue() - Method in class org.apache.drill.exec.sql.TestSimpleCastFunctions
-
- testCastStringToBooleanTrueValue() - Method in class org.apache.drill.exec.sql.TestSimpleCastFunctions
-
- testCastTimeDate() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDownForDateTimeCasts
-
- testCastTimestampDate() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDownForDateTimeCasts
-
- testCastTimestampVarchar() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDownForDateTimeCasts
-
- testCastTimeTimestamp() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDownForDateTimeCasts
-
- testCastTimeVarchar() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDownForDateTimeCasts
-
- testCastToBigInt() - Method in class org.apache.drill.exec.physical.impl.TestCastVarCharToBigInt
-
- testCastToVarcharWithLength() - Method in class org.apache.drill.TestExampleQueries
-
- testCastVarBinary() - Method in class org.apache.drill.exec.physical.impl.TestCastFunctions
-
- testCastVarChar() - Method in class org.apache.drill.exec.physical.impl.TestCastFunctions
-
- testCastVarCharDecimalOverflow() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCastVarCharIntervalYear() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- TestCastVarCharToBigInt - Class in org.apache.drill.exec.physical.impl
-
- TestCastVarCharToBigInt() - Constructor for class org.apache.drill.exec.physical.impl.TestCastVarCharToBigInt
-
- testCastVarDecimalToDecimal() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testCbrtFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testCeilDecimalFunction() - Method in class org.apache.drill.TestFunctionsQuery
-
- testCeilFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testChannelPromiseWithNullExecutor() - Method in class org.apache.drill.exec.server.rest.WebSessionResourcesTest
-
Validates
WebSessionResources.close()
throws NPE when closefuture passed to WebSessionResources doesn't
have a valid channel and EventExecutor associated with it.
- testChannelPromiseWithValidExecutor() - Method in class org.apache.drill.exec.server.rest.WebSessionResourcesTest
-
- testCharLength() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- TestClassCompilationTypes - Class in org.apache.drill.exec.compile
-
- TestClassCompilationTypes() - Constructor for class org.apache.drill.exec.compile.TestClassCompilationTypes
-
- TestClassPathScanner - Class in org.apache.drill.common.scanner
-
- TestClassPathScanner() - Constructor for class org.apache.drill.common.scanner.TestClassPathScanner
-
- TestClassTransformation - Class in org.apache.drill.exec.compile
-
- TestClassTransformation() - Constructor for class org.apache.drill.exec.compile.TestClassTransformation
-
- testCleanUp() - Static method in class org.apache.drill.exec.client.ConnectTriesPropertyTestClusterBits
-
- testClearBitVector() - Method in class org.apache.drill.exec.memory.TestAllocators
-
- testClientConfigCertificateVerification() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSL
-
- testClientConfigHostnameVerification() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSL
-
- testClientConfigHostNameVerificationFail() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSL
-
- testClientConfigNoCertificateVerification() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSL
-
- testClone() - Method in class org.apache.drill.exec.record.TestMaterializedField
-
- testClose() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultVectorCache
-
- testClose() - Method in class org.apache.drill.exec.work.fragment.FragmentStatusReporterTest
-
- testCloseClosed() - Method in class org.apache.drill.exec.work.fragment.FragmentStatusReporterTest
-
- testCloseWithListener() - Method in class org.apache.drill.exec.server.rest.WebSessionResourcesTest
-
Validates successful
WebSessionResources.close()
with valid CloseFuture and
TestClosedListener
getting invoked which is added to the close future.
- testCloseWithoutHarvest() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMapArray
-
Test that memory is released if the loader is closed with an active
batch (that is, before the batch is harvested.)
- testCloseWithoutHarvest() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderProtocol
-
Test that memory is released if the loader is closed with an active
batch (that is, before the batch is harvested.)
- testCloseWithOverflow() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderOverflow
-
Load a batch to overflow.
- testClusterDiscoveryPaths() - Method in class org.apache.drill.exec.coord.zk.TestZKACL
-
Test ACLs on znodes required to discover the cluster
ZK libraries only supports one client instance per-machine per-server and it is cached.
- testColumnDescriptorMap() - Method in class org.apache.drill.exec.store.parquet.TestParquetReaderUtility
-
- testColumnNamesDifferInCaseOnly() - Method in class org.apache.drill.TestExampleQueries
-
- testColumnNullability() - Method in class org.apache.drill.exec.store.sys.TestSystemTable
-
- TestColumnReaderFactory - Class in org.apache.drill.exec.store.parquet.columnreaders
-
- TestColumnReaderFactory() - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.TestColumnReaderFactory
-
- testColumnsCaseInsensitive() - Method in class org.apache.drill.exec.store.text.TestTextColumn
-
- testColunValueCnt() - Method in class org.apache.drill.TestExampleQueries
-
- testCombinedColumns() - Method in class org.apache.drill.exec.store.parquet.TestComplexColumnInSchema
-
- testCommaJoinFailsForEnabledOption() - Method in class org.apache.drill.exec.planner.sql.CrossJoinTest
-
- testCommaJoinSucceedsForDisabledOption() - Method in class org.apache.drill.exec.planner.sql.CrossJoinTest
-
- testCommandHandlers() - Method in class org.apache.drill.exec.client.DrillSqlLineApplicationTest
-
- testCommon(String[], String, String) - Method in class org.apache.drill.exec.fn.impl.TestDateFunctions
-
- testCompactHalfDayHourMin() - Method in class org.apache.drill.exec.server.TestDurationFormat
-
- testCompactHourMin() - Method in class org.apache.drill.exec.server.TestDurationFormat
-
- testCompactManyDayHourMin() - Method in class org.apache.drill.exec.server.TestDurationFormat
-
- testCompactMinSec() - Method in class org.apache.drill.exec.server.TestDurationFormat
-
- testCompactOneDayHourMin() - Method in class org.apache.drill.exec.server.TestDurationFormat
-
- testCompactSecMillis() - Method in class org.apache.drill.exec.server.TestDurationFormat
-
- testCompactTwoDigitMilliSec() - Method in class org.apache.drill.exec.server.TestDurationFormat
-
- TestComparisonFunctions - Class in org.apache.drill.exec.physical.impl
-
- TestComparisonFunctions() - Constructor for class org.apache.drill.exec.physical.impl.TestComparisonFunctions
-
- testComparisonWithSingleValueSubQuery() - Method in class org.apache.drill.TestExampleQueries
-
- testCompilationNoDebug() - Method in class org.apache.drill.exec.compile.TestClassTransformation
-
- testCompleteLifeCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestBuildSidePartitioningImpl
-
- testComplex() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testComplexAndSimpleColumnSelection() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- TestComplexColumnInSchema - Class in org.apache.drill.exec.store.parquet
-
This test checks correctness of complex column detection in the Parquet file schema.
- TestComplexColumnInSchema() - Constructor for class org.apache.drill.exec.store.parquet.TestComplexColumnInSchema
-
- testComplexDecimal() - Method in class org.apache.drill.exec.physical.impl.TestDecimal
-
- testComplexDecimalSort() - Method in class org.apache.drill.exec.physical.impl.TestDecimal
-
- testComplexJSON_all_text() - Method in class org.apache.drill.TestFrameworkTest
-
- testComplexJsonInput() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testComplexLogicalIntTypes() - Method in class org.apache.drill.exec.store.parquet.TestParquetLogicalTypes
-
- testComplexLogicalIntTypes2() - Method in class org.apache.drill.exec.store.parquet.TestParquetLogicalTypes
-
- testComplexLogicalIntTypes3() - Method in class org.apache.drill.exec.store.parquet.TestParquetLogicalTypes
-
- testComplexLogicalIntTypes4() - Method in class org.apache.drill.exec.store.parquet.TestParquetLogicalTypes
-
- testComplexLogicalIntTypes5() - Method in class org.apache.drill.exec.store.parquet.TestParquetLogicalTypes
-
- testComplexMultipleTimes() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testComplexQueryWithUnionAllAndEmptyDir() - Method in class org.apache.drill.TestUnionAll
-
- testComplexQueryWithUnionAndEmptyDir() - Method in class org.apache.drill.TestUnionDistinct
-
- testComplexRepeated() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testComplexToJson() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- TestComplexToJson - Class in org.apache.drill.exec.vector.complex.writer
-
- TestComplexToJson() - Constructor for class org.apache.drill.exec.vector.complex.writer.TestComplexToJson
-
- TestComplexTypeReader - Class in org.apache.drill.exec.vector.complex.writer
-
- TestComplexTypeReader() - Constructor for class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- TestComplexTypeWriter - Class in org.apache.drill.exec.vector.complex.writer
-
- TestComplexTypeWriter() - Constructor for class org.apache.drill.exec.vector.complex.writer.TestComplexTypeWriter
-
- testCompoundIdentifierInWindowDefinition() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testComputedProbeRecordsPerBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testComputedProbeRecordsPerBatchRoundUp() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testComputedShouldBeMin() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testComputeMaxBatchSizeHash() - Method in class org.apache.drill.exec.physical.impl.join.TestBatchSizePredictorImpl
-
- testComputeMaxBatchSizeNoHash() - Method in class org.apache.drill.exec.physical.impl.join.TestBatchSizePredictorImpl
-
- testComputeValueVectorSizeNonPowerOf2() - Method in class org.apache.drill.exec.physical.impl.join.TestBatchSizePredictorImpl
-
- testComputeValueVectorSizePowerOf2() - Method in class org.apache.drill.exec.physical.impl.join.TestBatchSizePredictorImpl
-
- testConcat() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testConcatFunction() - Method in class org.apache.drill.TestFunctionsQuery
-
- testConcatOnNull() - Method in class org.apache.drill.TestExampleQueries
-
- testConcatOperator() - Method in class org.apache.drill.TestExampleQueries
-
- testConcatSingleInput() - Method in class org.apache.drill.TestFunctionsQuery
-
- testConcatWithMoreThanTwoArgs() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testConcurrentFunctionBodyLoad() - Method in class org.apache.drill.exec.expr.fn.FunctionInitializerTest
-
- testConcurrentQueries() - Method in class org.apache.drill.TestTpchDistributedConcurrent
-
- testConcurrentRegistrationOfTheSameJar() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testConcurrentRemoteRegistryUpdateForDifferentJars() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testConcurrentRemoteRegistryUpdateWithDuplicates() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testConfig() - Method in class org.apache.drill.exec.physical.impl.validate.TestValidationOptions
-
Config options override session options.
- testConfigBackwardCompatibility() - Method in class org.apache.drill.exec.server.rest.spnego.TestSpnegoAuthentication
-
Validate when none of the security mechanism is specified in the
ExecConstants.HTTP_AUTHENTICATION_MECHANISMS
, FORM security handler is still configured correctly when
authentication is enabled along with PAM authenticator module.
- testConfigConstraints() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
- testConfigDefaults() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
Verify defaults configured in drill-override.conf.
- testConfigLimits() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
Some properties have hard-coded limits.
- TestConfigLinkage - Class in org.apache.drill.exec.server.options
-
- TestConfigLinkage() - Constructor for class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testConfigOption() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testConfigOverride() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
Verify that the various constants do, in fact, map to the
expected properties, and that the properties are overridden.
- testConfigWithoutOverride() - Method in class org.apache.drill.exec.client.DrillSqlLineApplicationTest
-
- TestConformance - Class in org.apache.drill.exec.sql
-
- TestConformance() - Constructor for class org.apache.drill.exec.sql.TestConformance
-
- testConnectFailureUsingZKWithOnlyFakeBits() - Method in class org.apache.drill.exec.client.ConnectTriesPropertyTestClusterBits
-
- testConnectionBackpressure() - Method in class org.apache.drill.exec.rpc.data.TestBitRpc
-
- testConnectionCounters() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberosEncryption
-
Test connection counter values for both encrypted and unencrypted connections over all Drillbit channels.
- testConnectionUrlExamples() - Method in class org.apache.drill.exec.client.DrillSqlLineApplicationTest
-
- TestConstantColumnLoader - Class in org.apache.drill.exec.physical.impl.scan.project
-
Drill allows file metadata columns (also called "implicit" columns.)
These are columns that contain a long repeated sequences of the same
values.
- TestConstantColumnLoader() - Constructor for class org.apache.drill.exec.physical.impl.scan.project.TestConstantColumnLoader
-
- testConstantColumnLoader() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestConstantColumnLoader
-
Test the static column loader using one column of each type.
- TestConstantFolding - Class in org.apache.drill.exec.fn.interp
-
- TestConstantFolding() - Constructor for class org.apache.drill.exec.fn.interp.TestConstantFolding
-
- TestConstantFolding.SmallFileCreator - Class in org.apache.drill.exec.fn.interp
-
- testConstantFolding_allTypes() - Method in class org.apache.drill.exec.fn.interp.TestConstantFolding
-
- testConstantFoldingDisableOption() - Method in class org.apache.drill.exec.fn.interp.TestConstantFolding
-
- testConstantFoldingOff() - Method in class org.apache.drill.exec.planner.TestDirectoryExplorerUDFs
-
- testConstantsInMultiplePartitions() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testConstExprFolding_dontFoldRandom() - Method in class org.apache.drill.exec.fn.interp.TestConstantFolding
-
- testConstExprFolding_InSelect() - Method in class org.apache.drill.exec.fn.interp.TestConstantFolding
-
- testConstExprFolding_maxDir0() - Method in class org.apache.drill.exec.planner.TestDirectoryExplorerUDFs
-
- testConstExprFolding_moreComplicatedNonDirFilter() - Method in class org.apache.drill.exec.fn.interp.TestConstantFolding
-
- testConstExprFolding_nonDirFilter() - Method in class org.apache.drill.exec.fn.interp.TestConstantFolding
-
- testConstExprFolding_ToLimit0() - Method in class org.apache.drill.exec.fn.interp.TestConstantFolding
-
- testConstExprFolding_withPartitionPrune() - Method in class org.apache.drill.exec.fn.interp.TestConstantFolding
-
- testConstExprFolding_withPartitionPrune_verySmallFiles() - Method in class org.apache.drill.exec.fn.interp.TestConstantFolding
-
- testContainerMerge() - Method in class org.apache.drill.exec.record.TestVectorContainer
-
Test of the ability to merge two schemas and to merge
two vector containers.
- testContainingArray() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testContainsJar() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- TestContextFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestContextFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestContextFunctions
-
- TestConvertCountToDirectScan - Class in org.apache.drill.exec.planner.logical
-
- TestConvertCountToDirectScan() - Constructor for class org.apache.drill.exec.planner.logical.TestConvertCountToDirectScan
-
- testConvertFromConvertToInt() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testConvertFromJson_drill4679() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testConvertFromJson_drill4693() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testConvertFromJsonFunction() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- testConvertFromJsonNullableInput() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- TestConvertFunctions - Class in org.apache.drill.exec.physical.impl
-
- TestConvertFunctions() - Constructor for class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testConvertToComplexJSON() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testConvertToJsonFunction() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- TestCopier - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
Light-weight sanity test of the copier class.
- TestCopier() - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- testCopyRecords() - Method in class org.apache.drill.exec.physical.impl.svremover.AbstractGenericCopierTest
-
- testCorrectDatesAndExceptionWhileParsingCreatedBy() - Method in class org.apache.drill.exec.physical.impl.writer.TestCorruptParquetDateCorrection
-
- testCorrectDateValuesGeneratedByOldVersionOfDrill() - Method in class org.apache.drill.exec.physical.impl.writer.TestCorruptParquetDateCorrection
-
- testCorrelatedExistsWithInSubq() - Method in class org.apache.drill.TestExampleQueries
-
- TestCorrelation - Class in org.apache.drill
-
- TestCorrelation() - Constructor for class org.apache.drill.TestCorrelation
-
- testCorruptedMetadataFile() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- TestCorruptParquetDateCorrection - Class in org.apache.drill.exec.physical.impl.writer
-
Tests for compatibility reading old parquet files after date corruption
issue was fixed in DRILL-4203.
- TestCorruptParquetDateCorrection() - Constructor for class org.apache.drill.exec.physical.impl.writer.TestCorruptParquetDateCorrection
-
- testCorruptValueDetectionDuringPruning() - Method in class org.apache.drill.exec.physical.impl.writer.TestCorruptParquetDateCorrection
-
- testCosFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testCoshFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testCot() - Method in class org.apache.drill.exec.fn.impl.TestTrigFunctions
-
- testCotFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testCount() - Method in class org.apache.drill.exec.store.log.TestLogReader
-
- testCountComplexObjects() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testCountConst() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testCountDistinctOnBoolColumn() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- TestCountDownLatchInjection - Class in org.apache.drill.exec.testing
-
- TestCountDownLatchInjection() - Constructor for class org.apache.drill.exec.testing.TestCountDownLatchInjection
-
- testCountEmptyPartitionByWithExchange() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testCountingQueryNotSkippingInvalidJSONRecords() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testCountingQuerySkippingInvalidJSONRecords() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testCountOnCsvWithHeader() - Method in class org.apache.drill.exec.store.text.TestCsvHeader
-
- testCountOnFieldWithDots() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testCountOnNullableColumn() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testCountQuery() - Method in class org.apache.drill.exec.store.pcap.TestPcapRecordReader
-
- testCountQuery() - Method in class org.apache.drill.exec.store.pcapng.TestPcapngRecordReader
-
- testCountStar() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testCountStarRequired() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testCountStarWithImplicitColumnsInWhereClause() - Method in class org.apache.drill.exec.store.TestImplicitFileColumns
-
- testCountWithAvg() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testCovarianceCorrelation() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunction
-
- testCreate() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- testCreateNoPath() - Method in class org.apache.drill.exec.store.StorageStrategyTest
-
- testCreatePathAndDeleteOnExitFalse() - Method in class org.apache.drill.exec.store.StorageStrategyTest
-
- testCreatePathAndDeleteOnExitTrue() - Method in class org.apache.drill.exec.store.StorageStrategyTest
-
- testCreatePersistentTableWhenTemporaryTableExists() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testCreateReturnsNullWhenArgumentsAreIllegal() - Method in class org.apache.drill.exec.store.dfs.TestFileSelection
-
- testCreateTableIfNotExistsWhenTableWithSameNameAlreadyExists() - Method in class org.apache.drill.exec.sql.TestCTAS
-
- testCreateTableIfNotExistsWhenTableWithSameNameDoesNotExist() - Method in class org.apache.drill.exec.sql.TestCTAS
-
- testCreateTableIfNotExistsWhenViewWithSameNameAlreadyExists() - Method in class org.apache.drill.exec.sql.TestCTAS
-
- testCreateTableInDirWithGroupPermissionsForQueryUser() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- testCreateTableInDirWithOtherPermissionsForQueryUser() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- testCreateTableInDirWithUserPermissionsForQueryUser() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- testCreateTableInWSWithNoPermissionsForQueryUser() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- testCreateTableNanInf() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- testCreateTableSameColumnNames() - Method in class org.apache.drill.TestExampleQueries
-
- testCreateTableWithDifferentStorageFormats() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testCreateTemporaryTableIfNotExistsWhenTableWithSameNameAlreadyExists() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testCreateTemporaryTableIfNotExistsWhenTableWithSameNameDoesNotExist() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testCreateTemporaryTableIfNotExistsWhenViewWithSameNameAlreadyExists() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testCreateViewIfNotExists() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- testCreateViewInDirWithGroupPermissionsForQueryUser() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- testCreateViewInDirWithOtherPermissionsForQueryUser() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- testCreateViewInDirWithUserPermissionsForQueryUser() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- testCreateViewInWSWithNoPermissionsForQueryUser() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- testCreateViewWhenTemporaryTableExists() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testCreateWhenPersistentTableExists() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testCreateWhenTemporaryTableExistsCaseInsensitive() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testCreateWhenTemporaryTableExistsWithoutSchema() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testCreateWhenTemporaryTableExistsWithSchema() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testCreateWhenViewExists() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testCreationOutsideOfDefaultTemporaryWorkspace() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testCrLfSeparatedWithQuote() - Method in class org.apache.drill.exec.store.text.TestNewTextReader
-
- testCrossApplyFailsForEnabledOption() - Method in class org.apache.drill.exec.planner.sql.CrossJoinTest
-
- testCrossApplySucceedsForDisabledOption() - Method in class org.apache.drill.exec.planner.sql.CrossJoinTest
-
- testCrossJoinFailsForEnabledOption() - Method in class org.apache.drill.exec.planner.sql.CrossJoinTest
-
- testCrossJoinSucceedsForDisabledOption() - Method in class org.apache.drill.exec.planner.sql.CrossJoinTest
-
- testCrossJoinSucceedsForEnabledOptionAndScalarInput() - Method in class org.apache.drill.exec.planner.sql.CrossJoinTest
-
- TestCsv - Class in org.apache.drill.exec.store.easy.text.compliant
-
SQL-level tests for CSV headers.
- TestCsv() - Constructor for class org.apache.drill.exec.store.easy.text.compliant.TestCsv
-
- testCsvColumnSelection() - Method in class org.apache.drill.exec.store.text.TestTextColumn
-
- testCsvColumnSelectionCommasInsideQuotes() - Method in class org.apache.drill.exec.store.text.TestTextColumn
-
- testCsvColumnsWithHeader() - Method in class org.apache.drill.exec.store.text.TestCsvHeader
-
- TestCsvHeader - Class in org.apache.drill.exec.store.text
-
- TestCsvHeader() - Constructor for class org.apache.drill.exec.store.text.TestCsvHeader
-
- testCsvHeaderMismatch() - Method in class org.apache.drill.exec.store.text.TestCsvHeader
-
- testCsvHeaderNonExistingColumn() - Method in class org.apache.drill.exec.store.text.TestCsvHeader
-
- testCsvHeadersCaseInsensitive() - Method in class org.apache.drill.exec.store.easy.text.compliant.TestCsv
-
- testCsvHeaderShortCircuitReads() - Method in class org.apache.drill.exec.store.text.TestCsvHeader
-
- testCsvHeaderSkipFirstLine() - Method in class org.apache.drill.exec.store.text.TestCsvHeader
-
- testCsvStarPlusWithHeader() - Method in class org.apache.drill.exec.store.text.TestCsvHeader
-
- testCSVVerification() - Method in class org.apache.drill.TestFrameworkTest
-
- testCSVVerification_extra_column_fails() - Method in class org.apache.drill.TestFrameworkTest
-
- testCSVVerification_extra_records_fails() - Method in class org.apache.drill.TestFrameworkTest
-
- testCSVVerification_missing_column_fails() - Method in class org.apache.drill.TestFrameworkTest
-
- testCSVVerification_missing_records_fails() - Method in class org.apache.drill.TestFrameworkTest
-
- testCSVVerificationOfOrder_checkFailure() - Method in class org.apache.drill.TestFrameworkTest
-
- testCSVVerificationOfTypes() - Method in class org.apache.drill.TestFrameworkTest
-
- testCSVVerificationOfUnorderedComparison() - Method in class org.apache.drill.TestFrameworkTest
-
- testCSVVerificationTypeMap() - Method in class org.apache.drill.TestFrameworkTest
-
- testCsvWhereColumnsWithHeader() - Method in class org.apache.drill.exec.store.text.TestCsvHeader
-
- testCsvWhereWithHeader() - Method in class org.apache.drill.exec.store.text.TestCsvHeader
-
- testCsvWithHeader() - Method in class org.apache.drill.exec.store.text.TestCsvHeader
-
- TestCTAS - Class in org.apache.drill.exec.sql
-
- TestCTAS() - Constructor for class org.apache.drill.exec.sql.TestCTAS
-
- testctas_alltypes_map() - Method in class org.apache.drill.TestCTASJson
-
- testctas_alltypes_map_noskip() - Method in class org.apache.drill.TestCTASJson
-
- testctas_alltypes_repeated_map_noskip() - Method in class org.apache.drill.TestCTASJson
-
- testctas_alltypes_repeatedmap() - Method in class org.apache.drill.TestCTASJson
-
- TestCTASJson - Class in org.apache.drill
-
- TestCTASJson() - Constructor for class org.apache.drill.TestCTASJson
-
- testCTASOrderByCoumnNotInSelectClause() - Method in class org.apache.drill.TestExampleQueries
-
- TestCTASPartitionFilter - Class in org.apache.drill
-
- TestCTASPartitionFilter() - Constructor for class org.apache.drill.TestCTASPartitionFilter
-
- testCTASWithEmptyJson() - Method in class org.apache.drill.exec.sql.TestCTAS
-
- testCTASWithIntervalTypes() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- TestCTTAS - Class in org.apache.drill.exec.sql
-
- TestCTTAS() - Constructor for class org.apache.drill.exec.sql.TestCTTAS
-
- testCurrentDate() - Method in class org.apache.drill.exec.fn.impl.TestNewDateFunctions
-
- testCustomFloor() - Method in class org.apache.drill.exec.util.TestQueryMemoryAlloc
-
- testCustomNullType() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestNullColumnLoader
-
Test the ability to use a type other than nullable INT for null
columns.
- testCustomPercent() - Method in class org.apache.drill.exec.util.TestQueryMemoryAlloc
-
- testCustomRowLimit() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderLimits
-
Verify that the caller can set a row limit lower than the default.
- testCustomTextLineDelimiterAndNewLine() - Method in class org.apache.drill.TestSelectWithOption
-
- TestCustomTunnel - Class in org.apache.drill.exec.rpc.control
-
- TestCustomTunnel() - Constructor for class org.apache.drill.exec.rpc.control.TestCustomTunnel
-
- TestCustomTunnel.MesgA - Class in org.apache.drill.exec.rpc.control
-
- TestCustomTunnel.MesgB - Class in org.apache.drill.exec.rpc.control
-
- TestCustomUserAuthenticator - Class in org.apache.drill.exec.rpc.user.security
-
- TestCustomUserAuthenticator() - Constructor for class org.apache.drill.exec.rpc.user.security.TestCustomUserAuthenticator
-
- testDataFromInt(ValueType, TypeProtos.MajorType, int) - Static method in class org.apache.drill.test.rowSet.RowSetUtilities
-
- testDataWithPartOfMultiByteLineDelimiter() - Method in class org.apache.drill.TestSelectWithOption
-
- testDate() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testDate() - Method in class org.apache.drill.exec.record.vector.TestDateTypes
-
- testDate() - Method in class org.apache.drill.exec.store.log.TestLogReader
-
- testDate_Part() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testDateAdd() - Method in class org.apache.drill.exec.record.vector.TestDateTypes
-
- TestDateAddFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestDateAddFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestDateAddFunctions
-
- testDateAddIntegerAsDay() - Method in class org.apache.drill.exec.fn.impl.TestDateAddFunctions
-
- testDateAddIntervalDay() - Method in class org.apache.drill.exec.fn.impl.TestDateAddFunctions
-
- testDateAddIntervalYear() - Method in class org.apache.drill.exec.fn.impl.TestDateAddFunctions
-
- testDateAndTimestampJson() - Method in class org.apache.drill.TestUnionAll
-
- testDateAndTimestampJson() - Method in class org.apache.drill.TestUnionDistinct
-
- testDateArray() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- TestDateConversions - Class in org.apache.drill.exec.fn.impl.testing
-
- TestDateConversions() - Constructor for class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testDateDifferenceArithmetic() - Method in class org.apache.drill.exec.fn.impl.TestDateFunctions
-
- TestDateFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestDateFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestDateFunctions
-
- testDateImplicitCasting() - Method in class org.apache.drill.TestExampleQueries
-
- testDateIntervalArithmetic() - Method in class org.apache.drill.exec.fn.impl.TestDateFunctions
-
- testDatePartitionedReadWithCorruption() - Method in class org.apache.drill.exec.physical.impl.writer.TestCorruptParquetDateCorrection
-
- testDatePredicateAgainstCorruptedDateCol() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testDatePredicateAgainstDrillCTAS1_8WithEval() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testDatePredicateAgainstDrillCTASPost1_8WithEval() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testDatePredicateAgaistDrillCTASPost1_8() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- TestDateReader - Class in org.apache.drill.exec.store.parquet.columnreaders
-
- TestDateReader() - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.TestDateReader
-
- testDateRW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testDateTime1() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testDateTime2() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testDateTime3() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testDateTime4() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testDateTimeType() - Method in class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- testDateTrunc() - Method in class org.apache.drill.exec.fn.impl.TestDateTruncFunctions
-
- TestDateTruncFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestDateTruncFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestDateTruncFunctions
-
- TestDateTypes - Class in org.apache.drill.exec.record.vector
-
- TestDateTypes() - Constructor for class org.apache.drill.exec.record.vector.TestDateTypes
-
- testDateUtilityParser() - Method in class org.apache.drill.exec.physical.impl.TestNestedDateTimeTimestamp
-
- TestDecimal - Class in org.apache.drill.exec.physical.impl
-
- TestDecimal() - Constructor for class org.apache.drill.exec.physical.impl.TestDecimal
-
- testDecimal() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testDecimal() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
Test the ability to specify decimal precision and scale.
- testDecimal18Array() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testDecimal18Decimal38Comparison() - Method in class org.apache.drill.TestFunctionsQuery
-
- testDecimal18RW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testDecimal9AndDecimal18WithDictionary() - Method in class org.apache.drill.exec.store.parquet.columnreaders.TestColumnReaderFactory
-
check if Decimal9 and Decimal18 are read correctly with dictionary encoding.
- testDecimal9AndDecimal18WithNoDictionary() - Method in class org.apache.drill.exec.store.parquet.columnreaders.TestColumnReaderFactory
-
check if Decimal9 and Decimal18 are read correctly with plain encoding.
- testDecimal9Array() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testDecimal9RW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testDecimalAbs() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalAdd() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalAddConstant() - Method in class org.apache.drill.TestFunctionsQuery
-
- testDecimalAddIntConstant() - Method in class org.apache.drill.TestFunctionsQuery
-
- testDecimalAddOverflow() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalBaseline() - Method in class org.apache.drill.TestFrameworkTest
-
- testDecimalCeil() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalCompareToNullsHigh() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalCompareToNullsLow() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalDivide() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalDivideOverflow() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalDownwardCast() - Method in class org.apache.drill.TestFunctionsQuery
-
- testDecimalEquals() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalFloor() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalGreaterThan() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalGreaterThanEquals() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalLessThan() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalLessThanEquals() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalMod() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalMultiplicationOverflowHandling() - Method in class org.apache.drill.TestFunctionsQuery
-
- testDecimalMultiplicationOverflowNegativeScale() - Method in class org.apache.drill.TestFunctionsQuery
-
- testDecimalMultiply() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalMultiplyOverflow() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalNegate() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalPruningDifferentScale() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check partition pruning for decimals with different scale.
- testDecimalPruningWithNullPartition() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
- testDecimalPushDownDifferentScale() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check filter push down for decimals with different scale.
- testDecimalRound() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalRoundUp() - Method in class org.apache.drill.TestFunctionsQuery
-
- testDecimalRoundWithScale() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalScalePrecision() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
- testDecimalSign() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalToChar() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalTrunc() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalTruncWithScale() - Method in class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testDecimalWithGroupBy() - Method in class org.apache.drill.exec.physical.impl.agg.TestAggWithAnyValue.TestAggWithAnyValueSingleBatch
-
- testDefaultDelimiterColumnSelection() - Method in class org.apache.drill.exec.store.text.TestTextColumn
-
- testDefaultInternalValue() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testDefaultOptions() - Method in class org.apache.drill.exec.util.TestQueryMemoryAlloc
-
- testDefaults() - Method in class org.apache.drill.exec.physical.impl.validate.TestValidationOptions
-
Should do no validation with all-default options.
- testDefaultsDeserialization() - Method in class org.apache.drill.exec.store.parquet.TestParquetReaderConfig
-
- testDefaultValidatorInternalValue() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testDegreesFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testDelete() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- testDesc() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
- testDescNullsFirst() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- testDescNullsLast() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- testDescribeSchema() - Method in class org.apache.drill.exec.sql.TestSchemaCaseInsensitivity
-
- testDescribeTable() - Method in class org.apache.drill.exec.sql.TestSchemaCaseInsensitivity
-
- testDictionary() - Method in class org.apache.drill.exec.store.parquet.columnreaders.TestDateReader
-
check if DateReader works well with dictionary encoding.
- testDictionaryEncoding() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testDictionaryEncoding() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testDictionaryError() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testDictionaryError() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testDictionaryError_419() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testDiffCaseQuery() - Method in class org.apache.drill.exec.store.pcapng.TestPcapngRecordReader
-
- testDiffDataTypesAndModes() - Method in class org.apache.drill.TestUnionAll
-
- testDiffDataTypesAndModes() - Method in class org.apache.drill.TestUnionDistinct
-
- testDifferentCase() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaSmoothing
-
The prior and table schemas are identical, but the cases of names differ.
- testDifferentTypes() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaSmoothing
-
Column names match, but types differ.
- testDirectImpersonation_HasGroupReadPermissions() - Method in class org.apache.drill.exec.impersonation.TestImpersonationQueries
-
- testDirectImpersonation_HasUserReadPermissions() - Method in class org.apache.drill.exec.impersonation.TestImpersonationQueries
-
- testDirectImpersonation_NoReadPermissions() - Method in class org.apache.drill.exec.impersonation.TestImpersonationQueries
-
- TestDirectoryExplorerUDFs - Class in org.apache.drill.exec.planner
-
- TestDirectoryExplorerUDFs() - Constructor for class org.apache.drill.exec.planner.TestDirectoryExplorerUDFs
-
- testDirectoryPruning() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- testDirectoryPruningWithNestedStarSubQuery() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- testDirectoryPruningWithNestedStarSubQueryAndAdditionalColumns() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- testDirectoryUDFsWithAndWithoutMetadataCache() - Method in class org.apache.drill.exec.planner.TestDirectoryExplorerUDFs
-
- testDirectSubScan() - Method in class org.apache.drill.exec.TestOpSerialization
-
- testDirPruningTransitivePredicates() - Method in class org.apache.drill.TestPartitionFilter
-
- testDisableCube() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisabledCardinality() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisabledCastREAL() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisabledCastSMALLINT() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisabledCastTINYINT() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisableDecimalCasts() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisableDecimalFromParquet() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisabledExcept() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisabledExceptALL() - Method in class org.apache.drill.TestDisabledFunctionality
-
- TestDisabledFunctionality - Class in org.apache.drill
-
- TestDisabledFunctionality() - Constructor for class org.apache.drill.TestDisabledFunctionality
-
- testDisabledIntersect() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisabledIntersectALL() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisabledNaturalJoin() - Method in class org.apache.drill.TestDisabledFunctionality
-
- TestDisabledPlugin - Class in org.apache.drill.exec.store.store
-
- TestDisabledPlugin() - Constructor for class org.apache.drill.exec.store.store.TestDisabledPlugin
-
- testDisabledPluginQuery() - Method in class org.apache.drill.exec.store.store.TestDisabledPlugin
-
- testDisableDrillbitAuth_EnableClientAuthKerberos() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSaslCompatibility
-
Test showing when Drillbit is not configured for authentication whereas client explicitly requested for Kerberos
authentication then connection fails due to new check before SASL Handshake.
- testDisableDrillbitAuth_EnableClientAuthPlain() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSaslCompatibility
-
Test showing when Drillbit is not configured for authentication whereas client explicitly requested for PLAIN
authentication then connection succeeds without authentication.
- testDisableDrillbitAuth_EnableClientEncryption() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSaslCompatibility
-
Test showing failure before SASL handshake when Drillbit is not configured for authentication whereas client
explicitly requested for encrypted connection.
- testDisableDrillbitClientAuth() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSaslCompatibility
-
Test showing successful handshake when authentication is disabled on Drillbit side and client also
doesn't provide any security properties in connection URL.
- testDisableDrillbitEncryption_EnableClientEncryption() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSaslCompatibility
-
Test showing failure before SASL handshake when Drillbit is not configured for encryption whereas client explicitly
requested for encrypted connection.
- testDisableDynamicSupportCreate() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testDisableDynamicSupportDrop() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testDisableGroup_ID() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisableGrouping() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisableGrouping_ID() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisableGroupingInFilter() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisableGroupingSets() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisableRollup() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testDisableUtf8SupportInQueryString() - Method in class org.apache.drill.TestUtf8SupportInQueryString
-
- testDisjoint() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaLevelProjection
-
Drill is unique in that we can select (a, b) from a data source
that only offers (c, d).
- testDisjoint() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaSmoothing
-
Case in which the table schema and prior are disjoint
sets.
- testDisjointMapProjection() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderEmptyProject
-
Test disjoint projection, but with maps.
- testDisjointSchema() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderEmptyProject
-
Verify that a disjoint schema (projection does not overlap with
table schema) is treated the same as an empty projection.
- testDispatcherPropagatesEvents() - Method in class org.apache.drill.exec.coord.zk.TestEventDispatcher
-
- testDistinctAggrFlattened() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testDistinctOverAggFunctionWithGroupBy() - Method in class org.apache.drill.TestExampleQueries
-
- testDistinctOverUnionAllwithFullyQualifiedColumnNames() - Method in class org.apache.drill.TestUnionAll
-
- testDistinctOverUnionDistinctwithFullyQualifiedColumnNames() - Method in class org.apache.drill.TestUnionDistinct
-
- testDistinctQuery() - Method in class org.apache.drill.exec.store.pcap.TestPcapRecordReader
-
- testDistinctQuery() - Method in class org.apache.drill.exec.store.pcapng.TestPcapngRecordReader
-
- TestDistributedFragmentRun - Class in org.apache.drill.exec.physical.impl
-
- TestDistributedFragmentRun() - Constructor for class org.apache.drill.exec.physical.impl.TestDistributedFragmentRun
-
- testDivideFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testDontAdjustInitialPartitions() - Method in class org.apache.drill.exec.physical.impl.join.TestBuildSidePartitioningImpl
-
- TestDotDrillUtil - Class in org.apache.drill.exec.dotdrill
-
- TestDotDrillUtil() - Constructor for class org.apache.drill.exec.dotdrill.TestDotDrillUtil
-
- testDotFilesStatus() - Method in class org.apache.drill.exec.dotdrill.TestDotDrillUtil
-
- testDoubleArray() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testDoubleClose() - Method in class org.apache.drill.exec.server.rest.WebSessionResourcesTest
-
- testDoubleCommit() - Method in class org.apache.drill.exec.physical.impl.common.HashTableAllocationTrackerTest
-
- testDoubleGetNextCall() - Method in class org.apache.drill.exec.physical.impl.common.HashTableAllocationTrackerTest
-
- testDoubleNestedArray() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMapArray
-
Test a doubly-nested array of maps.
- testDoubleNestedArray() - Method in class org.apache.drill.test.rowSet.test.TestMapAccessors
-
Test a doubly-nested array of maps.
- testDoubleNestedSchema_NoNullValues() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testDoubleNestedSchema_NoNullValues_NotAllColumnsProjected() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testDoubleNestedSchema_StarQuery() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testDoubleQuotesForQuotingIdentifiers() - Method in class org.apache.drill.exec.planner.sql.TestDrillSQLWorker
-
- testDoubleRW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testDoubleType() - Method in class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- testDRILL1337_LocalLeftFilterLeftOutJoin() - Method in class org.apache.drill.TestBugFixes
-
- testDRILL1337_LocalRightFilterLeftOutJoin() - Method in class org.apache.drill.TestBugFixes
-
- testDrill1665() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testDrill2092() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testDrill2170() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testDRILL2361_AggColumnAliasWithDots() - Method in class org.apache.drill.TestBugFixes
-
- testDRILL2361_JoinColumnAliasWithDots() - Method in class org.apache.drill.TestBugFixes
-
- testDRILL2361_SortColumnAliasWithDots() - Method in class org.apache.drill.TestBugFixes
-
- testDRILL3410() - Method in class org.apache.drill.TestCTASPartitionFilter
-
- testDRILL3414() - Method in class org.apache.drill.TestCTASPartitionFilter
-
- testDRILL3414_2() - Method in class org.apache.drill.TestCTASPartitionFilter
-
- testDrill3965() - Method in class org.apache.drill.TestCTASPartitionFilter
-
- testDrill4147_1() - Method in class org.apache.drill.TestUnionAll
-
- testDrill4147_1() - Method in class org.apache.drill.TestUnionDistinct
-
- testDrill4147_2() - Method in class org.apache.drill.TestUnionAll
-
- testDrill4147_3() - Method in class org.apache.drill.TestUnionAll
-
- testDrill4165() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testDRILL4192() - Method in class org.apache.drill.TestBugFixes
-
- testDrill4196() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testDrill428() - Method in class org.apache.drill.TestExampleQueries
-
- testDrill4530_1() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testDrill4530_2() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testDrill4530_3() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testDrill4530_4() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testDRILL4771() - Method in class org.apache.drill.TestBugFixes
-
- testDrill4786_1() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testDrill4786_2() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testDrill4794() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testDrill4833_1() - Method in class org.apache.drill.TestUnionAll
-
- testDrill4833_2() - Method in class org.apache.drill.TestUnionAll
-
- testDrill4877() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testDRILL4884() - Method in class org.apache.drill.TestBugFixes
-
- testDRILL5051() - Method in class org.apache.drill.TestBugFixes
-
- testDRILL5269() - Method in class org.apache.drill.TestBugFixes
-
- testDRILL6318() - Method in class org.apache.drill.TestBugFixes
-
- testDrill6809() - Method in class org.apache.drill.test.rowSet.test.TestMapAccessors
-
Test that the schema inference handles repeated map vectors.
- testDrill_1314() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testDrill_1314() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testDrill_1314_all_columns() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testDrill_1314_all_columns() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testDrill_1419() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testDrill_1770() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testDrill_2013() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testDRILL_2106() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testDRILL_3004() - Method in class org.apache.drill.TestExampleQueries
-
- testDRILL_595WithClause() - Method in class org.apache.drill.TestStarQueries
-
- testDRILL_595WithClauseJoin() - Method in class org.apache.drill.TestStarQueries
-
- testDRILL_811Json() - Method in class org.apache.drill.TestExampleQueries
-
- testDRILL_811View() - Method in class org.apache.drill.TestExampleQueries
-
- testDRILL_811ViewJoin() - Method in class org.apache.drill.TestExampleQueries
-
- testDRILL_FilterMerge() - Method in class org.apache.drill.TestMergeFilterPlan
-
- TestDrillbitResilience - Class in org.apache.drill.exec.server
-
Test how resilient drillbits are to throwing exceptions during various phases of query
execution by injecting exceptions at various points, and to cancellations in various phases.
- TestDrillbitResilience() - Constructor for class org.apache.drill.exec.server.TestDrillbitResilience
-
- testDrillbits() - Method in class org.apache.drill.exec.server.TestOptions
-
- TestDrillFileSystem - Class in org.apache.drill.exec.store.dfs
-
- TestDrillFileSystem() - Constructor for class org.apache.drill.exec.store.dfs.TestDrillFileSystem
-
- testDRILLNestedGBWithSubsetKeys() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- TestDrillParquetReader - Class in org.apache.drill.exec.store.parquet2
-
- TestDrillParquetReader() - Constructor for class org.apache.drill.exec.store.parquet2.TestDrillParquetReader
-
- TestDrillSpnegoAuthenticator - Class in org.apache.drill.exec.server.rest.spnego
-
- TestDrillSpnegoAuthenticator() - Constructor for class org.apache.drill.exec.server.rest.spnego.TestDrillSpnegoAuthenticator
-
- testDrillSpnegoLoginService() - Method in class org.apache.drill.exec.server.rest.spnego.TestSpnegoAuthentication
-
- TestDrillSQLWorker - Class in org.apache.drill.exec.planner.sql
-
- TestDrillSQLWorker() - Constructor for class org.apache.drill.exec.planner.sql.TestDrillSQLWorker
-
- testDrillTypeOf() - Method in class org.apache.drill.exec.expr.fn.impl.TestTypeFns
-
- testDrivers() - Method in class org.apache.drill.exec.client.DrillSqlLineApplicationTest
-
- testDropAbsentJar() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testDropFunction() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testDropJsonTable() - Method in class org.apache.drill.TestDropTable
-
- testDropOnImmutableSchema() - Method in class org.apache.drill.TestDropTable
-
- testDropParquetTable() - Method in class org.apache.drill.TestDropTable
-
- testDropTable() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- TestDropTable - Class in org.apache.drill
-
- TestDropTable() - Constructor for class org.apache.drill.TestDropTable
-
- testDropTableIfExistsWhileItIsAView() - Method in class org.apache.drill.TestDropTable
-
- testDropTableIfExistsWhileTableDoesNotExist() - Method in class org.apache.drill.TestDropTable
-
- testDropTableIfExistsWhileTableExists() - Method in class org.apache.drill.TestDropTable
-
- testDropTableNameStartsWithSlash() - Method in class org.apache.drill.TestDropTable
-
- testDropTemporaryTableAsViewWithException() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testDropTemporaryTableAsViewWithoutException() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testDropTemporaryTableNameStartsWithSlash() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testDropTextTable() - Method in class org.apache.drill.TestDropTable
-
- testDropViewNameStartsWithSlash() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- testDummyMap() - Method in class org.apache.drill.test.rowSet.test.DummyWriterTest
-
Test a dummy map or map array.
- testDummyScalar() - Method in class org.apache.drill.test.rowSet.test.DummyWriterTest
-
Test dummy column writers for scalars and arrays of
scalars.
- testDumpCat() - Method in class org.apache.drill.exec.client.DumpCatTest
-
- testDuplicatedFunctionsInLocalRegistry() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testDuplicatedFunctionsInRemoteRegistry() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testDuplicatedJarInLocalRegistry() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testDuplicatedJarInRemoteRegistry() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testDuplicateNames() - Method in class org.apache.drill.exec.store.easy.text.compliant.TestHeaderBuilder
-
- testDuplicateType() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
- TestDurationFormat - Class in org.apache.drill.exec.server
-
Test translation of millisecond durations into human readable format
- TestDurationFormat() - Constructor for class org.apache.drill.exec.server.TestDurationFormat
-
- testDynamicLimit() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderLimits
-
Test that the row limit can change between batches.
- TestDynamicUDFSupport - Class in org.apache.drill.exec.udf.dynamic
-
- TestDynamicUDFSupport() - Constructor for class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- TestE2EUnnestAndLateral - Class in org.apache.drill.exec.physical.impl.lateraljoin
-
- TestE2EUnnestAndLateral() - Constructor for class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- TestEarlyLimit0Optimization - Class in org.apache.drill.exec.physical.impl.limit
-
- TestEarlyLimit0Optimization() - Constructor for class org.apache.drill.exec.physical.impl.limit.TestEarlyLimit0Optimization
-
- testEmptyBatch() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- testEmptyBatchFixedWidth() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testEmptyBatchMap() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testEmptyBatchNestedMap() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testEmptyBatchNullableFixedWidth() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testEmptyBatchNullableVariableWidth() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testEmptyBatchRepeatedFixedWidth() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testEmptyBatchRepeatedMap() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testEmptyBatchRepeatedVariableWidth() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testEmptyBatchVariableWidth() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testEmptyColProjectInJsonScan() - Method in class org.apache.drill.TestProjectPushDown
-
- testEmptyColProjectInParquetScan() - Method in class org.apache.drill.TestProjectPushDown
-
- testEmptyColProjectInTextScan() - Method in class org.apache.drill.TestProjectPushDown
-
- testEmptyConfig() - Method in class org.apache.drill.exec.client.DrillSqlLineApplicationTest
-
- testEmptyCsvHeaders() - Method in class org.apache.drill.exec.store.easy.text.compliant.TestCsv
-
- testEmptyCSVinDirectory() - Method in class org.apache.drill.TestExampleQueries
-
- testEmptyDirectory() - Method in class org.apache.drill.exec.TestEmptyInputSql
-
- testEmptyDirectoryAndFieldInQuery() - Method in class org.apache.drill.exec.TestEmptyInputSql
-
- testEmptyDirectoryPlanSerDe() - Method in class org.apache.drill.exec.TestEmptyInputSql
-
- testEmptyDirectoryWithMetadataDirFile() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testEmptyDirectoryWithMetadataFile() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testEmptyFinalColumn() - Method in class org.apache.drill.exec.store.text.TestCsvHeader
-
- testEmptyHeader() - Method in class org.apache.drill.exec.store.easy.text.compliant.TestHeaderBuilder
-
- testEmptyInput() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- testEmptyInput() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl
-
Test for an input with a schema, but only an empty input batch.
- TestEmptyInputSql - Class in org.apache.drill.exec
-
- TestEmptyInputSql() - Constructor for class org.apache.drill.exec.TestEmptyInputSql
-
- testEmptyJsonInput() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
Test ScanBatch with a single empty json file.
- testEmptyList() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testEmptyMapAddition() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMaps
-
Test adding an empty map to a loader after writing the first row.
- testEmptyMapDoesNotFailValueCapacityCheck() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testEmptyMapProjection() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderEmptyProject
-
- testEmptyMetadataFile() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testEmptyOverClause() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testEmptyPartitionBy() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- TestEmptyPopulation - Class in org.apache.drill.exec.vector.complex
-
- TestEmptyPopulation() - Constructor for class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testEmptyPopulationWorks() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testEmptyProjection() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestScanLevelProjection
-
Test an empty projection which occurs in a
SELECT COUNT(*) query.
- testEmptyResultAfterProjectPushDownOverUnionAll() - Method in class org.apache.drill.TestUnionAll
-
- testEmptyResultSet() - Method in class org.apache.drill.TestFrameworkTest
-
- testEmptyRootTuple() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
Test the basics of an empty root tuple (i.e.
- testEmptyRowSet() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
- testEmptyTopSchema() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderEmptyProject
-
Verify that empty projection works: allows skipping rows and
reporting those rows as a batch with no vectors but with the
desired row count.
- testEmptyVariableWidthVector() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
Test to verify that record batch sizer handles the actual empty vectors correctly.
- testEnableAllTextMode() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testEnableDrillbitAuth_DisableClientAuth() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSaslCompatibility
-
Test showing failure in SASL handshake when Drillbit is configured for authentication only whereas client doesn't
provide any security properties like username/password in this case.
- testEnableDrillbitClientAuth() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSaslCompatibility
-
Test showing successful SASL handshake when both Drillbit and client side authentication is enabled using PLAIN
mechanism.
- testEnableDrillbitClientEncryption_UsingPlain() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSaslCompatibility
-
Below test shows the failure in Sasl layer with client and Drillbit side encryption enabled using PLAIN
mechanism.
- testEnableDrillbitEncryption_DisableClientAuth() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSaslCompatibility
-
Test showing failure in SASL handshake when Drillbit is configured for encryption whereas client doesn't provide any
security properties like username/password in this case.
- testEnableDrillbitImpersonation_DisableClientAuth() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSaslCompatibility
-
Test showing successful handshake when authentication is disabled but impersonation is enabled on Drillbit side
and client only provides USERNAME as a security property in connection URL.
- testEnableDynamicSupport() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testEncryptedConnectionCountersAllChannel() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberosEncryption
-
Test connection counter values for both encrypted and unencrypted connections over all Drillbit channels.
- testEntriesReturnsRelativePaths() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- TestEphemeralStore - Class in org.apache.drill.exec.coord.zk
-
- TestEphemeralStore() - Constructor for class org.apache.drill.exec.coord.zk.TestEphemeralStore
-
- testEpsImage() - Method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- testEqual() - Method in class org.apache.drill.exec.fn.impl.TestByteComparisonFunctions
-
- testEqualBetweenIntervalAndTimestampDiff() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testEqualCompare() - Method in class org.apache.drill.exec.fn.impl.TestByteComparisonFunctions
-
- testEqualCompareLong() - Method in class org.apache.drill.exec.fn.impl.TestByteComparisonFunctions
-
- testEqualFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testEqualLong() - Method in class org.apache.drill.exec.fn.impl.TestByteComparisonFunctions
-
- testErrorColumnAndWildcard() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestScanLevelProjection
-
Can't include both a column name and a wildcard.
- testErrorFormating() - Method in class org.apache.drill.exec.planner.sql.TestDrillSQLWorker
-
- testErrorTwoWildcards() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestScanLevelProjection
-
Can't include a wildcard twice.
- testErrorWildcardAndColumns() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestScanLevelProjection
-
Can't include both a wildcard and a column name.
- testEvaluation() - Method in class org.apache.drill.exec.compile.TestEvaluationVisitor
-
- TestEvaluationVisitor - Class in org.apache.drill.exec.compile
-
- TestEvaluationVisitor() - Constructor for class org.apache.drill.exec.compile.TestEvaluationVisitor
-
- TestEventDispatcher - Class in org.apache.drill.exec.coord.zk
-
- TestEventDispatcher() - Constructor for class org.apache.drill.exec.coord.zk.TestEventDispatcher
-
- TestExampleQueries - Class in org.apache.drill
-
- TestExampleQueries() - Constructor for class org.apache.drill.TestExampleQueries
-
- testExceedRetryAttemptsDuringRegistration() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testExceedRetryAttemptsDuringUnregistration() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testExceptionHandling() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- TestExceptionInjection - Class in org.apache.drill.exec.testing
-
- TestExceptionInjection() - Constructor for class org.apache.drill.exec.testing.TestExceptionInjection
-
- testExchangeRemoveForJoinPlan() - Method in class org.apache.drill.TestExampleQueries
-
- testExcludeNan() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- testExcludeNegativeInfinity() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- testExcludePositiveInfinity() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- testExist() - Method in class org.apache.drill.exec.work.filter.BloomFilterTest
-
- testExistsScalarSubquery() - Method in class org.apache.drill.TestCorrelation
-
- testExpFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testExplainLateralSql() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testExplainLogical() - Method in class org.apache.drill.TestExampleQueries
-
- testExplainPhysical() - Method in class org.apache.drill.TestExampleQueries
-
- testExplainPlanForCartesianJoin() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testExplainPlanOuterJoinWithInequality() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testExplicit() - Method in class org.apache.drill.exec.store.log.TestLogReader
-
- testExpressionInWindowFunction() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testExprInSelect() - Method in class org.apache.drill.TestProjectPushDown
-
- testExprInWhere() - Method in class org.apache.drill.TestProjectPushDown
-
- testExprParseError() - Method in class org.apache.drill.exec.expr.ExpressionTest
-
- testExprParseLowerExponent() - Method in class org.apache.drill.exec.expr.ExpressionTest
-
- testExprParseNoError() - Method in class org.apache.drill.exec.expr.ExpressionTest
-
- testExprParseUpperExponent() - Method in class org.apache.drill.exec.expr.ExpressionTest
-
- testExprsInInList() - Method in class org.apache.drill.exec.physical.impl.filter.TestLargeInClause
-
- testExtendedMathFunc() - Method in class org.apache.drill.exec.fn.impl.TestNewMathFunctions
-
- TestExtendedTypes - Class in org.apache.drill.exec.vector.complex.writer
-
- TestExtendedTypes() - Constructor for class org.apache.drill.exec.vector.complex.writer.TestExtendedTypes
-
- testEXTERNAL_SORT() - Method in class org.apache.drill.exec.compile.TestLargeFileCompilation
-
- TestExternalSort - Class in org.apache.drill.exec.physical.impl.xsort
-
- TestExternalSort() - Constructor for class org.apache.drill.exec.physical.impl.xsort.TestExternalSort
-
- testExternalSort() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- TestExternalSortExec - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
- TestExternalSortExec() - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortExec
-
- TestExternalSortInternals - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
- TestExternalSortInternals() - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
- testExternalSortLowMemory1() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- testExternalSortLowMemory2() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- testExternalSortLowMemory3() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- testExternalSortLowMemory4() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- testExternalSortUnchecked() - Method in class org.apache.drill.TestOperatorDump
-
- TestExtractFunctions - Class in org.apache.drill.exec.physical.impl
-
- TestExtractFunctions() - Constructor for class org.apache.drill.exec.physical.impl.TestExtractFunctions
-
- testExtractSecond() - Method in class org.apache.drill.TestFunctionsQuery
-
- testExtractSecond() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
In the following query, the extract function would be borrowed from Calcite,
which asserts the return type as be BIG-INT
- testExtractSecondFromInterval() - Method in class org.apache.drill.TestFunctionsQuery
-
- testExtremeLowMemory() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
- testFail() - Method in class org.apache.drill.exec.work.fragment.FragmentStatusReporterTest
-
- testFailAfterClose() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
Simulate the caller failing the operator after close.
- testFailBeforeClose() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
Simulate the caller failing the operator after EOF but before close.
- testFailEarly() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
Simulate the caller failing the operator before getting the schema.
- testFailedExecution() - Method in class org.apache.drill.exec.util.ExecutorServiceUtilTest
-
- testFailingFlattenAlone() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFailureOnExistentFile() - Method in class org.apache.drill.exec.store.StorageStrategyTest
-
- testFailureUsingDirectConnectionAllFakeBits() - Method in class org.apache.drill.exec.client.ConnectTriesPropertyTestClusterBits
-
- TestFailureUtils - Class in org.apache.drill.exec.server
-
- TestFailureUtils() - Constructor for class org.apache.drill.exec.server.TestFailureUtils
-
- testFailWhileReading() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
Simulate the caller failing the operator before EOF.
- testFalttenWithStar() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- TestFastComplexSchema - Class in org.apache.drill.exec.nested
-
- TestFastComplexSchema() - Constructor for class org.apache.drill.exec.nested.TestFastComplexSchema
-
- testFieldNameWithDot() - Method in class org.apache.drill.exec.expr.TestSchemaPathMaterialization
-
- testFieldReference() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortExec
-
- testFieldSelectionBug() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testFieldWithDots() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testFieldWithDots() - Method in class org.apache.drill.TestUnionAll
-
- TestFileGenerator - Class in org.apache.drill.exec.store.parquet
-
- TestFileGenerator() - Constructor for class org.apache.drill.exec.store.parquet.TestFileGenerator
-
- TestFileSelection - Class in org.apache.drill.exec.store.dfs
-
- TestFileSelection() - Constructor for class org.apache.drill.exec.store.dfs.TestFileSelection
-
- TestFilesTable - Class in org.apache.drill.exec.store.ischema
-
- TestFilesTable() - Constructor for class org.apache.drill.exec.store.ischema.TestFilesTable
-
- testFileWithNulls() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- TestFillEmpties - Class in org.apache.drill.test.rowSet.test
-
Test the "fill empties" logic for all types for all modes.
- TestFillEmpties() - Constructor for class org.apache.drill.test.rowSet.test.TestFillEmpties
-
- testFillEmpties() - Method in class org.apache.drill.test.rowSet.test.TestFixedWidthWriter
-
Required, fixed-width vectors are back-filling with 0 to fill in missing
values.
- testFillEmpties() - Method in class org.apache.drill.test.rowSet.test.TestOffsetVectorWriter
-
Offset vectors have specific behavior when back-filling missing values:
the last offset must be carried forward into the missing slots.
- testFillEmpties() - Method in class org.apache.drill.test.rowSet.test.TestVariableWidthWriter
-
Filling empties in a variable-width row means carrying forward
offsets (as tested elsewhere), leaving zero-length values.
- TestFillEmpties - Class in org.apache.drill.vector
-
- TestFillEmpties() - Constructor for class org.apache.drill.vector.TestFillEmpties
-
- testFillEmptiesNullable() - Method in class org.apache.drill.test.rowSet.test.TestFillEmpties
-
Test "fill empties" for nullable types which are the most
"natural" type for omitted values.
- testFillEmptiesRepeated() - Method in class org.apache.drill.test.rowSet.test.TestFillEmpties
-
Test "fill empties" for repeated types.
- testFillEmptiesRequired() - Method in class org.apache.drill.test.rowSet.test.TestFillEmpties
-
Test "fill empties" for required types.
- testFillingUpOutputBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test to show LATERAL tries to pack the output batch until it's full or all the data is consumed from left and
right side.
- testFillingUpOutputBatch_With2ExcludedColumns() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
- testFillingUpOutputBatch_WithExcludedColumns() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
- testFILTER() - Method in class org.apache.drill.exec.compile.TestLargeFileCompilation
-
- testFilter() - Method in class org.apache.drill.exec.physical.impl.filter.TestSimpleFilter
-
- testFilter() - Method in class org.apache.drill.exec.physical.impl.trace.TestTraceMultiRecordBatch
-
- testFilter() - Method in class org.apache.drill.exec.physical.impl.trace.TestTraceOutputDump
-
- testFilter() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- TestFilterBatchEmitOutcome - Class in org.apache.drill.exec.physical.impl.filter
-
- TestFilterBatchEmitOutcome() - Constructor for class org.apache.drill.exec.physical.impl.filter.TestFilterBatchEmitOutcome
-
- testFilterEmpty() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testFilterEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.filter.TestFilterBatchEmitOutcome
-
Test to show if an empty batch is accompanied with EMIT outcome then Filter operator is not ignoring it and
asking for next batch with data.
- testFilterFlattenedRecords() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFilterFlattenedRecords2() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFilterInSubqueryAndOutside() - Method in class org.apache.drill.TestExampleQueries
-
- testFilterNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.filter.TestFilterBatchEmitOutcome
-
Test to show if a non-empty batch is accompanied with EMIT outcome then Filter operator produces output for
that batch with data matching filter condition and return the output using EMIT outcome.
- testFilterNonEmptyBatchEmitOutcome_WithNonMatchingCondition() - Method in class org.apache.drill.exec.physical.impl.filter.TestFilterBatchEmitOutcome
-
Test to show if a non-empty batch is accompanied with EMIT outcome then Filter operator produces empty output
batch since filter condition is not satisfied by any data in incoming batch.
- testFilterNonEmptyFirst_EmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.filter.TestFilterBatchEmitOutcome
-
Test to show that non-empty first batch produces output for that batch with OK_NEW_SCHEMA and later empty batch
with EMIT outcome is also passed through rather than getting ignored.
- testFilterNonEmptyFirst_EmptyOK_EmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.filter.TestFilterBatchEmitOutcome
-
Test to show if an empty batch is accompanied with OK outcome then that batch is ignored by Filter operator and
it doesn't return anything instead call's next() to get another batch.
- testFilterNonEmptyFirst_NonEmptyOK_EmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.filter.TestFilterBatchEmitOutcome
-
Test to show empty batch with OK outcome is ignore and later non-empty batch with OK outcome produces an output
batch.
- testFilterOnArrayTypes() - Method in class org.apache.drill.TestExampleQueries
-
- testFilterPruning() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testFilterPruningWithNulls() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testFilterPushCorrelate() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testFilterPushdown_And() - Method in class org.apache.drill.exec.store.ischema.TestInfoSchemaFilterPushDown
-
- testFilterPushdown_Equal() - Method in class org.apache.drill.exec.store.ischema.TestInfoSchemaFilterPushDown
-
- testFilterPushDown_Full() - Method in class org.apache.drill.exec.store.ischema.TestFilesTable
-
- testFilterPushdown_Like() - Method in class org.apache.drill.exec.store.ischema.TestInfoSchemaFilterPushDown
-
- testFilterPushdown_LikeWithEscape() - Method in class org.apache.drill.exec.store.ischema.TestInfoSchemaFilterPushDown
-
- testFilterPushDown_None() - Method in class org.apache.drill.exec.store.ischema.TestFilesTable
-
- testFilterPushdown_NonEqual() - Method in class org.apache.drill.exec.store.ischema.TestInfoSchemaFilterPushDown
-
- testFilterPushdown_Or() - Method in class org.apache.drill.exec.store.ischema.TestInfoSchemaFilterPushDown
-
- testFilterPushDown_Partial() - Method in class org.apache.drill.exec.store.ischema.TestFilesTable
-
- testFilterPushDownMultipleConditions() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- testFilterPushDownOverUnionAll() - Method in class org.apache.drill.TestUnionAll
-
- testFilterPushDownOverUnionAllCSV() - Method in class org.apache.drill.TestUnionAll
-
- testFilterPushDownOverUnionDistinct() - Method in class org.apache.drill.TestUnionDistinct
-
- testFilterPushDownOverUnionDistinctCSV() - Method in class org.apache.drill.TestUnionDistinct
-
- testFilterPushDownSingleCondition() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- testFilterPushDownWithProject_Equal() - Method in class org.apache.drill.exec.store.ischema.TestInfoSchemaFilterPushDown
-
- testFilterPushDownWithProject_Like() - Method in class org.apache.drill.exec.store.ischema.TestInfoSchemaFilterPushDown
-
- testFilterPushDownWithProject_NotEqual() - Method in class org.apache.drill.exec.store.ischema.TestInfoSchemaFilterPushDown
-
- testFilterPushDownWithSeveralNestedStarSubQueries() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- testFilterPushDownWithSeveralNestedStarSubQueriesWithAdditionalColumns() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- testFilterSelectivityOptions() - Method in class org.apache.drill.TestSelectivity
-
- testFiltersOnVarBinary() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testFiltersOnVarchar() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
Previously a bug in the Avro table metadata would cause wrong results
for some queries on varchar types, as a length was not provided during metadata
population.
- testFilterWithItemFlatten() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testFirst_Last_Value() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testFirstBatchEOF() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
Simulate reaching EOF on the first batch.
- testFirstLetter() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataVersion
-
- testFirstPageAllNulls() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testFirstPageOneNull() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testFirstPattern() - Method in class org.apache.drill.exec.store.httpd.HttpdParserTest
-
- testFirstValue() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testFirstValueAllTypes() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testFirstValueRangeCurrentAndCurrent() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testFix2967() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testFix3604() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testFix3605() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testFix3606() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testFix4376() - Method in class org.apache.drill.exec.store.parquet.TestParquetGroupScan
-
- testFix4449() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testFixedBinary() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testFixedInts1() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFixedInts10() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFixedInts11() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFixedInts12() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFixedInts13() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFixedInts2() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFixedInts3() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFixedInts4() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFixedInts4SQL_from() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFixedInts4SQL_to() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFixedInts5() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFixedInts6() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFixedInts7() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFixedInts8() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFixedInts9() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- TestFixedlenDecimal - Class in org.apache.drill.exec.store.parquet
-
- TestFixedlenDecimal() - Constructor for class org.apache.drill.exec.store.parquet.TestFixedlenDecimal
-
- testFixedLengthToVarlen() - Method in class org.apache.drill.exec.store.parquet.TestParquetBulkReader
-
Load variable length data which was originally fixed length and then became variable length
- testFixedLengthWithLargePrecisionAndNulls() - Method in class org.apache.drill.exec.store.parquet.TestParquetBulkReader
-
Load variable columns with fixed length data with large precision and null values
- testFixedType() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- testFixedVectorReallocation() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- testFixedWidth() - Method in class org.apache.drill.exec.store.parquet.ParquetInternalsTest
-
- testFixedWidth() - Method in class org.apache.drill.vector.TestToNullable
-
- TestFixedWidthWriter - Class in org.apache.drill.test.rowSet.test
-
Test the int writer as a typical example of a fixed-width
writer.
- TestFixedWidthWriter() - Constructor for class org.apache.drill.test.rowSet.test.TestFixedWidthWriter
-
- TestFixedWidthWriter.TestIndex - Class in org.apache.drill.test.rowSet.test
-
- testFlagFormatting() - Method in class org.apache.drill.exec.store.pcap.TestPcapRecordReader
-
- TestFlatten - Class in org.apache.drill.exec.physical.impl.flatten
-
- TestFlatten() - Constructor for class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFlatten() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- testFlatten2_levelRepeatedMap() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFlatten_Drill2162_complex() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFlatten_Drill2162_simple() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFlattenAfterJoin1() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFlattenAfterJoin2() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFlattenAfterJoin3() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFlattenAfterSort() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFlattenComplexArray() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testFlattenComplexRepeatedMap() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFlattenEmpty() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testFlattenEmptyArrayWithAllTextMode() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testFlattenEmptyArrayWithUnionType() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testFlattenEmptyComplexArrayMustYieldNoResults() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testFlattenEmptyList() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testFlattenFailure() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFlattenFixedWidth() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testFlattenFixedWidthList() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testFlattenKVGenFlatten() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFlattenLargeRecords() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testFlattenListOfMaps() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testFlattenLowerLimit() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testFlattenMap() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testFlattenNestedMap() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testFlattenOnEmptyArrayAndNestedMap() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- TestFlattenPlanning - Class in org.apache.drill.exec.physical.impl.flatten
-
- TestFlattenPlanning() - Constructor for class org.apache.drill.exec.physical.impl.flatten.TestFlattenPlanning
-
- testFlattenPlanningAvoidUnnecessaryProject() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlattenPlanning
-
- testFlattenPrimitiveArray() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testFlattenReferenceImpl() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFlattenRepeatedMap() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFlattenUpperLimit() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testFlattenVariableWidth() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testFlattenVariableWidthList() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testFlattenWithinAggFunction() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testFlattenWithinDistinct() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testFlattenWithinGroupBy() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testFlattenWithinOrderBy() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testFlattenWithScalarFunc() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testFlatWithNulls() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestRowBatchMerger
-
- testFloat4() - Method in class org.apache.drill.exec.physical.impl.TestComparisonFunctions
-
- testFloat8() - Method in class org.apache.drill.exec.physical.impl.TestComparisonFunctions
-
- testFloatArray() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testFloatRW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testFloats1() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFloats2() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFloats2be() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFloats3() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFloats4() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFloats5() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFloats5be() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFloats6() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFloats7() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFloats8() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testFloorDecimalFunction() - Method in class org.apache.drill.TestFunctionsQuery
-
- testFloorFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testFOJWithRequiredTypes() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinAdvanced
-
- testForBackwardCompatability() - Method in class org.apache.drill.exec.TestSSLConfig
-
- testForBetweenOperator() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- testForCommaSeparatedJoins() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- testForFilterInHaving() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- testForFilterInJoinOperator() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- testForGreaterThanAndLessThanOperators() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- testForInAndNotOperators() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- testForInAndNotOperatorsInJoinCondition() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- testForKeystoreConfig() - Method in class org.apache.drill.exec.TestSSLConfig
-
- testForLeftAndRightJoins() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- TestFormatPluginOptionExtractor - Class in org.apache.drill.exec.store.dfs
-
- TestFormatPluginOptionExtractor() - Constructor for class org.apache.drill.exec.store.dfs.TestFormatPluginOptionExtractor
-
- testFormatValueVectorElementAllDateTimeFormats() - Method in class org.apache.drill.exec.util.TestValueVectorElementFormatter
-
- testFormatValueVectorElementDateEmptyPattern() - Method in class org.apache.drill.exec.util.TestValueVectorElementFormatter
-
- testFormatValueVectorElementDateUnsupportedPattern() - Method in class org.apache.drill.exec.util.TestValueVectorElementFormatter
-
- testFormatValueVectorElementDateValidPattern() - Method in class org.apache.drill.exec.util.TestValueVectorElementFormatter
-
- testFormatValueVectorElementTimeEmptyPattern() - Method in class org.apache.drill.exec.util.TestValueVectorElementFormatter
-
- testFormatValueVectorElementTimestampEmptyPattern() - Method in class org.apache.drill.exec.util.TestValueVectorElementFormatter
-
- testFormatValueVectorElementTimestampValidPattern() - Method in class org.apache.drill.exec.util.TestValueVectorElementFormatter
-
- testFormatValueVectorElementTimeUnsupportedPattern() - Method in class org.apache.drill.exec.util.TestValueVectorElementFormatter
-
- testFormatValueVectorElementTimeValidPattern() - Method in class org.apache.drill.exec.util.TestValueVectorElementFormatter
-
- testFORMEnabledWithPlainDisabled() - Method in class org.apache.drill.exec.server.rest.spnego.TestSpnegoAuthentication
-
Validate failure in creating FORM security handler when PAM authenticator is absent.
- testForOrOperator() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- testForSeveralInnerJoins() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- testForSubQuery() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- testForSubQueryAndDynamicStar() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- testForTransitiveFilterPushPastAgg() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- testForTrustStore() - Method in class org.apache.drill.exec.TestSSLConfig
-
- testForTwoExists() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- testForwardCompatibility() - Method in class org.apache.drill.exec.server.options.PersistedOptionValueTest
-
DRILL-5809 Test forward compatibility with Drill 1.11 and earlier.
- testForWithStatement() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- testForWithStatementAndDynamicStar() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- TestFragmentChecker - Class in org.apache.drill.exec.pop
-
- TestFragmentChecker() - Constructor for class org.apache.drill.exec.pop.TestFragmentChecker
-
- TestFragmenter - Class in org.apache.drill.exec.pop
-
- TestFragmenter() - Constructor for class org.apache.drill.exec.pop.TestFragmenter
-
- TestFragmentExecutorCancel - Class in org.apache.drill.exec.work.fragment
-
Run several tpch queries and inject an OutOfMemoryException in ScanBatch that will cause an OUT_OF_MEMORY outcome to
be propagated downstream.
- TestFragmentExecutorCancel() - Constructor for class org.apache.drill.exec.work.fragment.TestFragmentExecutorCancel
-
- TestFrameworkTest - Class in org.apache.drill
-
- TestFrameworkTest() - Constructor for class org.apache.drill.TestFrameworkTest
-
- testFromDate() - Method in class org.apache.drill.exec.physical.impl.TestExtractFunctions
-
- testFromInfoSchema() - Method in class org.apache.drill.TestProjectPushDown
-
- testFromInterval() - Method in class org.apache.drill.exec.physical.impl.TestExtractFunctions
-
- testFromIntervalDay() - Method in class org.apache.drill.exec.physical.impl.TestExtractFunctions
-
- testFromIntervalYear() - Method in class org.apache.drill.exec.physical.impl.TestExtractFunctions
-
- testFromTime() - Method in class org.apache.drill.exec.physical.impl.TestExtractFunctions
-
- testFromTimeStamp() - Method in class org.apache.drill.exec.physical.impl.TestExtractFunctions
-
- testFull() - Method in class org.apache.drill.exec.store.log.TestLogReader
-
- testFullExecution() - Method in class org.apache.drill.exec.store.text.TextRecordReaderTest
-
- testFullHashJoinEmptyBoth() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testFullJoinIsNotSupported() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testFullList() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaLevelProjection
-
Test SELECT list with columns defined in a order and with
name case different than the early-schema table.
- testFullMergeJoinEmptyBoth() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testFunctionCaseInsensitiveNames() - Method in class org.apache.drill.TestFunctionsQuery
-
- TestFunctionsQuery - Class in org.apache.drill
-
- TestFunctionsQuery() - Constructor for class org.apache.drill.TestFunctionsQuery
-
- testFunctionsSize() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- TestFunctionsWithTypeExpoQueries - Class in org.apache.drill
-
- TestFunctionsWithTypeExpoQueries() - Constructor for class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testFunctionTemplates() - Method in class org.apache.drill.common.scanner.TestClassPathScanner
-
- testFutureUnsupportedMetadataVersion() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testGbAndObDifferentExp() - Method in class org.apache.drill.TestExampleQueries
-
- testGBExprWithDrillFunc() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testGetAllFunctionsWithHolders() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- testGetAllFunctionsWithHoldersWithVersion() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- testGetAllFunctionsWithSignatures() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- testGetAllJarNames() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- testGetAllJarsWithFunctionHolders() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- testGetFunctionNamesByJar() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- testGetHoldersByFunctionName() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- testGetHoldersByFunctionNameWithVersion() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- testGetImports() - Method in class org.apache.drill.exec.expr.fn.FunctionInitializerTest
-
- testGetMaxBytesSizeForPrecision() - Method in class org.apache.drill.exec.physical.impl.TestDecimal
-
- testGetMethod() - Method in class org.apache.drill.exec.expr.fn.FunctionInitializerTest
-
- testGetObject() - Method in class org.apache.drill.exec.vector.accessor.GenericAccessorTest
-
- testGetObject_indexOutOfBounds() - Method in class org.apache.drill.exec.vector.accessor.GenericAccessorTest
-
- testGetType() - Method in class org.apache.drill.exec.vector.accessor.GenericAccessorTest
-
- testGetWithEventualConsistencyHitsCache() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- testGetWithVersion() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- testGifImage() - Method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- TestGlob - Class in org.apache.drill.exec.store.dfs
-
- TestGlob() - Constructor for class org.apache.drill.exec.store.dfs.TestGlob
-
- testGlobSet() - Method in class org.apache.drill.exec.store.dfs.TestGlob
-
- testGlobSingleCharacter() - Method in class org.apache.drill.exec.store.dfs.TestGlob
-
- testGlobSingleCharacterRange() - Method in class org.apache.drill.exec.store.dfs.TestGlob
-
- testGlobWildcard() - Method in class org.apache.drill.exec.store.dfs.TestGlob
-
- TestGracefulShutdown - Class in org.apache.drill.test
-
- TestGracefulShutdown() - Constructor for class org.apache.drill.test.TestGracefulShutdown
-
- testGROUP_BY() - Method in class org.apache.drill.exec.compile.TestLargeFileCompilation
-
- testGroupBy() - Method in class org.apache.drill.exec.store.pcapng.TestPcapngRecordReader
-
- testGroupBy() - Method in class org.apache.drill.TestExampleQueries
-
- testGroupBy() - Method in class org.apache.drill.TestProjectPushDown
-
- testGroupBy_Mux_DeMux() - Method in class org.apache.drill.exec.physical.impl.TestLocalExchange
-
- testGroupBy_Mux_NoDeMux() - Method in class org.apache.drill.exec.physical.impl.TestLocalExchange
-
- testGroupBy_NoMux_DeMux() - Method in class org.apache.drill.exec.physical.impl.TestLocalExchange
-
- testGroupBy_NoMux_NoDeMux() - Method in class org.apache.drill.exec.physical.impl.TestLocalExchange
-
- testGroupByCaseInSubquery() - Method in class org.apache.drill.TestExampleQueries
-
- testGroupByMultiFields() - Method in class org.apache.drill.exec.physical.impl.TestLocalExchange
-
- testGroupByStarSchemaless() - Method in class org.apache.drill.TestExampleQueries
-
- testGroupBySystemFuncFileSystemTable() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testGroupBySystemFuncSchemaTable() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testGroupByUnionDistinct() - Method in class org.apache.drill.TestUnionDistinct
-
- testGroupByWithNamedAlias() - Method in class org.apache.drill.exec.sql.TestConformance
-
- testGroupByWithoutAggregate() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testGroupByWithPositionalAlias() - Method in class org.apache.drill.exec.sql.TestConformance
-
- testGroupScanRowCount1() - Method in class org.apache.drill.TestExampleQueries
-
- testGroupScanRowCount2() - Method in class org.apache.drill.TestExampleQueries
-
- testGroupScanRowCountExp1() - Method in class org.apache.drill.TestExampleQueries
-
- testGroupScanRowCountExp2() - Method in class org.apache.drill.TestExampleQueries
-
- testGroupTypeColumn() - Method in class org.apache.drill.exec.store.parquet.TestComplexColumnInSchema
-
- testHadooopVInt() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testHandlingEMITFromLeft() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
When multiple left batch is received with same schema but with OK_NEW_SCHEMA, then LATERAL detects that
correctly and suppresses schema change operation by producing output in same batch created with initial schema.
- testHandlingEmptyEMITAfterOK() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test for the case when LATERAL received a left batch with OK outcome and then populate the Join output in the
outgoing batch.
- testHandlingNoneAfterOK() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test for the case where LATERAL received a left batch with OK outcome and then populate the Join output in the
outgoing batch.
- testHandlingNonEmpty_EMITAfterOK_WithMultipleOutput() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Temporary test to validate LATERAL handling output batch getting filled without consuming full output from left
and right batch join.
- testHandlingNonEmptyEMITAfterOK() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test for the case when LATERAL received a left batch with OK outcome and then populate the Join output in the
outgoing batch.
- testHandlingOOMFromLeft() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
- testHandlingOOMFromRight() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
- testHandlingSchemaChangeForNonUnnestField() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
When multiple left batches are received with different schema, then LATERAL produces output for each schema type
separately (even though output batch is not filled completely) and handles the schema change in left batch.
- testHandlingSchemaChangeForUnnestField() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
When multiple left and right batches are received with different schema, then LATERAL produces output for each
schema type separately (even though output batch is not filled completely) and handles the schema change correctly.
- testHandlingUnexpectedSchemaChangeForUnnestField() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Verify if there is no schema change on left side and LATERAL still sees an unexpected schema change on right side
then it handles it correctly.
- TestHardAffinityFragmentParallelizer - Class in org.apache.drill.exec.planner.fragment
-
- TestHardAffinityFragmentParallelizer() - Constructor for class org.apache.drill.exec.planner.fragment.TestHardAffinityFragmentParallelizer
-
- testHasDataProbeEmpty() - Method in class org.apache.drill.exec.physical.impl.join.TestBuildSidePartitioningImpl
-
- testHash32() - Method in class org.apache.drill.TestFunctionsQuery
-
- testHash64() - Method in class org.apache.drill.TestFunctionsQuery
-
- testHashAggAvg() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- TestHashAggBatch - Class in org.apache.drill.exec.physical.impl.agg
-
- TestHashAggBatch() - Constructor for class org.apache.drill.exec.physical.impl.agg.TestHashAggBatch
-
- TestHashAggEmitOutcome - Class in org.apache.drill.exec.physical.impl.agg
-
- TestHashAggEmitOutcome() - Constructor for class org.apache.drill.exec.physical.impl.agg.TestHashAggEmitOutcome
-
- testHashAggEmpty() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testHashAggMax() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testHashAggNullableColumns() - Method in class org.apache.drill.TestAggNullable
-
- TestHashAggr - Class in org.apache.drill.exec.physical.impl.agg
-
- TestHashAggr() - Constructor for class org.apache.drill.exec.physical.impl.agg.TestHashAggr
-
- testHashAggr_NonEmptyFirst_EmptyOKEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggEmitOutcome
-
Verifies HashAggr correctness for the case where it receives non-empty batch in build schema phase followed by
empty batchs with OK and EMIT outcomes.
- testHashAggr_WithEmptyNonEmptyBatchesAndOKOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggEmitOutcome
-
**************************************************************************************
Test validating a regular HashAggr behavior with no EMIT outcome input
**************************************************************************************
- testHashAggrEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggEmitOutcome
-
Verifies that if HashAggBatch receives empty batches with OK_NEW_SCHEMA and EMIT outcome then it correctly produces
empty batches as output.
- testHashAggrEmptyBatchFollowedByNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggEmitOutcome
-
- testHashAggrFailWithFallbackDisabed() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggrSpill
-
Test with the "fallback" option disabled: When not enough memory available to allow spilling, then fail (Resource error) !!
- testHashAggrMultipleEMITOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggEmitOutcome
-
- testHashAggrMultipleEmptyBatchFollowedByNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggEmitOutcome
-
- testHashAggrMultipleInputToMultipleOutputBatch() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggEmitOutcome
-
- testHashAggrMultipleInputToSingleOutputBatch() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggEmitOutcome
-
- testHashAggrMultipleOutputBatch() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggEmitOutcome
-
Verifies that if HashAggr receives multiple non-empty record batches with EMIT outcome in between then it produces
output for those input batch correctly.
- testHashAggrNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggEmitOutcome
-
Verifies that if HashAgg receives a RecordBatch with EMIT outcome post build schema phase then it produces
output for those input batch correctly.
- testHashAggrSecondaryTertiarySpill() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggrSpill
-
Test Secondary and Tertiary spill cycles - Happens when some of the spilled partitions cause more spilling as they are read back
- TestHashAggrSpill - Class in org.apache.drill.exec.physical.impl.agg
-
Test spilling for the Hash Aggr operator (using the mock reader)
- TestHashAggrSpill() - Constructor for class org.apache.drill.exec.physical.impl.agg.TestHashAggrSpill
-
- testHashAggrSuccessWithFallbackEnabled() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggrSpill
-
Test with the "fallback" option ON: When not enough memory is available to allow spilling (internally need enough memory to
create multiple partitions), then behave like the pre-1.11 Hash Aggregate: Allocate unlimited memory, no spill.
- testHashAggrWithEmptyDataSet() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggEmitOutcome
-
Test receiving just a single input batch, empty
- testHashAggSum() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testHashAgrResetsAfterFirstEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggEmitOutcome
-
Verifies that if HashAggr receives multiple non-empty record batch with EMIT outcome in between then it produces
output for those input batch correctly.
- testHashFOJOnNullableColumns() - Method in class org.apache.drill.TestJoinNullable
-
FullOuterJoin on nullable cols, HashJoin
- testHashFunctionResolution() - Method in class org.apache.drill.exec.physical.impl.TestSimpleFunctions
-
- testHashFunctions() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testHashInnerJoinOnNullableColumns() - Method in class org.apache.drill.TestJoinNullable
-
InnerJoin on nullable cols, HashJoin
- testHashInnerJoinWithBothEmptyDirTables() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testHashInnerJoinWithEmptyTable() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinAdvanced
-
- testHashInnerJoinWithLeftEmptyDirTable() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testHashInnerJoinWithRightEmptyDirTable() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testHashJoin() - Method in class org.apache.drill.exec.compile.TestLargeFileCompilation
-
- TestHashJoin - Class in org.apache.drill.exec.physical.impl.join
-
- TestHashJoin() - Constructor for class org.apache.drill.exec.physical.impl.join.TestHashJoin
-
- TestHashJoinAdvanced - Class in org.apache.drill.exec.physical.impl.join
-
- TestHashJoinAdvanced() - Constructor for class org.apache.drill.exec.physical.impl.join.TestHashJoinAdvanced
-
- testHashJoinEmptyBoth() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testHashJoinExprInCondition() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoin
-
- TestHashJoinHelperSizeCalculatorImpl - Class in org.apache.drill.exec.physical.impl.join
-
- TestHashJoinHelperSizeCalculatorImpl() - Constructor for class org.apache.drill.exec.physical.impl.join.TestHashJoinHelperSizeCalculatorImpl
-
- TestHashJoinJPPD - Class in org.apache.drill.exec.physical.impl.join
-
- TestHashJoinJPPD() - Constructor for class org.apache.drill.exec.physical.impl.join.TestHashJoinJPPD
-
- TestHashJoinJPPDPlan - Class in org.apache.drill.exec.physical.impl.join
-
- TestHashJoinJPPDPlan() - Constructor for class org.apache.drill.exec.physical.impl.join.TestHashJoinJPPDPlan
-
- testHashJoinLeftEmpty() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testHashJoinLowerLimit() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- TestHashJoinMemoryCalculator - Class in org.apache.drill.exec.physical.impl.join
-
- TestHashJoinMemoryCalculator() - Constructor for class org.apache.drill.exec.physical.impl.join.TestHashJoinMemoryCalculator
-
- testHashJoinMultipleOutputBatches() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testHashJoinNoneOutcomeUninitLeftSide() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinOutcome
-
- testHashJoinNoneOutcomeUninitRightSide() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinOutcome
-
- TestHashJoinOutcome - Class in org.apache.drill.exec.physical.impl.join
-
Unit tests of the Hash Join getting various outcomes as input
with uninitialized vector containers
- TestHashJoinOutcome() - Constructor for class org.apache.drill.exec.physical.impl.join.TestHashJoinOutcome
-
- testHashJoinRightEmpty() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testHashJoinSingleOutputBatch() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- TestHashJoinSpill - Class in org.apache.drill.exec.physical.impl.join
-
- TestHashJoinSpill() - Constructor for class org.apache.drill.exec.physical.impl.join.TestHashJoinSpill
-
- testHashJoinStopOutcomeUninitLeftSide() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinOutcome
-
- testHashJoinStopOutcomeUninitRightSide() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinOutcome
-
- testHashJoinUpperLimit() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testHashJoinWhenProbeIsNONE() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinOutcome
-
Testing for DRILL-6755: No Hash Table is built when the first probe batch is NONE
- testHashJoinWithFuncJoinCondition() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinJPPDPlan
-
- testHashJoinWithNaN() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- testHashLeftJoinWithEmptyTable() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinAdvanced
-
- testHashLeftJoinWithRightEmptyDirTable() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testHashLOJOnNullableColumns() - Method in class org.apache.drill.TestJoinNullable
-
LeftOuterJoin on nullable cols, HashJoin
- testHashPartitionSV2() - Method in class org.apache.drill.TestExampleQueries
-
- testHashPartitionSV4() - Method in class org.apache.drill.TestExampleQueries
-
- testHashRightJoinWithEmptyTable() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinAdvanced
-
- testHashRightJoinWithRightEmptyDirTable() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testHashROJOnNullableColumns() - Method in class org.apache.drill.TestJoinNullable
-
RightOuterJoin on nullable cols, HashJoin
- TestHashTableSizeCalculatorConservativeImpl - Class in org.apache.drill.exec.physical.impl.join
-
- TestHashTableSizeCalculatorConservativeImpl() - Constructor for class org.apache.drill.exec.physical.impl.join.TestHashTableSizeCalculatorConservativeImpl
-
- TestHashTableSizeCalculatorLeanImpl - Class in org.apache.drill.exec.physical.impl.join
-
- TestHashTableSizeCalculatorLeanImpl() - Constructor for class org.apache.drill.exec.physical.impl.join.TestHashTableSizeCalculatorLeanImpl
-
- TestHashToRandomExchange - Class in org.apache.drill.exec.physical.impl
-
- TestHashToRandomExchange() - Constructor for class org.apache.drill.exec.physical.impl.TestHashToRandomExchange
-
- testHasNoProbeDataButProbeNonEmptyFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testHasNoProbeDataButProbeNonEmptyNotFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testHasPathFalseWithVersion() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- testHasPathThrowsDrillRuntimeException() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- testHasPathTrueWithVersion() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- testHasPathWithEventualConsistencyHitsCache() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- testHasProbeDataButProbeEmpty() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testHavingAggFunction() - Method in class org.apache.drill.TestExampleQueries
-
- testHavingWithNamedAlias() - Method in class org.apache.drill.exec.sql.TestConformance
-
- TestHeaderBuilder - Class in org.apache.drill.exec.store.easy.text.compliant
-
- TestHeaderBuilder() - Constructor for class org.apache.drill.exec.store.easy.text.compliant.TestHeaderBuilder
-
- testHiveParquetTimestampAsInt96_basic() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testHiveParquetTimestampAsInt96_compare() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testHttpd() - Method in class org.apache.drill.exec.store.FormatPluginSerDeTest
-
- TestHyperVectorReaders - Class in org.apache.drill.test.rowSet.test
-
Test the reader mechanism that reads rows indexed via an SV4.
- TestHyperVectorReaders() - Constructor for class org.apache.drill.test.rowSet.test.TestHyperVectorReaders
-
- testIcoImage() - Method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- testIdentifierMaxLength() - Method in class org.apache.drill.TestExampleQueries
-
- testIfDrillCanInferReturnTypeOfRepeatedContains() - Method in class org.apache.drill.exec.expr.fn.impl.TestSimpleRepeatedFunctions
-
- testIfDrillCanInferReturnTypeOfRepeatedContainsPreceedingTrue() - Method in class org.apache.drill.exec.expr.fn.impl.TestSimpleRepeatedFunctions
-
- testIfDrillCanQuerySingleRecordWithEmpties() - Method in class org.apache.drill.exec.vector.complex.fn.TestJsonReaderWithSparseFiles
-
- testIfDrillCanReadSparseNestedRecordsWithoutRaisingException() - Method in class org.apache.drill.exec.vector.complex.fn.TestJsonReaderWithSparseFiles
-
- testIfDrillCanReadSparseRecords() - Method in class org.apache.drill.exec.vector.complex.fn.TestJsonReaderWithSparseFiles
-
- testILike() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testILikeEscape() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- TestImageRecordReader - Class in org.apache.drill.exec.store.image
-
- TestImageRecordReader() - Constructor for class org.apache.drill.exec.store.image.TestImageRecordReader
-
- testImpalaParquetBinaryAsTimeStamp_DictChange() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testImpalaParquetBinaryAsVarBinary_DictChange() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testImpalaParquetInt96() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testImpalaParquetInt96Partitioned() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testImpalaParquetTimestampInt96AsTimeStamp() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testImpersonatingProcessUser() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- TestImpersonationDisabledWithMiniDFS - Class in org.apache.drill.exec.impersonation
-
Note to future devs, please do not put random tests here.
- TestImpersonationDisabledWithMiniDFS() - Constructor for class org.apache.drill.exec.impersonation.TestImpersonationDisabledWithMiniDFS
-
- TestImpersonationMetadata - Class in org.apache.drill.exec.impersonation
-
Tests impersonation on metadata related queries as SHOW FILES, SHOW TABLES, CREATE VIEW, CREATE TABLE and DROP TABLE
- TestImpersonationMetadata() - Constructor for class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- TestImpersonationQueries - Class in org.apache.drill.exec.impersonation
-
Test queries involving direct impersonation and multilevel impersonation including join queries where each side is
a nested view.
- TestImpersonationQueries() - Constructor for class org.apache.drill.exec.impersonation.TestImpersonationQueries
-
- testImplicitAndPartitionColumnsInSelectClause() - Method in class org.apache.drill.exec.store.TestImplicitFileColumns
-
- testImplicitCartesianJoin() - Method in class org.apache.drill.TestDisabledFunctionality
-
- TestImplicitCastFunctions - Class in org.apache.drill.exec.physical.impl
-
- TestImplicitCastFunctions() - Constructor for class org.apache.drill.exec.physical.impl.TestImplicitCastFunctions
-
- TestImplicitCasting - Class in org.apache.drill
-
- TestImplicitCasting() - Constructor for class org.apache.drill.TestImplicitCasting
-
- testImplicitCastStringToBoolean() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testImplicitCastVarcharToDouble() - Method in class org.apache.drill.TestFunctionsQuery
-
- testImplicitCastWithConstant() - Method in class org.apache.drill.exec.physical.impl.TestImplicitCastFunctions
-
- testImplicitCastWithMockColumn() - Method in class org.apache.drill.exec.physical.impl.TestImplicitCastFunctions
-
- testImplicitCastWithNullExpression() - Method in class org.apache.drill.exec.physical.impl.TestImplicitCastFunctions
-
- testImplicitColumnAlone() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testImplicitColumnAlone() - Method in class org.apache.drill.exec.store.TestImplicitFileColumns
-
- testImplicitColumnInWhereClause() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testImplicitColumnInWhereClause() - Method in class org.apache.drill.exec.store.TestImplicitFileColumns
-
- testImplicitColumns() - Method in class org.apache.drill.exec.store.TestImplicitFileColumns
-
- testImplicitColumnsForParquet() - Method in class org.apache.drill.exec.store.TestImplicitFileColumns
-
- testImplicitColumnsWithStar() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testImplicitColumnWithTableColumns() - Method in class org.apache.drill.exec.store.TestImplicitFileColumns
-
- testImplicitDownwardCast() - Method in class org.apache.drill.TestExampleQueries
-
- TestImplicitFileColumns - Class in org.apache.drill.exec.store
-
- TestImplicitFileColumns() - Constructor for class org.apache.drill.exec.store.TestImplicitFileColumns
-
- testImplicitFlat() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestRowBatchMerger
-
- TestInboundImpersonation - Class in org.apache.drill.exec.impersonation
-
- TestInboundImpersonation() - Constructor for class org.apache.drill.exec.impersonation.TestInboundImpersonation
-
- TestInboundImpersonationPrivileges - Class in org.apache.drill.exec.impersonation
-
- TestInboundImpersonationPrivileges() - Constructor for class org.apache.drill.exec.impersonation.TestInboundImpersonationPrivileges
-
- testInClauseToSemiJoin() - Method in class org.apache.drill.exec.physical.impl.join.TestSemiJoin
-
- testInClauseWithSemiJoinDisabled() - Method in class org.apache.drill.exec.physical.impl.join.TestSemiJoin
-
- testIncludeNan() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- testIncludePositiveInfinity() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- testIncompleteVectors() - Method in class org.apache.drill.test.rowSet.test.TestRepeatedListAccessors
-
- testIncorrectFunctionPlacement() - Method in class org.apache.drill.exec.planner.TestDirectoryExplorerUDFs
-
- testIncorrectNumericBoolean() - Method in class org.apache.drill.exec.sql.TestSimpleCastFunctions
-
- testIncorrectStringBoolean() - Method in class org.apache.drill.exec.sql.TestSimpleCastFunctions
-
- TestIndex() - Constructor for class org.apache.drill.test.rowSet.test.TestFixedWidthWriter.TestIndex
-
- TestIndirectReaders - Class in org.apache.drill.test.rowSet.test
-
Test reading with an indirection vector (sv2.) This form of
indirection vector reorders values within a single batch.
- TestIndirectReaders() - Constructor for class org.apache.drill.test.rowSet.test.TestIndirectReaders
-
- testInfoMessage() - Method in class org.apache.drill.exec.client.DrillSqlLineApplicationTest
-
- testInformReceiverFinished_success() - Method in class org.apache.drill.exec.rpc.control.TestLocalControlConnectionManager
-
Verify that FinishedReceiver is handled correctly using ControlTunnel with LocalControlConnectionManager
- TestInfoSchema - Class in org.apache.drill.exec.sql
-
Contains tests for
-- InformationSchema
-- Queries on InformationSchema such as SHOW TABLES, SHOW SCHEMAS or DESCRIBE table
-- USE schema
- TestInfoSchema() - Constructor for class org.apache.drill.exec.sql.TestInfoSchema
-
- TestInfoSchemaFilterPushDown - Class in org.apache.drill.exec.store.ischema
-
- TestInfoSchemaFilterPushDown() - Constructor for class org.apache.drill.exec.store.ischema.TestInfoSchemaFilterPushDown
-
- testInfoSchemaStringsNotOfLength1() - Method in class org.apache.drill.exec.store.ischema.Drill2283InfoSchemaVarchar1BugTest
-
- testInitcap() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testInitialSchema() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderProtocol
-
Provide a schema up front to the loader; schema is built before
the first row.
- testInjected() - Method in class org.apache.drill.exec.pop.TestInjectionValue
-
- TestInjectionValue - Class in org.apache.drill.exec.pop
-
- TestInjectionValue() - Constructor for class org.apache.drill.exec.pop.TestInjectionValue
-
- TestInList - Class in org.apache.drill
-
- TestInList() - Constructor for class org.apache.drill.TestInList
-
- testInListOnUnionAll() - Method in class org.apache.drill.TestUnionAll
-
- testInListPushDownOverUnionDistinct() - Method in class org.apache.drill.TestUnionDistinct
-
- testInnerJoin() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testInnerMetadataFilesAreAbsent() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testInt() - Method in class org.apache.drill.exec.physical.impl.TestComparisonFunctions
-
- testInt() - Method in class org.apache.drill.vector.TestFillEmpties
-
- testInt96TimeStampValueWidth() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testIntArray() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testInternalFunctionsTable() - Method in class org.apache.drill.exec.store.sys.TestSystemTable
-
- testInternalSystemOption() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testInterval() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
Test the INTERVAL data type as a sort key.
- testInterval() - Method in class org.apache.drill.exec.record.vector.TestDateTypes
-
- testIntervalArithmetic() - Method in class org.apache.drill.exec.fn.impl.TestDateFunctions
-
- testIntervalArray() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testIntervalDay() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
Test the INTERVALDAY data type as a sort key.
- testIntervalDayArray() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testIntervalDayPartitionPruning() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testIntervalDayRW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testIntervalDayUtils() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
Test the low-level interval-day utilities used by the column accessors.
- testIntervalRW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testIntervalUtils() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
Test the low-level interval utilities used by the column accessors.
- testIntervalYear() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
Test the INTERVALYEAR data type as a sort key.
- testIntervalYearArray() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testIntervalYearPartitionPruning() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testIntervalYearRW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testIntervalYearUtils() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
Test the low-level interval-year utilities used by the column accessors.
- testIntMinToDecimal() - Method in class org.apache.drill.TestFunctionsQuery
-
- testIntNullable() - Method in class org.apache.drill.exec.physical.impl.TestComparisonFunctions
-
- testIntPredicateAgainstAllNullColWithEval() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testIntPredicateWithEval() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testIntRW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testIntType() - Method in class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- testIntWithNullsPartitionPruning() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testInvalidConnectTriesValue() - Method in class org.apache.drill.exec.client.ConnectTriesPropertyTestClusterBits
-
- testInvalidCsvHeaders() - Method in class org.apache.drill.exec.store.easy.text.compliant.TestCsv
-
- testInvalidHadoopKeystore() - Method in class org.apache.drill.exec.TestSSLConfig
-
- testInvalidKeyAboveMaxKeyValueSupported() - Method in class org.apache.drill.exec.util.TestArrayWrappedIntIntMap
-
- testInvalidKeyAccess() - Method in class org.apache.drill.exec.util.TestArrayWrappedIntIntMap
-
- testInvalidKeyBelowMinValueSupported() - Method in class org.apache.drill.exec.util.TestArrayWrappedIntIntMap
-
- testInvalidKeyPassword() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSLServer
-
- testInvalidKeystorePassword() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSLServer
-
- testInvalidKeystorePath() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSLServer
-
- testInvalidSpnegoConfig() - Method in class org.apache.drill.exec.server.rest.spnego.TestSpnegoConfig
-
- testInvalidUmask() - Method in class org.apache.drill.exec.store.StorageStrategyTest
-
- testInvalidValuePut() - Method in class org.apache.drill.exec.util.TestArrayWrappedIntIntMap
-
- testIOStats() - Method in class org.apache.drill.exec.store.dfs.TestDrillFileSystem
-
- testIsDate() - Method in class org.apache.drill.exec.fn.impl.TestNewDateFunctions
-
- testIsDirectMemoryOOM() - Method in class org.apache.drill.exec.server.TestFailureUtils
-
- testIsHeapOOM() - Method in class org.apache.drill.exec.server.TestFailureUtils
-
- testIsNotNulFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testIsNulFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testIsNull() - Method in class org.apache.drill.exec.vector.accessor.GenericAccessorTest
-
- testIsNull() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testIsNumeric() - Method in class org.apache.drill.exec.fn.impl.TestNewMathFunctions
-
- testIsPromotable() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultVectorCache
-
- testJaninoClassCompiler() - Method in class org.apache.drill.exec.compile.TestClassTransformation
-
- testJaninoHugeStringConstantCompilation() - Method in class org.apache.drill.exec.compile.TestLargeFileCompilation
-
- testJarNameByFunctionSignature() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- testJarWithoutFunctions() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testJarWithoutMarkerFile() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testJDKClassCompiler() - Method in class org.apache.drill.exec.compile.TestClassTransformation
-
- testJDKHugeStringConstantCompilation() - Method in class org.apache.drill.exec.compile.TestLargeFileCompilation
-
- testJodaDate() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testJodaDateTime() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testJodaDateTimeNested() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testJodaTime() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testJoin() - Method in class org.apache.drill.TestExampleQueries
-
- testJoin() - Method in class org.apache.drill.TestProjectPushDown
-
- testJoin_Mux_DeMux() - Method in class org.apache.drill.exec.physical.impl.TestLocalExchange
-
- testJoin_Mux_NoDeMux() - Method in class org.apache.drill.exec.physical.impl.TestLocalExchange
-
- testJoin_NoMux_DeMux() - Method in class org.apache.drill.exec.physical.impl.TestLocalExchange
-
- testJoin_NoMux_NoDeMux() - Method in class org.apache.drill.exec.physical.impl.TestLocalExchange
-
- testJoinBatchSize() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoin
-
- testJoinCondWithDifferentTypes() - Method in class org.apache.drill.TestExampleQueries
-
- TestJoinEmptyDirTable - Class in org.apache.drill.exec.physical.impl.join
-
- TestJoinEmptyDirTable() - Constructor for class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testJoinExpOn() - Method in class org.apache.drill.TestExampleQueries
-
- testJoinExpWhere() - Method in class org.apache.drill.TestExampleQueries
-
- testJoinHelper(boolean, boolean) - Static method in class org.apache.drill.exec.physical.impl.TestLocalExchange
-
- testJoinLimit0Schema() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinAdvanced
-
- testJoinMerge() - Method in class org.apache.drill.TestExampleQueries
-
- TestJoinNullable - Class in org.apache.drill
-
- TestJoinNullable() - Constructor for class org.apache.drill.TestJoinNullable
-
- testJoinOrdering() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinAdvanced
-
- testJoinPreservesAbsoluteOrRelativePaths() - Method in class org.apache.drill.exec.coord.zk.TestPathUtils
-
- testJoinTemporaryWithPersistentTable() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testJoinWithDifferentTypesInCondition() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinAdvanced
-
- testJoinWithDifferentTypesInCondition() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testJoinWithEmptyFile(File, String, String[], long) - Method in class org.apache.drill.exec.physical.impl.join.JoinTestBase
-
This method runs a join query with one of the table generated as an
empty json file.
- testJoinWithLimit() - Method in class org.apache.drill.TestAltSortQueries
-
- testJoinWithMapAndDotField() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinAdvanced
-
- testJpegImage() - Method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- testJson() - Method in class org.apache.drill.exec.store.FormatPluginSerDeTest
-
- testJsonDirectoryWithEmptyFile() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testJsonInputMixedWithEmptyFiles1() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
Test ScanBatch with mixed json files.
- testJsonInputMixedWithEmptyFiles2() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
Test ScanBatch with mixed json files.
- testJsonInputMixedWithEmptyFiles3() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
Test ScanBatch with mixed json files.
- testJsonInputMixedWithEmptyFiles4() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
Test ScanBatch with mixed json files.
- TestJsonNanInf - Class in org.apache.drill.exec.vector.complex.writer
-
- TestJsonNanInf() - Constructor for class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- TestJsonReader - Class in org.apache.drill.exec.vector.complex.writer
-
- TestJsonReader() - Constructor for class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- TestJsonReaderWithSparseFiles - Class in org.apache.drill.exec.vector.complex.fn
-
- TestJsonReaderWithSparseFiles() - Constructor for class org.apache.drill.exec.vector.complex.fn.TestJsonReaderWithSparseFiles
-
- TestJsonRecordReader - Class in org.apache.drill.exec.store.json
-
- TestJsonRecordReader() - Constructor for class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testJsonWithNulls1() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testJsonWithNulls2() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testJUnitHamcrestMatcherFailureWorks() - Method in class org.apache.drill.exec.test.Drill2130JavaExecHamcrestConfigurationTest
-
- testKeyValueGen() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testKVGenFlatten1() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testKVGenFlatten2() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testKVGenWithComplexValues() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testKVGenWithNullableInput() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testKvgenWithUnionAll() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testLag() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testLagWithPby() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testLargeArray() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderOverflow
-
Create an array that contains more than 64K values.
- testLargeBatch() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl
-
Hit the sort with the largest possible batch size to ensure nothing is lost
at the edges.
- TestLargeFileCompilation - Class in org.apache.drill.exec.compile
-
- TestLargeFileCompilation() - Constructor for class org.apache.drill.exec.compile.TestLargeFileCompilation
-
- testLargeFooter() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- TestLargeInClause - Class in org.apache.drill.exec.physical.impl.filter
-
- TestLargeInClause() - Constructor for class org.apache.drill.exec.physical.impl.filter.TestLargeInClause
-
- testLargeInClauseToSemiJoin() - Method in class org.apache.drill.exec.physical.impl.join.TestSemiJoin
-
- testLargeInList1() - Method in class org.apache.drill.TestInList
-
- testLargeVarlen() - Method in class org.apache.drill.exec.store.parquet.TestParquetBulkReader
-
Load variable length data with values larger than chunk size (4k)
- testLastPageAllNulls() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testLastPageOneNull() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testLastValue() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testLastValueAllTypes() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testLastValueRowsUnboundedAndCurrentRow() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- TestLateLimit0Optimization - Class in org.apache.drill.exec.physical.impl.limit
-
- TestLateLimit0Optimization() - Constructor for class org.apache.drill.exec.physical.impl.limit.TestLateLimit0Optimization
-
- testLateral_HashAgg_with_nulls() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testLateral_SchemaChange_Left_EmptyRightBatchForFirst() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test to verify that for first left incoming if there is no right side incoming batch and then second left
incoming comes with schema change, then the schema change with empty output batch for first incoming is handled
properly.
- testLateral_StreamingAgg_with_nulls() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testLateral_WithFilterAndLimitInSubQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testLateral_WithFilterInSubQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testLateral_WithLimitInSubQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
Test with single batch but using different keyword for Lateral and it has limit/filter operator
within the subquery of Lateral and Unnest
- testLateral_WithSortAndLimitInSubQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
Test which disables the TopN operator from planner settintestLateral_WithTopNInSubQuerygs before running query using SORT and LIMIT in
subquery.
- testLateral_WithSortInSubQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testLateral_WithTopNInSubQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testLateralAndUnnestExplainPlan() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- TestLateralJoinCorrectness - Class in org.apache.drill.exec.physical.impl.join
-
- TestLateralJoinCorrectness() - Constructor for class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
- TestLateralJoinCorrectnessBatchProcessing - Class in org.apache.drill.exec.physical.impl.join
-
- TestLateralJoinCorrectnessBatchProcessing() - Constructor for class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- TestLateralPlans - Class in org.apache.drill.exec.physical.impl.lateraljoin
-
- TestLateralPlans() - Constructor for class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testLateralSql() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testLateralSqlPlainCol() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testLateralSqlStar() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testLateralSqlStar2() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testLateralSqlStar3() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testLateralSqlStar4() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testLateralSqlWithAS() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testLateralWithAgg() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testLateralWithComplexProject() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testLazyInit() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testLazyInitConcurrent() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testLazyInitNoReload() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testLazyInitWhenDynamicUdfSupportIsDisabled() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testLead() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testLeadLag() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testLeadMissingOver() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testLeadParams() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testLeadWithPby() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testLeft() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testLeftAndRight_OutputFull_InRightBatchMiddle() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- testLeftAndRight_OutputFull_WithPendingLeftRow() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- testLeftAndRight_OutputFull_WithPendingLeftRow_LeftJoin() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- testLeftAndRightAllMatchingRows_MultipleBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- testLeftAndRightAllMatchingRows_SecondBatch_Empty() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- testLeftAndRightAllMatchingRows_SingleBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- testLeftAndRightWithInitialMissingRows_LeftJoin_MultipleBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- testLeftAndRightWithInitialMissingRows_MultipleBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- testLeftAndRightWithLastMissingRows_LeftJoin_MultipleBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- testLeftAndRightWithLastMissingRows_MultipleBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- testLeftAndRightWithMissingRows_LeftJoin_SingleBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- testLeftAndRightWithMissingRows_SingleBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- testLeftHashJoin() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinJPPDPlan
-
- testLeftHashJoinEmptyBoth() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testLeftHashJoinLeftEmpty() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testLeftHashJoinRightEmpty() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testLeftHashJoinWithMap() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinAdvanced
-
- testLeftLateral_WithFilterAndLimitInSubQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testLeftLateralJoin_WithAndWithoutMatching() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test to see if there are multiple rows in left batch and for some rows right side produces batch with records
and for other rows right side produces empty batches then based on left join type we are populating the output
batch correctly.
- testLeftLateralJoin_WithAndWithoutMatching_MultipleBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test to see if there are multiple rows in left batch and for some rows right side produces batch with records
and for other rows right side produces empty batches then based on left join type we are populating the output
batch correctly.
- testLeftLateralJoin_WithMatchingAndEmptyBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test to see if there are multiple rows in left batch and for some rows right side produces multiple batches such
that some are with records and some are empty then we are not duplicating those left side records based on left
join type.
- testLeftMergeJoinEmptyBoth() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testLeftNestedLoopJoin() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testLeftOuterHashJoin() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testLeftOuterHashJoinSpill() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinSpill
-
- testLeftOuterJoin() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testLeftSelfHashJoinWithMap() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinAdvanced
-
- testLenient() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestLenientAllocation
-
Use a test-time hack to force the allocator to be lenient,
regardless of whether we are in debug mode or not.
- TestLenientAllocation - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
Test of temporary allocator feature to allow a grace margin
for error in allocations from operators that make a good-faith
effort to stay within their budgets, but are sometimes undone
by unexpected power-of-two buffer sizes and vector doubling.
- TestLenientAllocation() - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.TestLenientAllocation
-
- testLenientLimit() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestLenientAllocation
-
- testLessThanFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testLessThanOrEqualToFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testLifecycle() - Method in class org.apache.drill.exec.physical.impl.common.HashTableAllocationTrackerTest
-
Test for when we know the final size of the hash table
- testLifecycle1() - Method in class org.apache.drill.exec.physical.impl.common.HashTableAllocationTrackerTest
-
Test for when we do not know the final size of the hash table.
- testLike() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testLikeConstant() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testLikeContains() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testLikeEndsWith() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testLikeEscape() - Method in class org.apache.drill.TestExampleQueries
-
- testLikeRandom() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testLikeStartsWith() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testLikeWithEscapeConstant() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testLikeWithEscapeContains() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testLikeWithEscapeEndsWith() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testLikeWithEscapeStartsWith() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testLimit() - Method in class org.apache.drill.exec.physical.impl.limit.TestSimpleLimit
-
- testLimit() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testLimit0_1() - Method in class org.apache.drill.TestExampleQueries
-
- testLimit0IsAbsentWhenDisabled() - Method in class org.apache.drill.exec.physical.impl.limit.TestLateLimit0Optimization
-
- testLimit0SubqueryWithFilter() - Method in class org.apache.drill.TestExampleQueries
-
- TestLimit0VsRegularQueriesMetadata - Class in org.apache.drill.exec.work.prepare
-
- TestLimit0VsRegularQueriesMetadata() - Constructor for class org.apache.drill.exec.work.prepare.TestLimit0VsRegularQueriesMetadata
-
- testLimitAcrossBatches() - Method in class org.apache.drill.exec.physical.impl.limit.TestSimpleLimit
-
- TestLimitAllOnParquet() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitWithExchanges
-
- TestLimitBatchEmitOutcome - Class in org.apache.drill.exec.physical.impl.limit
-
- TestLimitBatchEmitOutcome() - Constructor for class org.apache.drill.exec.physical.impl.limit.TestLimitBatchEmitOutcome
-
- testLimitBeyondRowCount() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testLimitEmpty() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testLimitEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitBatchEmitOutcome
-
Test to show empty batch with both OK_NEW_SCHEMA and EMIT outcome is not ignored by Limit and is pass through to
the downstream operator.
- testLimitImpactExchange() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitWithExchanges
-
- testLimitInSubqAndOrderByOuter() - Method in class org.apache.drill.TestExampleQueries
-
- testLimitIntegrationTest() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitOperator
-
- testLimitLessRecords() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitOperator
-
- testLimitMoreRecords() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitOperator
-
- testLimitMultipleRowGroups() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testLimitMultipleRowGroupsBeyondRowCount() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testLimitNoEnd() - Method in class org.apache.drill.exec.physical.impl.limit.TestSimpleLimit
-
- testLimitNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitBatchEmitOutcome
-
Test to validate limit considers all the data until it sees EMIT outcome and return output batch with data that
meets the limit criteria.
- testLimitNonEmptyFirst_EmptyOKEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitBatchEmitOutcome
-
Test to show that when the limit number of records is found with first incoming batch, then next empty incoming
batch with OK outcome is ignored, but the empty EMIT outcome batch is not ignored.
- testLimitNonEmptyFirst_NonEmptyOK_EmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitBatchEmitOutcome
-
Test shows that limit operates on multiple input batches until it finds limit number of records or it sees an
EMIT outcome to refresh it's state.
- testLimitOnOrderedMux() - Method in class org.apache.drill.exec.physical.impl.TestOrderedMuxExchange
-
Test case to verify the OrderedMuxExchange created for order by with limit.
- testLimitOnOrderedMuxWindow() - Method in class org.apache.drill.exec.physical.impl.TestOrderedMuxExchange
-
Test case to verify the OrderedMuxExchange created for order by with limit and window agg.
- TestLimitOperator - Class in org.apache.drill.exec.physical.impl.limit
-
- TestLimitOperator() - Constructor for class org.apache.drill.exec.physical.impl.limit.TestLimitOperator
-
- TestLimitPlanning - Class in org.apache.drill.exec.physical.impl.limit
-
- TestLimitPlanning() - Constructor for class org.apache.drill.exec.physical.impl.limit.TestLimitPlanning
-
- testLimitPushdownPastFlatten() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlattenPlanning
-
- testLimitResetsAfterFirstEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitBatchEmitOutcome
-
Test to show that once a limit number of records is produced using first set of batches then on getting a batch
with EMIT outcome, the limit state is again refreshed and applied to next set of batches with data.
- TestLimitWithExchanges - Class in org.apache.drill.exec.physical.impl.limit
-
- TestLimitWithExchanges() - Constructor for class org.apache.drill.exec.physical.impl.limit.TestLimitWithExchanges
-
- testLimitWithExchanges() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitWithExchanges
-
- testLimitWithNegativeFirstLast() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitOperator
-
- testLimitWithNegativeOffset() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitOperator
-
- testLimitWithNoLastRecord() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitOperator
-
- testLimitWithOffset() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitOperator
-
- testLimitWithOffsetOutOfRange() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitOperator
-
- testLimitZero() - Method in class org.apache.drill.exec.store.parquet.TestParquetLimitPushDown
-
- testLinkedList() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testListAllEmptyResult() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListAllRecursiveWithFilter() - Method in class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- testListAllRecursiveWithFilter() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListAllRecursiveWithoutFilter() - Method in class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- testListAllRecursiveWithoutFilter() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListAllSafe() - Method in class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- testListAllSafe() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListAllWithFilter() - Method in class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- testListAllWithFilter() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListAllWithoutFilter() - Method in class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- testListAllWithoutFilter() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListColumn() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
- testListDirectoriesEmptyResult() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListDirectoriesRecursiveWithFilter() - Method in class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- testListDirectoriesRecursiveWithFilter() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListDirectoriesRecursiveWithoutFilter() - Method in class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- testListDirectoriesRecursiveWithoutFilter() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListDirectoriesSafe() - Method in class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- testListDirectoriesSafe() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListDirectoriesWithFilter() - Method in class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- testListDirectoriesWithFilter() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListDirectoriesWithoutFilter() - Method in class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- testListDirectoriesWithoutFilter() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListFilesEmptyResult() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListFilesRecursiveWithFilter() - Method in class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- testListFilesRecursiveWithFilter() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListFilesRecursiveWithoutFilter() - Method in class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- testListFilesRecursiveWithoutFilter() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListFilesSafe() - Method in class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- testListFilesSafe() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListFilesWithFilter() - Method in class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- testListFilesWithFilter() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListFilesWithoutFilter() - Method in class org.apache.drill.exec.util.DrillFileSystemUtilTest
-
- testListFilesWithoutFilter() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testListInRow() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
Test building a list (of unions) in the top-level schema.
- testListInUnion() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
- testListofListofScalar() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderUnions
-
The semantics of the ListVector are such that it allows
multi-dimensional lists.
- testListOfMaps() - Method in class org.apache.drill.test.rowSet.test.TestVariantAccessors
-
List of maps.
- testListOfUnions() - Method in class org.apache.drill.test.rowSet.test.TestVariantAccessors
-
Test a union list.
- testListSchema() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
- testListVectorShouldNotThrowOversizedAllocationException() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- testLiteralCastToBIGINTYieldsBIGINT() - Method in class org.apache.drill.TestFunctionsQuery
-
- testLiteralCastToDOUBLEYieldsDOUBLE() - Method in class org.apache.drill.TestFunctionsQuery
-
- testLiteralCastToFLOATYieldsFLOAT() - Method in class org.apache.drill.TestFunctionsQuery
-
Test for DRILL-2668, that "CAST ( 1.5 AS FLOAT )" really yields type FLOAT
(rather than type DOUBLE).
- testLiteralCastToINTEGERYieldsINTEGER() - Method in class org.apache.drill.TestFunctionsQuery
-
- testLiteralCastToSMALLINTYieldsSMALLINT() - Method in class org.apache.drill.TestFunctionsQuery
-
- testLiteralCastToTINYINTYieldsTINYINT() - Method in class org.apache.drill.TestFunctionsQuery
-
- testLiterals() - Method in class org.apache.drill.exec.record.vector.TestDateTypes
-
- TestLoad - Class in org.apache.drill.exec.record.vector
-
- TestLoad() - Constructor for class org.apache.drill.exec.record.vector.TestLoad
-
- testLoadValueVector() - Method in class org.apache.drill.exec.record.vector.TestLoad
-
- testLocal() - Method in class org.apache.drill.exec.physical.impl.TestSchema
-
- testLocalCancelFragment_NegativeAck() - Method in class org.apache.drill.exec.rpc.control.TestLocalControlConnectionManager
-
Verify that CancelFragment with negative ack is handled correctly using ControlTunnel with
LocalControlConnectionManager
- testLocalCancelFragment_PositiveAck() - Method in class org.apache.drill.exec.rpc.control.TestLocalControlConnectionManager
-
Verify that CancelFragment with positive ack is handled correctly using ControlTunnel with
LocalControlConnectionManager
- testLocalConnectionManager() - Method in class org.apache.drill.exec.rpc.control.ConnectionManagerRegistryTest
-
- testLocalConnectionManager_differentState() - Method in class org.apache.drill.exec.rpc.control.ConnectionManagerRegistryTest
-
- testLocalConnectionManager_differentUserDataPort() - Method in class org.apache.drill.exec.rpc.control.ConnectionManagerRegistryTest
-
- TestLocalControlConnectionManager - Class in org.apache.drill.exec.rpc.control
-
- TestLocalControlConnectionManager() - Constructor for class org.apache.drill.exec.rpc.control.TestLocalControlConnectionManager
-
- testLocalDistributed() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- TestLocalExchange - Class in org.apache.drill.exec.physical.impl
-
This test starts a Drill cluster with CLUSTER_SIZE nodes and generates data for test tables.
- TestLocalExchange() - Constructor for class org.apache.drill.exec.physical.impl.TestLocalExchange
-
- testLocalSendFragments_Failure() - Method in class org.apache.drill.exec.rpc.control.TestLocalControlConnectionManager
-
Verify that InitializeFragments failure case is handled correctly using ControlTunnel with
LocalControlConnectionManager
- testLocalSendFragments_NegativeAck() - Method in class org.apache.drill.exec.rpc.control.TestLocalControlConnectionManager
-
Verify that InitializeFragments with negative ack is handled correctly using ControlTunnel with
LocalControlConnectionManager
- testLocalSendFragments_PositiveAck() - Method in class org.apache.drill.exec.rpc.control.TestLocalControlConnectionManager
-
Verify that InitializeFragments with positive ack is handled correctly using ControlTunnel with
LocalControlConnectionManager
- testLocalSendFragmentStatus_Failure() - Method in class org.apache.drill.exec.rpc.control.TestLocalControlConnectionManager
-
Verify that SendFragmentStatus failure scenario is handled correctly using ControlTunnel with
LocalControlConnectionManager
- testLocalSendFragmentStatus_Success() - Method in class org.apache.drill.exec.rpc.control.TestLocalControlConnectionManager
-
Verify that SendFragmentStatus is handled correctly using ControlTunnel with LocalControlConnectionManager
- testLocalTimestamp() - Method in class org.apache.drill.exec.fn.impl.TestNewDateFunctions
-
- testLog10WithBigInt() - Method in class org.apache.drill.exec.fn.impl.TestNewMathFunctions
-
- testLog10WithDouble() - Method in class org.apache.drill.exec.fn.impl.TestNewMathFunctions
-
- testLog10WithFloat() - Method in class org.apache.drill.exec.fn.impl.TestNewMathFunctions
-
- testLog10WithInt() - Method in class org.apache.drill.exec.fn.impl.TestNewMathFunctions
-
- testLog10WithUint4() - Method in class org.apache.drill.exec.fn.impl.TestNewMathFunctions
-
- testLogFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testLogicalDirPruning() - Method in class org.apache.drill.TestPartitionFilter
-
- testLogicalDirPruning2() - Method in class org.apache.drill.TestPartitionFilter
-
- TestLogicalExprSerDe - Class in org.apache.drill.exec.expr
-
Test LogicalExpressions are serialized and deserialized properly when query is planned into multiple fragments.
- TestLogicalExprSerDe() - Constructor for class org.apache.drill.exec.expr.TestLogicalExprSerDe
-
- testLogicalIntTypes() - Method in class org.apache.drill.exec.store.parquet2.TestDrillParquetReader
-
- testLogicalIntTypes2() - Method in class org.apache.drill.exec.store.parquet2.TestDrillParquetReader
-
- testLogicalIntTypes3() - Method in class org.apache.drill.exec.store.parquet2.TestDrillParquetReader
-
- testLogicalIntTypes4() - Method in class org.apache.drill.exec.store.parquet2.TestDrillParquetReader
-
- testLogicalIntTypes5() - Method in class org.apache.drill.exec.store.parquet2.TestDrillParquetReader
-
- testLogicalWithResults(String) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- TestLogReader - Class in org.apache.drill.exec.store.log
-
- TestLogReader() - Constructor for class org.apache.drill.exec.store.log.TestLogReader
-
- testLongArray() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testLongRW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testLower() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testLower() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testLowerMemory() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
- testLowMemory() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
- testLpad() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testLpadTwoArgConvergeToLpad() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testLRBTrimOneArg() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testLtrim() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testLtrimOneArgConvergeToLtrim() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- TestMainLoginPageModel - Class in org.apache.drill.exec.server.rest
-
- TestMainLoginPageModel() - Constructor for class org.apache.drill.exec.server.rest.TestMainLoginPageModel
-
- testMainQueryFalseCondition() - Method in class org.apache.drill.TestPartitionFilter
-
- testMainQueryFilterRegularColumn() - Method in class org.apache.drill.TestPartitionFilter
-
- testMainQueryTrueCondition() - Method in class org.apache.drill.TestPartitionFilter
-
- testMakeDebugString() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinMemoryCalculator
-
- testMakeDebugString() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testManualDropWithoutSchema() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testManualDropWithSchema() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testManyDateCasts() - Method in class org.apache.drill.TestBugFixes
-
- testMap() - Method in class org.apache.drill.exec.cache.TestBatchSerialization
-
Tests a map type and an SV2.
- testMap() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestScanLevelProjection
-
Map projection occurs when a query contains project-list items with
a dot, such as "a.b".
- testMap() - Method in class org.apache.drill.test.rowSet.test.TestHyperVectorReaders
-
Maps are an interesting case.
- TestMapAccessors - Class in org.apache.drill.test.rowSet.test
-
Test map support in the column readers and writers.
- TestMapAccessors() - Constructor for class org.apache.drill.test.rowSet.test.TestMapAccessors
-
- testMapAddition() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMaps
-
Test adding a map to a loader after writing the first row.
- testMapArray() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
- testMapArrayProjection() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderProjection
-
Test a map array.
- testMapArrayRevision() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestRowBatchMerger
-
Test that the merger mechanism can rewrite a map array to include
projected null columns.
- testMapColumn() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
Tests a map column.
- testMapDetails() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
- testMapDups() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
- testMapDupsIgnored() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
When the project list includes references to both the
map as a whole, and members, then the parser is forgiving
of duplicate map members since all members are projected.
- testMapEmptyBetween() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testMapEmptyFirst() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testMapEmptyLast() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testMapEvolution() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMaps
-
Create schema with a map, then add columns to the map
after delivering the first batch.
- testMapInMap() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
Verify that the map-in-map plumbing works.
- testMapInRepeatedList() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
- testMapInRow() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
Tests creating a map within a row.
- testMapInUnion() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
- testMapKey() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
- testMapMismatch() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaLevelProjection
-
Project of a non-map as a map
- testMapOrdering() - Method in class org.apache.drill.TestFrameworkTest
-
- testMapOverflowWithNewColumn() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMaps
-
Test the case in which a new column is added during the overflow row.
- testMapProjection() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderProjection
-
- testMapProjectionMemberAndMap() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderProjection
-
- testMapRevision() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestRowBatchMerger
-
Test that the merger mechanism can rewrite a map to include
projected null columns.
- testMapSchema_withNullValues() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testMapSchemaChange() - Method in class org.apache.drill.exec.record.vector.TestLoad
-
- testMapSchemaComplex_withNullValues() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testMapStructure() - Method in class org.apache.drill.test.rowSet.test.RowSetTest
-
Test a simple map structure at the top level of a row.
- testMapTupleFromField() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
- testMapTupleFromMetadata() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
Test a complex map schema of the form:
a.`b.x`.`c.y`.d
in which columns "a", "b.x" and "c.y" are maps, "b.x" and "c.y" are names
that contains dots, and d is primitive.
- testMapType() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- testMapType(OperatorFixture) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- testMapWithArray() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMaps
-
Test a map that contains a scalar array.
- testMapWithOverflow() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMaps
-
Create a schema with a map, then trigger an overflow on one of the columns
in the map.
- testMarkResetIterator() - Method in class org.apache.drill.exec.record.TestRecordIterator
-
- TestMaterializedField - Class in org.apache.drill.exec.record
-
- TestMaterializedField() - Constructor for class org.apache.drill.exec.record.TestMaterializedField
-
- testMaterializingConstantTree() - Method in class org.apache.drill.exec.record.ExpressionTreeMaterializerTest
-
- testMaterializingLateboundField() - Method in class org.apache.drill.exec.record.ExpressionTreeMaterializerTest
-
- testMaterializingLateboundTree() - Method in class org.apache.drill.exec.record.ExpressionTreeMaterializerTest
-
- testMaterializingLateboundTreeValidated() - Method in class org.apache.drill.exec.record.ExpressionTreeMaterializerTest
-
- TestMathFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestMathFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestMathFunctions
-
- TestMathFunctionsWithNanInf - Class in org.apache.drill.exec.fn.impl
-
- TestMathFunctionsWithNanInf() - Constructor for class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testMaxFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testMaxVarChar() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testMaxWidthPerNodeConfig() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testMaxWidthPerNodeDefault() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testMaxWidthPerNodeSession() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testMaxWidthPerNodeSystem() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testMaxWithZeroInput() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testMemoryDynamics() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
- testMemoryManagerBasics() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
- testMemoryOverflow() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
- TestMemoryRetention - Class in org.apache.drill.exec
-
- TestMemoryRetention() - Constructor for class org.apache.drill.exec.TestMemoryRetention
-
- testMergeCalcs() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
- testMergeCalcsExtreme() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
- testMerged() - Method in class org.apache.drill.exec.work.filter.BloomFilterTest
-
- TestMergeFilterPlan - Class in org.apache.drill
-
- TestMergeFilterPlan() - Constructor for class org.apache.drill.TestMergeFilterPlan
-
- testMergeFiltersWithMissingParameters() - Method in class org.apache.drill.exec.util.FileSystemUtilTest
-
- testMergeInnerJoinLargeLeft() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testMergeInnerJoinLargeRight() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testMergeInnerJoinOnNullableColumns() - Method in class org.apache.drill.TestJoinNullable
-
InnerJoin on nullable cols, MergeJoin
- testMergeInnerJoinRandomized() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testMergeInnerJoinWithBothEmptyDirTables() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testMergeInnerJoinWithEmptyTable() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testMergeInnerJoinWithLeftEmptyDirTable() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testMergeInnerJoinWithRightEmptyDirTable() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testMergeIsNotSelectedForFullJoin() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testMergeJoin() - Method in class org.apache.drill.exec.compile.TestLargeFileCompilation
-
- TestMergeJoin - Class in org.apache.drill.exec.physical.impl.join
-
- TestMergeJoin() - Constructor for class org.apache.drill.exec.physical.impl.join.TestMergeJoin
-
- TestMergeJoinAdvanced - Class in org.apache.drill.exec.physical.impl.join
-
- TestMergeJoinAdvanced() - Constructor for class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testMergeJoinEmptyBoth() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testMergeJoinExprInCondition() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoin
-
- testMergeJoinInnerEmptyBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoin
-
- testMergeJoinInnerNullKey() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinMulCondition
-
- testMergeJoinLeftEmptyBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoin
-
- testMergeJoinLeftOuterNullKey() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinMulCondition
-
- testMergeJoinLowerLimit() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- TestMergeJoinMulCondition - Class in org.apache.drill.exec.physical.impl.join
-
- TestMergeJoinMulCondition() - Constructor for class org.apache.drill.exec.physical.impl.join.TestMergeJoinMulCondition
-
- testMergeJoinMultiKeys() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinMulCondition
-
- testMergeJoinMultipleOutputBatches() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testMergeJoinRightEmptyBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoin
-
- testMergeJoinSingleOutputBatch() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testMergeJoinUpperLimit() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testMergeJoinWithNaN() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- TestMergeJoinWithSchemaChanges - Class in org.apache.drill.exec.physical.impl.join
-
- TestMergeJoinWithSchemaChanges() - Constructor for class org.apache.drill.exec.physical.impl.join.TestMergeJoinWithSchemaChanges
-
- testMergeLeftJoinLargeLeft() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testMergeLeftJoinLargeRight() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testMergeLeftJoinRandomized() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testMergeLeftJoinWithEmptyTable() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testMergeLeftJoinWithRightEmptyDirTable() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testMergeLimit() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
- testMergeLOJNullable() - Method in class org.apache.drill.TestJoinNullable
-
LeftOuterJoin on nullable cols, MergeJoin
- testMergeLOJNullableBothInputsOrderedAscNullsFirstVsAscNullsFirst() - Method in class org.apache.drill.TestJoinNullable
-
Left outer join, merge, nullable col.
- testMergeLOJNullableBothInputsOrderedAscNullsFirstVsAscNullsLast() - Method in class org.apache.drill.TestJoinNullable
-
Left outer join, merge, nullable col.
- testMergeLOJNullableBothInputsOrderedAscNullsLastVsAscNullsFirst() - Method in class org.apache.drill.TestJoinNullable
-
Left outer join, merge, nullable col.
- testMergeLOJNullableBothInputsOrderedAscNullsLastVsAscNullsLast() - Method in class org.apache.drill.TestJoinNullable
-
Left outer join, merge, nullable col.
- testMergeLOJNullableBothInputsOrderedDescNullsFirstVsAscNullsFirst() - Method in class org.apache.drill.TestJoinNullable
-
Left outer join, merge, nullable col.
- testMergeLOJNullableBothInputsOrderedDescNullsFirstVsAscNullsLast() - Method in class org.apache.drill.TestJoinNullable
-
Left outer join, merge, nullable col.
- testMergeLOJNullableBothInputsOrderedDescNullsLastVsAscNullsFirst() - Method in class org.apache.drill.TestJoinNullable
-
Left outer join, merge, nullable col.
- testMergeLOJNullableBothInputsOrderedDescNullsLastVsAscNullsLast() - Method in class org.apache.drill.TestJoinNullable
-
Left outer join, merge, nullable col.
- testMergeLOJNullableNoOrderedInputs() - Method in class org.apache.drill.TestJoinNullable
-
Left outer join, merge, nullable col.
- testMergeLOJNullableOneOrderedInputAscNullsFirst() - Method in class org.apache.drill.TestJoinNullable
-
Left outer join, merge, nullable col.
- testMergeLOJNullableOneOrderedInputAscNullsLast() - Method in class org.apache.drill.TestJoinNullable
-
Left outer join, merge, nullable col.
- testMergeLOJNullableOneOrderedInputDescNullsFirst() - Method in class org.apache.drill.TestJoinNullable
-
Left outer join, merge, nullable col.
- testMergeLOJNullableOneOrderedInputDescNullsLast() - Method in class org.apache.drill.TestJoinNullable
-
Left outer join, merge, nullable col.
- testMergeRightJoinLargeLeft() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testMergeRightJoinLargeRight() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testMergeRightJoinRandomized() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testMergeRightJoinWithEmptyTable() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- testMergeRightJoinWithRightEmptyDirTable() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testMergeROJOnNullableColumns() - Method in class org.apache.drill.TestJoinNullable
-
RightOuterJoin on nullable cols, MergeJoin
- TestMergingReceiver - Class in org.apache.drill.exec.physical.impl.mergereceiver
-
- TestMergingReceiver() - Constructor for class org.apache.drill.exec.physical.impl.mergereceiver.TestMergingReceiver
-
- testMergingReceiver() - Method in class org.apache.drill.exec.TestQueriesOnLargeFile
-
- testMetadataCacheFieldWithDots() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testMetaDataExposeType() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- TestMetadataProvider - Class in org.apache.drill.exec.work.metadata
-
Tests for metadata provider APIs.
- TestMetadataProvider() - Constructor for class org.apache.drill.exec.work.metadata.TestMetadataProvider
-
- testMetricNames() - Method in class org.apache.drill.TestOperatorMetrics
-
- testMetrics() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
- testMinFalseMaxFalse() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testMinFalseMaxTrue() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testMinFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- TestMiniPlan - Class in org.apache.drill.exec.physical.unit
-
This class contains examples to show how to use MiniPlanTestBuilder to test a
specific plan fragment (MiniPlan).
- TestMiniPlan() - Constructor for class org.apache.drill.exec.physical.unit.TestMiniPlan
-
- testMinorVersion() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataVersion
-
- testMinTrueMaxTrue() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testMissing() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaLevelProjection
-
Test SELECT list with columns missing from the table schema.
- testMissing() - Method in class org.apache.drill.exec.store.log.TestLogReader
-
- testMissing() - Method in class org.apache.drill.exec.store.parquet.ParquetInternalsTest
-
- testMissingAndNewColumns() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinWithSchemaChanges
-
- testMissingArrayValues() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderOverflow
-
Test the case that an array has "missing values" before the overflow.
- testMissingColumn() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNSchemaChanges
-
- testMissingKeystorePassword() - Method in class org.apache.drill.exec.TestSSLConfig
-
- testMissingKeystorePath() - Method in class org.apache.drill.exec.TestSSLConfig
-
- testMissingNullableColumns() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaSmoothing
-
Preserve the prior schema if table is a subset and missing columns
are nullable or repeated.
- testMissingOverWithConstant() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testMissingOverWithWindowClause() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testMixColumns() - Method in class org.apache.drill.exec.store.pcapng.TestPcapngHeaders
-
- testMixedEqualAndEqualOrHashJoin() - Method in class org.apache.drill.TestJoinNullable
-
- testMixedEqualAndEqualOrMergeJoin() - Method in class org.apache.drill.TestJoinNullable
-
- testMixedEqualAndIsNotDistinctFilterHashJoin() - Method in class org.apache.drill.TestJoinNullable
-
- testMixedEqualAndIsNotDistinctFilterMergeJoin() - Method in class org.apache.drill.TestJoinNullable
-
- testMixedEqualAndIsNotDistinctHashJoin() - Method in class org.apache.drill.TestJoinNullable
-
- testMixedEqualAndIsNotDistinctMergeJoin() - Method in class org.apache.drill.TestJoinNullable
-
- testMixedExecution() - Method in class org.apache.drill.exec.util.ExecutorServiceUtilTest
-
- testMixedNumberTypes() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testMixedNumberTypesInAllTextMode() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testMixedNumberTypesWhenReadingNumbersAsDouble() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testMixedWidth() - Method in class org.apache.drill.exec.store.parquet.ParquetInternalsTest
-
- testMockSubScan() - Method in class org.apache.drill.exec.TestOpSerialization
-
- testModeOf() - Method in class org.apache.drill.exec.expr.fn.impl.TestTypeFns
-
- testModerateBatch() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl
-
Most tests have used small row counts because we want to probe specific bits
of interest.
- testModFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testMongoExtendedTypes() - Method in class org.apache.drill.exec.vector.complex.writer.TestExtendedTypes
-
- testMoveCache() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testMovImage() - Method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- testMp4Image() - Method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- testMulipleRowGroups() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testMultiByteEncoding() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testMultiByteLineDelimiter() - Method in class org.apache.drill.TestSelectWithOption
-
- testMultiColumnInClauseWithSemiJoin() - Method in class org.apache.drill.exec.physical.impl.join.TestSemiJoin
-
- testMultiFilesWithDifferentSchema() - Method in class org.apache.drill.TestSchemaChange
-
- testMultiFlattenFromNestedRepeatedList() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- TestMultiInputAdd - Class in org.apache.drill.exec.fn.impl
-
- TestMultiInputAdd() - Constructor for class org.apache.drill.exec.fn.impl.TestMultiInputAdd
-
- testMultiInputAdd() - Method in class org.apache.drill.exec.fn.impl.TestMultiInputAdd
-
- testMultiLateralWithComplexProject() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testMultiLevelImpersonationEqualToMaxUserHops() - Method in class org.apache.drill.exec.impersonation.TestImpersonationQueries
-
- testMultiLevelImpersonationExceedsMaxUserHops() - Method in class org.apache.drill.exec.impersonation.TestImpersonationQueries
-
- testMultiLevelImpersonationJoinEachSideReachesMaxUserHops() - Method in class org.apache.drill.exec.impersonation.TestImpersonationQueries
-
- testMultiLevelImpersonationJoinOneSideExceedsMaxUserHops() - Method in class org.apache.drill.exec.impersonation.TestImpersonationQueries
-
- testMultiLevelLateral() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
This test generates an operator tree for multi level LATERAL by stacking 2 LATERAL and finally an UNNEST pair
(using MockRecord Batch) as left and right child of lower level LATERAL.
- testMultiLevelLateral_MultipleOutput() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
This test generates an operator tree for multi level LATERAL by stacking 2 LATERAL and finally an UNNEST pair
(using MockRecord Batch) as left and right child of lower level LATERAL.
- testMultiLevelLateral_SchemaChange_LeftRightUnnest() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
This test generates an operator tree for multi level LATERAL by stacking 2 LATERAL and finally an UNNEST pair
(using MockRecord Batch) as left and right child of lower level LATERAL.
- testMultiLevelLateral_SchemaChange_LeftRightUnnest_NonEmptyBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test to verify in case of Multilevel lateral when a non-empty OK_NEW_SCHEMA batch post build schema phase is
received from right most UNNEST of lower LATERAL then pipeline works fine.
- testMultiLevelLateral_SchemaChange_LeftUnnest() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
This test generates an operator tree for multi level LATERAL by stacking 2 LATERAL and finally an UNNEST pair
(using MockRecord Batch) as left and right child of lower level LATERAL.
- testMultiLevelLateral_SchemaChange_RightUnnest() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
This test generates an operator tree for multi level LATERAL by stacking 2 LATERAL and finally an UNNEST pair
(using MockRecord Batch) as left and right child of lower level LATERAL.
- testMultilevelParquetWithSchemaChange() - Method in class org.apache.drill.exec.store.TestImplicitFileColumns
-
- testMultiLevelRepeatedListEmptyBetween() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testMultiLevelRepeatedListEmptyFirst() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testMultiLevelRepeatedListEmptyLast() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testMultiLevelRepeatedListWithMultipleEmpties() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testMultiMinorFragmentComplexQuery() - Method in class org.apache.drill.exec.DrillSeparatePlanningTest
-
- testMultiMinorFragmentSimpleQuery() - Method in class org.apache.drill.exec.DrillSeparatePlanningTest
-
- testMultipleBatchesLateral_WithFilterInParent() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testMultipleBatchesLateral_WithGroupByInParent() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testMultipleBatchesLateral_WithHashAgg() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testMultipleBatchesLateral_WithLimitFilterInSubQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testMultipleBatchesLateral_WithLimitInParent() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
Test where Limit/Filter/Agg/Sort operator are used in parent query
- testMultipleBatchesLateral_WithLimitInSubQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testMultipleBatchesLateral_WithOrderByInParent() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testMultipleBatchesLateral_WithSortAndLimitInSubQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testMultipleBatchesLateral_WithSortInSubQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testMultipleBatchesLateral_WithStreamingAgg() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testMultipleBatchesLateral_WithStreamingAggNoGroup() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testMultipleBatchesLateral_WithTopNInSubQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testMultipleBatchesLateralQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
Test where multiple files are used to trigger multiple batch scenario.
- testMultipleCasesNullableTypes() - Method in class org.apache.drill.exec.planner.logical.TestCaseNullableTypes
-
- testMultipleComparisonWithSingleValueSubQuery() - Method in class org.apache.drill.TestExampleQueries
-
- testMultipleCountDistinctWithGroupBy() - Method in class org.apache.drill.TestExampleQueries
-
- testMultipleExchangesSingleThread() - Method in class org.apache.drill.exec.work.batch.TestSpoolingBuffer
-
- testMultipleFalttenWithWhereClause() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testMultipleFiles() - Method in class org.apache.drill.exec.store.parquet.TestParquetLimitPushDown
-
- testMultipleFramers() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testMultipleJoinsWithOneNonEqualJoin() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testMultipleLeftAndRight_OutputFull_WithPendingLeftRow_LeftJoin() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectnessBatchProcessing
-
- testMultipleLimitWithEMITOutcome() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitBatchEmitOutcome
-
Test to show that limit refreshes it's state after seeing first EMIT outcome and works on data batches following
it as new set's of incoming batch and apply the limits rule from fresh on those.
- testMultipleOutput() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- testMultipleOutputDesc() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- testMultiplePartitions1() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testMultiplePartitions2() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testMultipleProvidersEmptyBatches() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.TestMergingReceiver
-
- testMultipleProvidersMixedSizes() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.TestMergingReceiver
-
- testMultipleRowGroups() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testMultipleRowGroups() - Method in class org.apache.drill.exec.store.parquet.TestParquetLimitPushDown
-
- testMultipleRowGroupsAndReads() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testMultipleRowGroupsAndReads2() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testMultipleRowGroupsAndReads3() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testMultipleRowGroupsAndReadsPigError() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testMultipleRowGroupsEvent() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- TestMultipleSendLocationBroadcastExchange() - Method in class org.apache.drill.exec.physical.impl.TestBroadcastExchange
-
- testMultipleUnnestAtSameLevel() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
This test generates an operator tree for multiple UNNEST at same level by stacking 2 LATERAL and UNNEST pair on
top of each other.
- testMultipleWriters() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriterEmptyFiles
-
- testMultiplyFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testMultiProjectionFromMultiLevelRepeatedListWhenFieldsExist() - Method in class org.apache.drill.exec.expr.TestSchemaPathMaterialization
-
- testMultiRowGroup() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testMultiUnnestAtSameLevel() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testMultiUnnestAtSameLevelExec() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testMultiUnnestAtSameLevelExecExplicitResult() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testMultiUnnestLateralAtSameLevel() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testMultiUnnestQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testMultiUnnestWithMap() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testNamed() - Method in class org.apache.drill.exec.store.FormatPluginSerDeTest
-
- testNameSpace() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMaps
-
Verify that map name spaces (and implementations) are
independent.
- testNanInfFailure() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- testNanInfLiterals() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- testNanInfSelect() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- testNegate() - Method in class org.apache.drill.TestFunctionsQuery
-
Test for DRILL-5645, where negation of expressions that do not contain
a RelNode input results in a NullPointerException
- testNegative() - Method in class org.apache.drill.TestFunctionsQuery
-
- testNegativeByInterpreter() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testNegativeExtractOperator() - Method in class org.apache.drill.TestExampleQueries
-
- testNegativeFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testNegativeValuesThrowException() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testNegPushFilterInExprPastAgg() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testNegPushLimitPastUnionExchange() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitWithExchanges
-
- testNested() - Method in class org.apache.drill.exec.physical.impl.TestNestedDateTimeTimestamp
-
Test reading of from the parquet file that contains nested time, date, and
timestamp
- testNested1() - Method in class org.apache.drill.exec.nested.TestNestedComplexSchema
-
- testNested2() - Method in class org.apache.drill.exec.nested.TestNestedComplexSchema
-
- testNested3() - Method in class org.apache.drill.exec.nested.TestNestedComplexSchema
-
- testNestedAggregates() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testNestedAggregates1() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testNestedArray() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMapArray
-
- testNestedArray() - Method in class org.apache.drill.test.rowSet.test.TestMapAccessors
-
- testNestedArrayInRepeatedMap() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testNestedCaseNullableTypes() - Method in class org.apache.drill.exec.planner.logical.TestCaseNullableTypes
-
- testNestedColumn() - Method in class org.apache.drill.exec.store.parquet.TestComplexColumnInSchema
-
- testNestedColumnQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- TestNestedComplexSchema - Class in org.apache.drill.exec.nested
-
- TestNestedComplexSchema() - Constructor for class org.apache.drill.exec.nested.TestNestedComplexSchema
-
- testNestedDateTimeCTASExtendedJson() - Method in class org.apache.drill.exec.physical.impl.TestNestedDateTimeTimestamp
-
Test the extended json output is consistent as before
- testNestedDateTimeCTASJson() - Method in class org.apache.drill.exec.physical.impl.TestNestedDateTimeTimestamp
-
Test the json output is consistent as before
- testNestedDateTimeCTASParquet() - Method in class org.apache.drill.exec.physical.impl.TestNestedDateTimeTimestamp
-
Test parquet output is consistent as before
- testNestedDateTimePrint() - Method in class org.apache.drill.exec.physical.impl.TestNestedDateTimeTimestamp
-
Test the textual display to make sure it is consistent with actual JSON
output
- TestNestedDateTimeTimestamp - Class in org.apache.drill.exec.physical.impl
-
For DRILL-6242, output for Date, Time, Timestamp should use different classes
- TestNestedDateTimeTimestamp() - Constructor for class org.apache.drill.exec.physical.impl.TestNestedDateTimeTimestamp
-
- testNestedFilter() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testNestedFlatten() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testNestedFlattenWithJoin() - Method in class org.apache.drill.exec.nested.TestNestedComplexSchema
-
- testNestedInnerJoinWithEmptyTable() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNestedLeftJoinWithEmptyTable() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNestedLoopInnerJoinWithBothEmptyDirTables() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testNestedLoopInnerJoinWithLeftEmptyDirTable() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testNestedLoopInnerJoinWithRightEmptyDirTable() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testNestedLoopJoin() - Method in class org.apache.drill.exec.compile.TestLargeFileCompilation
-
- TestNestedLoopJoin - Class in org.apache.drill.exec.physical.impl.join
-
- TestNestedLoopJoin() - Constructor for class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNestedLoopJoinLowerLimit() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testNestedLoopJoinMultipleOutputBatches() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testNestedLoopJoinSingleOutputBatch() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testNestedLoopJoinUpperLimit() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testNestedLoopJoinWithNaN() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- testNestedLoopLeftJoinWithLeftEmptyDirTable() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testNestedLoopLeftJoinWithRightEmptyDirTable() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testNestedLoopRightJoinWithLeftEmptyDirTable() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testNestedLoopRightJoinWithRightEmptyDirTable() - Method in class org.apache.drill.exec.physical.impl.join.TestJoinEmptyDirTable
-
- testNestedMapsNullable() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMaps
-
Create nested maps.
- testNestedMapsRequired() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMaps
-
Create nested maps.
- testNestedMapsRequired() - Method in class org.apache.drill.test.rowSet.test.TestMapAccessors
-
Create nested maps.
- testNestedRepeatedColumn() - Method in class org.apache.drill.exec.store.parquet.TestComplexColumnInSchema
-
- testNestedRepeatedListInsideRepeatedList() - Method in class org.apache.drill.exec.TestRepeatedReaders
-
- testNestedRepeatedListInsideRepeatedMap() - Method in class org.apache.drill.exec.TestRepeatedReaders
-
- testNestedRepeatedMapInsideMapInsideRepeatedMap() - Method in class org.apache.drill.exec.TestRepeatedReaders
-
- testNestedRepeatedMapInsideRepeatedList() - Method in class org.apache.drill.exec.TestRepeatedReaders
-
- testNestedRepeatedMapInsideRepeatedMap() - Method in class org.apache.drill.exec.TestRepeatedReaders
-
- testNestedRightJoinWithEmptyTable() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNestedSchema() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
- testNestedTypesPastJoinReportsValidResult() - Method in class org.apache.drill.TestExampleQueries
-
- testNestedUnionArraySchema_withNullValues() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testNestedUnionSchema_withNullValues() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testNestedUnnest() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testNestedUnnestMapColumn() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestWithLateralCorrectness
-
- testNestedVariableCaseColumn() - Method in class org.apache.drill.exec.store.parquet.TestComplexColumnInSchema
-
- testNestLoopJoinScalarSubQ() - Method in class org.apache.drill.TestExampleQueries
-
- TestNewAggregateFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestNewAggregateFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestNewAggregateFunctions
-
- testNewColumnsLegacy() - Method in class org.apache.drill.exec.physical.impl.xsort.TestExternalSort
-
- testNewColumnsManaged() - Method in class org.apache.drill.exec.physical.impl.xsort.TestExternalSort
-
- TestNewDateFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestNewDateFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestNewDateFunctions
-
- testNewFilesPruningNoMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForVarchar
-
- testNewFilesPruningWithNewMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForVarchar
-
- testNewFilesPruningWithNullPartition() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForVarchar
-
- testNewFilesPushDownNoMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForVarchar
-
- testNewFilesPushDownWithMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForVarchar
-
- testNewFixedDecimalPushDown() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check filter push down for fixed decimal generated after upgrade to parquet 1.10.0
with and without using Drill metadata file.
- testNewIntDecimalPushDownNoMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check filter push down for new int_32 and int_64 decimal files
without using Drill metadata file.
- testNewIntDecimalPushDownWithMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check filter push down for new int_32 and int_64 decimal files
using Drill metadata file.
- TestNewMathFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestNewMathFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestNewMathFunctions
-
- testNewSessionReqForSpnegoLogin() - Method in class org.apache.drill.exec.server.rest.spnego.TestDrillSpnegoAuthenticator
-
- TestNewSimpleRepeatedFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestNewSimpleRepeatedFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestNewSimpleRepeatedFunctions
-
- testNewStringFuncs() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- TestNewTextReader - Class in org.apache.drill.exec.store.text
-
- TestNewTextReader() - Constructor for class org.apache.drill.exec.store.text.TestNewTextReader
-
- testNlJoinAggrs_1_planning() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNLJoinCorrectnessRightMultipleBatches() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
Validates correctness of NestedLoopJoin when right side has multiple batches.
- testNlJoinEqualityNonScalar_1_planning() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinEqualityNonScalar_2_planning() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinEqualityScalar_1_planning() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinEqualityScalar_2_planning() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinExists_1_exec() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinExists_1_planning() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinInequality_1() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinInequality_2() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinInequality_3() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinInnerBetween() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinLeftBetween() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinNotIn_1_exec() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinNotIn_1_planning() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinNotIn_2_exec() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinWithLargeRightInputFailure() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinWithLargeRightInputSuccess() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNlJoinWithStringsInCondition() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNLJWithEmptyBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestNestedLoopJoin
-
- testNoDictionary() - Method in class org.apache.drill.exec.store.parquet.columnreaders.TestDateReader
-
check if DateReader works well with plain encoding.
- testNoExchangeWithAggWithoutGrpBy() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
Following test cases are introduced to make sure no exchanges are present on right side of
Lateral join.
- testNoExchangeWithHashAggWithGrpBy() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testNoExchangeWithLateralsDownStreamAgg() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testNoExchangeWithLateralsDownStreamJoin() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testNoExchangeWithLateralsDownStreamUnion() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testNoExchangeWithOrderByLimit() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testNoExchangeWithOrderByWithoutLimit() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testNoExchangeWithStreamAggWithGrpBy() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testNoKeyPassword() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSLServer
-
- testNonClusterDiscoveryPaths() - Method in class org.apache.drill.exec.coord.zk.TestZKACL
-
Test ACLs on znodes other than ones required to discover the cluster
ZK libraries only supports one client instance per-machine per-server and it is cached.
- testNonEmptyRootTuple() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
Test the basics of a non-empty root tuple (i.e.
- testNonEmptySchema() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderEmptyProject
-
Verify that skip rows works even if the the projection is non-empty.
- testNonEqualJoin() - Method in class org.apache.drill.TestDisabledFunctionality
-
- testNonExistentColumn() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testNonexistentColumn() - Method in class org.apache.drill.exec.store.parquet.TestComplexColumnInSchema
-
- testNonExistentColumnLargeFile() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testNonExistentColumnReadAlone() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testNonExistentColumnsSomePresentColumnsLargeFile() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testNonExistentFieldConverting() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testNonExistentMetricNames() - Method in class org.apache.drill.TestOperatorMetrics
-
- testNonHomogenousDrop() - Method in class org.apache.drill.TestDropTable
-
- testNonNullableDictionaries() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testNonNullType(TypeProtos.MinorType) - Method in class org.apache.drill.exec.cache.TestBatchSerialization
-
- testNoNulls() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testNoPredictHashAggrSpill() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggrSpill
-
Test with "needed memory" prediction turned off
(i.e., do exercise code paths that catch OOMs from the Hash Table and recover)
- testNoProbeDataForStats() - Method in class org.apache.drill.exec.physical.impl.join.TestBuildSidePartitioningImpl
-
- testNoResult(String, Object...) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- testNoResult(int, String, Object...) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- testNormalizeRemovesRedundantForwardSlashes() - Method in class org.apache.drill.exec.coord.zk.TestPathUtils
-
- testNormalLifeCycle() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
Simulate a normal run: return some batches, encounter a schema change.
- testNoRoomInMemoryForBatch1FirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestBuildSidePartitioningImpl
-
- testNoRoomInMemoryForBatch1NotFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestBuildSidePartitioningImpl
-
- testNoSupportedError() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testNotCountingQueryNotSkippingInvalidJSONRecords() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testNotCountingQuerySkippingInvalidJSONRecords() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- testNotEqual() - Method in class org.apache.drill.exec.fn.impl.TestByteComparisonFunctions
-
- testNotEqualFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testNotEqualLong() - Method in class org.apache.drill.exec.fn.impl.TestByteComparisonFunctions
-
- testNotExist() - Method in class org.apache.drill.exec.work.filter.BloomFilterTest
-
- testNotNullCount() - Method in class org.apache.drill.exec.store.parquet.TestFixedlenDecimal
-
- testNotNullCount() - Method in class org.apache.drill.exec.store.parquet.TestParquetBulkReader
-
Load variable length data which has non-nulls data
- testNotNullCount() - Method in class org.apache.drill.exec.store.parquet.TestVarlenDecimal
-
- testNtile() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testNullable() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
Verify that nulls sort in the requested position: high or low.
- testNullable() - Method in class org.apache.drill.vector.TestToNullable
-
- testNullableAgg() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testNullableColumns() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testNullableColumnsVarLen() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testNullableDate() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testNullableDecimal18() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testNullableDecimal9() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testNullableDouble() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testNullableFilter() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testNullableFixedType() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- testNullableFixedWidthColumn() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
- testNullableFloat() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- testNullableFloat() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testNullableInt() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testNullableInterval() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testNullableIntervalDay() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testNullableIntervalYear() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testNullableLong() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testNullableSmallInt() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testNullableTimestamp() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testNullableTinyInt() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testNullableType(TypeProtos.MinorType) - Method in class org.apache.drill.exec.cache.TestBatchSerialization
-
- testNullableVarBinary() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testNullableVarchar() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testNullableVarChar() - Method in class org.apache.drill.vector.TestFillEmpties
-
- testNullableVarCharMemory() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testNullableVarCharVectorLoad() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- testNullableVariableWidthColumn() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
- testNullableVarLen2() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- testNullColumnBuilder() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestNullColumnLoader
-
Test the shim class that adapts between the null column loader
and the projection mechanism.
- TestNullColumnLoader - Class in org.apache.drill.exec.physical.impl.scan.project
-
Test the mechanism that handles all-null columns during projection.
- TestNullColumnLoader() - Constructor for class org.apache.drill.exec.physical.impl.scan.project.TestNullColumnLoader
-
- testNullConstantsTimeTimeStampAndDate() - Method in class org.apache.drill.TestFunctionsQuery
-
- testNullCount() - Method in class org.apache.drill.exec.store.parquet.TestFixedlenDecimal
-
- testNullCount() - Method in class org.apache.drill.exec.store.parquet.TestParquetBulkReader
-
Load variable length data which has nulls
- testNullCount() - Method in class org.apache.drill.exec.store.parquet.TestVarlenDecimal
-
- testNullEqualAdditionFilter() - Method in class org.apache.drill.TestJoinNullable
-
- testNullEqualHashJoin() - Method in class org.apache.drill.TestJoinNullable
-
- testNullEqualInWhereConditionHashJoin() - Method in class org.apache.drill.TestJoinNullable
-
- testNullEqualInWhereConditionMergeJoin() - Method in class org.apache.drill.TestJoinNullable
-
- testNullEqualMergeJoin() - Method in class org.apache.drill.TestJoinNullable
-
- testNullInput() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl
-
Test for null input (no input batches).
- TestNullInputMiniPlan - Class in org.apache.drill.exec.physical.unit
-
- TestNullInputMiniPlan() - Constructor for class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testNullMaps() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestRowBatchMerger
-
Test the ability to create maps from whole cloth if requested in
the projection list, and the map is not available from the data
source.
- testNullReadWrite() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testNullSegmentThrowsNPE() - Method in class org.apache.drill.exec.coord.zk.TestPathUtils
-
- testNullType() - Method in class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- testNullWhereListExpected() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testNullWhereMapExpected() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testNumericAndStringTypes() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNSchemaChanges
-
- testNumericAndStringTypesLegacy() - Method in class org.apache.drill.exec.physical.impl.xsort.TestExternalSort
-
- testNumericAndStringTypesManaged() - Method in class org.apache.drill.exec.physical.impl.xsort.TestExternalSort
-
- testNumericStringTypes() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinWithSchemaChanges
-
- testNumericTypes() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinWithSchemaChanges
-
- testNumericTypes() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNSchemaChanges
-
- testNumericTypes() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
- testNumericTypesLegacy() - Method in class org.apache.drill.exec.physical.impl.xsort.TestExternalSort
-
- testNumericTypesManaged() - Method in class org.apache.drill.exec.physical.impl.xsort.TestExternalSort
-
- testObjectIdType() - Method in class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- TestOffsetVectorWriter - Class in org.apache.drill.test.rowSet.test
-
The offset vector writer is unique: it follows the same API as
the other writers, but has a unique twist because offsets are written
into the slot one after the other vectors.
- TestOffsetVectorWriter() - Constructor for class org.apache.drill.test.rowSet.test.TestOffsetVectorWriter
-
- testOK_NEW_SCHEMA_WithNoActualSchemaChange_ForNonUnnestField() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
When multiple left batch is received with same schema but with OK_NEW_SCHEMA, then LATERAL rebuilds the
schema each time and sends output in multiple output batches
The schema change was only for columns which are not produced by the UNNEST or right branch.
- testOK_NEW_SCHEMA_WithNoActualSchemaChange_ForUnnestField() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
When multiple left batch is received with same schema but with OK_NEW_SCHEMA, then LATERAL correctly
handles it by re-creating the schema and producing multiple batches of final output
The schema change is for columns common on both left and right side.
- testOldFilesPruningWithAndWithoutMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForVarchar
-
- testOldFilesPruningWithNewMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForVarchar
-
- testOldFilesPushDownNoMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForVarchar
-
- testOldFilesPushDownWithOldMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForVarchar
-
- testOldFixedDecimalPruningWithOldMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check partition pruning for old and new fixed decimal files
using old Drill metadata file, i.e.
- testOldFixedDecimalPushDownNoMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check filter push down for old fixed decimal files
without using Drill metadata file.
- testOldFixedDecimalPushDownWithNewMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check filter push down for old fixed decimal with
using new Drill metadata file, i.e.
- testOldFixedDecimalPushDownWithOldMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check filter push down for old fixed decimal with
using old Drill metadata file, i.e.
- testOldIntDecimalPushDownNoMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check filter push down for old int_32 and int_64 decimal files
without using Drill metadata file.
- testOldIntDecimalPushDownWithNewMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check filter push down for old int_32 and int_64 decimal files
using new Drill metadata file, i.e.
- testOldIntDecimalPushDownWithOldMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check filter push down for old int_32 and int_64 decimal files
using old Drill metadata file, i.e.
- testOldMetadataVersions() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testOldNewFixedDecimalPruningNoMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check partition pruning for old and new fixed decimal files
without using Drill metadata file.
- testOldNewFixedDecimalPruningWithNewMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check partition pruning for old and new fixed decimal files
using new Drill metadata file, i.e.
- testOldNewIntDecimalPruningNoMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check partition pruning for old and new int_32 and int_64 decimal files
without using Drill metadata file.
- testOldNewIntDecimalPruningWithMeta() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
Check partition pruning for old and new int_32 and int_64 decimal files
using Drill metadata file generated by current Drill version (i.e.
- testOmittedMap() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaLevelProjection
-
Test the obscure case that the data source contains a map, but we
project only one of the members of the map.
- testOmittedMapMembers() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaLevelProjection
-
Test of a map with missing columns.
- testOmittedValues() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMapArray
-
Check that the "fill-empties" logic descends down into
a repeated map.
- testOmittedValuesAtEnd() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderOmittedValues
-
Test "holes" in the middle of a batch, and unset columns at
the end.
- testOmittedValuesAtEndWithOverflow() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderOmittedValues
-
Test "holes" at the end of a batch when batch overflows.
- testOneArgQueryDirFunctions() - Method in class org.apache.drill.exec.planner.TestDirectoryExplorerUDFs
-
- testOneSideSchemaChanges() - Method in class org.apache.drill.exec.physical.impl.join.TestMergeJoinWithSchemaChanges
-
- testOnlineEndPoints() - Method in class org.apache.drill.test.TestGracefulShutdown
-
- testOnlyFORMEnabled() - Method in class org.apache.drill.exec.server.rest.spnego.TestSpnegoAuthentication
-
Validate if FORM security handler is created successfully when only form is configured as auth mechanism
- testOnlySPNEGOEnabled() - Method in class org.apache.drill.exec.server.rest.spnego.TestSpnegoAuthentication
-
Validate only SPNEGO security handler is configured properly when enabled via configuration
- TestOperatorDump - Class in org.apache.drill
-
- TestOperatorDump() - Constructor for class org.apache.drill.TestOperatorDump
-
- TestOperatorMetrics - Class in org.apache.drill
-
- TestOperatorMetrics() - Constructor for class org.apache.drill.TestOperatorMetrics
-
- TestOperatorRecordBatch - Class in org.apache.drill.exec.physical.impl.protocol
-
Test the implementation of the Drill Volcano iterator protocol that
wraps the modular operator implementation.
- TestOperatorRecordBatch() - Constructor for class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
- testOpMemory() - Method in class org.apache.drill.exec.util.TestQueryMemoryAlloc
-
Test with default options, various memory configs.
- TestOpSerialization - Class in org.apache.drill.exec
-
- TestOpSerialization() - Constructor for class org.apache.drill.exec.TestOpSerialization
-
- testOptional() - Method in class org.apache.drill.test.rowSet.test.TestHyperVectorReaders
-
Test a nullable varchar.
- testOptionalDecimal28() - Method in class org.apache.drill.exec.store.parquet2.TestDrillParquetReader
-
- testOptionalDecimal38() - Method in class org.apache.drill.exec.store.parquet2.TestDrillParquetReader
-
- testOptions() - Method in class org.apache.drill.exec.physical.impl.validate.TestValidationOptions
-
- TestOptions - Class in org.apache.drill.exec.server
-
- TestOptions() - Constructor for class org.apache.drill.exec.server.TestOptions
-
- testOptions() - Method in class org.apache.drill.exec.server.TestOptions
-
- TestOptionsAuthEnabled - Class in org.apache.drill.exec.server
-
Test setting system scoped options with user authentication enabled.
- TestOptionsAuthEnabled() - Constructor for class org.apache.drill.exec.server.TestOptionsAuthEnabled
-
- testOptiqDecimalCapping() - Method in class org.apache.drill.TestFunctionsQuery
-
- testOptiqValidationFunctions() - Method in class org.apache.drill.TestFunctionsQuery
-
- testOpts() - Method in class org.apache.drill.exec.client.DrillSqlLineApplicationTest
-
- testOrderBy() - Method in class org.apache.drill.TestAltSortQueries
-
- testOrderBy() - Method in class org.apache.drill.TestProjectPushDown
-
- testOrderbyArrayElement() - Method in class org.apache.drill.TestExampleQueries
-
- testOrderbyArrayElementInSubquery() - Method in class org.apache.drill.TestExampleQueries
-
- testOrderByDiffColumn() - Method in class org.apache.drill.TestExampleQueries
-
- testOrderByDiffColumnsInSubqAndOuter() - Method in class org.apache.drill.TestExampleQueries
-
- testOrderBySingleFile() - Method in class org.apache.drill.TestAltSortQueries
-
- testOrderByWithNaN() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonNanInf
-
- TestOrderedMuxExchange - Class in org.apache.drill.exec.physical.impl
-
- TestOrderedMuxExchange() - Constructor for class org.apache.drill.exec.physical.impl.TestOrderedMuxExchange
-
- testOrderedMuxForOrderBy() - Method in class org.apache.drill.exec.physical.impl.TestOrderedMuxExchange
-
Test case to verify the OrderedMuxExchange created for order by clause.
- testOrderedMuxForWindowAgg() - Method in class org.apache.drill.exec.physical.impl.TestOrderedMuxExchange
-
Test case to verify the OrderedMuxExchange created for window functions.
- TestOrderedPartitionExchange - Class in org.apache.drill.exec.physical.impl.orderedpartitioner
-
Tests the OrderedPartitionExchange Operator
- TestOrderedPartitionExchange() - Constructor for class org.apache.drill.exec.physical.impl.orderedpartitioner.TestOrderedPartitionExchange
-
- testOrdering() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortExec
-
- testOrderWithNamedAlias() - Method in class org.apache.drill.exec.sql.TestConformance
-
- testOrderWithPositionalAlias() - Method in class org.apache.drill.exec.sql.TestConformance
-
- testOuterApply_WithFilterAndLimitInSubQuery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testOuterJoinWithInequality() - Method in class org.apache.drill.TestDisabledFunctionality
-
- TestOutOfMemoryOutcome - Class in org.apache.drill
-
Run several tpch queries and inject an OutOfMemoryException in ScanBatch that will cause an OUT_OF_MEMORY outcome to
be propagated downstream.
- TestOutOfMemoryOutcome() - Constructor for class org.apache.drill.TestOutOfMemoryOutcome
-
- TestOutputBatchSize - Class in org.apache.drill.exec.physical.unit
-
- TestOutputBatchSize() - Constructor for class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testOutputFormats() - Method in class org.apache.drill.exec.client.DrillSqlLineApplicationTest
-
- TestOutputMutator - Class in org.apache.drill.exec.store
-
- TestOutputMutator(BufferAllocator) - Constructor for class org.apache.drill.exec.store.TestOutputMutator
-
- testOutputProjectEmpty() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testOverAsking() - Method in class org.apache.drill.exec.physical.impl.common.HashTableAllocationTrackerTest
-
- testOverflowWithNullables() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderOverflow
-
- testOverloadedFunctionExecutionStage() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testOverloadedFunctionPlanningStage() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testOversizeArray() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderOverflow
-
Case where a single array fills up the vector to the maximum size
limit.
- testOverwriteRow() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMapArray
-
Version of the {#link TestResultSetLoaderProtocol#testOverwriteRow()} test
that uses nested columns inside an array of maps.
- testOverwriteRow() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMaps
-
Version of the {#link TestResultSetLoaderProtocol#testOverwriteRow()} test
that uses nested columns.
- testOverwriteRow() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderProtocol
-
The writer protocol allows a client to write to a row any number of times
before invoking save().
- testPadFunctions() - Method in class org.apache.drill.TestFunctionsQuery
-
- testParquet() - Method in class org.apache.drill.exec.store.FormatPluginSerDeTest
-
- testPARQUET_WRITER() - Method in class org.apache.drill.exec.compile.TestLargeFileCompilation
-
- TestParquetBulkReader - Class in org.apache.drill.exec.store.parquet
-
Tests the Parquet bulk reader
- TestParquetBulkReader() - Constructor for class org.apache.drill.exec.store.parquet.TestParquetBulkReader
-
- TestParquetComplex - Class in org.apache.drill.exec.store.parquet
-
- TestParquetComplex() - Constructor for class org.apache.drill.exec.store.parquet.TestParquetComplex
-
- testParquetComplex() - Method in class org.apache.drill.TestExampleQueries
-
- testParquetFilterPDOptionsDisabled() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testParquetFilterPDOptionsThreshold() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- TestParquetFilterPushDown - Class in org.apache.drill.exec.store.parquet
-
- TestParquetFilterPushDown() - Constructor for class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- TestParquetFilterPushDownForComplexTypes - Class in org.apache.drill.exec.store.parquet
-
- TestParquetFilterPushDownForComplexTypes() - Constructor for class org.apache.drill.exec.store.parquet.TestParquetFilterPushDownForComplexTypes
-
- TestParquetFilterPushDownForDateTimeCasts - Class in org.apache.drill.exec.store.parquet
-
- TestParquetFilterPushDownForDateTimeCasts() - Constructor for class org.apache.drill.exec.store.parquet.TestParquetFilterPushDownForDateTimeCasts
-
- TestParquetFilterPushdownWithTransitivePredicates - Class in org.apache.drill.exec.store.parquet
-
- TestParquetFilterPushdownWithTransitivePredicates() - Constructor for class org.apache.drill.exec.store.parquet.TestParquetFilterPushdownWithTransitivePredicates
-
- testParquetFullEngineEventBased(boolean, String, String, String, int, ParquetTestProperties) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testParquetFullEngineEventBased(boolean, String, String, int, ParquetTestProperties) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testParquetFullEngineEventBased(boolean, boolean, String, String, String, int, ParquetTestProperties, UserBitShared.QueryType) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testParquetFullEngineLocalPath(String, String, int, int, int) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testParquetFullEngineLocalText(String, String, int, int, int, boolean) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testParquetFullEngineLocalTextDistributed(String, String, int, int, int) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testParquetFullEngineRemote(String, String, int, int, int) - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- TestParquetGroupScan - Class in org.apache.drill.exec.store.parquet
-
- TestParquetGroupScan() - Constructor for class org.apache.drill.exec.store.parquet.TestParquetGroupScan
-
- TestParquetLimitPushDown - Class in org.apache.drill.exec.store.parquet
-
- TestParquetLimitPushDown() - Constructor for class org.apache.drill.exec.store.parquet.TestParquetLimitPushDown
-
- TestParquetLogicalTypes - Class in org.apache.drill.exec.store.parquet
-
Test Parquet logical type handling with default Parquet reader.
- TestParquetLogicalTypes() - Constructor for class org.apache.drill.exec.store.parquet.TestParquetLogicalTypes
-
- TestParquetMetadataCache - Class in org.apache.drill.exec.store.parquet
-
- TestParquetMetadataCache() - Constructor for class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- TestParquetMetadataVersion - Class in org.apache.drill.exec.store.parquet
-
- TestParquetMetadataVersion() - Constructor for class org.apache.drill.exec.store.parquet.TestParquetMetadataVersion
-
- TestParquetPhysicalPlan - Class in org.apache.drill.exec.store.parquet
-
- TestParquetPhysicalPlan() - Constructor for class org.apache.drill.exec.store.parquet.TestParquetPhysicalPlan
-
- testParquetRead_checkNulls() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testParquetRead_checkNulls_NullsFirst() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testParquetRead_checkShortNullLists() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testParquetRead_checkStartWithNull() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- TestParquetReaderConfig - Class in org.apache.drill.exec.store.parquet
-
- TestParquetReaderConfig() - Constructor for class org.apache.drill.exec.store.parquet.TestParquetReaderConfig
-
- TestParquetReaderUtility - Class in org.apache.drill.exec.store.parquet
-
- TestParquetReaderUtility() - Constructor for class org.apache.drill.exec.store.parquet.TestParquetReaderUtility
-
- testParquetReadWebReturns() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- TestParquetScan - Class in org.apache.drill.exec.store.parquet
-
- TestParquetScan() - Constructor for class org.apache.drill.exec.store.parquet.TestParquetScan
-
- testParquetSingleRowGroupFilterRemoving() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testParquetWithMetadata() - Method in class org.apache.drill.exec.store.FormatPluginSerDeTest
-
- TestParquetWriter - Class in org.apache.drill.exec.physical.impl.writer
-
- TestParquetWriter() - Constructor for class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- TestParquetWriterEmptyFiles - Class in org.apache.drill.exec.physical.impl.writer
-
- TestParquetWriterEmptyFiles() - Constructor for class org.apache.drill.exec.physical.impl.writer.TestParquetWriterEmptyFiles
-
- testParseAndVerifyEndpointsEmptyString() - Method in class org.apache.drill.exec.client.DrillClientTest
-
- testParseAndVerifyEndpointsIpWithDelim() - Method in class org.apache.drill.exec.client.DrillClientTest
-
- testParseAndVerifyEndpointsIpWithEmptyPort() - Method in class org.apache.drill.exec.client.DrillClientTest
-
- testParseAndVerifyEndpointsIpWithSpaces() - Method in class org.apache.drill.exec.client.DrillClientTest
-
- testParseAndVerifyEndpointsMultipleDrillbitIp() - Method in class org.apache.drill.exec.client.DrillClientTest
-
- testParseAndVerifyEndpointsMultipleDrillbitIpPort() - Method in class org.apache.drill.exec.client.DrillClientTest
-
- testParseAndVerifyEndpointsMultipleDrillbitIpPortIp() - Method in class org.apache.drill.exec.client.DrillClientTest
-
- testParseAndVerifyEndpointsNonNumericPort() - Method in class org.apache.drill.exec.client.DrillClientTest
-
- testParseAndVerifyEndpointsOnlyDelim() - Method in class org.apache.drill.exec.client.DrillClientTest
-
- testParseAndVerifyEndpointsOnlyPortDelim() - Method in class org.apache.drill.exec.client.DrillClientTest
-
- testParseAndVerifyEndpointsSingleDrillbitIp() - Method in class org.apache.drill.exec.client.DrillClientTest
-
- testParseAndVerifyEndpointsSingleDrillbitIpPort() - Method in class org.apache.drill.exec.client.DrillClientTest
-
- testParseAndVerifyEndpointsStringWithSpaces() - Method in class org.apache.drill.exec.client.DrillClientTest
-
- testParseAndVerifyEndpointsWithMultiplePort() - Method in class org.apache.drill.exec.client.DrillClientTest
-
- testParseAndVerifyEndpointsWithOnlyPort() - Method in class org.apache.drill.exec.client.DrillClientTest
-
- TestParseFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestParseFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestParseFunctions
-
- testParseParquetPhysicalPlan() - Method in class org.apache.drill.exec.store.parquet.TestParquetPhysicalPlan
-
- testParseParquetPhysicalPlanRemote() - Method in class org.apache.drill.exec.store.parquet.TestParquetPhysicalPlan
-
- TestParsePhysicalPlan - Class in org.apache.drill.exec.physical.config
-
- TestParsePhysicalPlan() - Constructor for class org.apache.drill.exec.physical.config.TestParsePhysicalPlan
-
- testParseQueryFunction() - Method in class org.apache.drill.exec.fn.impl.TestParseFunctions
-
- testParseUrlFunction() - Method in class org.apache.drill.exec.fn.impl.TestParseFunctions
-
- testPartialFilterPushDownWithProject() - Method in class org.apache.drill.exec.store.ischema.TestInfoSchemaFilterPushDown
-
- testPartitionByForAllTypes() - Method in class org.apache.drill.exec.sql.TestCTAS
-
- testPartitionByWithTemporaryTables() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testPartitionColumn() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testPartitionCTAS() - Method in class org.apache.drill.TestExampleQueries
-
- TestPartitionFilter - Class in org.apache.drill
-
- TestPartitionFilter() - Constructor for class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter1_Csv() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter1_Json() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter1_JsonFileMixDir() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter1_Parquet() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter1_Parquet_from_CTAS() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter2_Csv() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter2_Json() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter2_Parquet() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter2_Parquet_from_CTAS() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter3_Csv() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter3_Json() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter3_Parquet() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter3_Parquet_from_CTAS() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter4_Csv() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter4_Json() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter4_Parquet() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter4_Parquet_from_CTAS() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter5_Csv() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter5_Json() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter5_Parquet() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter5_Parquet_from_CTAS() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter6_Parquet() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter6_Parquet_from_CTAS() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter7_Parquet() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter7_Parquet_from_CTAS() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter8_Parquet() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter8_Parquet_from_CTAS() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter9_Parquet() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter9_Parquet_from_CTAS() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilter_Json_WithFlatten() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilterAfterPushFilterPastAgg() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilterIsNotNull_JsonFileMixDir() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilterIsNull_JsonFileMixDir() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilterWithCast() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilterWithInSubquery() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilterWithLike() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionFilterWithNonNullabeFilterExpr() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionLimit_AcrossEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
Verifies that
PartitionLimitRecordBatch
refreshes it's state after seeing first EMIT outcome and works on
data batches following it as new set's of incoming batch and apply the partition limit rule from fresh on those.
- testPartitionLimit_EmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
Verifies that empty batch with both OK_NEW_SCHEMA and EMIT outcome is not ignored by
PartitionLimitRecordBatch
and is passed to the downstream operator.
- testPartitionLimit_IgnoreOnePartitionIdWithOffset() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
Verifies
PartitionLimitRecordBatch
works correctly in cases where start offset is such that all the
records of a partition id is ignored but records in other partition id is selected.
- testPartitionLimit_LargeOffsetIgnoreAllRecords() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
- testPartitionLimit_Limit0() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
- testPartitionLimit_MultipleEmit_SingleMultipleBatch() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
Verifies
PartitionLimitRecordBatch
behaves correctly across EMIT boundary with single or multiple
batches within each EMIT boundary.
- testPartitionLimit_MultipleEmit_SingleMultipleBatch_WithSV2() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
Verifies
PartitionLimitRecordBatch
behaves correctly across EMIT boundary with single or multiple
batches (with sv2) within each EMIT boundary.
- testPartitionLimit_MultipleEmit_SingleMultipleBatch_WithSV2_FilteredRows() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
Verifies
PartitionLimitRecordBatch
behaves correctly across EMIT boundary with single or multiple
batches (with sv2) within each EMIT boundary.
- testPartitionLimit_NegativeOffset() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
- testPartitionLimit_NoLimit() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
- testPartitionLimit_NonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
- testPartitionLimit_NonEmptyFirst_EmptyOKEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
Verifies that when the
PartitionLimitRecordBatch
number of records is found with first incoming batch,
then next empty incoming batch with OK outcome is ignored, but the empty EMIT outcome batch is not ignored.
- testPartitionLimit_PartitionIdSelectedAcrossBatches() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
Verifies
PartitionLimitRecordBatch
works correctly in cases a partition id spans across batches and
limit condition is met by picking records from multiple batch for same partition id.
- testPartitionLimit_PartitionIdSpanningAcrossBatches() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
Verifies that
PartitionLimitRecordBatch
considers same partition id across batches but within EMIT
boundary to impose limit condition.
- testPartitionLimit_PartitionIdSpanningAcrossBatches_WithOffset() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
- testPartitionLimit_ResetsAfterFirstEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
- TestPartitionLimitBatch - Class in org.apache.drill.exec.physical.impl.PartitionLimit
-
- TestPartitionLimitBatch() - Constructor for class org.apache.drill.exec.physical.impl.PartitionLimit.TestPartitionLimitBatch
-
- testPartitionNtile() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testPartitionPruningWithIsNotNull() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testPartitionPruningWithIsNull() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testPartitionPruningWithMetadataCache_1() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testPartitionPruningWithMetadataCache_2() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testPartitionPruningWithMetadataCache_3() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testPartitionPruningWithMetadataCache_4() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- TestPartitionSender - Class in org.apache.drill.exec.physical.impl.partitionsender
-
PartitionerSenderRootExec test to cover mostly part that deals with multithreaded
ability to copy and flush data
- TestPartitionSender() - Constructor for class org.apache.drill.exec.physical.impl.partitionsender.TestPartitionSender
-
- testPartitionSenderCostToThreads() - Method in class org.apache.drill.exec.physical.impl.partitionsender.TestPartitionSender
-
- TestPartitionStat - Class in org.apache.drill.exec.physical.impl.join
-
- TestPartitionStat() - Constructor for class org.apache.drill.exec.physical.impl.join.TestPartitionStat
-
- testPartitionWithCoalesceFilter_1() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitionWithCoalesceFilter_2() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitoinFilter10_Parquet() - Method in class org.apache.drill.TestPartitionFilter
-
- testPartitoinFilter10_Parquet_from_CTAS() - Method in class org.apache.drill.TestPartitionFilter
-
- TestPathUtils - Class in org.apache.drill.exec.coord.zk
-
- TestPathUtils() - Constructor for class org.apache.drill.exec.coord.zk.TestPathUtils
-
- TestPauseInjection - Class in org.apache.drill.exec.testing
-
- TestPauseInjection() - Constructor for class org.apache.drill.exec.testing.TestPauseInjection
-
- testPcap() - Method in class org.apache.drill.exec.store.FormatPluginSerDeTest
-
- TestPcapDecoder - Class in org.apache.drill.exec.store.pcap
-
- TestPcapDecoder() - Constructor for class org.apache.drill.exec.store.pcap.TestPcapDecoder
-
- TestPcapngHeaders - Class in org.apache.drill.exec.store.pcapng
-
- TestPcapngHeaders() - Constructor for class org.apache.drill.exec.store.pcapng.TestPcapngHeaders
-
- TestPcapngRecordReader - Class in org.apache.drill.exec.store.pcapng
-
- TestPcapngRecordReader() - Constructor for class org.apache.drill.exec.store.pcapng.TestPcapngRecordReader
-
- TestPcapRecordReader - Class in org.apache.drill.exec.store.pcap
-
- TestPcapRecordReader() - Constructor for class org.apache.drill.exec.store.pcap.TestPcapRecordReader
-
- testPcxImage() - Method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- testPerformance() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testPermissionAndDeleteOnExitFalseForFileOnly() - Method in class org.apache.drill.exec.store.StorageStrategyTest
-
- testPermissionAndDeleteOnExitFalseForFileWithParent() - Method in class org.apache.drill.exec.store.StorageStrategyTest
-
- testPermissionAndDeleteOnExitTrueForFileOnly() - Method in class org.apache.drill.exec.store.StorageStrategyTest
-
- testPermissionAndDeleteOnExitTrueForFileWithParent() - Method in class org.apache.drill.exec.store.StorageStrategyTest
-
- testPermissive() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultVectorCache
-
- testPhysical(String) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- testPhysicalFromFile(String) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- testPhysicalPlan(String, String...) - Static method in class org.apache.drill.PlanTestBase
-
This method will take a SQL string statement, get the PHYSICAL plan in json
format.
- testPhysicalPlanExecutionBasedOnQuery() - Method in class org.apache.drill.exec.store.pcapng.TestPcapngRecordReader
-
- testPhysicalPlanExecutionBasedOnQuery(String) - Static method in class org.apache.drill.PlanTestBase
-
Creates physical plan for the given query and then executes this plan.
- testPhysicalWithResults(String) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- testPipSeparatedWithQuote() - Method in class org.apache.drill.exec.store.text.TestNewTextReader
-
- testPlanMatchingPatterns(String, String[], String[]) - Static method in class org.apache.drill.PlanTestBase
-
Runs an explain plan query and check for expected regex patterns (in optiq
text format), also ensure excluded patterns are not found.
- testPlanMatchingPatterns(String, Pattern[], Pattern[]) - Static method in class org.apache.drill.PlanTestBase
-
- testPlanMatchingPatterns(String, String[]) - Static method in class org.apache.drill.PlanTestBase
-
The same as above, but without excludedPatterns
- testPlanning() - Method in class org.apache.drill.exec.DrillSeparatePlanningTest
-
- testPlanningNegative() - Method in class org.apache.drill.exec.DrillSeparatePlanningTest
-
- testPlanningNoSplit() - Method in class org.apache.drill.exec.DrillSeparatePlanningTest
-
- testPlanOneExcludedPattern(String, String) - Static method in class org.apache.drill.PlanTestBase
-
- testPlanOneExpectedPattern(String, String) - Static method in class org.apache.drill.PlanTestBase
-
- testPlanOneExpectedPatternOneExcluded(String, String, String) - Static method in class org.apache.drill.PlanTestBase
-
- testPlanSubstrPatterns(String, String[], String[]) - Static method in class org.apache.drill.PlanTestBase
-
Runs an explain plan query and check for expected substring patterns (in optiq
text format), also ensure excluded patterns are not found.
- TestPlanVerificationUtilities - Class in org.apache.drill
-
- TestPlanVerificationUtilities() - Constructor for class org.apache.drill.TestPlanVerificationUtilities
-
- testPlanVerifier() - Method in class org.apache.drill.TestPlanVerificationUtilities
-
- testPlanWithAttributesMatchingPatterns(String, String[], String[]) - Static method in class org.apache.drill.PlanTestBase
-
Runs an explain plan including attributes query and check for expected regex patterns
(in optiq text format), also ensure excluded patterns are not found.
- testPngImage() - Method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- testPosition() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- TestPostBuildCalculationsImpl - Class in org.apache.drill.exec.physical.impl.join
-
- TestPostBuildCalculationsImpl() - Constructor for class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- TestPostBuildCalculationsImpl.ConditionalMockBatchSizePredictor - Class in org.apache.drill.exec.physical.impl.join
-
- TestPostBuildCalculationsImpl.MockHashJoinHelperSizeCalculator - Class in org.apache.drill.exec.physical.impl.join
-
- TestPostBuildCalculationsImpl.MockHashTableSizeCalculator - Class in org.apache.drill.exec.physical.impl.join
-
- testPostBuildSchema_OK_NEW_SCHEMA_NonEmptyRightBatch() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Verifies that if a non-empty batch with OK_NEW_SCHEMA is received from right side post buildSchema phase then it
is handled correctly by sending an empty batch with OK_NEW_SCHEMA and later consuming it to produce actual
output batch with some data
- testPostgresDate() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testPostgresDateFormatError() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testPostgresDateTime() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testPostgresDateTimeNested() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testPostgresPatternFormatError() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testPostgresTime() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testPowerFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testPPWithCase() - Method in class org.apache.drill.TestPartitionFilter
-
- testPPWithNestedExpression() - Method in class org.apache.drill.TestPartitionFilter
-
- testPrematureCommit() - Method in class org.apache.drill.exec.physical.impl.common.HashTableAllocationTrackerTest
-
- testPreparedStatement(UserProtos.PreparedStatementHandle) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- TestPreparedStatementProvider - Class in org.apache.drill.exec.work.prepare
-
Tests for creating and executing prepared statements.
- TestPreparedStatementProvider() - Constructor for class org.apache.drill.exec.work.prepare.TestPreparedStatementProvider
-
- testPrettyPrintRecord() - Method in class org.apache.drill.exec.record.TestVectorContainer
-
- testPrintingMillis() - Method in class org.apache.drill.exec.vector.accessor.TestTimePrintMillis
-
- testPriorityAssignmentForStringsSignedMinMax() - Method in class org.apache.drill.exec.store.parquet.TestParquetReaderConfig
-
- testProbeEmpty() - Method in class org.apache.drill.exec.physical.impl.join.TestBuildSidePartitioningImpl
-
- testProbeEmpty() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testProbeTooBig() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testProbingAndPartitioningBuildAllInMemoryNoSpillFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testProbingAndPartitioningBuildAllInMemoryNoSpillNotFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testProbingAndPartitioningBuildAllInMemoryNoSpillWithHashFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testProbingAndPartitioningBuildAllInMemoryNoSpillWithHashNotFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testProbingAndPartitioningBuildAllInMemorySpillFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testProbingAndPartitioningBuildAllInMemorySpillNotFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testProbingAndPartitioningBuildAllInMemoryWithSpillFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testProbingAndPartitioningBuildAllInMemoryWithSpillNotFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testProbingAndPartitioningBuildNoneInMemoryFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testProbingAndPartitioningBuildNoneInMemoryNotFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testProbingAndPartitioningBuildSomeInMemoryFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testProbingAndPartitioningBuildSomeInMemoryNotFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestPostBuildCalculationsImpl
-
- testProfilesLimitPushDown() - Method in class org.apache.drill.exec.store.sys.TestSystemTable
-
- testProject() - Method in class org.apache.drill.exec.compile.TestLargeFileCompilation
-
- testProjectComplexOutput() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- testProjectDownOverUnionAllImplicitCasting() - Method in class org.apache.drill.TestUnionAll
-
- testProjectDownOverUnionDistinctImplicitCasting() - Method in class org.apache.drill.TestUnionDistinct
-
- TestProjectedTuple - Class in org.apache.drill.exec.physical.rowSet.impl
-
- TestProjectedTuple() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
- TestProjectEmitOutcome - Class in org.apache.drill.exec.physical.impl.project
-
- TestProjectEmitOutcome() - Constructor for class org.apache.drill.exec.physical.impl.project.TestProjectEmitOutcome
-
- testProjectEmpty() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testProjectEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.project.TestProjectEmitOutcome
-
Test that if empty input batch is received with OK_NEW_SCHEMA or EMIT outcome, then Project doesn't ignores
these empty batches and instead return them downstream with correct outcomes.
- testProjectFiltertPushDownOverUnionAll() - Method in class org.apache.drill.TestUnionAll
-
- testProjectFiltertPushDownOverUnionDistinct() - Method in class org.apache.drill.TestUnionDistinct
-
- testProjectFixedWidthImpl(boolean, int) - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
Tests BatchSizing of fixed-width transfers and new column creations in Project.
- testProjectFixedWidthNewColumn() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testProjectFixedWidthTransfer() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testProjectingByName() - Method in class org.apache.drill.exec.store.pcapng.TestPcapngRecordReader
-
- testProjectingMissColls() - Method in class org.apache.drill.exec.store.pcapng.TestPcapngRecordReader
-
- testProjectIntoScanWithNestedStarSubQuery() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- testProjectIntoScanWithSeveralNestedStarSubQueries() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- TestProjection(VectorSource, int) - Constructor for class org.apache.drill.exec.physical.impl.scan.project.TestRowBatchMerger.TestProjection
-
- testProjectionAll() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
- testProjectionDynamic() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderProjection
-
- testProjectionFromMultiLevelRepeatedList() - Method in class org.apache.drill.exec.expr.TestSchemaPathMaterialization
-
- testProjectionFromMultiLevelRepeatedListMap() - Method in class org.apache.drill.exec.expr.TestSchemaPathMaterialization
-
- testProjectionMapFieldAndMap() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
- testProjectionMapSubset() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
- testProjectionMultipleFiles() - Method in class org.apache.drill.exec.expr.TestSchemaPathMaterialization
-
- testProjectionNone() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
Test an empty projection which occurs in a
SELECT COUNT(*) query.
- testProjectionSimple() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
- testProjectionStatic() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderProjection
-
Test imposing a selection mask between the client and the underlying
vector container.
- testProjectionWholeMap() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
- testProjectMap() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testProjectNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.project.TestProjectEmitOutcome
-
Test to show if a non-empty batch is accompanied with EMIT outcome then Project operator produces output for
that batch and return the output using EMIT outcome.
- testProjectNonEmptyFirst_EmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.project.TestProjectEmitOutcome
-
Test to show that non-empty first batch produces output for that batch with OK_NEW_SCHEMA and later empty batch
with EMIT outcome is also passed through rather than getting ignored.
- testProjectNonEmptyFirst_EmptyOK_EmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.project.TestProjectEmitOutcome
-
Test to show if an empty batch is accompanied with OK outcome then that batch is ignored by Project operator and
it doesn't return anything instead call's next() to get another batch.
- testProjectPastFilterPastJoinPastJoinPushDown() - Method in class org.apache.drill.TestProjectPushDown
-
- testProjectPastFilterPastJoinPushDown() - Method in class org.apache.drill.TestProjectPushDown
-
- testProjectPastFilterPastJoinPushDownWhenItemsAreWithinNestedOperators() - Method in class org.apache.drill.TestProjectPushDown
-
- testProjectPastFilterPushDown() - Method in class org.apache.drill.TestProjectPushDown
-
- testProjectPastJoinPastFilterPastJoinPushDown() - Method in class org.apache.drill.TestProjectPushDown
-
- testProjectPastJoinPushDown() - Method in class org.apache.drill.TestProjectPushDown
-
- testProjectPushdown() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- TestProjectPushDown - Class in org.apache.drill
-
- TestProjectPushDown() - Constructor for class org.apache.drill.TestProjectPushDown
-
- testProjectPushDown() - Method in class org.apache.drill.TestProjectPushDown
-
- TestProjectPushDown.PushDownTestInstance - Class in org.apache.drill
-
- testProjectPushDownOverUnionAllWithoutProject() - Method in class org.apache.drill.TestUnionAll
-
- testProjectPushDownOverUnionAllWithProject() - Method in class org.apache.drill.TestUnionAll
-
- testProjectPushDownOverUnionDistinctWithoutProject() - Method in class org.apache.drill.TestUnionDistinct
-
- testProjectPushDownOverUnionDistinctWithProject() - Method in class org.apache.drill.TestUnionDistinct
-
- testProjectPushdownPastJoinWithJoinPushExpressions() - Method in class org.apache.drill.TestProjectPushDown
-
- testProjectPushDownProjectColumnReorderingAndAlias() - Method in class org.apache.drill.TestUnionAll
-
- testProjectPushDownProjectColumnReorderingAndAlias() - Method in class org.apache.drill.TestUnionDistinct
-
- testProjectPushPastWindow() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testProjectVariableWidthFunctions() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testProjectVariableWidthImpl(boolean, int, String) - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testProjectVariableWidthMixed() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
Test expression with transfer and new columns
- testProjectVariableWidthNewColumn() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testProjectVariableWidthTransfer() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testProjectWithComplexWritersAndEmitOutcome_EmptyFirstBatch() - Method in class org.apache.drill.exec.physical.impl.project.TestProjectEmitOutcome
-
Test to show that in cases with functions in project list whose output is complex types, if Project sees an EMIT
outcome then it fails.
- testProjectWithComplexWritersAndEmitOutcome_NonEmptyFirstBatch() - Method in class org.apache.drill.exec.physical.impl.project.TestProjectEmitOutcome
-
Test to show that in cases with functions in project list whose output is complex types, if Project sees an EMIT
outcome then it fails.
- testProjectWithExpressionPushDownOverUnionAll() - Method in class org.apache.drill.TestUnionAll
-
- testProjectWithExpressionPushDownOverUnionDistinct() - Method in class org.apache.drill.TestUnionDistinct
-
- TestProjectWithFunctions - Class in org.apache.drill
-
Test the optimizer plan in terms of projecting different functions e.g.
- TestProjectWithFunctions() - Constructor for class org.apache.drill.TestProjectWithFunctions
-
- testProjectWithOverflow() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderProjection
-
Verify that the projection code plays nice with vector overflow.
- testProjectZeroWidth() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- TestPromotableWriter - Class in org.apache.drill.exec.vector.complex.writer
-
- TestPromotableWriter() - Constructor for class org.apache.drill.exec.vector.complex.writer.TestPromotableWriter
-
- testPruneSameTableInJoin() - Method in class org.apache.drill.TestPartitionFilter
-
- testPruneSameTableInUnionAll() - Method in class org.apache.drill.TestPartitionFilter
-
- testPsdImage() - Method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- TestPStoreProviders - Class in org.apache.drill.exec.store.sys
-
- TestPStoreProviders() - Constructor for class org.apache.drill.exec.store.sys.TestPStoreProviders
-
- testPushDown(TestProjectPushDown.PushDownTestInstance) - Method in class org.apache.drill.TestProjectPushDown
-
- TestPushDownAndPruningForDecimal - Class in org.apache.drill.exec.store.parquet
-
- TestPushDownAndPruningForDecimal() - Constructor for class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForDecimal
-
- TestPushDownAndPruningForVarchar - Class in org.apache.drill.exec.store.parquet
-
- TestPushDownAndPruningForVarchar() - Constructor for class org.apache.drill.exec.store.parquet.TestPushDownAndPruningForVarchar
-
- TestPushDownAndPruningWithItemStar - Class in org.apache.drill.exec.store.parquet
-
- TestPushDownAndPruningWithItemStar() - Constructor for class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- testPushDownArray() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDownForComplexTypes
-
- testPushDownComplexBooleanColumn() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDownForComplexTypes
-
- testPushDownComplexIntColumn() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDownForComplexTypes
-
- testPushExpInJoinConditionInnerJoin() - Method in class org.apache.drill.TestExampleQueries
-
- testPushExpInJoinConditionLeftJoin() - Method in class org.apache.drill.TestExampleQueries
-
- testPushExpInJoinConditionRightJoin() - Method in class org.apache.drill.TestExampleQueries
-
- testPushExpInJoinConditionWhere() - Method in class org.apache.drill.TestExampleQueries
-
- testPushFilterDown() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testPushFilterInExprPastAgg() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testPushFilterPastAgg() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testPushFilterPastProjectWithFlatten() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlattenPlanning
-
- testPushFilterPastProjectWithFlattenNeg() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlattenPlanning
-
- testPushLimitPastUnionExchange() - Method in class org.apache.drill.exec.physical.impl.limit.TestLimitWithExchanges
-
- testPushProjectIntoScanWithComplexInFilter() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- testPushProjectIntoScanWithComplexInProject() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- testPushProjectIntoScanWithExpressionInFilter() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- testPushProjectIntoScanWithExpressionInProject() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- testPushProjectIntoScanWithGroupByClause() - Method in class org.apache.drill.exec.store.parquet.TestPushDownAndPruningWithItemStar
-
- testPutAndGetWorks() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- testPutAndGetWorksAntagonistacally() - Method in class org.apache.drill.exec.coord.zk.TestEphemeralStore
-
- testPutIfAbsentWhenAbsent() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- testPutIfAbsentWhenPresent() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- testPutWithMatchingVersion() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- testPutWithNonMatchingVersion() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- testQ6() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggr
-
- testQ7_1() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggr
-
- testQ7_2() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggr
-
- testQ7_3() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggr
-
- testQ8_1() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggr
-
- TestQueriesOnLargeFile - Class in org.apache.drill.exec
-
- TestQueriesOnLargeFile() - Constructor for class org.apache.drill.exec.TestQueriesOnLargeFile
-
- testQueryBrokenStorage() - Method in class org.apache.drill.exec.physical.impl.TestSchema
-
- testQueryConstExprEmptyJson() - Method in class org.apache.drill.exec.TestEmptyInputSql
-
Test with query against an empty file.
- testQueryEmptyCsv() - Method in class org.apache.drill.exec.TestEmptyInputSql
-
Test select * against empty csv file.
- testQueryEmptyCsvH() - Method in class org.apache.drill.exec.TestEmptyInputSql
-
Test select * against empty csv with empty header.
- testQueryEmptyJson() - Method in class org.apache.drill.exec.TestEmptyInputSql
-
Test with query against an empty file.
- testQueryGoodStorage() - Method in class org.apache.drill.exec.physical.impl.TestSchema
-
- testQueryGoodStorageWithDefaultSchema() - Method in class org.apache.drill.exec.physical.impl.TestSchema
-
- testQueryMapArrayEmptyJson() - Method in class org.apache.drill.exec.TestEmptyInputSql
-
- TestQueryMemoryAlloc - Class in org.apache.drill.exec.util
-
- TestQueryMemoryAlloc() - Constructor for class org.apache.drill.exec.util.TestQueryMemoryAlloc
-
- testQueryQualifiedStarColEmptyJson() - Method in class org.apache.drill.exec.TestEmptyInputSql
-
Test with query against an empty file.
- testQueryStarColEmptyJson() - Method in class org.apache.drill.exec.TestEmptyInputSql
-
Test with query against an empty file.
- testQueryWithCorruptedDates() - Method in class org.apache.drill.exec.physical.impl.writer.TestCorruptParquetDateCorrection
-
- testQueryWithNullValues() - Method in class org.apache.drill.TestExampleQueries
-
- testRadiansFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testRandom() - Method in class org.apache.drill.TestFunctionsQuery
-
- testRankWithGroupBy() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testRaw() - Method in class org.apache.drill.exec.store.log.TestLogReader
-
- testRawNoSchema() - Method in class org.apache.drill.exec.store.log.TestLogReader
-
- testRawUMNoSchema() - Method in class org.apache.drill.exec.store.log.TestLogReader
-
- testRead() - Method in class org.apache.drill.exec.TestQueriesOnLargeFile
-
- testReadBug_Drill_418() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testReadCompressed() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testReadCorruptDatesWithNullFilledColumns() - Method in class org.apache.drill.exec.physical.impl.writer.TestCorruptParquetDateCorrection
-
To fix some of the corrupted dates fixed as part of DRILL-4203 it requires
actually looking at the values stored in the file.
- testReadError_Drill_839() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testReadError_Drill_901() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testReadLargeParquetFileFromDFS() - Method in class org.apache.drill.exec.impersonation.TestImpersonationDisabledWithMiniDFS
-
When working on merging the Drill fork of parquet a bug was found that only manifested when
run on a cluster.
- testReadMixedOldAndNewBothReaders() - Method in class org.apache.drill.exec.physical.impl.writer.TestCorruptParquetDateCorrection
-
Test reading a directory full of parquet files with dates, some of which have corrupted values
due to DRILL-4203.
- testReadNewMetadataCacheFileOverOldAndNewFiles() - Method in class org.apache.drill.exec.physical.impl.writer.TestCorruptParquetDateCorrection
-
- testReadOldMetadataCacheFile() - Method in class org.apache.drill.exec.physical.impl.writer.TestCorruptParquetDateCorrection
-
- testReadOldMetadataCacheFileWithPruning() - Method in class org.apache.drill.exec.physical.impl.writer.TestCorruptParquetDateCorrection
-
- testReadOptions() - Method in class org.apache.drill.exec.store.parquet.TestParquetReaderConfig
-
- testReadPartitionedOnCorrectDates() - Method in class org.apache.drill.exec.physical.impl.writer.TestCorruptParquetDateCorrection
-
Test reading a directory full of partitioned parquet files with dates, these files have a drill version
number of "1.9.0-SNAPSHOT" and parquet-writer version number of "2" in their footers, so we can be certain
they do not have corruption.
- testReadRepeatedDecimals() - Method in class org.apache.drill.exec.store.parquet.TestParquetComplex
-
- testReadSf_100_supplier() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testReadSf_1_supplier() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testReadVoter() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testReadVoter() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testReAllocNullableFixedWidthVector() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- testReAllocNullableVariableWidthVector() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- testReAllocZeroSize() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestShortArrays
-
Test that a zero-length vector, on reAlloc, will default
to 256 bytes.
- TestRecordBatchSizer - Class in org.apache.drill.exec.record
-
- TestRecordBatchSizer() - Constructor for class org.apache.drill.exec.record.TestRecordBatchSizer
-
- TestRecordIterator - Class in org.apache.drill.exec.record
-
- TestRecordIterator() - Constructor for class org.apache.drill.exec.record.TestRecordIterator
-
- testRecursiveDocuments() - Method in class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- testRefreshMetadata() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- testRegexpMatches() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testRegexpMatchesNonAscii() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testRegexpReplace() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testRegexpReplace() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testRegistrationFailDuringRegistryUpdate() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testRegularTopNWithEmptyDataSet() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNEmitOutcome
-
- testRegularTopNWithEmptyDataSet() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
- testRegularTopNWithEmptyDataSetAndNoneOutcome() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNEmitOutcome
-
- testRelLogicalJoinOrder(String, String...) - Static method in class org.apache.drill.PlanTestBase
-
This method will take a SQL string statement, get the LOGICAL plan in Optiq
RelNode format.
- testRelLogicalPlanLevDigest(String, String...) - Static method in class org.apache.drill.PlanTestBase
-
This method will take a SQL string statement, get the LOGICAL plan in Optiq
RelNode format.
- testRelLogicalPlanLevExplain(String, String...) - Static method in class org.apache.drill.PlanTestBase
-
This method will take a SQL string statement, get the LOGICAL plan in Optiq
RelNode format.
- testRelPhysicalJoinOrder(String, String...) - Static method in class org.apache.drill.PlanTestBase
-
This method will take a SQL string statement, get the LOGICAL plan in Optiq
RelNode format.
- testRelPhysicalPlanLevDigest(String, String...) - Static method in class org.apache.drill.PlanTestBase
-
This method will take a SQL string statement, get the PHYSICAL plan in
Optiq RelNode format.
- testRelPhysicalPlanLevExplain(String, String...) - Static method in class org.apache.drill.PlanTestBase
-
This method will take a SQL string statement, get the PHYSICAL plan in
Optiq RelNode format.
- testRemoteAndLocalConnectionManager() - Method in class org.apache.drill.exec.rpc.control.ConnectionManagerRegistryTest
-
- testRemoteConnectionManager() - Method in class org.apache.drill.exec.rpc.control.ConnectionManagerRegistryTest
-
- testRemoteConnectionManager_differentAddress() - Method in class org.apache.drill.exec.rpc.control.ConnectionManagerRegistryTest
-
- testRemoteConnectionManager_differentControlPort() - Method in class org.apache.drill.exec.rpc.control.ConnectionManagerRegistryTest
-
- testRemoteDistributed() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- testRemoveJar() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- testRenameProjectEmptyDirectory() - Method in class org.apache.drill.exec.TestEmptyInputSql
-
- testRenameProjectEmptyJson() - Method in class org.apache.drill.exec.TestEmptyInputSql
-
- testReordering() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaSmoothing
-
Preserve the prior schema if table is a subset.
- testRepeated() - Method in class org.apache.drill.exec.fn.impl.TestRepeatedFunction
-
- testRepeated() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- TestRepeated - Class in org.apache.drill.exec.vector.complex.writer
-
- TestRepeated() - Constructor for class org.apache.drill.exec.vector.complex.writer.TestRepeated
-
- testRepeated() - Method in class org.apache.drill.test.rowSet.test.TestHyperVectorReaders
-
Test an array to test the indirection from the repeated vector
to the array offsets vector and the array values vector.
- testRepeatedBadArrayOffset() - Method in class org.apache.drill.exec.physical.impl.validate.TestBatchValidator
-
- testRepeatedBadValueOffset() - Method in class org.apache.drill.exec.physical.impl.validate.TestBatchValidator
-
- testRepeatedBool() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testRepeatedColumn() - Method in class org.apache.drill.exec.store.parquet.TestComplexColumnInSchema
-
- testRepeatedColumnMatching() - Method in class org.apache.drill.TestFrameworkTest
-
- testRepeatedContains() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testRepeatedContainsForWildCards() - Method in class org.apache.drill.exec.fn.impl.TestNewSimpleRepeatedFunctions
-
- testRepeatedCount() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testRepeatedDecimalWithGroupBy() - Method in class org.apache.drill.exec.physical.impl.agg.TestAggWithAnyValue.TestAggWithAnyValueSingleBatch
-
- testRepeatedDouble() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testRepeatedFixedWidthColumn() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
- TestRepeatedFunction - Class in org.apache.drill.exec.fn.impl
-
- TestRepeatedFunction() - Constructor for class org.apache.drill.exec.fn.impl.TestRepeatedFunction
-
- testRepeatedIntVector() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- testRepeatedJson() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- TestRepeatedListAccessors - Class in org.apache.drill.test.rowSet.test
-
Test the basics of repeated list support in the schema builder,
column writers and column readers.
- TestRepeatedListAccessors() - Constructor for class org.apache.drill.test.rowSet.test.TestRepeatedListAccessors
-
- testRepeatedListEmptyBetween() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testRepeatedListEmptyFirst() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testRepeatedListEmptyLast() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testRepeatedListInMap() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
Verify that the repeated list-in-map plumbing works.
- testRepeatedListInRepeatedList() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
Test that repeated lists can be nested to provide 3D or
higher dimensions.
- testRepeatedListInRow() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
Test building a repeated list in the top-level schema.
- testRepeatedListInUnion() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
- testRepeatedListProjectionPastJoin() - Method in class org.apache.drill.TestExampleQueries
-
- testRepeatedListShortcut() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
- testRepeatedLong() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testRepeatedMap() - Method in class org.apache.drill.test.rowSet.test.TestHyperVectorReaders
-
- testRepeatedMapColumn() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
- testRepeatedMapEmptyBetween() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testRepeatedMapEmptyFirst() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testRepeatedMapEmptyLast() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testRepeatedMapStructure() - Method in class org.apache.drill.test.rowSet.test.RowSetTest
-
- TestRepeatedReaders - Class in org.apache.drill.exec
-
- TestRepeatedReaders() - Constructor for class org.apache.drill.exec.TestRepeatedReaders
-
- testRepeatedScalarEmptyFirst() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testRepeatedScalarEmptyInBetween() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testRepeatedScalarEmptyLast() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testRepeatedVarChar() - Method in class org.apache.drill.vector.TestFillEmpties
-
- testRepeatedVariableWidthColumn() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
- testReplace() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testRequestQueryStatus() - Method in class org.apache.drill.exec.rpc.control.TestLocalControlConnectionManager
-
Verify that RequestQueryStatus is handled correctly using ControlTunnel with LocalControlConnectionManager
- testRequired() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaSmoothing
-
Can't preserve the prior schema if it had required columns
where the new schema has no columns.
- testRequired() - Method in class org.apache.drill.test.rowSet.test.TestHyperVectorReaders
-
Test the simplest case: a top-level required vector.
- testRequired() - Method in class org.apache.drill.test.rowSet.test.TestIndirectReaders
-
Simplest case: required reader, uses the index
directly.
- testRequiredDecimal28() - Method in class org.apache.drill.exec.store.parquet2.TestDrillParquetReader
-
- testRequiredDecimal38() - Method in class org.apache.drill.exec.store.parquet2.TestDrillParquetReader
-
- testRequiredFixedWidthColumn() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
Test a fixed-width, primitive, required column.
- testRequiredVariableWidthColumn() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
- testReRegisterTheSameJarWithDifferentContent() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testResizing() - Method in class org.apache.drill.exec.util.TestArrayWrappedIntIntMap
-
- testResolveTemporaryTableWithPartialSchema() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- TestResourceLeak - Class in org.apache.drill.exec.testing
-
- TestResourceLeak() - Constructor for class org.apache.drill.exec.testing.TestResourceLeak
-
- TestResourceLeak.Leak - Class in org.apache.drill.exec.testing
-
- testRestApi() - Method in class org.apache.drill.test.TestGracefulShutdown
-
- testRestApiShutdown() - Method in class org.apache.drill.test.TestGracefulShutdown
-
- testRestartRow() - Method in class org.apache.drill.test.rowSet.test.TestFixedWidthWriter
-
- testRestartRow() - Method in class org.apache.drill.test.rowSet.test.TestOffsetVectorWriter
-
- testRestartRow() - Method in class org.apache.drill.test.rowSet.test.TestVariableWidthWriter
-
- TestResultSet() - Constructor for class org.apache.drill.test.BaseTestQuery.TestResultSet
-
Deprecated.
- TestResultSet(List<QueryDataBatch>) - Constructor for class org.apache.drill.test.BaseTestQuery.TestResultSet
-
Deprecated.
- TestResultSetLoaderEmptyProject - Class in org.apache.drill.exec.physical.rowSet.impl
-
- TestResultSetLoaderEmptyProject() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderEmptyProject
-
- TestResultSetLoaderLimits - Class in org.apache.drill.exec.physical.rowSet.impl
-
Tests of the row limit functionality of the result set loader.
- TestResultSetLoaderLimits() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderLimits
-
- TestResultSetLoaderMapArray - Class in org.apache.drill.exec.physical.rowSet.impl
-
Test map array support in the result set loader.
- TestResultSetLoaderMapArray() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMapArray
-
- TestResultSetLoaderMaps - Class in org.apache.drill.exec.physical.rowSet.impl
-
Test (non-array) map support in the result set loader and related classes.
- TestResultSetLoaderMaps() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderMaps
-
- TestResultSetLoaderOmittedValues - Class in org.apache.drill.exec.physical.rowSet.impl
-
- TestResultSetLoaderOmittedValues() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderOmittedValues
-
- TestResultSetLoaderOverflow - Class in org.apache.drill.exec.physical.rowSet.impl
-
Exercise the vector overflow functionality for the result set loader.
- TestResultSetLoaderOverflow() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderOverflow
-
- TestResultSetLoaderProjection - Class in org.apache.drill.exec.physical.rowSet.impl
-
Test of the basics of the projection mechanism.
- TestResultSetLoaderProjection() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderProjection
-
- TestResultSetLoaderProtocol - Class in org.apache.drill.exec.physical.rowSet.impl
-
Tests of the overall result set loader protocol focusing on which operations
are valid in each state, basics of column lookup, basics of adding columns
and so on.
- TestResultSetLoaderProtocol() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderProtocol
-
- TestResultSetLoaderRepeatedList - Class in org.apache.drill.exec.physical.rowSet.impl
-
Tests repeated list support.
- TestResultSetLoaderRepeatedList() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderRepeatedList
-
- TestResultSetLoaderTorture - Class in org.apache.drill.exec.physical.rowSet.impl
-
Runs a worst-case scenario test that combines aspects of all
previous tests.
- TestResultSetLoaderTorture() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderTorture
-
- TestResultSetLoaderTorture.ReadState - Class in org.apache.drill.exec.physical.rowSet.impl
-
- TestResultSetLoaderUnions - Class in org.apache.drill.exec.physical.rowSet.impl
-
Tests the result set loader support for union vectors.
- TestResultSetLoaderUnions() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderUnions
-
- TestResultSetSchemaChange - Class in org.apache.drill.exec.physical.rowSet.impl
-
- TestResultSetSchemaChange() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TestResultSetSchemaChange
-
- TestResultVectorCache - Class in org.apache.drill.exec.physical.rowSet.impl
-
- TestResultVectorCache() - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TestResultVectorCache
-
- testRetrieveInternalOption() - Method in class org.apache.drill.exec.server.rest.StatusResourcesTest
-
- testRetrievePublicOption() - Method in class org.apache.drill.exec.server.rest.StatusResourcesTest
-
- testReverse() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- TestReverseImplicitCast - Class in org.apache.drill.exec.physical.impl
-
- TestReverseImplicitCast() - Constructor for class org.apache.drill.exec.physical.impl.TestReverseImplicitCast
-
- testReverseLongVarChars() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testRight() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testRightHashJoinEmptyBoth() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testRightJoinWithMap() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinAdvanced
-
- testRightMergeJoinEmptyBoth() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testRightOuterHashJoin() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testRightOuterHashJoinSpill() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinSpill
-
- testRollover() - Method in class org.apache.drill.test.rowSet.test.TestFixedWidthWriter
-
The rollover method is used during vector overflow.
- testRollover() - Method in class org.apache.drill.test.rowSet.test.TestOffsetVectorWriter
-
The rollover method is used during vector overflow.
- testRollover() - Method in class org.apache.drill.test.rowSet.test.TestVariableWidthWriter
-
The rollover method is used during vector overflow.
- testRolloverWithEmpties() - Method in class org.apache.drill.test.rowSet.test.TestFixedWidthWriter
-
Simulate the case in which the tail end of an overflow
batch has empties.
- testRolloverWithEmpties() - Method in class org.apache.drill.test.rowSet.test.TestOffsetVectorWriter
-
Simulate the case in which the tail end of an overflow
batch has empties.
- testRolloverWithEmpties() - Method in class org.apache.drill.test.rowSet.test.TestVariableWidthWriter
-
Simulate the case in which the tail end of an overflow
batch has empties.
- testRootMetadataFileIsAbsent() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testRoundDecimalFunction() - Method in class org.apache.drill.TestFunctionsQuery
-
- testRoundFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testRoundUpPowerOf2() - Method in class org.apache.drill.exec.physical.impl.join.TestBatchSizePredictorImpl
-
- testRoundWithOneParam() - Method in class org.apache.drill.TestFunctionsQuery
-
- testRoundWithParamFunction() - Method in class org.apache.drill.TestFunctionsQuery
-
- testRoundWithScaleDecimalFunction() - Method in class org.apache.drill.TestFunctionsQuery
-
- testRounUpNonPowerOf2ToPowerOf2() - Method in class org.apache.drill.exec.physical.impl.join.TestBatchSizePredictorImpl
-
- testRow_NumberInView() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testRowBasics() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
- TestRowBatchMerger - Class in org.apache.drill.exec.physical.impl.scan.project
-
Test the row batch merger by merging two batches.
- TestRowBatchMerger() - Constructor for class org.apache.drill.exec.physical.impl.scan.project.TestRowBatchMerger
-
- TestRowBatchMerger.RowSetSource - Class in org.apache.drill.exec.physical.impl.scan.project
-
- TestRowBatchMerger.TestProjection - Class in org.apache.drill.exec.physical.impl.scan.project
-
- testRowBounds() - Method in class org.apache.drill.test.rowSet.test.RowSetTest
-
Test filling a row set up to the maximum number of rows.
- testRowLimit() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderLimits
-
Verify that the writer stops when reaching the row limit.
- testRowPreBuilt() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
- TestRowSetComparison - Class in org.apache.drill.test.rowSet
-
- TestRowSetComparison() - Constructor for class org.apache.drill.test.rowSet.TestRowSetComparison
-
- testRpad() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testRpadTwoArgConvergeToRpad() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testRtrim() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testRtrimOneArgConvergeToRtrim() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testRunAndLog(DrillClient, UserBitShared.QueryType, String) - Static method in class org.apache.drill.test.QueryTestUtil
-
Execute a SQL query, and log the results.
- testRunAndLog(DrillClient, String) - Static method in class org.apache.drill.test.QueryTestUtil
-
Execute one or more queries separated by semicolons, and log the results.
- testRunAndLog(DrillClient, String, Object...) - Static method in class org.apache.drill.test.QueryTestUtil
-
Execute one or more queries separated by semicolons, and log the results, with the option to
add formatted arguments to the query string.
- testRunAndOutput(DrillClient, String, boolean) - Static method in class org.apache.drill.test.QueryTestUtil
-
Execute one or more queries separated by semicolons, and output the results.
- testRunAndPrint(UserBitShared.QueryType, String) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- testRunAndPrint(DrillClient, UserBitShared.QueryType, String) - Static method in class org.apache.drill.test.QueryTestUtil
-
Execute a SQL query, and print the results.
- testRunAndPrint(DrillClient, String) - Static method in class org.apache.drill.test.QueryTestUtil
-
Execute one or more queries separated by semicolons, and print the results.
- testRunAndPrint(DrillClient, String, Object...) - Static method in class org.apache.drill.test.QueryTestUtil
-
Execute one or more queries separated by semicolons, and print the results, with the option to
add formatted arguments to the query string.
- testRunAndReturn(UserBitShared.QueryType, Object) - Method in class org.apache.drill.test.BaseTestQuery.ClassicTestServices
-
Deprecated.
- testRunAndReturn(UserBitShared.QueryType, Object) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- testRunAndReturn(UserBitShared.QueryType, Object) - Method in class org.apache.drill.test.ClusterFixture.FixtureTestServices
-
- testRunAndReturn(UserBitShared.QueryType, Object) - Method in interface org.apache.drill.test.DrillTestWrapper.TestServices
-
- testSameSchemas() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaSmoothing
-
The prior and table schemas are identical.
- TestScalarAccessors - Class in org.apache.drill.test.rowSet.test
-
Verify that simple scalar (non-repeated) column readers
and writers work as expected.
- TestScalarAccessors() - Constructor for class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testScalarAggAndFilterCorrelatedSubquery() - Method in class org.apache.drill.TestCorrelation
-
- testScalarAggCorrelatedSubquery() - Method in class org.apache.drill.TestCorrelation
-
- testScalarArrayStructure() - Method in class org.apache.drill.test.rowSet.test.RowSetTest
-
Test a record with a top level array.
- testScalarList() - Method in class org.apache.drill.test.rowSet.test.TestHyperVectorReaders
-
- testScalarList() - Method in class org.apache.drill.test.rowSet.test.TestVariantAccessors
-
Test a scalar list.
- testScalarStructure() - Method in class org.apache.drill.test.rowSet.test.RowSetTest
-
Test the simplest constructs: a row with top-level scalar
columns.
- testScalarVariant() - Method in class org.apache.drill.test.rowSet.test.TestVariantAccessors
-
Test a variant (AKA "union vector") at the top level, using
just scalar values.
- testScanBatchChecked() - Method in class org.apache.drill.TestOperatorDump
-
- TestScanLevelProjection - Class in org.apache.drill.exec.physical.impl.scan.project
-
Test the level of projection done at the level of the scan as a whole;
before knowledge of table "implicit" columns or the specific table schema.
- TestScanLevelProjection() - Constructor for class org.apache.drill.exec.physical.impl.scan.project.TestScanLevelProjection
-
- TestSchema - Class in org.apache.drill.exec.physical.impl
-
- TestSchema() - Constructor for class org.apache.drill.exec.physical.impl.TestSchema
-
- testSchema2DBatch() - Method in class org.apache.drill.test.rowSet.test.TestRepeatedListAccessors
-
Test the case of a simple 2D array.
- testSchema2DMetadata() - Method in class org.apache.drill.test.rowSet.test.TestRepeatedListAccessors
-
Test a 2D array using metadata.
- testSchema2DVector() - Method in class org.apache.drill.test.rowSet.test.TestRepeatedListAccessors
-
- testSchema2DWriterReader() - Method in class org.apache.drill.test.rowSet.test.TestRepeatedListAccessors
-
- testSchema3DBatch() - Method in class org.apache.drill.test.rowSet.test.TestRepeatedListAccessors
-
- testSchema3DMetadata() - Method in class org.apache.drill.test.rowSet.test.TestRepeatedListAccessors
-
- testSchema3DVector() - Method in class org.apache.drill.test.rowSet.test.TestRepeatedListAccessors
-
- testSchema3DWriterReader() - Method in class org.apache.drill.test.rowSet.test.TestRepeatedListAccessors
-
- TestSchemaBuilder - Class in org.apache.drill.test.rowSet.test
-
The schema builder for tests has grown complex to handle maps, unions,
lists and repeated lists.
- TestSchemaBuilder() - Constructor for class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
- TestSchemaCaseInsensitivity - Class in org.apache.drill.exec.sql
-
- TestSchemaCaseInsensitivity() - Constructor for class org.apache.drill.exec.sql.TestSchemaCaseInsensitivity
-
- testSchemaChange() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
- testSchemaChange() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testSchemaChange() - Method in class org.apache.drill.exec.record.vector.TestLoad
-
- TestSchemaChange - Class in org.apache.drill
-
- TestSchemaChange() - Constructor for class org.apache.drill.TestSchemaChange
-
- testSchemaChangeFirstBatch() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetSchemaChange
-
Test the case where the schema changes in the first batch.
- testSchemaChangeOnMultipleColumns() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testSchemaChangeOnNonUnnestColumn() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
Test where multiple files are used to trigger schema change for Lateral and Unnest
- testSchemaChangeOnNonUnnestColumn_InMultilevelCase() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testSchemaChangeOnUnnestColumn() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testSchemaChangeOnUnnestColumn_InMultilevelCase() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testSchemaChangeWithOverflow() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetSchemaChange
-
Test a schema change on the row that overflows.
- testSchemaElementsMap() - Method in class org.apache.drill.exec.store.parquet.TestParquetReaderUtility
-
- testSchemaEOF() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
Simulate reaching EOF when trying to create the schema.
- testSchemaExpression() - Method in class org.apache.drill.exec.expr.ExpressionTest
-
- testSchemaForParallelizedStarOrderBy() - Method in class org.apache.drill.TestStarQueries
-
- testSchemaForStarOrderByLimit() - Method in class org.apache.drill.TestStarQueries
-
- testSchemaIncompleteBatch() - Method in class org.apache.drill.test.rowSet.test.TestRepeatedListAccessors
-
Test the intermediate case in which a repeated list
does not yet have child type.
- testSchemaIncompleteMetadata() - Method in class org.apache.drill.test.rowSet.test.TestRepeatedListAccessors
-
- TestSchemaLevelProjection - Class in org.apache.drill.exec.physical.impl.scan.project
-
"Schema level projection" describes one side of the projection
mechanism.
- TestSchemaLevelProjection() - Constructor for class org.apache.drill.exec.physical.impl.scan.project.TestSchemaLevelProjection
-
- TestSchemaNotFoundException - Class in org.apache.drill.exec.store.dfs
-
- TestSchemaNotFoundException() - Constructor for class org.apache.drill.exec.store.dfs.TestSchemaNotFoundException
-
- testSchemaNotFoundForWrongStoragePlgn() - Method in class org.apache.drill.exec.store.dfs.TestSchemaNotFoundException
-
- testSchemaNotFoundForWrongWorkspace() - Method in class org.apache.drill.exec.store.dfs.TestSchemaNotFoundException
-
- testSchemaNotFoundForWrongWorkspaceUsingDefaultWorkspace() - Method in class org.apache.drill.exec.store.dfs.TestSchemaNotFoundException
-
- TestSchemaPathMaterialization - Class in org.apache.drill.exec.expr
-
- TestSchemaPathMaterialization() - Constructor for class org.apache.drill.exec.expr.TestSchemaPathMaterialization
-
- TestSchemaSmoothing - Class in org.apache.drill.exec.physical.impl.scan.project
-
Tests schema smoothing at the schema projection level.
- TestSchemaSmoothing() - Constructor for class org.apache.drill.exec.physical.impl.scan.project.TestSchemaSmoothing
-
- testSchemaTestBuilderSetInvalidBaselineColumns() - Method in class org.apache.drill.TestFrameworkTest
-
- testSchemaTestBuilderSetInvalidBaselineRecords() - Method in class org.apache.drill.TestFrameworkTest
-
- testSchemaTestBuilderSetInvalidBaselineValues() - Method in class org.apache.drill.TestFrameworkTest
-
- testScope() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testScopeAlterSession() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testScopeAlterSystem() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testScopeSession() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testScopeSystem() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testSelectAllWithPartitionColumn() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testSelectColumnRead() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
Tests the attribute in a scan node to limit the columns read by a scan.
- testSelectEmptyNoCache() - Method in class org.apache.drill.exec.store.parquet.TestParquetGroupScan
-
- testSelectEmptyWithCache() - Method in class org.apache.drill.exec.store.parquet.TestParquetGroupScan
-
- testSelectFromListWithCase() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testSelectFromTemporaryTableWithAndWithoutLeadingSlash() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testSelectionVectorRemoval() - Method in class org.apache.drill.exec.physical.impl.svremover.TestSVRemover
-
- TestSelectivity - Class in org.apache.drill
-
- TestSelectivity() - Constructor for class org.apache.drill.TestSelectivity
-
- testSelectPartitionColumnOnly() - Method in class org.apache.drill.TestStarQueries
-
- testSelectStartSubQueryJoinWithWhereClause() - Method in class org.apache.drill.TestStarQueries
-
- testSelectStarWithUnionType() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testSelectStatement() - Method in class org.apache.drill.exec.sql.TestSchemaCaseInsensitivity
-
- testSelectWithJoinOnTemporaryTables() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testSelectWithLimit() - Method in class org.apache.drill.TestAltSortQueries
-
- testSelectWithLimit() - Method in class org.apache.drill.TestExampleQueries
-
- testSelectWithLimit2() - Method in class org.apache.drill.TestExampleQueries
-
- testSelectWithLimitOffset() - Method in class org.apache.drill.TestAltSortQueries
-
- TestSelectWithOption - Class in org.apache.drill
-
- TestSelectWithOption() - Constructor for class org.apache.drill.TestSelectWithOption
-
- testSelectWithoutRecursion() - Method in class org.apache.drill.exec.store.ischema.TestFilesTable
-
- testSelectWithRecursion() - Method in class org.apache.drill.exec.store.ischema.TestFilesTable
-
- testSelLeftStarJoin() - Method in class org.apache.drill.TestStarQueries
-
- testSelRightStarJoin() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarAmbiguousJoin() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarBothSideJoin() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarCommaSameColumnRepeated() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarDifferentColumnOrder() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarJoin() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarJoinSameColName() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarJoinSchemaWithSchemaLess() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarMultipleStars() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarMultipleStarsRegularColumnAsAlias() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarOrderBy() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarOrderByLimit() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarPlusRegCol() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarRegColConstJoin() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarSubQJoin() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarSubQJson2() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarSubQNoPrefix() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarSubQPrefix() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarSubQSchemaTable() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarWhereOrderBy() - Method in class org.apache.drill.TestStarQueries
-
- testSelStarWithAdditionalColumnLimit() - Method in class org.apache.drill.TestStarQueries
-
- TestSemiJoin - Class in org.apache.drill.exec.physical.impl.join
-
- TestSemiJoin() - Constructor for class org.apache.drill.exec.physical.impl.join.TestSemiJoin
-
- testSequenceFile() - Method in class org.apache.drill.exec.store.FormatPluginSerDeTest
-
- TestSequenceFileReader - Class in org.apache.drill.exec.store.sequencefile
-
- TestSequenceFileReader() - Constructor for class org.apache.drill.exec.store.sequencefile.TestSequenceFileReader
-
- testSequenceFileReader() - Method in class org.apache.drill.exec.store.sequencefile.TestSequenceFileReader
-
- testSerializedDeserialize() - Method in class org.apache.drill.exec.TestOpSerialization
-
- testServerMeta() - Method in class org.apache.drill.exec.work.metadata.TestServerMetaProvider
-
- TestServerMetaProvider - Class in org.apache.drill.exec.work.metadata
-
Tests for server metadata provider APIs.
- TestServerMetaProvider() - Constructor for class org.apache.drill.exec.work.metadata.TestServerMetaProvider
-
- testSessionIdUDFWithTwoConnections() - Method in class org.apache.drill.exec.client.DrillClientSystemTest
-
- testSessionOption() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testSessionPrecedence() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testSetUp() - Static method in class org.apache.drill.exec.client.ConnectTriesPropertyTestClusterBits
-
- testSetup() - Method in class org.apache.drill.exec.DrillSeparatePlanningTest
-
- testSeveralExistsCorrelateSubquery() - Method in class org.apache.drill.TestCorrelation
-
- TestShortArrays - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
DRILL-5804.
- TestShortArrays() - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.TestShortArrays
-
- testShouldFailSimpleUnionNonNullSchema_StarQuery() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testShowFilesForDefaultSchema() - Method in class org.apache.drill.exec.store.ischema.TestFilesTable
-
- testShowFilesForSpecificDirectory() - Method in class org.apache.drill.exec.store.ischema.TestFilesTable
-
- testShowFilesInWSWithNoPermissionsForQueryUser() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- testShowFilesInWSWithOtherPermissionsForQueryUser() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- testShowFilesInWSWithUserAndGroupPermissionsForQueryUser() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- testShowFilesWithInCondition() - Method in class org.apache.drill.exec.store.ischema.TestFilesTable
-
- testShowFilesWithPartialUseClause() - Method in class org.apache.drill.exec.store.ischema.TestFilesTable
-
- testShowFilesWithUseClause() - Method in class org.apache.drill.exec.store.ischema.TestFilesTable
-
- testShowSchemas() - Method in class org.apache.drill.exec.sql.TestSchemaCaseInsensitivity
-
- testShowSchemasAsUser1() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- testShowSchemasAsUser2() - Method in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- testShowTables() - Method in class org.apache.drill.exec.sql.TestSchemaCaseInsensitivity
-
- testSignFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testSignFunction() - Method in class org.apache.drill.TestFunctionsQuery
-
- testSimilar() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testSimilar() - Method in class org.apache.drill.TestExampleQueries
-
- testSimilarEscape() - Method in class org.apache.drill.TestExampleQueries
-
- testSimple() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testSimple() - Method in class org.apache.drill.exec.util.TestArrayWrappedIntIntMap
-
- testSimpleAndArray() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
- testSimpleArraySchema_NoNullValues() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testSimpleArraySchema_StarQuery() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- TestSimpleCastFunctions - Class in org.apache.drill.exec.sql
-
- TestSimpleCastFunctions() - Constructor for class org.apache.drill.exec.sql.TestSimpleCastFunctions
-
- testSimpleColumn() - Method in class org.apache.drill.exec.store.parquet.TestComplexColumnInSchema
-
- testSimpleColumns() - Method in class org.apache.drill.exec.store.parquet.TestComplexColumnInSchema
-
- testSimpleDecimal() - Method in class org.apache.drill.exec.physical.impl.TestDecimal
-
- testSimpleDecimalArithmetic() - Method in class org.apache.drill.exec.physical.impl.TestDecimal
-
- testSimpleDecimalMathFunc() - Method in class org.apache.drill.exec.physical.impl.TestDecimal
-
- testSimpleDups() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
- testSimpleEnumSchema_NoNullValues() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testSimpleEnumSchema_StarQuery() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- TestSimpleExternalSort - Class in org.apache.drill.exec.physical.impl.xsort
-
- TestSimpleExternalSort() - Constructor for class org.apache.drill.exec.physical.impl.xsort.TestSimpleExternalSort
-
- TestSimpleFilter - Class in org.apache.drill.exec.physical.impl.filter
-
- TestSimpleFilter() - Constructor for class org.apache.drill.exec.physical.impl.filter.TestSimpleFilter
-
- testSimpleFlat() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestRowBatchMerger
-
- TestSimpleFragmentRun - Class in org.apache.drill.exec.physical.impl
-
- TestSimpleFragmentRun() - Constructor for class org.apache.drill.exec.physical.impl.TestSimpleFragmentRun
-
- TestSimpleFunctions - Class in org.apache.drill.exec.physical.impl
-
- TestSimpleFunctions() - Constructor for class org.apache.drill.exec.physical.impl.TestSimpleFunctions
-
- testSimpleHashAgg() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- testSimpleHashAgg() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testSimpleHashAggrSpill() - Method in class org.apache.drill.exec.physical.impl.agg.TestHashAggrSpill
-
Test "normal" spilling: Only 2 (or 3) partitions (out of 4) would require spilling
("normal spill" means spill-cycle = 1 )
- testSimpleHashJoin() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- testSimpleHashJoinSpill() - Method in class org.apache.drill.exec.physical.impl.join.TestHashJoinSpill
-
- testSimpleIterator() - Method in class org.apache.drill.exec.record.TestRecordIterator
-
- testSimpleJson() - Method in class org.apache.drill.exec.physical.unit.TestMiniPlan
-
- TestSimpleLimit - Class in org.apache.drill.exec.physical.impl.limit
-
- TestSimpleLimit() - Constructor for class org.apache.drill.exec.physical.impl.limit.TestSimpleLimit
-
- testSimpleList() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderUnions
-
Test for the case of a list defined to contain exactly one type.
- testSimpleListDynamic() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderUnions
-
Test a simple list created dynamically at load time.
- testSimpleListMultiTypes() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderUnions
-
Try to create a simple (non-expandable) list while specifying
two types.
- testSimpleListNoTypes() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderUnions
-
Try to create a simple (non-expandable) list without
giving a member type.
- testSimpleLogicalIntTypes1() - Method in class org.apache.drill.exec.store.parquet.TestParquetLogicalTypes
-
- testSimpleLogicalIntTypes2() - Method in class org.apache.drill.exec.store.parquet.TestParquetLogicalTypes
-
- testSimpleLogicalIntTypes3() - Method in class org.apache.drill.exec.store.parquet.TestParquetLogicalTypes
-
- testSimpleLogicalIntTypes4() - Method in class org.apache.drill.exec.store.parquet.TestParquetLogicalTypes
-
- testSimpleMapProject() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaLevelProjection
-
Simple map project.
- testSimpleMergeJoin() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- testSimpleMergingReceiver() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- testSimpleNestedSchema_NoNullValues() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testSimpleNestedSchema_StarQuery() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testSimpleParquetScan() - Method in class org.apache.drill.exec.physical.unit.TestMiniPlan
-
- testSimplePrimitiveSchema_NoColumnsExistInTheSchema() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testSimplePrimitiveSchema_NoNullValues() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testSimplePrimitiveSchema_OneExistAndOneDoesNotExistInTheSchema() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testSimplePrimitiveSchema_SelectColumnSubset() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testSimplePrimitiveSchema_StarQuery() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testSimpleProject() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- TestSimpleProjection - Class in org.apache.drill.exec.physical.impl.project
-
- TestSimpleProjection() - Constructor for class org.apache.drill.exec.physical.impl.project.TestSimpleProjection
-
- testSimpleProjectPastJoinPastFilterPastJoinPushDown() - Method in class org.apache.drill.TestProjectPushDown
-
- testSimpleQuery() - Method in class org.apache.drill.exec.impersonation.TestImpersonationDisabledWithMiniDFS
-
- testSimpleQuery() - Method in class org.apache.drill.exec.store.parquet.TestVarlenDecimal
-
- testSimpleQueryDrill4704Fix() - Method in class org.apache.drill.exec.store.parquet.TestFixedlenDecimal
-
- testSimpleQueryWithCast() - Method in class org.apache.drill.exec.store.parquet.TestFixedlenDecimal
-
- TestSimpleRepeatedFunctions - Class in org.apache.drill.exec.expr.fn.impl
-
- TestSimpleRepeatedFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.TestSimpleRepeatedFunctions
-
- testSimpleReserveMemoryCalculationHash() - Method in class org.apache.drill.exec.physical.impl.join.TestBuildSidePartitioningImpl
-
- testSimpleReserveMemoryCalculationNoHashFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestBuildSidePartitioningImpl
-
- testSimpleReserveMemoryCalculationNoHashNotFirstCycle() - Method in class org.apache.drill.exec.physical.impl.join.TestBuildSidePartitioningImpl
-
- TestSimpleSort - Class in org.apache.drill.exec.physical.impl.sort
-
- TestSimpleSort() - Constructor for class org.apache.drill.exec.physical.impl.sort.TestSimpleSort
-
- testSimpleStreamAgg() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- TestSimpleUnion - Class in org.apache.drill.exec.physical.impl.union
-
- TestSimpleUnion() - Constructor for class org.apache.drill.exec.physical.impl.union.TestSimpleUnion
-
- testSimpleUnionSchema_StarQuery() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- testSinFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testSingleBatch() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl
-
Degenerate case: two (unsorted) rows in single batch
- TestSingleBroadcastExchangeWithTwoScans() - Method in class org.apache.drill.exec.physical.impl.TestBroadcastExchange
-
- testSingleColumnRead_vector_fill_bug() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testSingleFlattenFromNestedRepeatedList() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testSingleFragmentQuery() - Method in class org.apache.drill.exec.DrillSeparatePlanningTest
-
- testSingleMultiFlattenFromNestedRepeatedList() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testSinglePartition() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testSinglePartitionDefinedInWindowList() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testSingleProjectionFromMultiLevelRepeatedList() - Method in class org.apache.drill.exec.expr.TestSchemaPathMaterialization
-
- testSingleRow() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- testSingleRow() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
- testSingleRow() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl
-
Degenerate case: single row in single batch.
- testSingleTextLineDelimiter() - Method in class org.apache.drill.TestSelectWithOption
-
- testSingleUnnestCol() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testSingleValueFunction() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testSingleValueWithMultipleValuesInput() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testSinhFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testSizeLimit() - Method in class org.apache.drill.test.rowSet.test.TestFixedWidthWriter
-
Test resize monitoring.
- testSizeLimit() - Method in class org.apache.drill.test.rowSet.test.TestOffsetVectorWriter
-
Test resize monitoring.
- testSizeLimit() - Method in class org.apache.drill.test.rowSet.test.TestVariableWidthWriter
-
Test resize monitoring.
- testSizeLimitOnArray() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderOverflow
-
Test a row with a single array column which overflows.
- testSizer() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestShortArrays
-
- testSizerFixedWidth() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testSizerMap() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testSizerNestedMap() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testSizerNullableFixedWidth() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testSizerNullableVariableWidth() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testSizerRepeatedFixedWidth() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testSizerRepeatedList() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testSizerRepeatedMap() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testSizerRepeatedRepeatedList() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testSizerRepeatedVariableWidth() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testSizerVariableWidth() - Method in class org.apache.drill.exec.record.TestRecordBatchSizer
-
- testSkipNulls() - Method in class org.apache.drill.test.rowSet.test.TestFixedWidthWriter
-
Test the case in which a scalar vector is used in conjunction
with a nullable bits vector.
- testSkipNulls() - Method in class org.apache.drill.test.rowSet.test.TestVariableWidthWriter
-
Test the case in which a scalar vector is used in conjunction
with a nullable bits vector.
- testSkipOverflowRow() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderOmittedValues
-
Test that discarding a row works even if that row happens to be an
overflow row.
- testSkipRows() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderOmittedValues
-
Test that omitting the call to saveRow() effectively discards
the row.
- testSmallArray() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testSmaller() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaSmoothing
-
Case in which the table schema is a superset of the prior
schema.
- testSmallFileValueReadWrite() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testSmallInClauseToSemiJoin() - Method in class org.apache.drill.exec.physical.impl.join.TestSemiJoin
-
- testSmallIntRW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testSmallRows() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortInternals
-
- testSmoothableSchemaBatches() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaSmoothing
-
Integrated test across multiple schemas at the batch level.
- testSmoothingProjection() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaSmoothing
-
Low-level test of the smoothing projection, including the exceptions
it throws when things are not going its way.
- testSomeFieldsQueryNoSchema() - Method in class org.apache.drill.exec.store.log.TestLogReader
-
- TestSort - Class in org.apache.drill.exec.physical.impl.sort
-
Placeholder for all sort related test.
- TestSort() - Constructor for class org.apache.drill.exec.physical.impl.sort.TestSort
-
- testSort_NonEmptyFirst_EmptyOKEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
Verifies ExternalSortBatch behavior when it receives incoming batches with different IterOutcomes like
OK_NEW_SCHEMA / OK / EMIT / NONE
- testSortDate() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunction
-
- testSortDate() - Method in class org.apache.drill.exec.record.vector.TestDateTypes
-
- TestSortEmitOutcome - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
- TestSortEmitOutcome() - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
- testSortEmpty() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testSortEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
Verifies that if SortBatch receives empty batches with OK_NEW_SCHEMA and EMIT outcome then it correctly produces
empty batches as output.
- testSortEmptyBatchFollowedByNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
Verifies ExternalSortBatch behavior when it receives first incoming batch post buildSchema phase as empty batch
with EMIT outcome followed by non-empty batch with EMIT outcome.
- TestSorter - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
Tests the generated per-batch sort code via its wrapper layer.
- TestSorter() - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
- TestSortImpl - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
Tests the external sort implementation: the "guts" of the sort stripped of the
Volcano-protocol layer.
- TestSortImpl() - Constructor for class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl
-
- TestSortImpl.DataGenerator - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
Crude-but-effective data generator that produces pseudo-random data
that can be easily verified.
- TestSortImpl.DataValidator - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
Validate a sort output batch based on the expectation that the key
is an ordered sequence of integers, split across multiple batches.
- TestSortImpl.SortTestFixture - Class in org.apache.drill.exec.physical.impl.xsort.managed
-
Handy fixture to hold a sort, a set of input row sets (batches) and the
output set of row sets (batches.) Pumps the input into the sort and
harvests the output.
- testSortMultipleEMITOutcome() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
- testSortMultipleEmptyBatchWithANonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
Verifies ExternalSortBatch behavior with runs of empty batch with EMIT outcome followed by an non-empty batch
with EMIT outcome.
- testSortMultipleInputToSingleOutputBatch() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
Verifies ExternalSortBatch behavior when it receives multiple non-empty batch across same EMIT boundary such
that all the output records can fit within single output batch.
- testSortNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
Verifies ExternalSortBatch handling of first non-empty batch with EMIT outcome post buildSchema phase.
- testSortSpec() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestExternalSortExec
-
- TestSortSpillWithException - Class in org.apache.drill.exec.physical.impl.xsort
-
Testing External Sort's spilling to disk.
- TestSortSpillWithException() - Constructor for class org.apache.drill.exec.physical.impl.xsort.TestSortSpillWithException
-
- testSortWithComplexInput() - Method in class org.apache.drill.exec.physical.impl.sort.TestSort
-
- testSortWithRepeatedMapWithExchanges() - Method in class org.apache.drill.exec.physical.impl.sort.TestSort
-
- testSpaceSeparatedWithQuote() - Method in class org.apache.drill.exec.store.text.TestNewTextReader
-
- testSpacesInMetadataCachePath() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testSparkParquetBinaryAsTimeStamp_DictChange() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testSpecial() - Method in class org.apache.drill.exec.expr.ExpressionTest
-
- testSpecialCharStringType() - Method in class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- testSpill() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl
-
Force the sorter to spill, and verify that the resulting data
is correct.
- testSpillLeakLegacy() - Method in class org.apache.drill.exec.physical.impl.xsort.TestSortSpillWithException
-
- testSpillLeakManaged() - Method in class org.apache.drill.exec.physical.impl.xsort.TestSortSpillWithException
-
- testSpillNotSupportedWithEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
Verifies ExternalSortBatch behavior when it sees batches with EMIT outcome but has to spill to disk because of
memory pressure.
- testSpillWithNoEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
Verifies successful spilling in absence of EMIT outcome
- testSplit() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- TestSplitAndTransfer - Class in org.apache.drill.exec.vector
-
- TestSplitAndTransfer() - Constructor for class org.apache.drill.exec.vector.TestSplitAndTransfer
-
- testSplitAndTransferFailure() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testSplitFunction() - Method in class org.apache.drill.TestUntypedNull
-
- testSplitPart() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testSplitWithNullInput() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testSPNEGOAndFORMEnabled() - Method in class org.apache.drill.exec.server.rest.spnego.TestSpnegoAuthentication
-
Both SPNEGO and FORM mechanism is enabled for WebServer in configuration.
- TestSpnegoAuthentication - Class in org.apache.drill.exec.server.rest.spnego
-
- TestSpnegoAuthentication() - Constructor for class org.apache.drill.exec.server.rest.spnego.TestSpnegoAuthentication
-
- TestSpnegoConfig - Class in org.apache.drill.exec.server.rest.spnego
-
- TestSpnegoConfig() - Constructor for class org.apache.drill.exec.server.rest.spnego.TestSpnegoConfig
-
- testSpnegoConfigOnlyKeytab() - Method in class org.apache.drill.exec.server.rest.spnego.TestSpnegoConfig
-
Invalid configuration with keytab only and missing principal
- testSpnegoConfigOnlyPrincipal() - Method in class org.apache.drill.exec.server.rest.spnego.TestSpnegoConfig
-
Invalid configuration with principal only and missing keytab
- testSpnegoLoginInvalidToken() - Method in class org.apache.drill.exec.server.rest.spnego.TestDrillSpnegoAuthenticator
-
- TestSpoolingBuffer - Class in org.apache.drill.exec.work.batch
-
- TestSpoolingBuffer() - Constructor for class org.apache.drill.exec.work.batch.TestSpoolingBuffer
-
- testSql(String) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- TestSqlBracketlessSyntax - Class in org.apache.drill.exec.sql
-
- TestSqlBracketlessSyntax() - Constructor for class org.apache.drill.exec.sql.TestSqlBracketlessSyntax
-
- testSqlPatternComplex() - Method in class org.apache.drill.exec.expr.fn.impl.TestSqlPatterns
-
- testSqlPatternConstant() - Method in class org.apache.drill.exec.expr.fn.impl.TestSqlPatterns
-
- testSqlPatternContains() - Method in class org.apache.drill.exec.expr.fn.impl.TestSqlPatterns
-
- testSqlPatternContainsMUltipleMatchers() - Method in class org.apache.drill.exec.expr.fn.impl.TestSqlPatterns
-
- testSqlPatternEndsWith() - Method in class org.apache.drill.exec.expr.fn.impl.TestSqlPatterns
-
- TestSqlPatterns - Class in org.apache.drill.exec.expr.fn.impl
-
- TestSqlPatterns() - Constructor for class org.apache.drill.exec.expr.fn.impl.TestSqlPatterns
-
- testSqlPatternStartsWith() - Method in class org.apache.drill.exec.expr.fn.impl.TestSqlPatterns
-
- testSqlPlan(String) - Method in class org.apache.drill.PlanningBase
-
- testSqlPlanFromFile(String) - Method in class org.apache.drill.PlanningBase
-
- testSqlRegexLike() - Method in class org.apache.drill.exec.expr.fn.impl.TestSqlPatterns
-
- testSqlToDateWithEmptyString() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testSqlToDateWithLiteralEmptyString() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testSqlToTimeStampWithEmptyString() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testSqlToTimeStampWithLiteralEmptyString() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testSqlToTimeWithEmptyString() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testSqlToTimeWithLiteralEmptyString() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testSqlTypeOf() - Method in class org.apache.drill.exec.expr.fn.impl.TestTypeFns
-
- testSqlWithResults(String) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- testSQRTDecimalLiteral() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testSqrtFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testSQRTIntegerLiteral() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testSqrtNestedFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- TestSSLConfig - Class in org.apache.drill.exec
-
- TestSSLConfig() - Constructor for class org.apache.drill.exec.TestSSLConfig
-
- testSSLConnection() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSL
-
- testSSLConnectionFailBadPassword() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSL
-
- testSSLConnectionFailBadTrustStore() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSL
-
- testSSLConnectionFailEmptyTrustStore() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSL
-
- testSSLConnectionWithKeystore() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSL
-
- testSSLQuery() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitSSL
-
- testStar() - Method in class org.apache.drill.exec.store.parquet.ParquetInternalsTest
-
- testStar() - Method in class org.apache.drill.exec.store.parquet.TestParquetComplex
-
- testStarColumnCsv() - Method in class org.apache.drill.exec.store.TestImplicitFileColumns
-
- testStarColumnJson() - Method in class org.apache.drill.exec.store.TestImplicitFileColumns
-
- testStarColumnParquet() - Method in class org.apache.drill.exec.store.TestImplicitFileColumns
-
- testStarInSubquery() - Method in class org.apache.drill.TestStarQueries
-
- testStarPartitionFilterOrderBy() - Method in class org.apache.drill.TestStarQueries
-
- TestStarQueries - Class in org.apache.drill
-
- TestStarQueries() - Constructor for class org.apache.drill.TestStarQueries
-
- testStarQuery() - Method in class org.apache.drill.exec.store.pcap.TestPcapRecordReader
-
- testStarQuery() - Method in class org.apache.drill.exec.store.pcapng.TestPcapngRecordReader
-
- testStarQueryNoSchema() - Method in class org.apache.drill.exec.store.log.TestLogReader
-
- testStartingClientEnablesCacheAndEnsuresRootNodeExists() - Method in class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- testStarView1() - Method in class org.apache.drill.TestStarQueries
-
- testStarWithInClauseToSemiJoin() - Method in class org.apache.drill.exec.physical.impl.join.TestSemiJoin
-
- testStarWithOtherExpression() - Method in class org.apache.drill.TestStarQueries
-
- testStateChanged() - Method in class org.apache.drill.exec.work.fragment.FragmentStatusReporterTest
-
- testStateChangedAfterClose() - Method in class org.apache.drill.exec.work.fragment.FragmentStatusReporterTest
-
- testStatisticalWindowFunctions() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testStddevOnKnownType() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testStddevPopDecimal() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testStddevpopFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testStddevSampDecimal() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testStddevsampFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testStoreRegistersDispatcherAndStartsItsClient() - Method in class org.apache.drill.exec.coord.zk.TestEphemeralStore
-
This test ensures store subscribes to receive events from underlying client.
- testStrategyForExistingFile() - Method in class org.apache.drill.exec.store.StorageStrategyTest
-
- testStreamAggNullableColumns() - Method in class org.apache.drill.TestAggNullable
-
- testStreamAggWithGroupBy() - Method in class org.apache.drill.exec.physical.impl.agg.TestAggWithAnyValue.TestAggWithAnyValueMultipleBatches
-
- TestStreamingAggEmitOutcome - Class in org.apache.drill.exec.physical.impl.agg
-
- TestStreamingAggEmitOutcome() - Constructor for class org.apache.drill.exec.physical.impl.agg.TestStreamingAggEmitOutcome
-
- testStreamingAggEmpty() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testStrict() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestLenientAllocation
-
Test that the allocator is normally strict in debug mode.
- testStringAndUtf8Data() - Method in class org.apache.drill.exec.store.avro.AvroFormatTest
-
- TestStringFunctions - Class in org.apache.drill.exec.expr.fn.impl
-
- TestStringFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- TestStringFunctions - Class in org.apache.drill.exec.physical.impl
-
- TestStringFunctions() - Constructor for class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testStringLiterals() - Method in class org.apache.drill.exec.physical.impl.filter.TestLargeInClause
-
- testStringMatcher() - Method in class org.apache.drill.exec.util.TestApproximateStringMatcher
-
- testStringType() - Method in class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- testStrPosMultiByte() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testSubmitPlanSingleNode() - Method in class org.apache.drill.exec.client.DrillClientSystemTest
-
- testSubmitPlanTwoNodes() - Method in class org.apache.drill.exec.client.DrillClientSystemTest
-
- testSubQuerySql() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testSubSelectCrossJoinFailsForEnabledOption() - Method in class org.apache.drill.exec.planner.sql.CrossJoinTest
-
- testSubSelectCrossJoinSucceedsForDisabledOption() - Method in class org.apache.drill.exec.planner.sql.CrossJoinTest
-
- testSubset() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaLevelProjection
-
Test an explicit projection (providing columns) in which the
names in the project lists are a different case than the data
source, the order of columns differs, and we ask for a
subset of data source columns.
- testSubstr() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testSubstr() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testSubstring() - Method in class org.apache.drill.exec.physical.impl.TestSimpleFunctions
-
- testSubstringNegative() - Method in class org.apache.drill.exec.physical.impl.TestSimpleFunctions
-
- testSubtractFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testSuccessDirectConnectionDefaultConnectTriesAndFakeDrillbits() - Method in class org.apache.drill.exec.client.ConnectTriesPropertyTestClusterBits
-
- testSuccessFile() - Method in class org.apache.drill.exec.store.parquet.TestParquetScan
-
- testSuccessfulExecution() - Method in class org.apache.drill.exec.util.ExecutorServiceUtilTest
-
- testSuccessfulRegistration() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testSuccessfulRegistrationAfterSeveralRetryAttempts() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testSuccessfulUnregistrationAfterSeveralRetryAttempts() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testSuccessUsingDirectConnectionAndFakeDrillbitPresent() - Method in class org.apache.drill.exec.client.ConnectTriesPropertyTestClusterBits
-
- testSuccessUsingZKWithDefaultConnectTriesFakeBits() - Method in class org.apache.drill.exec.client.ConnectTriesPropertyTestClusterBits
-
- testSuccessUsingZKWithFakeBits() - Method in class org.apache.drill.exec.client.ConnectTriesPropertyTestClusterBits
-
- testSuccessUsingZKWithNoFakeBits() - Method in class org.apache.drill.exec.client.ConnectTriesPropertyTestClusterBits
-
- testSumAvgDecimalLimit0() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testSumDecimal() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testSumFilesWithDifferentSchema() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testSumFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testSumMultipleBatches() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testSumRequiredType() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testSumWithTypeCase() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testSv2() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
Test that an SV2 is properly handled by the proper container accessor.
- testSV4Filter() - Method in class org.apache.drill.exec.physical.impl.filter.TestSimpleFilter
-
- TestSVRemover - Class in org.apache.drill.exec.physical.impl.svremover
-
- TestSVRemover() - Constructor for class org.apache.drill.exec.physical.impl.svremover.TestSVRemover
-
- TestSVRemoverIterOutcome - Class in org.apache.drill.exec.physical.impl.svremover
-
- TestSVRemoverIterOutcome() - Constructor for class org.apache.drill.exec.physical.impl.svremover.TestSVRemoverIterOutcome
-
- testSVRV4() - Method in class org.apache.drill.TestExampleQueries
-
- testSVRV4Join() - Method in class org.apache.drill.TestExampleQueries
-
- testSVRV4MultBatch() - Method in class org.apache.drill.TestExampleQueries
-
- testSVRWithNoFilter() - Method in class org.apache.drill.exec.physical.impl.svremover.TestSVRemover
-
- testSymbolType() - Method in class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- testSyntax() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testSyntax() - Method in class org.apache.drill.exec.store.easy.text.compliant.TestHeaderBuilder
-
- testSyntax() - Method in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- testSysDrillbits() - Method in class org.apache.drill.TestBugFixes
-
- testSystemOption() - Method in class org.apache.drill.exec.server.options.TestConfigLinkage
-
- testSystemPlugins() - Method in class org.apache.drill.common.scanner.TestClassPathScanner
-
- TestSystemTable - Class in org.apache.drill.exec.store.sys
-
- TestSystemTable() - Constructor for class org.apache.drill.exec.store.sys.TestSystemTable
-
- testTabFieldDelimiter() - Method in class org.apache.drill.TestSelectWithOption
-
- testTableCreation() - Method in class org.apache.drill.TestUntypedNull
-
- testTableDoesNotExistWithEmptyDirectory() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testTableDoesNotExistWithIncorrectTableName() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testTableIsCreatedWithinWorkspace() - Method in class org.apache.drill.exec.sql.TestCTAS
-
- testTableIsFoundWithinWorkspaceWhenNameStartsWithSlash() - Method in class org.apache.drill.exec.sql.TestCTAS
-
- testTableNotFoundException() - Method in class org.apache.drill.exec.store.dfs.TestSchemaNotFoundException
-
- testTabSeparatedWithQuote() - Method in class org.apache.drill.exec.store.text.TestNewTextReader
-
- testTanFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testTanhFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testTemporaryAndPersistentTablesPriority() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testTemporaryTableAndViewPriority() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testTemporaryTablesCaseInsensitivity() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testTemporaryTablesInViewDefinitions() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testTemporaryTablesInViewExpansionLogic() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testTemporaryTableWithAndWithoutLeadingSlashAreTheSame() - Method in class org.apache.drill.exec.sql.TestCTTAS
-
- testText() - Method in class org.apache.drill.exec.store.FormatPluginSerDeTest
-
- testText() - Method in class org.apache.drill.TestExampleQueries
-
- testTEXT_WRITER() - Method in class org.apache.drill.exec.compile.TestLargeFileCompilation
-
- TestTextColumn - Class in org.apache.drill.exec.store.text
-
- TestTextColumn() - Constructor for class org.apache.drill.exec.store.text.TestTextColumn
-
- testTextComment() - Method in class org.apache.drill.TestSelectWithOption
-
- testTextFieldDelimiter() - Method in class org.apache.drill.TestSelectWithOption
-
- testTextHeader() - Method in class org.apache.drill.TestSelectWithOption
-
- testTextInClasspathStorage() - Method in class org.apache.drill.TestExampleQueries
-
- testTextJoin() - Method in class org.apache.drill.TestExampleQueries
-
- TestTextJoin - Class in org.apache.drill
-
- TestTextJoin() - Constructor for class org.apache.drill.TestTextJoin
-
- testTextJoin1() - Method in class org.apache.drill.TestTextJoin
-
- testTextJoin2() - Method in class org.apache.drill.TestTextJoin
-
- testTextLineDelimiterWithCarriageReturn() - Method in class org.apache.drill.TestSelectWithOption
-
- testTextPartitions() - Method in class org.apache.drill.TestExampleQueries
-
- testTextQueries() - Method in class org.apache.drill.TestExampleQueries
-
- testTextQuote() - Method in class org.apache.drill.TestSelectWithOption
-
- testTiffImage() - Method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- testTimeAndTimeStampWithDictionary() - Method in class org.apache.drill.exec.store.parquet.columnreaders.TestColumnReaderFactory
-
check if Time and TimeStamp are read correctly with dictionary encoding.
- testTimeAndTimeStampWithNoDictionary() - Method in class org.apache.drill.exec.store.parquet.columnreaders.TestColumnReaderFactory
-
check if Time and TimeStamp are read correctly with plain encoding.
- TestTimedCallable - Class in org.apache.drill.exec.store
-
- TestTimedCallable() - Constructor for class org.apache.drill.exec.store.TestTimedCallable
-
- testTimeOfDay() - Method in class org.apache.drill.exec.physical.impl.TestNestedDateTimeTimestamp
-
Test timeofday() function.
- TestTimePrintMillis - Class in org.apache.drill.exec.vector.accessor
-
- TestTimePrintMillis() - Constructor for class org.apache.drill.exec.vector.accessor.TestTimePrintMillis
-
- testTimeStamp() - Method in class org.apache.drill.exec.record.vector.TestDateTypes
-
- TestTimestampAddDiffFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestTimestampAddDiffFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestTimestampAddDiffFunctions
-
- testTimestampAddDiffLiteralTypeInference() - Method in class org.apache.drill.exec.fn.impl.TestTimestampAddDiffFunctions
-
- testTimestampAddDiffNull() - Method in class org.apache.drill.exec.fn.impl.TestTimestampAddDiffFunctions
-
- testTimestampAddDiffTypeInference() - Method in class org.apache.drill.exec.fn.impl.TestTimestampAddDiffFunctions
-
- testTimestampAddParquet() - Method in class org.apache.drill.exec.fn.impl.TestTimestampAddDiffFunctions
-
- testTimeStampAndTime() - Method in class org.apache.drill.TestImplicitCasting
-
- testTimestampArray() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testTimeStampConstant() - Method in class org.apache.drill.TestFunctionsQuery
-
- testTimestampDiff() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testTimestampDiffParquet() - Method in class org.apache.drill.exec.fn.impl.TestTimestampAddDiffFunctions
-
- testTimestampDiffTimeDateTransition() - Method in class org.apache.drill.exec.fn.impl.TestTimestampAddDiffFunctions
-
- testTimestampImpalaConvertFrom() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testTimeStampPredicate() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testTimeStampPredicateWithEval() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testTimestampRW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testTimeStampType() - Method in class org.apache.drill.exec.store.bson.TestBsonRecordReader
-
- testTimeZoneChangeAndReverse() - Method in class org.apache.drill.exec.physical.impl.TestNestedDateTimeTimestamp
-
Testing time zone change and revert
- testTinyIntArray() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testTinyIntRW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testToChar() - Method in class org.apache.drill.exec.fn.impl.TestDateFunctions
-
- testToCharFunction() - Method in class org.apache.drill.TestFunctionsQuery
-
- testToDateForTimeStamp() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testToDateType() - Method in class org.apache.drill.exec.fn.impl.TestDateFunctions
-
- testToDateWithEmptyString() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testToDateWithLiteralEmptyString() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- TestToNullable - Class in org.apache.drill.vector
-
- TestToNullable() - Constructor for class org.apache.drill.vector.TestToNullable
-
- testTOP_N_SORT() - Method in class org.apache.drill.exec.compile.TestLargeFileCompilation
-
- testTopFixedWidthArray() - Method in class org.apache.drill.test.rowSet.test.RowSetTest
-
Test an array of ints (as an example fixed-width type)
at the top level of a schema.
- testTopN() - Method in class org.apache.drill.exec.physical.unit.BasicPhysicalOpUnitTest
-
- testTopN_NonEmptyFirst_EmptyOKEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNEmitOutcome
-
Verifies TopNBatch correctness for the case where it receives non-empty batch in build schema phase followed by
empty batchs with OK and EMIT outcomes.
- testTopN_WithEmptyNonEmptyBatchesAndOKOutcome() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNEmitOutcome
-
Tests for validating regular TopN behavior with no EMIT outcome
- testTopN_WithEmptyNonEmptyBatchesAndOKOutcome() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
Test for validating ExternalSortBatch behavior without EMIT outcome
- TestTopNEmitOutcome - Class in org.apache.drill.exec.physical.impl.TopN
-
- TestTopNEmitOutcome() - Constructor for class org.apache.drill.exec.physical.impl.TopN.TestTopNEmitOutcome
-
- testTopNEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNEmitOutcome
-
Verifies that if TopNBatch receives empty batches with OK_NEW_SCHEMA and EMIT outcome then it correctly produces
empty batches as output.
- testTopNEmptyBatchFollowedByNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNEmitOutcome
-
- testTopNMultipleEMITOutcome() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNEmitOutcome
-
- testTopNMultipleEmptyBatchFollowedByNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNEmitOutcome
-
- testTopNMultipleInputToMultipleOutputBatch_LowerLimits() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNEmitOutcome
-
- testTopNMultipleInputToSingleOutputBatch() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNEmitOutcome
-
- testTopNMultipleOutputBatch() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
- testTopNMultipleOutputBatchWithLowerLimits() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNEmitOutcome
-
Verifies that if TopNBatch receives multiple non-empty record batch with EMIT outcome in between then it produces
output for those input batch correctly.
- testTopNNonEmptyBatchEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNEmitOutcome
-
Verifies that if TopNBatch receives a RecordBatch with EMIT outcome post build schema phase then it produces
output for those input batch correctly.
- testTopNResetsAfterFirstEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNEmitOutcome
-
Verifies that if TopNBatch receives multiple non-empty record batch with EMIT outcome in between then it produces
output for those input batch correctly.
- testTopNResetsAfterFirstEmitOutcome() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortEmitOutcome
-
Verifies ExternalSortBatch behavior when it receives non-empty batch in BuildSchema phase followed by empty EMIT
batch.
- TestTopNSchemaChanges - Class in org.apache.drill.exec.physical.impl.TopN
-
- TestTopNSchemaChanges() - Constructor for class org.apache.drill.exec.physical.impl.TopN.TestTopNSchemaChanges
-
- testTopNWithSV2() - Method in class org.apache.drill.TestExampleQueries
-
- testToTimeStamp() - Method in class org.apache.drill.TestFunctionsQuery
-
- testToTimeStampWithEmptyString() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testToTimeStampWithLiteralEmptyString() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testToTimeWithEmptyString() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- testToTimeWithLiteralEmptyString() - Method in class org.apache.drill.exec.fn.impl.testing.TestDateConversions
-
- TestTpcdsSf1Leaks - Class in org.apache.drill.exec.server
-
To run this unit class you need to download the following data file:
http://apache-drill.s3.amazonaws.com/files/tpcds-sf1-parquet.tgz
and untar it in a some folder (e.g.
- TestTpcdsSf1Leaks() - Constructor for class org.apache.drill.exec.server.TestTpcdsSf1Leaks
-
- testTPCH1() - Method in class org.apache.drill.TestProjectPushDown
-
- testTPCH3() - Method in class org.apache.drill.TestProjectPushDown
-
- TestTpchDistributed - Class in org.apache.drill
-
- TestTpchDistributed() - Constructor for class org.apache.drill.TestTpchDistributed
-
- TestTpchDistributedConcurrent - Class in org.apache.drill
-
- TestTpchDistributedConcurrent() - Constructor for class org.apache.drill.TestTpchDistributedConcurrent
-
- TestTpchDistributedStreaming - Class in org.apache.drill
-
- TestTpchDistributedStreaming() - Constructor for class org.apache.drill.TestTpchDistributedStreaming
-
- TestTpchExplain - Class in org.apache.drill
-
- TestTpchExplain() - Constructor for class org.apache.drill.TestTpchExplain
-
- TestTpchLimit0 - Class in org.apache.drill
-
- TestTpchLimit0() - Constructor for class org.apache.drill.TestTpchLimit0
-
- testTPCHPerformace_SF1() - Method in class org.apache.drill.exec.store.parquet.ParquetRecordReaderTest
-
- TestTpchPlanning - Class in org.apache.drill
-
- TestTpchPlanning() - Constructor for class org.apache.drill.TestTpchPlanning
-
- testTPCHReadWrite1() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testTPCHReadWrite1_date_convertedType() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testTPCHReadWrite2() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testTPCHReadWrite3() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testTPCHReadWrite4() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testTPCHReadWrite5() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testTPCHReadWrite6() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testTPCHReadWrite7() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testTPCHReadWrite8() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testTPCHReadWriteDictGzip() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testTPCHReadWriteGzip() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testTPCHReadWriteNoDictUncompressed() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testTPCHReadWriteRunRepeated() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testTPCHReadWriteSnappy() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- TestTpchSingleMode - Class in org.apache.drill
-
- TestTpchSingleMode() - Constructor for class org.apache.drill.TestTpchSingleMode
-
- TestTraceMultiRecordBatch - Class in org.apache.drill.exec.physical.impl.trace
-
- TestTraceMultiRecordBatch() - Constructor for class org.apache.drill.exec.physical.impl.trace.TestTraceMultiRecordBatch
-
- TestTraceOutputDump - Class in org.apache.drill.exec.physical.impl.trace
-
- TestTraceOutputDump() - Constructor for class org.apache.drill.exec.physical.impl.trace.TestTraceOutputDump
-
- testTransfer() - Method in class org.apache.drill.exec.memory.TestAllocators
-
- TestTrigFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestTrigFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestTrigFunctions
-
- testTrigoMathFunc() - Method in class org.apache.drill.exec.fn.impl.TestNewMathFunctions
-
- testTrim() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testTrim() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testTrimOneArg() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testTrimTwoArg() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testTruncateDecimalFunction() - Method in class org.apache.drill.TestFunctionsQuery
-
- testTruncatedLifeCycle() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
Simulate a truncated life cycle: next() is never called.
- testTruncateWithParamDecimalFunction() - Method in class org.apache.drill.TestFunctionsQuery
-
- testTruncateWithParamFunction() - Method in class org.apache.drill.TestFunctionsQuery
-
- testTruncDivMod() - Method in class org.apache.drill.exec.fn.impl.TestNewMathFunctions
-
- testTruncFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- TestTupleSchema - Class in org.apache.drill.exec.record
-
Test the tuple and column metadata, including extended attributes.
- TestTupleSchema() - Constructor for class org.apache.drill.exec.record.TestTupleSchema
-
- testTwoBatches() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl
-
Degenerate case, one row in each of two
(unsorted) batches.
- testTwoBatchesSingleRow() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- testTwoDigitsMajorVersion() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataVersion
-
- testTwoDigitsMinorVersion() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataVersion
-
- testTwoFlattens() - Method in class org.apache.drill.exec.physical.impl.flatten.TestFlatten
-
- testTwoRows() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
- testType(TypeProtos.MinorType) - Method in class org.apache.drill.exec.cache.TestBatchSerialization
-
- testTypeAndMode() - Method in class org.apache.drill.TestUntypedNull
-
- testTypeCase() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- TestTypeFns - Class in org.apache.drill.exec.expr.fn.impl
-
- TestTypeFns() - Constructor for class org.apache.drill.exec.expr.fn.impl.TestTypeFns
-
- testTypeOf() - Method in class org.apache.drill.exec.expr.fn.impl.TestTypeFns
-
- testTypes() - Method in class org.apache.drill.exec.cache.TestBatchSerialization
-
- testTypes() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestCopier
-
- testUDFInGroupBy() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testUInt1RW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testUInt2RW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testUMNoSchema() - Method in class org.apache.drill.exec.store.log.TestLogReader
-
- testUnboundedFollowing() - Method in class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testUnecryptedConnectionCounter() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberos
-
- testUnecryptedConnectionCounter_LocalControlMessage() - Method in class org.apache.drill.exec.rpc.user.security.TestUserBitKerberos
-
- testUnicode() - Method in class org.apache.drill.exec.store.easy.text.compliant.TestHeaderBuilder
-
- testUnion() - Method in class org.apache.drill.exec.physical.impl.union.TestSimpleUnion
-
- testUnion() - Method in class org.apache.drill.test.rowSet.test.TestHyperVectorReaders
-
- testUnion() - Method in class org.apache.drill.TestUntypedNull
-
- testUnionAddTypes() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderUnions
-
- TestUnionAll - Class in org.apache.drill
-
- TestUnionAll() - Constructor for class org.apache.drill.TestUnionAll
-
- testUnionAll1() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAll10() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAll2() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAll3() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAll4() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAll5() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAll6() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAll6_1() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAll7() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAll8() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAll9() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllBothEmptyDataBatch() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllBothEmptyDirs() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllBothEmptyJson() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllContainsColumnANumericConstant() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllDiffTypesAtPlanning() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllEmptySides() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllImplicitCastingFailure() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllInWith() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllLeftEmptyDataBatch() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllLeftEmptyDir() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllLeftEmptyJson() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllMiddleEmptyDir() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllOneInputContainsAggFunction() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllRightEmptyDataBatch() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllRightEmptyDir() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllRightEmptyJson() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllViewExpandableStar() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllViewUnExpandableStar() - Method in class org.apache.drill.TestUnionAll
-
- testUnionAllWithValues() - Method in class org.apache.drill.TestUnionAll
-
- testUnionBasics() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderUnions
-
- testUnionBothEmptyDirs() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionColumn() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
- TestUnionDistinct - Class in org.apache.drill
-
- TestUnionDistinct() - Constructor for class org.apache.drill.TestUnionDistinct
-
- testUnionDistinct1() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinct10() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinct2() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinct3() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinct4() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinct5() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinct6() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinct6_1() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinct7() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinct8() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinct9() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinctBothEmptyDataBatch() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinctBothEmptyJson() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinctContainsColumnANumericConstant() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinctDiffTypesAtPlanning() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinctEmptySides() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinctImplicitCastingFailure() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinctLeftEmptyDataBatch() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinctLeftEmptyJson() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinctOneInputContainsAggFunction() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinctRightEmptyDataBatch() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinctRightEmptyJson() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinctViewExpandableStar() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionDistinctViewUnExpandableStar() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionEmptyBoth() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- TestUnionExchange - Class in org.apache.drill.exec.physical.impl
-
- TestUnionExchange() - Constructor for class org.apache.drill.exec.physical.impl.TestUnionExchange
-
- testUnionExpressionMaterialization() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testUnionFilter() - Method in class org.apache.drill.exec.physical.unit.TestMiniPlan
-
- testUnionFilterAll() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testUnionInMap() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
Verify that the union-in-map plumbing works.
- testUnionInputsGroupByOnCSV() - Method in class org.apache.drill.TestUnionAll
-
- testUnionInRow() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
Test building a union in the top-level schema.
- testUnionLeftEmptyDir() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionLeftEmtpy() - Method in class org.apache.drill.exec.physical.unit.TestNullInputMiniPlan
-
- testUnionList() - Method in class org.apache.drill.test.rowSet.test.TestHyperVectorReaders
-
- testUnionLowerLimit() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testUnionMiddleEmptyDir() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionMultipleOutputBatches() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testUnionOutputBatch() - Method in class org.apache.drill.exec.physical.unit.TestOutputBatchSize
-
- testUnionOverflow() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderUnions
-
- testUnionRightEmptyDir() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionSchema() - Method in class org.apache.drill.exec.record.TestTupleSchema
-
- testUnionTypes() - Method in class org.apache.drill.exec.physical.impl.TopN.TestTopNSchemaChanges
-
- testUnionWithList() - Method in class org.apache.drill.test.rowSet.test.TestVariantAccessors
-
Test a variant (AKA "union vector") at the top level which includes
a list.
- testUnionWithManyColumns() - Method in class org.apache.drill.TestUnionDistinct
-
- testUnionWithMap() - Method in class org.apache.drill.test.rowSet.test.TestVariantAccessors
-
Test a variant (AKA "union vector") at the top level which
includes a map.
- testUnixTimeStampForDate() - Method in class org.apache.drill.exec.fn.impl.TestNewDateFunctions
-
- testUnixTimeStampForDateWithPattern() - Method in class org.apache.drill.exec.fn.impl.TestNewDateFunctions
-
- testUnnestColumnAlias() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- TestUnnestCorrectness - Class in org.apache.drill.exec.physical.impl.unnest
-
- TestUnnestCorrectness() - Constructor for class org.apache.drill.exec.physical.impl.unnest.TestUnnestCorrectness
-
- testUnnestEmptyList() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestCorrectness
-
- testUnnestEmptyList() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestWithLateralCorrectness
-
- testUnnestFixedWidthColumn() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestCorrectness
-
- testUnnestFixedWidthColumn() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestWithLateralCorrectness
-
- testUnnestKillFromLimitSubquery1() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestCorrectness
-
- testUnnestKillFromLimitSubquery1() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestWithLateralCorrectness
-
- testUnnestKillFromLimitSubquery2() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestCorrectness
-
- testUnnestKillFromLimitSubquery2() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestWithLateralCorrectness
-
- testUnnestLimitBatchSize() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestCorrectness
-
- testUnnestLimitBatchSize() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestWithLateralCorrectness
-
- testUnnestLimitBatchSize_WithExcludedCols() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestWithLateralCorrectness
-
- testUnnestMapColumn() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestCorrectness
-
- testUnnestMapColumn() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestWithLateralCorrectness
-
- testUnnestMultipleNewSchemaIncoming() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestCorrectness
-
- testUnnestMultipleNewSchemaIncoming() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestWithLateralCorrectness
-
- testUnnestNestedStarSubquery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testUnnestNonArrayColumn() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestCorrectness
-
- testUnnestNonArrayColumn() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestWithLateralCorrectness
-
- testUnnestSchemaChange() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestCorrectness
-
- testUnnestSchemaChange() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestWithLateralCorrectness
-
- testUnnestTableAndColumnAlias() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testUnnestTopN() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testUnnestVarWidthColumn() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestCorrectness
-
- testUnnestVarWidthColumn() - Method in class org.apache.drill.exec.physical.impl.unnest.TestUnnestWithLateralCorrectness
-
- testUnnestWithAggInSubquery() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testUnnestWithAggOnOuterTable() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testUnnestWithFilter() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestLateralPlans
-
- testUnnestWithFunctionCall() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testUnnestWithItem() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- TestUnnestWithLateralCorrectness - Class in org.apache.drill.exec.physical.impl.unnest
-
- TestUnnestWithLateralCorrectness() - Constructor for class org.apache.drill.exec.physical.impl.unnest.TestUnnestWithLateralCorrectness
-
- testUnnestWithMap() - Method in class org.apache.drill.exec.physical.impl.lateraljoin.TestE2EUnnestAndLateral
-
- testUnpauseFragments() - Method in class org.apache.drill.exec.rpc.control.TestLocalControlConnectionManager
-
Verify that UnpauseFragment is handled correctly using ControlTunnel with LocalControlConnectionManager
- testUnsignedAndSignedIntTypes() - Method in class org.apache.drill.exec.store.parquet2.TestDrillParquetReader
-
- testUnsupportedRexNode() - Method in class org.apache.drill.exec.planner.logical.DrillOptiqTest
-
- testUnsupportedSelectionVector() - Method in class org.apache.drill.exec.physical.impl.join.TestLateralJoinCorrectness
-
Test unsupported incoming batch to LATERAL with SelectionVector
- TestUntypedNull - Class in org.apache.drill
-
- TestUntypedNull() - Constructor for class org.apache.drill.TestUntypedNull
-
- testUntypedPathWithUnion() - Method in class org.apache.drill.exec.vector.complex.writer.TestJsonReader
-
- testUnwrapException() - Method in class org.apache.drill.exec.util.DrillExceptionUtilTest
-
- testUnwrapNestedException() - Method in class org.apache.drill.exec.util.DrillExceptionUtilTest
-
- testUpdate() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataCache
-
- testUpper() - Method in class org.apache.drill.exec.expr.fn.impl.TestStringFunctions
-
- testUpper() - Method in class org.apache.drill.exec.physical.impl.TestStringFunctions
-
- testUse() - Method in class org.apache.drill.TestSelectWithOption
-
- testUseBrokenStorage() - Method in class org.apache.drill.exec.physical.impl.TestSchema
-
- testUseCommand() - Method in class org.apache.drill.exec.sql.TestSchemaCaseInsensitivity
-
- TestUserBitKerberos - Class in org.apache.drill.exec.rpc.user.security
-
- TestUserBitKerberos() - Constructor for class org.apache.drill.exec.rpc.user.security.TestUserBitKerberos
-
- TestUserBitKerberosEncryption - Class in org.apache.drill.exec.rpc.user.security
-
- TestUserBitKerberosEncryption() - Constructor for class org.apache.drill.exec.rpc.user.security.TestUserBitKerberosEncryption
-
- TestUserBitSaslCompatibility - Class in org.apache.drill.exec.rpc.user.security
-
Helps to test different scenarios based on security configuration on client and Drillbit side with respect to SASL
and specifically using PLAIN mechanism
- TestUserBitSaslCompatibility() - Constructor for class org.apache.drill.exec.rpc.user.security.TestUserBitSaslCompatibility
-
- TestUserBitSSL - Class in org.apache.drill.exec.rpc.user.security
-
- TestUserBitSSL() - Constructor for class org.apache.drill.exec.rpc.user.security.TestUserBitSSL
-
- TestUserBitSSLServer - Class in org.apache.drill.exec.rpc.user.security
-
- TestUserBitSSLServer() - Constructor for class org.apache.drill.exec.rpc.user.security.TestUserBitSSLServer
-
- testUserExceptionOnBind() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
- testUserExceptionOnBuildSchema() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
- testUserExceptionOnClose() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
- testUserExceptionOnNext() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
- testUserOverrideDateCorrection() - Method in class org.apache.drill.exec.physical.impl.writer.TestCorruptParquetDateCorrection
-
- testUseStatement() - Method in class org.apache.drill.exec.store.store.TestDisabledPlugin
-
- testUTF8() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- TestUtf8SupportInQueryString - Class in org.apache.drill
-
- TestUtf8SupportInQueryString() - Constructor for class org.apache.drill.TestUtf8SupportInQueryString
-
- testUtf8SupportInQueryStringByDefault() - Method in class org.apache.drill.TestUtf8SupportInQueryString
-
- TestValidationOptions - Class in org.apache.drill.exec.physical.impl.validate
-
- TestValidationOptions() - Constructor for class org.apache.drill.exec.physical.impl.validate.TestValidationOptions
-
- testValidCsvHeaders() - Method in class org.apache.drill.exec.store.easy.text.compliant.TestCsv
-
- testValidFixed() - Method in class org.apache.drill.exec.physical.impl.validate.TestBatchValidator
-
- testValidHeaderForArrayColumns() - Method in class org.apache.drill.exec.store.pcapng.TestPcapngHeaders
-
- testValidHeaderForNestedColumns() - Method in class org.apache.drill.exec.store.pcapng.TestPcapngHeaders
-
- testValidHeadersForMissColumns() - Method in class org.apache.drill.exec.store.pcapng.TestPcapngHeaders
-
- testValidHeadersForProjection() - Method in class org.apache.drill.exec.store.pcapng.TestPcapngHeaders
-
- testValidHeadersForStarQuery() - Method in class org.apache.drill.exec.store.pcapng.TestPcapngHeaders
-
- testValidRepeated() - Method in class org.apache.drill.exec.physical.impl.validate.TestBatchValidator
-
- testValidSpnegoConfig() - Method in class org.apache.drill.exec.server.rest.spnego.TestSpnegoConfig
-
Valid Configuration with both keytab & principal
- testValidVariable() - Method in class org.apache.drill.exec.physical.impl.validate.TestBatchValidator
-
- TestValueVector - Class in org.apache.drill.exec.record.vector
-
- TestValueVector() - Constructor for class org.apache.drill.exec.record.vector.TestValueVector
-
- TestValueVector.ChildVerifier - Class in org.apache.drill.exec.record.vector
-
- TestValueVector.VectorVerifier - Interface in org.apache.drill.exec.record.vector
-
- TestValueVectorElementFormatter - Class in org.apache.drill.exec.util
-
- TestValueVectorElementFormatter() - Constructor for class org.apache.drill.exec.util.TestValueVectorElementFormatter
-
- testVarBinary() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
Test the VARBINARY data type as a sort key.
- testVarBinaryArray() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testVarBinaryRW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testVarbinaryToDate() - Method in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- testVarChar() - Method in class org.apache.drill.vector.TestFillEmpties
-
- testVarcharArray() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testVarcharPartitionedReadWithCorruption() - Method in class org.apache.drill.exec.physical.impl.writer.TestCorruptParquetDateCorrection
-
- testVarCharPrecision() - Method in class org.apache.drill.test.rowSet.test.TestSchemaBuilder
-
Test methods to provide a width (precision) for VarChar
columns.
- testVarcharRW() - Method in class org.apache.drill.test.rowSet.test.TestScalarAccessors
-
- testVarCharTypes() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSorter
-
- testVarCharVectorLoad() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- TestVarDecimalFunctions - Class in org.apache.drill.exec.fn.impl
-
- TestVarDecimalFunctions() - Constructor for class org.apache.drill.exec.fn.impl.TestVarDecimalFunctions
-
- testVariableCaseColumn() - Method in class org.apache.drill.exec.store.parquet.TestComplexColumnInSchema
-
- testVariableCaseSchemaPath() - Method in class org.apache.drill.exec.store.parquet.TestComplexColumnInSchema
-
- testVariableCorruptFirst() - Method in class org.apache.drill.exec.physical.impl.validate.TestBatchValidator
-
- testVariableCorruptLastOutOfRange() - Method in class org.apache.drill.exec.physical.impl.validate.TestBatchValidator
-
- testVariableCorruptMiddleHigh() - Method in class org.apache.drill.exec.physical.impl.validate.TestBatchValidator
-
- testVariableCorruptMiddleLow() - Method in class org.apache.drill.exec.physical.impl.validate.TestBatchValidator
-
- testVariableMissingLast() - Method in class org.apache.drill.exec.physical.impl.validate.TestBatchValidator
-
- testVariableVectorReallocation() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- testVariableWidth() - Method in class org.apache.drill.exec.store.parquet.ParquetInternalsTest
-
- testVariableWidth() - Method in class org.apache.drill.vector.TestToNullable
-
- TestVariableWidthWriter - Class in org.apache.drill.test.rowSet.test
-
- TestVariableWidthWriter() - Constructor for class org.apache.drill.test.rowSet.test.TestVariableWidthWriter
-
- TestVariantAccessors - Class in org.apache.drill.test.rowSet.test
-
Tests for readers and writers for union and list types.
- TestVariantAccessors() - Constructor for class org.apache.drill.test.rowSet.test.TestVariantAccessors
-
- testVariantListDynamic() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderUnions
-
Test a variant list created dynamically at load time.
- testVariationsCSV() - Method in class org.apache.drill.TestSelectWithOption
-
- testVariationsJSON() - Method in class org.apache.drill.TestSelectWithOption
-
- TestVarlenDecimal - Class in org.apache.drill.exec.store.parquet
-
- TestVarlenDecimal() - Constructor for class org.apache.drill.exec.store.parquet.TestVarlenDecimal
-
- testVarLengthVector_SetCountZeroAfterClear() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
For VariableLengthVectors when we clear of the vector and then explicitly set the
ValueCount of zero, then it should not fail with IndexOutOfBoundException.
- testVarLengthVector_SetOOBCount() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
For VariableLengthVectors when we try to set value count greater than value count for which memory is allocated,
then it should fail with IndexOutOfBoundException.
- testVarPopDecimal() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testVarpopFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testVarSampDecimal() - Method in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- testVarsampFunction() - Method in class org.apache.drill.exec.fn.impl.TestMathFunctionsWithNanInf
-
- testVarWidth() - Method in class org.apache.drill.test.rowSet.test.TestHyperVectorReaders
-
- testVectorCanLoadEmptyBuffer() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- TestVectorContainer - Class in org.apache.drill.exec.record
-
- TestVectorContainer() - Constructor for class org.apache.drill.exec.record.TestVectorContainer
-
- testVectorMetadataIsAccurate() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- testVectorSizeLimit() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderOverflow
-
Test that the writer detects a vector overflow.
- testVerboseHalfDayHourMin() - Method in class org.apache.drill.exec.server.TestDurationFormat
-
- testVerboseHourMin() - Method in class org.apache.drill.exec.server.TestDurationFormat
-
- testVerboseManyDayHourMin() - Method in class org.apache.drill.exec.server.TestDurationFormat
-
- testVerboseMinSec() - Method in class org.apache.drill.exec.server.TestDurationFormat
-
- testVerboseOneDayHourMin() - Method in class org.apache.drill.exec.server.TestDurationFormat
-
- testVerboseSecMillis() - Method in class org.apache.drill.exec.server.TestDurationFormat
-
- testVerboseTwoDigitMilliSec() - Method in class org.apache.drill.exec.server.TestDurationFormat
-
- testVersion() - Method in class org.apache.drill.exec.client.DrillSqlLineApplicationTest
-
- testVersion() - Method in class org.apache.drill.exec.expr.fn.registry.FunctionRegistryHolderTest
-
- testVersionTable() - Method in class org.apache.drill.TestBugFixes
-
- testVersionWithLetterInsteadOfNumber() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataVersion
-
- testViewFileName() - Method in class org.apache.drill.TestExampleQueries
-
- testViewFileStatus() - Method in class org.apache.drill.exec.dotdrill.TestDotDrillUtil
-
- testViewHelper(String, String, String, String, String[], List<Object[]>) - Static method in class org.apache.drill.exec.sql.TestBaseViewSupport
-
Tests creating a view with given parameters, query the view and check against the provided baselines and finally
drop the view.
- testViewIsCreatedWithinWorkspace() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- testViewIsFoundWithinWorkspaceWhenNameStartsWithSlash() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- TestViewSupport - Class in org.apache.drill.exec.sql
-
- TestViewSupport() - Constructor for class org.apache.drill.exec.sql.TestViewSupport
-
- testVInts1() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testVInts10() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testVInts11() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testVInts12() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testVInts13() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testVInts2() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testVInts3() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testVInts4() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testVInts5() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testVInts6() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testVInts7() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testVInts8() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testVInts9() - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- testVisitBooleanAndWithoutFunctionsEvaluation() - Method in class org.apache.drill.TestBugFixes
-
- testVisitBooleanOrWithoutFunctionsEvaluation() - Method in class org.apache.drill.TestBugFixes
-
- testVVInitialCapacity() - Method in class org.apache.drill.exec.record.vector.TestValueVector
-
- testWavImage() - Method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- testWebpImage() - Method in class org.apache.drill.exec.store.image.TestImageRecordReader
-
- testWhere() - Method in class org.apache.drill.TestExampleQueries
-
- testWhiteSpace() - Method in class org.apache.drill.exec.store.easy.text.compliant.TestHeaderBuilder
-
- testWideRows() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl
-
Test wide rows with the stock copier.
- testWildcard() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestScanLevelProjection
-
Simulate a SELECT * query by passing "*" as a column name.
- testWildcard() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaLevelProjection
-
Test wildcard projection: take all columns on offer from
the data source, in the order that the data source specifies.
- testWildcard() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestProjectedTuple
-
- testWildcard() - Method in class org.apache.drill.exec.store.log.TestLogReader
-
- testWildCardEmptyNoCache() - Method in class org.apache.drill.exec.store.parquet.TestParquetGroupScan
-
- testWildCardEmptyWithCache() - Method in class org.apache.drill.exec.store.parquet.TestParquetGroupScan
-
- testWildcardSmoothing() - Method in class org.apache.drill.exec.physical.impl.scan.project.TestSchemaSmoothing
-
A SELECT * query uses the schema of the table as the output schema.
- testWindowConstants() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- TestWindowFrame - Class in org.apache.drill.exec.physical.impl.window
-
- TestWindowFrame() - Constructor for class org.apache.drill.exec.physical.impl.window.TestWindowFrame
-
- testWindowFrame() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testWindowFrameEquivalentToDefault() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testWindowFunAndStarCol() - Method in class org.apache.drill.TestExampleQueries
-
- testWindowFunction() - Method in class org.apache.drill.TestUntypedNull
-
- TestWindowFunctions - Class in org.apache.drill.exec
-
- TestWindowFunctions() - Constructor for class org.apache.drill.exec.TestWindowFunctions
-
- testWindowFunctionWithDistinct() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testWindowFunctionWithKnownType() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testWindowFunInNestSubQ() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testWindowGroupBy() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testWindowGroupByOnView() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testWindowInWindow() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testWindowNTILE() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testWindowOnSubqueryWithStar() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testWindowRanking() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testWindowSumAggIsNotNull() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testWindowSumAvg() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testWindowSumConstant() - Method in class org.apache.drill.TestFunctionsWithTypeExpoQueries
-
- testWindowWithAlias() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testWindowWithAllowDisallow() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testWindowWithJoin() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- testWithAndWithoutPartitions() - Method in class org.apache.drill.exec.TestWindowFunctions
-
- TestWithClause - Class in org.apache.drill.exec.sql
-
- TestWithClause() - Constructor for class org.apache.drill.exec.sql.TestWithClause
-
- testWithGroupBy() - Method in class org.apache.drill.exec.physical.impl.agg.TestAggWithAnyValue.TestAggWithAnyValueSingleBatch
-
- testWithListener(UserBitShared.QueryType, String, UserResultsListener) - Static method in class org.apache.drill.test.BaseTestQuery
-
Deprecated.
- testWithListener(DrillClient, UserBitShared.QueryType, String, UserResultsListener) - Static method in class org.apache.drill.test.QueryTestUtil
-
Execute a single query with a user supplied result listener.
- testWithMissingStatistics() - Method in class org.apache.drill.exec.store.parquet.TestParquetFilterPushDown
-
- testWithoutGroupBy() - Method in class org.apache.drill.exec.physical.impl.agg.TestAggWithAnyValue.TestAggWithAnyValueSingleBatch
-
- testWithoutMinorVersion() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataVersion
-
- TestWithZookeeper - Class in org.apache.drill.exec
-
- TestWithZookeeper() - Constructor for class org.apache.drill.exec.TestWithZookeeper
-
- testWrappedExceptionOnBind() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
Failure on the bind method.
- testWrappedExceptionOnBuildSchema() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
Failure when building the schema (first call to next()).
- testWrappedExceptionOnClose() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
Failure when closing the operator implementation.
- testWrappedExceptionOnNext() - Method in class org.apache.drill.exec.physical.impl.protocol.TestOperatorRecordBatch
-
Failure on the second or subsequent calls to next(), when actually
fetching a record batch.
- testWrite() - Method in class org.apache.drill.test.rowSet.test.TestFixedWidthWriter
-
Basic test to write a contiguous set of values, enough to cause
the vector to double in size twice, then read back the values.
- testWrite() - Method in class org.apache.drill.test.rowSet.test.TestOffsetVectorWriter
-
Basic test to write a contiguous set of offsets, enough to cause
the vector to double in size twice, then read back the values.
- testWrite() - Method in class org.apache.drill.test.rowSet.test.TestVariableWidthWriter
-
Basic test to write a contiguous set of values, enough to cause
the vector to double in size twice, then read back the values.
- testWriteDecimal() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testWriteDecimalBinaryOnly() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testWriteDecimalBinaryRepeated() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testWriteDecimalFixedLenOnly() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testWriteDecimalFixedLenRepeated() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testWriteDecimalIntBigIntBinary() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testWriteDecimalIntBigIntFixedLen() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testWriteDecimalIntBigIntRepeated() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testWriteEmptyFile() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriterEmptyFiles
-
- testWriteEmptyFileAfterFlush() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriterEmptyFiles
-
- TestWriter - Class in org.apache.drill.exec.physical.impl.writer
-
- TestWriter() - Constructor for class org.apache.drill.exec.physical.impl.writer.TestWriter
-
- testWriteReadCsv() - Method in class org.apache.drill.exec.store.parquet.TestVarlenDecimal
-
- testWriteReadJson() - Method in class org.apache.drill.exec.store.parquet.TestVarlenDecimal
-
- testWriterWithStarAndExp() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- testWriterWithStarAndRegluarCol() - Method in class org.apache.drill.exec.physical.impl.writer.TestParquetWriter
-
- TestWriteToDisk - Class in org.apache.drill.exec.cache
-
- TestWriteToDisk() - Constructor for class org.apache.drill.exec.cache.TestWriteToDisk
-
- testWrongDelimiter() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataVersion
-
- testWrongFirstLetter() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataVersion
-
- testX() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testX2() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testX3() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testX4() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testX5() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testX6() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testX7() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testX8() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testX9() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testY() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testY2() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testY3() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testY6() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testZ() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testZ1() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testZ2() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testZ3() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testZ4() - Method in class org.apache.drill.exec.vector.complex.writer.TestComplexTypeReader
-
- testZeroHasNoEffect() - Method in class org.apache.drill.exec.vector.complex.TestEmptyPopulation
-
- testZeroMajorVersion() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataVersion
-
- testZeroMinorVersion() - Method in class org.apache.drill.exec.store.parquet.TestParquetMetadataVersion
-
- TestZKACL - Class in org.apache.drill.exec.coord.zk
-
- TestZKACL() - Constructor for class org.apache.drill.exec.coord.zk.TestZKACL
-
- TestZookeeperClient - Class in org.apache.drill.exec.coord.zk
-
- TestZookeeperClient() - Constructor for class org.apache.drill.exec.coord.zk.TestZookeeperClient
-
- 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
-
- textCrossAndCommaJoinFailsForEnabledOption() - Method in class org.apache.drill.exec.planner.sql.CrossJoinTest
-
- textCrossAndCommaJoinSucceedsForDisabledOption() - Method in class org.apache.drill.exec.planner.sql.CrossJoinTest
-
- TextFormatConfig() - Constructor for class org.apache.drill.exec.store.easy.text.TextFormatPlugin.TextFormatConfig
-
- 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
-
- TextParsingSettings - Class in org.apache.drill.exec.store.easy.text.compliant
-
- TextParsingSettings() - Constructor for class org.apache.drill.exec.store.easy.text.compliant.TextParsingSettings
-
- TextRecordReaderTest - Class in org.apache.drill.exec.store.text
-
- TextRecordReaderTest() - Constructor for class org.apache.drill.exec.store.text.TextRecordReaderTest
-
- TheInnerClass() - Constructor for class org.apache.drill.exec.compile.ExampleTemplateWithInner.TheInnerClass
-
- thirdTest() - Method in class org.apache.drill.test.ExampleTest
-
Example test using the SQL mock data source.
- ThreadsInfo() - Constructor for class org.apache.drill.exec.store.sys.ThreadsIterator.ThreadsInfo
-
- ThreadsIterator - Class in org.apache.drill.exec.store.sys
-
- ThreadsIterator(ExecutorFragmentContext) - Constructor for class org.apache.drill.exec.store.sys.ThreadsIterator
-
- ThreadsIterator.ThreadsInfo - Class in org.apache.drill.exec.store.sys
-
- ThreadsResources - Class in org.apache.drill.exec.server.rest
-
- ThreadsResources() - Constructor for class org.apache.drill.exec.server.rest.ThreadsResources
-
- threadsTable() - Method in class org.apache.drill.exec.store.sys.TestSystemTable
-
- 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.QueuedResourceAllocator - Class in org.apache.drill.exec.work.foreman.rm
-
- ThrottledResourceManager.QueuedResourceAllocator.BufferedOpFinder - Class in org.apache.drill.exec.work.foreman.rm
-
Searches a fragment operator tree to find buffered within that fragment.
- 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
-
- ThrowException() - Constructor for class org.apache.drill.exec.expr.fn.ExceptionFunction.ThrowException
-
- thrown - Variable in class org.apache.drill.exec.fn.impl.TestAggregateFunctions
-
- thrown - Variable in class org.apache.drill.exec.fn.impl.TestCastFunctions
-
- thrown - Variable in class org.apache.drill.exec.impersonation.TestImpersonationMetadata
-
- thrown - Variable in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- thrown - Variable in class org.apache.drill.exec.sql.TestCTTAS
-
- thrown - Variable in class org.apache.drill.exec.store.ischema.TestFilesTable
-
- thrown - Variable in class org.apache.drill.exec.udf.dynamic.TestDynamicUDFSupport
-
- throwSchemaNotFoundException(SchemaPlus, String) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
-
- throwSchemaNotFoundException(SchemaPlus, List<String>) - Static method in class org.apache.drill.exec.planner.sql.SchemaUtilites
-
- throwUnchecked() - Method in class org.apache.drill.exec.testing.ExceptionInjection
-
Throw the unchecked exception specified by this injection.
- time(TimeUnit) - Method in class org.apache.drill.exec.cache.VectorSerializer.Writer
-
- time(String) - Static method in class org.apache.drill.exec.expr.EscapeTest1
-
- TIME - Static variable in interface org.apache.drill.exec.vector.complex.fn.ExtendedTypeName
-
- 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
-
- TimeDateAddFunction() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeDateAddFunction
-
- TimedCallable<V> - Class in org.apache.drill.exec.store
-
Class used to allow parallel executions of tasks in a simplified way.
- TimedCallable() - Constructor for class org.apache.drill.exec.store.TimedCallable
-
- 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
-
- timedPauseInjected() - Method in class org.apache.drill.exec.testing.TestPauseInjection
-
- timedPauseOnSpecificBit() - Method in class org.apache.drill.exec.testing.TestPauseInjection
-
- 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
-
- TimeHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.TimeHash
-
- TimeHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.TimeHash
-
- TimeHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.TimeHash
-
- TimeHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.TimeHash
-
- timeNs() - Method in class org.apache.drill.exec.cache.VectorSerializer.Reader
-
- TimeOfDay() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeOfDay
-
- TIMEOUT - Variable in class org.apache.drill.exec.cache.TestWriteToDisk
-
- TIMEOUT - Variable in class org.apache.drill.exec.compile.TestLargeFileCompilation
-
- TIMEOUT - Variable in class org.apache.drill.exec.physical.impl.join.TestHashJoin
-
- TIMEOUT - Variable in class org.apache.drill.exec.physical.impl.join.TestMergeJoinAdvanced
-
- TIMEOUT - Variable in class org.apache.drill.exec.physical.impl.join.TestMergeJoinMulCondition
-
- TIMEOUT - Variable in class org.apache.drill.exec.physical.impl.xsort.TestSimpleExternalSort
-
- TIMEOUT - Variable in class org.apache.drill.exec.server.TestTpcdsSf1Leaks
-
- TIMEOUT - Variable in class org.apache.drill.exec.store.TestTimedCallable
-
- TIMEOUT - Variable in class org.apache.drill.PlanningBase
-
- TIMEOUT - Variable in class org.apache.drill.test.TestGracefulShutdown
-
- TIMEOUT - Variable in class org.apache.drill.TestTpchDistributedConcurrent
-
- TIMEOUT - Variable in class org.apache.drill.TestTpchPlanning
-
- 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
-
- TimePrinter() - Constructor for class org.apache.drill.test.ProfileParser.TimePrinter
-
- 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
-
- Timer(String) - Constructor for class org.apache.drill.exec.expr.EscapeTest1.Timer
-
- TIMESTAMP - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaTable
-
- 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
-
- 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
-
- TimeStampHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.TimeStampHash
-
- TimeStampHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.TimeStampHash
-
- TimeStampHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.TimeStampHash
-
- TimeStampHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.TimeStampHash
-
- TimeStampType() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeStampType
-
- TimeType() - Constructor for class org.apache.drill.exec.expr.fn.impl.DateTypeFunctions.TimeType
-
- timeVarColumnRead - Variable in class org.apache.drill.exec.store.parquet.ParquetReaderStats
-
- timeZone - Variable in class org.apache.drill.exec.store.image.ImageFormatConfig
-
- 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
-
- toBatchSchema(BatchSchema.SelectionVectorMode) - Method in class org.apache.drill.exec.record.metadata.TupleSchema
-
- toByta(Object) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(byte) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(byte[]) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(short) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(short[]) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(char) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(char[]) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(int) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(int[]) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(long) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(long[]) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(float) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(float[]) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(double) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(double[]) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(boolean) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByta(boolean[]) - Static method in class org.apache.drill.exec.store.ByteArrayUtil
-
- toByteArray() - Method in class org.apache.drill.exec.store.parquet.ColumnDataReader.HadoopBytesInput
-
- toConsole() - Method in class org.apache.drill.test.LogFixture.LogFixtureBuilder
-
Send all enabled logging to the console (if not already configured.) Some
Drill log configuration files send the root to the console (or file), but
the Drill loggers to Lilith.
- toConsole(ConsoleAppender<ILoggingEvent>, String) - Method in class org.apache.drill.test.LogFixture.LogFixtureBuilder
-
- toConsole(String) - Method in class org.apache.drill.test.LogFixture.LogFixtureBuilder
-
Send logging to the console using the defined format.
- toDrill(DrillParseContext, DrillProjectRelBase, RelNode, RexNode) - Static method in class org.apache.drill.exec.planner.index.RexToExpression
-
- 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(DrillParseContext, RelDataType, RexBuilder, RexNode) - Static method in class org.apache.drill.exec.planner.logical.DrillOptiq
-
- 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
-
- toFieldList() - Method in class org.apache.drill.exec.record.metadata.TupleSchema
-
- toIndirect() - Method in class org.apache.drill.test.rowSet.DirectRowSet
-
- toIndirect(Set<Integer>) - Method in class org.apache.drill.test.rowSet.DirectRowSet
-
- toIndirect() - Method in class org.apache.drill.test.rowSet.IndirectRowSet
-
- toIndirect(Set<Integer>) - Method in class org.apache.drill.test.rowSet.IndirectRowSet
-
- toIndirect() - Method in interface org.apache.drill.test.rowSet.RowSet.SingleRowSet
-
- toIndirect(Set<Integer>) - Method in interface org.apache.drill.test.rowSet.RowSet.SingleRowSet
-
- toMajorType(PrimitiveType.PrimitiveTypeName, int, TypeProtos.DataMode, SchemaElement, OptionManager) - Static method in class org.apache.drill.exec.store.parquet.columnreaders.ParquetToDrillTypeConverter
-
- ToNullableNumber() - Constructor for class org.apache.drill.exec.expr.fn.impl.MathFunctions.ToNullableNumber
-
- ToNullableNumberNullableInput() - Constructor for class org.apache.drill.exec.expr.fn.impl.MathFunctions.ToNullableNumberNullableInput
-
- ToNumber() - Constructor for class org.apache.drill.exec.expr.fn.impl.MathFunctions.ToNumber
-
- toOptionValue(OptionDefinition, OptionValue.OptionScope) - Method in class org.apache.drill.exec.server.options.PersistedOptionValue
-
- 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
-
- TOPN - Static variable in class org.apache.drill.exec.planner.physical.PlannerSettings
-
- topN() - Method in class org.apache.drill.exec.store.parquet.TestParquetComplex
-
- TopNBatch - Class in org.apache.drill.exec.physical.impl.TopN
-
Operator Batch which implements the TopN functionality.
- 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
-
- TopNBatchTest - Class in org.apache.drill.exec.physical.impl.TopN
-
- TopNBatchTest() - Constructor for class org.apache.drill.exec.physical.impl.TopN.TopNBatchTest
-
- 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
-
- toReadOptions() - Method in class org.apache.drill.exec.store.parquet.ParquetReaderConfig
-
- 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
-
- toRemoveSort(RelCollation, RelCollation) - Static method in class org.apache.drill.exec.planner.index.generators.AbstractIndexPlanGenerator
-
- toResponse(Throwable) - Method in class org.apache.drill.exec.server.rest.GenericExceptionMapper
-
- toRex(LogicalExpression) - Method in class org.apache.drill.exec.planner.torel.ConversionContext
-
- tortureTest() - Method in class org.apache.drill.exec.physical.rowSet.impl.TestResultSetLoaderTorture
-
- 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.ValueVectorReadExpression
-
- toString() - Method in class org.apache.drill.exec.physical.base.ScanStats
-
- toString() - Method in class org.apache.drill.exec.physical.base.SchemalessScan
-
- toString() - Method in class org.apache.drill.exec.physical.config.HashAggregate
-
- toString() - Method in class org.apache.drill.exec.physical.config.OrderedPartitionSender
-
- toString() - Method in class org.apache.drill.exec.physical.config.PartitionLimit
-
- toString() - Method in class org.apache.drill.exec.physical.config.Screen
-
- toString() - Method in class org.apache.drill.exec.physical.config.Sort
-
- toString() - Method in class org.apache.drill.exec.physical.config.TopN
-
- toString() - Method in class org.apache.drill.exec.physical.config.WindowPOP.Bound
-
- toString() - Method in class org.apache.drill.exec.physical.config.WindowPOP
-
- toString() - Method in class org.apache.drill.exec.physical.EndpointAffinity
-
- toString() - Method in class org.apache.drill.exec.physical.impl.aggregate.HashAggTemplate
-
- toString() - Method in class org.apache.drill.exec.physical.impl.aggregate.StreamingAggTemplate
-
- toString() - Method in class org.apache.drill.exec.physical.impl.filter.FilterTemplate2
-
- toString() - Method in class org.apache.drill.exec.physical.impl.filter.FilterTemplate4
-
- toString() - Method in class org.apache.drill.exec.physical.impl.flatten.FlattenTemplate
-
- toString() - Method in class org.apache.drill.exec.physical.impl.join.HashJoinProbeTemplate
-
- 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.project.ProjectorTemplate
-
- toString() - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTableColumn
-
- toString() - Method in class org.apache.drill.exec.physical.impl.scan.project.ScanLevelProjection
-
- toString() - Method in class org.apache.drill.exec.physical.impl.scan.project.UnresolvedColumn
-
- toString() - Method in class org.apache.drill.exec.physical.impl.sort.SortTemplate
-
- toString() - Method in class org.apache.drill.exec.physical.impl.unnest.UnnestImpl
-
- toString() - Method in class org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator
-
- toString() - Method in class org.apache.drill.exec.physical.impl.window.FrameSupportTemplate
-
- toString() - Method in class org.apache.drill.exec.physical.impl.window.NoFrameSupportTemplate
-
- toString() - Method in class org.apache.drill.exec.physical.impl.window.Partition
-
- toString() - Method in class org.apache.drill.exec.physical.impl.window.WindowDataBatch
-
- toString() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortConfig
-
- toString() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortImpl
-
- toString() - Method in class org.apache.drill.exec.physical.impl.xsort.MSortTemplate
-
- toString() - Method in class org.apache.drill.exec.physical.impl.xsort.SingleBatchSorterTemplate
-
- toString() - Method in class org.apache.drill.exec.physical.MinorFragmentEndpoint
-
- toString() - Method in class org.apache.drill.exec.physical.rowSet.project.RequestedColumnImpl
-
- 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.index.DrillIndexDefinition
-
- 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.handlers.FindLimit0Visitor.RelDataTypeReader
-
Represents RelDataTypeReader content as string, used in query plan json.
- 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.metadata.AbstractColumnMetadata
-
- toString() - Method in class org.apache.drill.exec.record.metadata.TupleSchema
-
- toString() - Method in class org.apache.drill.exec.record.metadata.VariantSchema
-
- toString() - Method in class org.apache.drill.exec.record.RawFragmentBatch
-
- toString() - Method in class org.apache.drill.exec.record.RecordBatchLoader
-
- toString() - Method in class org.apache.drill.exec.record.RecordBatchSizer.ColumnSize
-
- toString() - Method in class org.apache.drill.exec.record.RecordBatchSizer
-
- toString() - Method in class org.apache.drill.exec.record.RecordIterator
-
- toString() - Method in class org.apache.drill.exec.record.selection.SelectionVector2
-
- toString() - Method in class org.apache.drill.exec.record.selection.SelectionVector4
-
- 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.options.PersistedOptionValueTest.MockPersistedOptionValue
-
- 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.avro.AvroRecordReader
-
- toString() - Method in class org.apache.drill.exec.store.bson.BsonRecordReader
-
- toString() - Method in class org.apache.drill.exec.store.dfs.easy.EasyGroupScan
-
- toString() - Method in class org.apache.drill.exec.store.dfs.easy.EasyWriter
-
- 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.easy.json.reader.BaseJsonProcessor
-
- toString() - Method in class org.apache.drill.exec.store.easy.sequencefile.SequenceFileRecordReader
-
- toString() - Method in class org.apache.drill.exec.store.easy.text.compliant.CompliantTextRecordReader
-
- toString() - Method in class org.apache.drill.exec.store.image.ImageRecordReader
-
- 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.log.LogRecordReader
-
- 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.columnreaders.ParquetRecordReader
-
- toString() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V1.ParquetFileMetadata_v1
-
- toString() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ColumnTypeMetadata_v2.Key
-
- toString() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V2.ParquetFileMetadata_v2
-
- toString() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ColumnTypeMetadata_v3.Key
-
- toString() - Method in class org.apache.drill.exec.store.parquet.metadata.Metadata_V3.ParquetFileMetadata_v3
-
- toString() - Method in class org.apache.drill.exec.store.parquet.metadata.MetadataVersion
-
- toString() - Method in class org.apache.drill.exec.store.parquet.ParquetFormatConfig
-
- toString() - Method in class org.apache.drill.exec.store.parquet.ParquetGroupScan
-
- toString() - Method in class org.apache.drill.exec.store.parquet.ParquetReaderConfig
-
- toString() - Method in class org.apache.drill.exec.store.parquet.ParquetWriter
-
- toString() - Method in class org.apache.drill.exec.store.parquet2.DrillParquetReader
-
- toString() - Method in class org.apache.drill.exec.store.pcap.PcapRecordReader
-
- 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.store.StorageStrategy
-
- toString() - Method in class org.apache.drill.exec.store.text.DrillTextRecordReader
-
- 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.filter.BloomFilterDef
-
- toString() - Method in class org.apache.drill.exec.work.filter.RuntimeFilterWritable
-
- 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
-
- toString() - Method in class org.apache.drill.exec.work.prepare.PreparedStatementTestBase.ExpectedColumnResult
-
- toString() - Method in class org.apache.drill.test.FieldDef
-
- toString() - Method in class org.apache.drill.test.ProfileParser.OperatorProfile
-
- toString() - Method in class org.apache.drill.test.ProfileParser.OperatorSummary
-
- toString() - Method in class org.apache.parquet.hadoop.ColumnChunkIncReadStore
-
- 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 - Variable in class org.apache.drill.test.ProfileParser.Aggregator
-
- TOTAL_STUFF_COL - Static variable in class org.apache.drill.exec.physical.impl.agg.TestHashAggBatch
-
- 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
-
- totalProcess - Variable in class org.apache.drill.test.ProfileParser.Aggregator
-
- totalRowCount() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- totalRowCount() - Method in interface org.apache.drill.exec.physical.rowSet.ResultSetLoader
-
Total number of rows loaded for all previous batches and the
current batch.
- totalSetup - Variable in class org.apache.drill.test.ProfileParser.Aggregator
-
- totalTime - Variable in class org.apache.drill.exec.store.sys.ProfileInfoIterator.ProfileInfo
-
- totalValuesReadAndReadyToReadInPage() - Method in class org.apache.drill.exec.store.parquet.columnreaders.ColumnReader
-
- totalValuesReadAndReadyToReadInPage() - Method in class org.apache.drill.exec.store.parquet.columnreaders.FixedWidthRepeatedReader
-
- tpch01() - Method in class org.apache.drill.exec.testing.TestResourceLeak
-
- tpch01() - Method in class org.apache.drill.TestOutOfMemoryOutcome
-
- tpch01() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch01() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch01() - Method in class org.apache.drill.TestTpchExplain
-
- tpch01() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch01() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch01() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch02() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch02() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch02() - Method in class org.apache.drill.TestTpchExplain
-
- tpch02() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch02() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch02() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch03() - Method in class org.apache.drill.TestOutOfMemoryOutcome
-
- tpch03() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch03() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch03() - Method in class org.apache.drill.TestTpchExplain
-
- tpch03() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch03() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch03() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch04() - Method in class org.apache.drill.TestOutOfMemoryOutcome
-
- tpch04() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch04() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch04() - Method in class org.apache.drill.TestTpchExplain
-
- tpch04() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch04() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch04() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch05() - Method in class org.apache.drill.TestOutOfMemoryOutcome
-
- tpch05() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch05() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch05() - Method in class org.apache.drill.TestTpchExplain
-
- tpch05() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch05() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch05() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch06() - Method in class org.apache.drill.TestOutOfMemoryOutcome
-
- tpch06() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch06() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch06() - Method in class org.apache.drill.TestTpchExplain
-
- tpch06() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch06() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch06() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch07() - Method in class org.apache.drill.TestOutOfMemoryOutcome
-
- tpch07() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch07() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch07() - Method in class org.apache.drill.TestTpchExplain
-
- tpch07() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch07() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch07() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch08() - Method in class org.apache.drill.TestOutOfMemoryOutcome
-
- tpch08() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch08() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch08() - Method in class org.apache.drill.TestTpchExplain
-
- tpch08() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch08() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch08() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch09() - Method in class org.apache.drill.TestOutOfMemoryOutcome
-
- tpch09() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch09() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch09() - Method in class org.apache.drill.TestTpchExplain
-
- tpch09() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch09() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch09() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch10() - Method in class org.apache.drill.TestOutOfMemoryOutcome
-
- tpch10() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch10() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch10() - Method in class org.apache.drill.TestTpchExplain
-
- tpch10() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch10() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch10() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch11() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch11() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch11() - Method in class org.apache.drill.TestTpchExplain
-
- tpch11() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch11() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch11() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch12() - Method in class org.apache.drill.TestOutOfMemoryOutcome
-
- tpch12() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch12() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch12() - Method in class org.apache.drill.TestTpchExplain
-
- tpch12() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch12() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch12() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch13() - Method in class org.apache.drill.TestOutOfMemoryOutcome
-
- tpch13() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch13() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch13() - Method in class org.apache.drill.TestTpchExplain
-
- tpch13() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch13() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch13() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch14() - Method in class org.apache.drill.TestOutOfMemoryOutcome
-
- tpch14() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch14() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch14() - Method in class org.apache.drill.TestTpchExplain
-
- tpch14() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch14() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch14() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch15() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch15() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch15() - Method in class org.apache.drill.TestTpchExplain
-
- tpch15() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch15() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch15() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch16() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch16() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch16() - Method in class org.apache.drill.TestTpchExplain
-
- tpch16() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch16() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch16() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch17() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch17() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch17() - Method in class org.apache.drill.TestTpchExplain
-
- tpch17() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch17() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch17() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch18() - Method in class org.apache.drill.TestOutOfMemoryOutcome
-
- tpch18() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch18() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch18() - Method in class org.apache.drill.TestTpchExplain
-
- tpch18() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch18() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch18() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch19() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch19() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch19() - Method in class org.apache.drill.TestTpchExplain
-
- tpch19() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch19() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch19() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch19_1() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch19_1() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch19_1() - Method in class org.apache.drill.TestTpchExplain
-
- tpch20() - Method in class org.apache.drill.TestOutOfMemoryOutcome
-
- tpch20() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch20() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch20() - Method in class org.apache.drill.TestTpchExplain
-
- tpch20() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch20() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch20() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch21() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch21() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch21() - Method in class org.apache.drill.TestTpchExplain
-
- tpch21() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch21() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch21() - Method in class org.apache.drill.TestTpchSingleMode
-
- tpch22() - Method in class org.apache.drill.TestTpchDistributed
-
- tpch22() - Method in class org.apache.drill.TestTpchDistributedStreaming
-
- tpch22() - Method in class org.apache.drill.TestTpchExplain
-
- tpch22() - Method in class org.apache.drill.TestTpchLimit0
-
- tpch22() - Method in class org.apache.drill.TestTpchPlanning
-
- tpch22() - Method in class org.apache.drill.TestTpchSingleMode
-
- 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.DrillCorrelateRule
-
- 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 contains value vectors which are exactly the same
as the incoming record batch's value vectors.
- 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
-
- trackSchema(VectorContainer) - Method in class org.apache.drill.exec.physical.impl.protocol.SchemaTracker
-
- 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
- transferPairs - Variable in class org.apache.drill.exec.physical.impl.svremover.AbstractSV2Copier
-
- 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.
- transformBinaryInMetadataCache(MetadataBase.ParquetTableMetadataBase, ParquetReaderConfig) - Static method in class org.apache.drill.exec.store.parquet.ParquetReaderUtility
-
Transforms values for min / max binary statistics to byte array.
- transformColumns(Collection<SchemaPath>) - Method in class org.apache.drill.exec.store.AbstractRecordReader
-
- transformExpr(RexBuilder, RexNode, Map<Integer, Integer>) - Static method in class org.apache.drill.exec.planner.common.DrillRelOptUtil
-
Given a of rexnode it transforms the rexnode by changing the expr to use new index mapped to the old index.
- transformExprs(RexBuilder, List<RexNode>, Map<Integer, Integer>) - Static method in class org.apache.drill.exec.planner.common.DrillRelOptUtil
-
Given a list of rexnodes it transforms the rexnodes by changing the expr to use new index mapped to the old index.
- 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
-
- transition(String) - Method in class org.apache.drill.exec.compile.FsmCursor
-
Record a transition in the state machine.
- translateRecordListToHeapVectors(List<Map<String, Object>>) - Static method in class org.apache.drill.test.DrillTestWrapper
-
- traverseClassDeclaration(Java.AbstractClassDeclaration) - 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
-
- TreePrinter() - Constructor for class org.apache.drill.test.ProfileParser.TreePrinter
-
- TreeVisitor() - Constructor for class org.apache.drill.test.ProfileParser.TreeVisitor
-
- trimSlash(String) - Static method in class org.apache.drill.test.ClusterFixture
-
Guava likes paths to resources without an initial slash, the JDK
needs a slash.
- trimUnused() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultVectorCacheImpl
-
- TRIVIAL_TABLE - Static variable in class org.apache.drill.exec.physical.base.ScanStats
-
- truncate(Path, long) - Method in class org.apache.drill.exec.store.dfs.DrillFileSystem
-
- trySettingAdminOptsAtSessionScopeAsAdmin() - Method in class org.apache.drill.exec.server.TestOptionsAuthEnabled
-
- trySettingAdminOptsAtSessionScopeAsNonAdmin() - Method in class org.apache.drill.exec.server.TestOptionsAuthEnabled
-
- trySimpleQueryWithLimit() - Method in class org.apache.drill.exec.store.json.TestJsonRecordReader
-
- tuple() - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.ArraySchemaCreator
-
- tuple() - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.ArraySchemaRetrieval
-
- tuple() - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.MetadataCreator
-
- tuple() - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.MetadataRetrieval
-
- tuple() - Method in interface org.apache.drill.exec.physical.rowSet.model.MetadataProvider
-
- tuple() - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.VariantSchemaCreator
-
- tuple() - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.VariantSchemaRetrieval
-
- TupleModel - Interface in org.apache.drill.exec.physical.rowSet.model
-
Common interface to access a tuple backed by a vector container or a
map vector.
- TupleModel.ColumnModel - Interface in org.apache.drill.exec.physical.rowSet.model
-
Common interface to access a column vector, its metadata, and its
tuple definition (for maps.) Provides a visitor interface for common
vector tasks.
- TupleModel.RowSetModel - Interface in org.apache.drill.exec.physical.rowSet.model
-
Tuple-model interface for the top-level row (tuple) structure.
- TupleSchema - Class in org.apache.drill.exec.record.metadata
-
Defines the schema of a tuple: either the top-level row or a nested
"map" (really structure).
- TupleSchema() - Constructor for class org.apache.drill.exec.record.metadata.TupleSchema
-
- tupleSchema() - Method in class org.apache.drill.test.rowSet.RowSetReaderImpl
-
- TupleState - Class in org.apache.drill.exec.physical.rowSet.impl
-
Represents the loader state for a tuple: a row or a map.
- TupleState(LoaderInternals, ResultVectorCache, RequestedTuple) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.TupleState
-
- TupleState.MapArrayState - Class in org.apache.drill.exec.physical.rowSet.impl
-
- TupleState.MapColumnState - Class in org.apache.drill.exec.physical.rowSet.impl
-
Represents a map column (either single or repeated).
- TupleState.MapState - Class in org.apache.drill.exec.physical.rowSet.impl
-
Represents a tuple defined as a Drill map: single or repeated.
- TupleState.MapVectorState - Class in org.apache.drill.exec.physical.rowSet.impl
-
State for a map vector.
- TupleState.RowState - Class in org.apache.drill.exec.physical.rowSet.impl
-
Handles the details of the top-level tuple, the data row itself.
- TupleState.SingleMapState - Class in org.apache.drill.exec.physical.rowSet.impl
-
- twoBitOneExchangeTwoEntryRun() - Method in class org.apache.drill.exec.physical.impl.TestDistributedFragmentRun
-
- twoBitTwoExchange() - Method in class org.apache.drill.exec.physical.impl.mergereceiver.TestMergingReceiver
-
- twoBitTwoExchangeRun() - Method in class org.apache.drill.exec.physical.impl.orderedpartitioner.TestOrderedPartitionExchange
-
Starts two drillbits and runs a physical plan with a Mock scan, project, OrderedParititionExchange, Union Exchange,
and sort.
- twoBitTwoExchangeTwoEntryRun() - Method in class org.apache.drill.exec.physical.impl.TestHashToRandomExchange
-
- twoBitTwoExchangeTwoEntryRun() - Method in class org.apache.drill.exec.physical.impl.TestUnionExchange
-
- twoKeyAgg() - Method in class org.apache.drill.exec.physical.impl.agg.TestAgg
-
- twoLevelDir() - Method in class org.apache.drill.exec.planner.logical.FilterSplitTest
-
- twoTargetGroups() - Method in class org.apache.drill.exec.impersonation.TestInboundImpersonationPrivileges
-
- twoTargetUsers() - Method in class org.apache.drill.exec.impersonation.TestInboundImpersonationPrivileges
-
- twoWayCast() - Method in class org.apache.drill.exec.physical.impl.TestReverseImplicitCast
-
- TYPE - Static variable in class org.apache.drill.exec.physical.impl.join.HashTableSizeCalculatorConservativeImpl
-
- TYPE - Static variable in class org.apache.drill.exec.physical.impl.join.HashTableSizeCalculatorLeanImpl
-
- type() - Method in interface org.apache.drill.exec.physical.impl.scan.project.NullColumnLoader.NullColumnSpec
-
- type() - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedNullColumn
-
- type() - Method in class org.apache.drill.exec.physical.rowSet.project.RequestedColumnImpl
-
- type() - Method in interface org.apache.drill.exec.physical.rowSet.project.RequestedTuple.RequestedColumn
-
- type - Variable in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- type() - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- TYPE - Static variable in class org.apache.drill.exec.rpc.user.security.testing.UserAuthenticatorTestImpl
-
- type - Variable in class org.apache.drill.exec.server.options.PersistedOptionValueTest.MockPersistedOptionValue
-
- 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 - Variable in class org.apache.drill.test.BufferingQueryEventListener.QueryEvent
-
- type - Variable in class org.apache.drill.test.FieldDef
-
- type - Variable in class org.apache.drill.test.ProfileParser.OperatorProfile
-
- type - Variable in class org.apache.drill.test.ProfileParser.OperatorSummary
-
- 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
-
- 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
-
- typeFactory - Variable in class org.apache.drill.exec.planner.types.AbstractRelDataTypeHolder
-
- TypeInferenceUtils - Class in org.apache.drill.exec.planner.sql
-
- types() - Method in class org.apache.drill.exec.record.metadata.VariantSchema
-
- types - Variable in class org.apache.drill.exec.record.vector.TestValueVector.ChildVerifier
-
- typeStr - Variable in class org.apache.drill.test.FieldDef
-
- TypeValidator(String, OptionValue.Kind, OptionValidator.OptionDescription) - Constructor for class org.apache.drill.exec.server.options.TypeValidators.TypeValidator
-
- 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.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.BooleanValidator - Class in org.apache.drill.exec.server.options
-
- TypeValidators.DateTimeFormatValidator - Class in org.apache.drill.exec.server.options
-
Validator that checks if the given DateTime format template is valid.
- TypeValidators.DoubleValidator - Class in org.apache.drill.exec.server.options
-
- 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.IntegerValidator - Class in org.apache.drill.exec.server.options
-
- TypeValidators.LongValidator - Class in org.apache.drill.exec.server.options
-
- TypeValidators.MaxRangeDoubleValidator - Class in org.apache.drill.exec.server.options
-
- TypeValidators.MaxWidthValidator - Class in org.apache.drill.exec.server.options
-
Max width is a special validator which computes and validates
the maxwidth.
- TypeValidators.MinRangeDoubleValidator - Class in org.apache.drill.exec.server.options
-
- TypeValidators.PositiveLongValidator - Class in org.apache.drill.exec.server.options
-
- TypeValidators.PowerOfTwoLongValidator - Class in org.apache.drill.exec.server.options
-
- TypeValidators.RangeDoubleValidator - Class in org.apache.drill.exec.server.options
-
- TypeValidators.RangeLongValidator - Class in org.apache.drill.exec.server.options
-
- TypeValidators.StringValidator - Class in org.apache.drill.exec.server.options
-
- TypeValidators.TypeValidator - Class in org.apache.drill.exec.server.options
-
- V1 - Static variable in class org.apache.drill.exec.store.parquet.metadata.MetadataVersion.Constants
-
Version 1: Introduces parquet file metadata caching.
See DRILL-2743
- V2 - Static variable in class org.apache.drill.exec.store.parquet.metadata.MetadataVersion.Constants
-
Version 2: Metadata cache file size is reduced.
See DRILL-4053
- V3 - Static variable in class org.apache.drill.exec.store.parquet.metadata.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.metadata.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.metadata.MetadataVersion.Constants
-
- V3_3 - Static variable in class org.apache.drill.exec.store.parquet.metadata.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 interface org.apache.drill.exec.physical.impl.scan.project.ScanLevelProjection.ScanProjectionParser
-
- validate() - Method in class org.apache.drill.exec.physical.impl.validate.BatchValidator
-
- validate(RowSet) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl.DataValidator
-
- 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.DateTimeFormatValidator
-
- 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.IntegerValidator
-
- 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
-
- validateColumn(ColumnProjection) - Method in interface org.apache.drill.exec.physical.impl.scan.project.ScanLevelProjection.ScanProjectionParser
-
- validateControlsString(String) - Static method in class org.apache.drill.exec.testing.ControlsInjectionUtil
-
- validateControlsString(String) - Static method in class org.apache.drill.exec.testing.ExecutionControls
-
- validateDone() - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl.DataValidator
-
- validateFinalStats(SortImpl) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl.SortTestFixture
-
- validateHandshake(int, List<String>, int, ClientConnection, BitConnectionConfig, BasicClient) - Static method in class org.apache.drill.exec.rpc.BitRpcUtility
-
Method to do validation on the handshake message received from server side.
- 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
-
- validateNode(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.DefaultSqlHandler
-
- validateNode(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.DescribeTableHandler
-
- validateNode(SqlNode) - Method in class org.apache.drill.exec.planner.sql.handlers.ShowTablesHandler
-
- validateRequest(ServletRequest, ServletResponse, boolean) - Method in class org.apache.drill.exec.server.rest.auth.DrillSpnegoAuthenticator
-
Updated logic as compared to default implementation in
SpnegoAuthenticator.validateRequest(ServletRequest, ServletResponse, boolean)
to handle below cases:
1) Perform SPNEGO authentication only when spnegoLogin resource is requested.
- validateSingleExchangeFragment() - Method in class org.apache.drill.exec.pop.TestFragmentChecker
-
- validateSort(SortImpl) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.TestSortImpl.SortTestFixture
-
- validateSpnegoConfig() - Method in class org.apache.drill.exec.server.rest.auth.SpnegoConfig
-
- validRexOperands(int, Litmus) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlAggFunctionWrapper
-
- validRexOperands(int, Litmus) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlFunctionWrapper
-
- validRexOperands(int, Litmus) - Method in class org.apache.drill.exec.planner.sql.DrillCalciteSqlOperatorWrapper
-
- value - Variable in class org.apache.drill.exec.physical.impl.common.IndexPointer
-
- value() - Method in interface org.apache.drill.exec.physical.impl.scan.project.ConstantColumnLoader.ConstantColumnSpec
-
- 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
-
- value - Variable in class org.apache.drill.test.ClusterFixtureBuilder.RuntimeOption
-
- valueAssignment() - Method in class org.apache.drill.exec.server.options.PersistedOptionValueTest
-
- 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.OutputWidthCalculatorType
-
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.expr.stat.ParquetFilterPredicate.RowsMatch
-
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.filter.RuntimeFilterRecordBatch.Metric
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.drill.exec.physical.impl.flatten.FlattenRecordBatch.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.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.HashJoinState
-
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.join.RowKeyJoin.RowKeyJoinState
-
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.protocol.OperatorDriver.State
-
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.unnest.UnnestRecordBatch.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.physical.rowSet.impl.ColumnState.State
-
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.index.IndexCollection.IndexCollectionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.drill.exec.planner.index.IndexDefinition.IndexType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.drill.exec.planner.index.IndexPlanUtils.ConditionIndexed
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.drill.exec.planner.logical.RowKeyJoinCallContext.RowKey
-
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.AbstractBinaryRecordBatch.Metric
-
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.parquet.ParquetSimpleTestFileGenerator.EnumType
-
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.util.record.RecordBatchStats.RecordBatchIOType
-
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.
- valueOf(String) - Static method in enum org.apache.drill.test.BaseDirTestWatcher.DirType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.drill.test.BufferingQueryEventListener.QueryEvent.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.drill.test.FieldDef.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.drill.test.FieldDef.TypeHint
-
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.OutputWidthCalculatorType
-
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.expr.stat.ParquetFilterPredicate.RowsMatch
-
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.filter.RuntimeFilterRecordBatch.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.flatten.FlattenRecordBatch.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.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.HashJoinState
-
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.join.RowKeyJoin.RowKeyJoinState
-
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.protocol.OperatorDriver.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.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.unnest.UnnestRecordBatch.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.physical.rowSet.impl.ColumnState.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.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.index.IndexCollection.IndexCollectionType
-
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.index.IndexDefinition.IndexType
-
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.index.IndexPlanUtils.ConditionIndexed
-
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.logical.RowKeyJoinCallContext.RowKey
-
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 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.AbstractBinaryRecordBatch.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.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.parquet.ParquetSimpleTestFileGenerator.EnumType
-
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.util.record.RecordBatchStats.RecordBatchIOType
-
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.
- values() - Static method in enum org.apache.drill.test.BaseDirTestWatcher.DirType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.drill.test.BufferingQueryEventListener.QueryEvent.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.test.FieldDef.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.test.FieldDef.TypeHint
-
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, List<? extends List<RexLiteral>>, RelTraitSet) - Constructor for class org.apache.drill.exec.planner.physical.ValuesPrel
-
- ValuesPrel(RelOptCluster, RelDataType, List<? extends List<RexLiteral>>, RelTraitSet, JSONOptions) - Constructor for class org.apache.drill.exec.planner.physical.ValuesPrel
-
- ValuesPrule - Class in org.apache.drill.exec.planner.physical
-
- ValueVectorElementFormatter - Class in org.apache.drill.exec.util
-
This class is responsible for formatting ValueVector elements.
- ValueVectorElementFormatter(OptionManager) - Constructor for class org.apache.drill.exec.util.ValueVectorElementFormatter
-
- ValueVectorHashHelper - Class in org.apache.drill.exec.expr.fn.impl
-
- ValueVectorHashHelper(RecordBatch, FragmentContext) - Constructor for class org.apache.drill.exec.expr.fn.impl.ValueVectorHashHelper
-
- ValueVectorHashHelper.Hash64 - Interface in org.apache.drill.exec.expr.fn.impl
-
- ValueVectorHashHelper.Hash64Template - Class in org.apache.drill.exec.expr.fn.impl
-
- 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
-
- Var16CharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.Var16CharHash
-
- Var16CharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.Var16CharHash
-
- Var16CharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.Var16CharHash
-
- Var16CharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.Var16CharHash
-
- VarBinaryHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.VarBinaryHash
-
- VarBinaryHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.VarBinaryHash
-
- VarBinaryHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.VarBinaryHash
-
- VarBinaryHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.VarBinaryHash
-
- VARCHAR - Static variable in class org.apache.drill.exec.store.ischema.InfoSchemaTable
-
- VarCharAggregateErrorFunctions() - Constructor for class org.apache.drill.exec.expr.fn.impl.AggregateErrorFunctions.VarCharAggregateErrorFunctions
-
- VarCharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.VarCharHash
-
- VarCharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.VarCharHash
-
- VarCharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.VarCharHash
-
- VarCharHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.VarCharHash
-
- VarDecimalHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32AsDouble.VarDecimalHash
-
- VarDecimalHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32Functions.VarDecimalHash
-
- VarDecimalHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32FunctionsWithSeed.VarDecimalHash
-
- VarDecimalHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash32WithSeedAsDouble.VarDecimalHash
-
- VarDecimalHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64AsDouble.VarDecimalHash
-
- VarDecimalHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64Functions.VarDecimalHash
-
- VarDecimalHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64FunctionsWithSeed.VarDecimalHash
-
- VarDecimalHash() - Constructor for class org.apache.drill.exec.expr.fn.impl.Hash64WithSeedAsDouble.VarDecimalHash
-
- varDecimalVector - Variable in class org.apache.drill.exec.store.parquet.columnreaders.VarLengthColumnReaders.VarDecimalColumn
-
- VarHelpers - Class in org.apache.drill.exec.expr.fn.impl
-
- VarHelpers() - Constructor for class org.apache.drill.exec.expr.fn.impl.VarHelpers
-
- variableOutputSizeEstimate() - Method in class org.apache.drill.exec.expr.fn.DrillFuncHolder
-
- variableOutputSizeEstimate() - Method in class org.apache.drill.exec.expr.fn.FunctionAttributes
-
- 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
-
- VariableWidthReader(ReadState) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.BatchReader.VariableWidthReader
-
- VariableWidthVectorState(ColumnMetadata, WriterPosition, ValueVector) - Constructor for class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState.VariableWidthVectorState
-
- variant() - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.ArraySchemaCreator
-
- variant() - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.ArraySchemaRetrieval
-
- variant() - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.MetadataCreator
-
- variant() - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.MetadataRetrieval
-
- variant() - Method in interface org.apache.drill.exec.physical.rowSet.model.MetadataProvider
-
- variant() - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.VariantSchemaCreator
-
- variant() - Method in class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.VariantSchemaRetrieval
-
- variantArray(Object...) - Static method in class org.apache.drill.test.rowSet.RowSetUtilities
-
- VariantColumnMetadata - Class in org.apache.drill.exec.record.metadata
-
- VariantColumnMetadata(MaterializedField) - Constructor for class org.apache.drill.exec.record.metadata.VariantColumnMetadata
-
- VariantColumnMetadata(MaterializedField, VariantSchema) - Constructor for class org.apache.drill.exec.record.metadata.VariantColumnMetadata
-
- VariantColumnMetadata(String, TypeProtos.MinorType, VariantSchema) - Constructor for class org.apache.drill.exec.record.metadata.VariantColumnMetadata
-
- variantSchema() - Method in class org.apache.drill.exec.physical.rowSet.impl.ListState
-
- variantSchema() - Method in class org.apache.drill.exec.physical.rowSet.impl.UnionState
-
- variantSchema() - Method in class org.apache.drill.exec.record.metadata.AbstractColumnMetadata
-
- variantSchema() - Method in class org.apache.drill.exec.record.metadata.VariantColumnMetadata
-
- VariantSchema - Class in org.apache.drill.exec.record.metadata
-
- VariantSchema() - Constructor for class org.apache.drill.exec.record.metadata.VariantSchema
-
- VariantSchemaCreator(VariantSchema) - Constructor for class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.VariantSchemaCreator
-
- VariantSchemaRetrieval(VariantSchema) - Constructor for class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.VariantSchemaRetrieval
-
- VarLenBinaryReader - Class in org.apache.drill.exec.store.parquet.columnreaders
-
Class which handles reading a batch of rows from a set of variable columns
- VarLenBinaryReader(ParquetRecordReader, List<VarLengthColumn<? extends ValueVector>>) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.VarLenBinaryReader
-
- VarLenColumnBatchStats(ValueVector, int) - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager.VarLenColumnBatchStats
-
Constructor.
- VarLenColumnBulkInput<V extends ValueVector> - Class in org.apache.drill.exec.store.parquet.columnreaders
-
- 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.NullableVarBinaryColumn - Class in org.apache.drill.exec.store.parquet.columnreaders
-
- VarLengthColumnReaders.NullableVarCharColumn - Class in org.apache.drill.exec.store.parquet.columnreaders
-
- VarLengthColumnReaders.NullableVarDecimalColumn - 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
-
- VarLengthColumnReaders.VarDecimalColumn - 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
-
- VarLenOverflowReader - Class in org.apache.drill.exec.store.parquet.columnreaders
-
This class is responsible for processing serialized overflow data (generated in a previous batch); this way
overflow data becomes an input source and is thus a) efficiently re-loaded into the current
batch ValueVector and b) subjected to the same batching constraints rules.
- VarLenReadExpr(ValueVectorReadExpression) - Constructor for class org.apache.drill.exec.physical.impl.project.OutputWidthExpression.VarLenReadExpr
-
- VarLenReadExpr(String) - Constructor for class org.apache.drill.exec.physical.impl.project.OutputWidthExpression.VarLenReadExpr
-
- 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
-
- VaryingStringGen - Class in org.apache.drill.exec.store.mock
-
- VaryingStringGen() - Constructor for class org.apache.drill.exec.store.mock.VaryingStringGen
-
- vector(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.NullColumnBuilder
-
- vector(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedMap
-
- vector(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.ResolvedTuple.ResolvedRow
-
- vector(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.ScanSchemaOrchestrator.ReaderSchemaOrchestrator
-
- vector(int) - Method in class org.apache.drill.exec.physical.impl.scan.project.TestRowBatchMerger.RowSetSource
-
- vector(int) - Method in interface org.apache.drill.exec.physical.impl.scan.project.VectorSource
-
- vector() - Method in class org.apache.drill.exec.physical.rowSet.impl.ColumnState
-
- vector() - Method in class org.apache.drill.exec.physical.rowSet.impl.ListState.ListVectorState
-
- vector() - Method in class org.apache.drill.exec.physical.rowSet.impl.NullableVectorState
-
- vector() - Method in class org.apache.drill.exec.physical.rowSet.impl.NullVectorState.UnmanagedVectorState
-
- vector() - Method in class org.apache.drill.exec.physical.rowSet.impl.NullVectorState
-
- vector() - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedListState.RepeatedListVectorState
-
- vector() - Method in class org.apache.drill.exec.physical.rowSet.impl.RepeatedVectorState
-
- vector() - Method in class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState
-
- vector() - Method in class org.apache.drill.exec.physical.rowSet.impl.TupleState.MapVectorState
-
- vector() - Method in class org.apache.drill.exec.physical.rowSet.impl.UnionState.UnionVectorState
-
- vector() - Method in class org.apache.drill.exec.physical.rowSet.impl.UnionState
-
- vector() - Method in interface org.apache.drill.exec.physical.rowSet.impl.VectorState
-
Underlying vector: the one presented to the consumer of the
result set loader.
- vector() - Method in class org.apache.drill.exec.physical.rowSet.model.hyper.BaseReaderBuilder.HyperVectorAccessor
-
- vector - Variable in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.BatchSizingMemoryUtil.ColumnMemoryUsageInfo
-
Value vector which contains the column batch data
- vector - Variable in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.RecordBatchSizerManager.VarLenColumnBatchStats
-
Value vector associated with a VL column
- vector - Variable in class org.apache.drill.exec.store.pojo.AbstractPojoWriter
-
- VectorAccessible - Interface in org.apache.drill.exec.record
-
- vectorAccessible() - Method in class org.apache.drill.test.rowSet.AbstractRowSet
-
- vectorAccessible() - Method in interface org.apache.drill.test.rowSet.RowSet
-
- 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.
- VectorAllocator - Class in org.apache.drill.exec.physical.rowSet.model.single
-
Given a vector container, and a metadata schema that matches the container,
walk the schema tree to allocate new vectors according to a given
row count and the size information provided in column metadata.
- VectorAllocator(VectorContainer) - Constructor for class org.apache.drill.exec.physical.rowSet.model.single.VectorAllocator
-
- vectorCache - Variable in class org.apache.drill.exec.physical.impl.scan.project.StaticColumnLoader
-
- vectorCache - Variable in class org.apache.drill.exec.physical.rowSet.impl.ContainerState
-
Vector cache for this loader.
- vectorCache() - Method in class org.apache.drill.exec.physical.rowSet.impl.ContainerState
-
- vectorCache - Variable in class org.apache.drill.exec.physical.rowSet.impl.OptionBuilder
-
- vectorCache - Variable in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl.ResultSetOptions
-
- vectorCache() - Method in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl
-
- vectorCache() - Method in interface org.apache.drill.exec.physical.rowSet.ResultSetLoader
-
Peek at the internal vector cache for readers that need a bit of help
resolving types based on what was previously seen.
- 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.
- VectorContainerAccessor - Class in org.apache.drill.exec.physical.impl.protocol
-
- VectorContainerAccessor() - Constructor for class org.apache.drill.exec.physical.impl.protocol.VectorContainerAccessor
-
- VectorContainerAccessor.ContainerAndSv2Accessor - Class in org.apache.drill.exec.physical.impl.protocol
-
- VectorContainerAccessor.ContainerAndSv4Accessor - Class in org.apache.drill.exec.physical.impl.protocol
-
- 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
-
- VectorDescrip(MetadataProvider, ColumnMetadata) - Constructor for class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.VectorDescrip
-
- VectorDescrip(MetadataProvider, int, MaterializedField) - Constructor for class org.apache.drill.exec.physical.rowSet.model.MetadataProvider.VectorDescrip
-
- vectorIndex() - Method in class org.apache.drill.test.rowSet.test.TestFixedWidthWriter.TestIndex
-
- 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
-
- vectorMemoryUsage - Variable in class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.BatchSizingMemoryUtil.ColumnMemoryUsageInfo
-
Current vector memory usage
- VectorMemoryUsageInfo() - Constructor for class org.apache.drill.exec.store.parquet.columnreaders.batchsizing.BatchSizingMemoryUtil.VectorMemoryUsageInfo
-
- 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.Writer - Class in org.apache.drill.exec.cache
-
Writes multiple VectorAccessible or VectorContainer
objects to an output stream.
- vectorSizeLimit - Variable in class org.apache.drill.exec.physical.rowSet.impl.OptionBuilder
-
- vectorSizeLimit - Variable in class org.apache.drill.exec.physical.rowSet.impl.ResultSetLoaderImpl.ResultSetOptions
-
- VectorSource - Interface in org.apache.drill.exec.physical.impl.scan.project
-
Generic mechanism for retrieving vectors from a source tuple when
projecting columns to the output tuple.
- vectorState - Variable in class org.apache.drill.exec.physical.rowSet.impl.ColumnState
-
- vectorState() - Method in class org.apache.drill.exec.physical.rowSet.impl.ColumnState
-
- vectorState(ColumnMetadata, WriterPosition, ValueVector) - Static method in class org.apache.drill.exec.physical.rowSet.impl.SingleVectorState
-
- VectorState - Interface in org.apache.drill.exec.physical.rowSet.impl
-
Handles batch and overflow operation for a (possibly compound) vector.
- 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)
.
- verify(ValueVector) - Method in class org.apache.drill.exec.record.vector.TestValueVector.ChildVerifier
-
- verify(ValueVector) - Method in interface org.apache.drill.exec.record.vector.TestValueVector.VectorVerifier
-
- verify(RowSet) - Method in class org.apache.drill.test.rowSet.RowSetComparison
-
Verify the actual rows using the rules defined in this builder
- verify(RowSet, RowSet) - Static method in class org.apache.drill.test.rowSet.RowSetUtilities
-
Convenience method to verify the actual results, then free memory
for both the expected and actual result sets.
- verifyAndClear(RowSet) - Method in class org.apache.drill.test.rowSet.RowSetComparison
-
Convenience method to verify the actual results, then free memory
for the actual result sets.
- verifyAndClearAll(RowSet) - Method in class org.apache.drill.test.rowSet.RowSetComparison
-
Convenience method to verify the actual results, then free memory
for both the expected and actual result sets.
- verifyLocalStore() - Method in class org.apache.drill.exec.store.sys.TestPStoreProviders
-
- verifyMetadata(List<PreparedStatementTestBase.ExpectedColumnResult>, List<UserProtos.ResultColumnMetadata>) - Method in class org.apache.drill.exec.work.prepare.PreparedStatementTestBase
-
- verifyOutcomeToSetBatchState(RecordBatch.IterOutcome, RecordBatch.IterOutcome) - Method in class org.apache.drill.exec.record.AbstractBinaryRecordBatch
-
- verifyPhysicalPlan(String, T) - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- verifyResults(String, T, Object[]) - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- verifyResults(PriorityQueueCopierWrapper.BatchMerger, VectorContainer) - Method in class org.apache.drill.exec.physical.impl.xsort.managed.SortTestUtilities.CopierTester
-
- verifySQL(String, T) - Method in class org.apache.drill.exec.physical.impl.TestConvertFunctions
-
- verifyZkStore() - Method in class org.apache.drill.exec.store.sys.TestPStoreProviders
-
- version - Variable in class org.apache.drill.exec.store.sys.DrillbitIterator.DrillbitInstance
-
- version - Variable in class org.apache.drill.exec.store.sys.VersionIterator.VersionInfo
-
- VersionedDelegatingStore<V> - Class in org.apache.drill.exec.store.sys.store
-
Versioned store that delegates operations to PersistentStore and keeps versioning,
incrementing version each time write / delete operation is triggered.
- VersionedDelegatingStore(PersistentStore<V>) - Constructor for class org.apache.drill.exec.store.sys.store.VersionedDelegatingStore
-
- VersionedPersistentStore<V> - Interface in org.apache.drill.exec.store.sys
-
Extension to the Store interface that supports versions
- VersionInfo() - Constructor for 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
-
- 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(String, String, String, String) - Constructor for class org.apache.drill.exec.store.ischema.Records.View
-
- View.FieldType - Class in org.apache.drill.exec.dotdrill
-
- 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.
- viewCreatedFromAnotherView() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- 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.DropView - Class in org.apache.drill.exec.planner.sql.handlers
-
Handler for Drop View [If Exists] DDL command.
- viewResolvingTablesInWorkspaceSchema() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- Views(OptionManager) - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Views
-
- Views() - Constructor for class org.apache.drill.exec.store.ischema.InfoSchemaTable.Views
-
- VIEWS_COL_VIEW_DEFINITION - Static variable in interface org.apache.drill.exec.store.ischema.InfoSchemaConstants
-
- viewSchemaWhenSelectFieldsInDef_SelectFieldsInView() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- viewWithCompoundIdentifiersInDef() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- viewWithPartialSchemaIdentifier() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- viewWithSelectFieldsInDef_SelectFieldsInQuery1() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- viewWithSelectFieldsInDef_SelectFieldsInQuery2() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- viewWithSelectFieldsInDef_SelectFieldsInView_SelectFieldsInQuery1() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- viewWithSelectFieldsInDef_SelectFieldsInView_SelectFieldsInQuery2() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- viewWithSelectFieldsInDef_SelectFieldsInView_StarInQuery() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- viewWithSelectFieldsInDef_StarInQuery() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- viewWithStarInDef_SelectFieldsInQuery() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- viewWithStarInDef_StarInQuery() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- viewWithUnionWithSelectFieldsInDef_StarInQuery() - Method in class org.apache.drill.exec.sql.TestViewSupport
-
- 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(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(RelNode) - Method in class org.apache.drill.exec.planner.physical.visitor.LateralUnnestRowIDVisitor.CorrelateVarReplacer
-
- visit(LogicalCorrelate) - Method in class org.apache.drill.exec.planner.sql.handlers.ComplexUnnestVisitor
-
- visit(RelNode) - Method in class org.apache.drill.exec.planner.sql.handlers.ComplexUnnestVisitor
-
- visit(Uncollect) - Method in class org.apache.drill.exec.planner.sql.handlers.ComplexUnnestVisitor
-
- 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
-
- visit(ProfileParser.OperatorSummary) - Method in class org.apache.drill.test.ProfileParser.Aggregator
-
- visit(ProfileParser.OperatorSummary) - Method in class org.apache.drill.test.ProfileParser.TimePrinter
-
- visit(ProfileParser.OperatorSummary) - Method in class org.apache.drill.test.ProfileParser.TreeVisitor
-
- visit(ProfileParser.OperatorSummary, int) - Method in class org.apache.drill.test.ProfileParser.TreeVisitor
-
- 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.CheckClassVisitorFsm
-
- visitAnnotation(String, boolean) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
-
- visitAnnotationDefault() - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
-
- visitAnyValueExpression(AnyValueExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
-
- 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
-
- visitBooleanConstant(ValueExpressions.BooleanExpression, Void) - Method in class org.apache.drill.exec.expr.stat.RangeExprEvaluator
-
- visitBooleanConstant(ValueExpressions.BooleanExpression, Set<LogicalExpression>) - Method in class org.apache.drill.exec.store.parquet.ParquetFilterBuilder
-
- 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.common.DrillRelOptUtil.InputRefVisitor
-
- visitCall(RexCall) - Method in class org.apache.drill.exec.planner.index.FindFiltersForCollation
-
- visitCall(RexCall) - Method in class org.apache.drill.exec.planner.index.IndexableExprMarker
-
- visitCall(RexCall) - Method in class org.apache.drill.exec.planner.index.RexToExpression.RexToDrillExt
-
- visitCall(RexCall) - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap.FieldsMarker
-
- visitCall(RexCall) - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap.RexReplace
-
- visitCall(RexCall) - Method in class org.apache.drill.exec.planner.logical.DrillOptiq.RexToDrill
-
- visitCall(RexCall) - Method in class org.apache.drill.exec.planner.logical.FieldsReWriterUtil.FieldsReWriter
-
- 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.planner.index.ExprToRex
-
- visitCastExpression(CastExpression, Void) - Method in class org.apache.drill.exec.planner.index.PathInExpr
-
- 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
-
- visitChildren(VectorContainer, A) - Method in class org.apache.drill.exec.physical.rowSet.model.ContainerVisitor
-
- 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.index.FindFiltersForCollation
-
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.drill.exec.planner.index.IndexableExprMarker
-
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.drill.exec.planner.index.RexToExpression.RexToDrillExt
-
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap.RexReplace
-
- visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.drill.exec.planner.logical.DrillOptiq.RexToDrill
-
- 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.index.FindFiltersForCollation
-
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.drill.exec.planner.index.IndexableExprMarker
-
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.drill.exec.planner.index.RexToExpression.RexToDrillExt
-
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap.RexReplace
-
- visitDynamicParam(RexDynamicParam) - Method in class org.apache.drill.exec.planner.logical.DrillOptiq.RexToDrill
-
- 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.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, boolean) - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor.VisualizationState
-
- visitField(String, Object[]) - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor.VisualizationState
-
- 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.index.FindFiltersForCollation
-
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.drill.exec.planner.index.IndexableExprMarker
-
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.drill.exec.planner.index.RexToExpression.RexToDrillExt
-
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap.RexReplace
-
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.drill.exec.planner.logical.DrillOptiq.RexToDrill
-
- 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.InstructionModifier
-
- visitFieldInsn(int, String, String, String) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
-
- visitFiles(String, SchemaPlus) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator.Files
-
- visitFiles(String, SchemaPlus) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaRecordGenerator
-
- 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
-
- visitFixedLenExpr(OutputWidthExpression.FixedLenExpr, VAL) - Method in class org.apache.drill.exec.expr.AbstractExecExprVisitor
-
- visitFixedLenExpr(OutputWidthExpression.FixedLenExpr, OutputWidthVisitorState) - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthVisitor
-
- 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.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.planner.index.PathInExpr
-
- visitFunctionCall(FunctionCall, Void) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilterBuilder
-
- visitFunctionCallExpr(OutputWidthExpression.FunctionCallExpr, VAL) - Method in class org.apache.drill.exec.expr.AbstractExecExprVisitor
-
- visitFunctionCallExpr(OutputWidthExpression.FunctionCallExpr, OutputWidthVisitorState) - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthVisitor
-
- 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, OutputWidthVisitorState) - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthVisitor
-
- visitFunctionHolderExpression(FunctionHolderExpression, Void) - Method in class org.apache.drill.exec.planner.index.PathInExpr
-
- 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
-
- 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
-
- visitIfElseWidthExpr(OutputWidthExpression.IfElseWidthExpr, VAL) - Method in class org.apache.drill.exec.expr.AbstractExecExprVisitor
-
- visitIfElseWidthExpr(OutputWidthExpression.IfElseWidthExpr, OutputWidthVisitorState) - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthVisitor
-
- 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
-
- visitIfExpression(IfExpression, OutputWidthVisitorState) - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthVisitor
-
- visitIfExpression(IfExpression, Void) - Method in class org.apache.drill.exec.planner.index.PathInExpr
-
- 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.common.DrillRelOptUtil.InputRefVisitor
-
- visitInputRef(RexInputRef) - Method in class org.apache.drill.exec.planner.index.FindFiltersForCollation
-
- visitInputRef(RexInputRef) - Method in class org.apache.drill.exec.planner.index.IndexableExprMarker
-
- visitInputRef(RexInputRef) - Method in class org.apache.drill.exec.planner.index.RexToExpression.RexToDrillExt
-
- visitInputRef(RexInputRef) - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap.FieldsMarker
-
- visitInputRef(RexInputRef) - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap.RexReplace
-
- visitInputRef(RexInputRef) - Method in class org.apache.drill.exec.planner.logical.DrillOptiq.RexToDrill
-
- visitInputRef(RexInputRef) - Method in class org.apache.drill.exec.planner.logical.FieldsReWriterUtil.FieldsReWriter
-
- 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.visitor.RexVisitorComplexExprSplitter
-
- 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.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.CheckMethodVisitorFsm
-
- 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, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.AdjustOperatorsSchemaVisitor
-
- visitJoin(JoinPrel, EXTRA) - Method in class org.apache.drill.exec.planner.physical.visitor.BasePrelVisitor
-
- 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, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.RuntimeFilterVisitor
-
- 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.CheckMethodVisitorFsm
-
- visitLabel(Label) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
-
- visitLateral(LateralJoinPrel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.AdjustOperatorsSchemaVisitor
-
- visitLateral(LateralJoinPrel, EXTRA) - Method in class org.apache.drill.exec.planner.physical.visitor.BasePrelVisitor
-
- visitLateral(LateralJoinPrel, ExcessiveExchangeIdentifier.MajorFragmentStat) - Method in class org.apache.drill.exec.planner.physical.visitor.ExcessiveExchangeIdentifier
-
- visitLateral(LateralJoinPrel, Boolean) - Method in class org.apache.drill.exec.planner.physical.visitor.LateralUnnestRowIDVisitor
-
- visitLateral(LateralJoinPrel, EXTRA) - Method in interface org.apache.drill.exec.planner.physical.visitor.PrelVisitor
-
- visitLateral(LateralJoinPrel, PrelVisualizerVisitor.VisualizationState) - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor
-
- visitLateralJoin(LateralJoinPOP, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
-
- visitLateralJoin(LateralJoinPOP, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
-
- visitLateralJoin(LateralJoinPOP, Materializer.IndexedFragmentNode) - Method in class org.apache.drill.exec.planner.fragment.Materializer
-
- 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.InstructionModifier
-
- visitLineNumber(int, Label) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
-
- visitList(ListVector, A) - Method in class org.apache.drill.exec.physical.rowSet.model.ContainerVisitor
-
- visitLiteral(RexLiteral) - Method in class org.apache.drill.exec.planner.index.FindFiltersForCollation
-
- visitLiteral(RexLiteral) - Method in class org.apache.drill.exec.planner.index.IndexableExprMarker
-
- visitLiteral(RexLiteral) - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap.RexReplace
-
- visitLiteral(RexLiteral) - Method in class org.apache.drill.exec.planner.logical.DrillOptiq.RexToDrill
-
- 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.index.FindFiltersForCollation
-
- visitLocalRef(RexLocalRef) - Method in class org.apache.drill.exec.planner.index.IndexableExprMarker
-
- visitLocalRef(RexLocalRef) - Method in class org.apache.drill.exec.planner.index.RexToExpression.RexToDrillExt
-
- visitLocalRef(RexLocalRef) - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap.RexReplace
-
- visitLocalRef(RexLocalRef) - Method in class org.apache.drill.exec.planner.logical.DrillOptiq.RexToDrill
-
- 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.visitor.RexVisitorComplexExprSplitter
-
- 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.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.CheckMethodVisitorFsm
-
- visitMap(AbstractMapVector, A) - Method in class org.apache.drill.exec.physical.rowSet.model.ContainerVisitor
-
- 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
-
- 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
-
- 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.CheckMethodVisitorFsm
-
- 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
-
- visitNullConstant(TypedNullConstant, OutputWidthVisitorState) - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthVisitor
-
- 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, RuntimeFilterRouter.RFHelperHolder) - Method in class org.apache.drill.exec.work.filter.RuntimeFilterRouter.RuntimeFilterParallelismCollector
-
- visitOp(PhysicalOperator, List<PhysicalOperator>) - Method in class org.apache.drill.exec.work.foreman.rm.ThrottledResourceManager.QueuedResourceAllocator.BufferedOpFinder
-
- visitOp(ProfileParser.OperatorSummary, int) - Method in class org.apache.drill.test.ProfileParser.Aggregator
-
- visitOp(ProfileParser.OperatorSummary, int) - Method in class org.apache.drill.test.ProfileParser.CostPrinter
-
- visitOp(ProfileParser.OperatorSummary, int) - Method in class org.apache.drill.test.ProfileParser.FindOpVisitor
-
- visitOp(ProfileParser.OperatorSummary, int) - Method in class org.apache.drill.test.ProfileParser.TimePrinter
-
- visitOp(ProfileParser.OperatorSummary, int) - Method in class org.apache.drill.test.ProfileParser.TreePrinter
-
- visitOp(ProfileParser.OperatorSummary, int) - Method in class org.apache.drill.test.ProfileParser.TreeVisitor
-
- 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.index.FindFiltersForCollation
-
- visitOver(RexOver) - Method in class org.apache.drill.exec.planner.index.IndexableExprMarker
-
- visitOver(RexOver) - Method in class org.apache.drill.exec.planner.index.RexToExpression.RexToDrillExt
-
- visitOver(RexOver) - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap.RexReplace
-
- visitOver(RexOver) - Method in class org.apache.drill.exec.planner.logical.DrillOptiq.RexToDrill
-
- 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.CheckMethodVisitorFsm
-
- visitParameter(ValueExpressions.ParameterExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
-
- 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, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.AdjustOperatorsSchemaVisitor
-
- 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, Boolean) - Method in class org.apache.drill.exec.planner.physical.visitor.LateralUnnestRowIDVisitor
-
- 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.RuntimeFilterVisitor
-
- 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
-
- visitPrimitive(ValueVector, A) - Method in class org.apache.drill.exec.physical.rowSet.model.ContainerVisitor
-
- 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.expr.stat.RangeExprEvaluator
-
- visitQuotedStringConstant(ValueExpressions.QuotedString, OutputWidthVisitorState) - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthVisitor
-
- visitQuotedStringConstant(ValueExpressions.QuotedString, Void) - Method in class org.apache.drill.exec.store.ischema.InfoSchemaFilterBuilder
-
- visitQuotedStringConstant(ValueExpressions.QuotedString, Set<LogicalExpression>) - Method in class org.apache.drill.exec.store.parquet.ParquetFilterBuilder
-
- visitRangePartitionSender(RangePartitionSender, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
-
- visitRangePartitionSender(RangePartitionSender, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
-
- visitRangeRef(RexRangeRef) - Method in class org.apache.drill.exec.planner.index.FindFiltersForCollation
-
- visitRangeRef(RexRangeRef) - Method in class org.apache.drill.exec.planner.index.IndexableExprMarker
-
- visitRangeRef(RexRangeRef) - Method in class org.apache.drill.exec.planner.index.RexToExpression.RexToDrillExt
-
- visitRangeRef(RexRangeRef) - Method in class org.apache.drill.exec.planner.index.SimpleRexRemap.RexReplace
-
- visitRangeRef(RexRangeRef) - Method in class org.apache.drill.exec.planner.logical.DrillOptiq.RexToDrill
-
- 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
-
- 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
-
- visitRepeatedList(RepeatedListVector, A) - Method in class org.apache.drill.exec.physical.rowSet.model.ContainerVisitor
-
- visitRepeatedMap(RepeatedMapVector, A) - Method in class org.apache.drill.exec.physical.rowSet.model.ContainerVisitor
-
- visitRepeatedPrimitive(BaseRepeatedValueVector, A) - Method in class org.apache.drill.exec.physical.rowSet.model.ContainerVisitor
-
- visitRowKeyJoin(RowKeyJoinPOP, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
-
- visitRowKeyJoin(RowKeyJoinPOP, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
-
- visitRowKeyJoin(RowKeyJoinPOP, Materializer.IndexedFragmentNode) - Method in class org.apache.drill.exec.planner.fragment.Materializer
-
- 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.RuntimeFilterVisitor
-
- 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.planner.index.ExprToRex
-
- visitSchemaPath(SchemaPath, Void) - Method in class org.apache.drill.exec.planner.index.PathInExpr
-
- 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
-
- visitSubtree(ProfileParser.OperatorSummary, int, int) - Method in class org.apache.drill.test.ProfileParser.CostPrinter
-
- visitSubtree(ProfileParser.OperatorSummary, int, int) - Method in class org.apache.drill.test.ProfileParser.TreePrinter
-
- visitSubtree(ProfileParser.OperatorSummary, int, int) - Method in class org.apache.drill.test.ProfileParser.TreeVisitor
-
- 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.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.CheckMethodVisitorFsm
-
- 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.CheckClassVisitorFsm
-
- visitTypeAnnotation(int, TypePath, String, boolean) - Method in class org.apache.drill.exec.compile.CheckMethodVisitorFsm
-
- visitTypedFieldExpr(TypedFieldExpr, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
-
- visitTypedFieldExpr(TypedFieldExpr, Void) - Method in class org.apache.drill.exec.expr.stat.RangeExprEvaluator
-
- visitTypedFieldExpr(TypedFieldExpr, Set<LogicalExpression>) - Method in class org.apache.drill.exec.store.parquet.ParquetFilterBuilder
-
- 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
-
- visitUnknown(LogicalExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
-
- visitUnknown(OutputWidthExpression, VAL) - Method in class org.apache.drill.exec.expr.AbstractExecExprVisitor
-
- 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, OutputWidthVisitorState) - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthVisitor
-
- visitUnknown(LogicalExpression, Void) - Method in class org.apache.drill.exec.planner.index.PathInExpr
-
- 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
-
- visitUnnest(UnnestPOP, X) - Method in class org.apache.drill.exec.physical.base.AbstractPhysicalVisitor
-
- visitUnnest(UnnestPOP, EXTRA) - Method in interface org.apache.drill.exec.physical.base.PhysicalVisitor
-
- visitUnnest(UnnestPOP, Materializer.IndexedFragmentNode) - Method in class org.apache.drill.exec.planner.fragment.Materializer
-
- visitUnnest(UnnestPrel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.AdjustOperatorsSchemaVisitor
-
- visitUnnest(UnnestPrel, EXTRA) - Method in class org.apache.drill.exec.planner.physical.visitor.BasePrelVisitor
-
- visitUnnest(UnnestPrel, ExcessiveExchangeIdentifier.MajorFragmentStat) - Method in class org.apache.drill.exec.planner.physical.visitor.ExcessiveExchangeIdentifier
-
- visitUnnest(UnnestPrel, Boolean) - Method in class org.apache.drill.exec.planner.physical.visitor.LateralUnnestRowIDVisitor
-
- visitUnnest(UnnestPrel, EXTRA) - Method in interface org.apache.drill.exec.planner.physical.visitor.PrelVisitor
-
- visitUnnest(UnnestPrel, PrelVisualizerVisitor.VisualizationState) - Method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor
-
- visitUnnest(UnnestPrel, Void) - Method in class org.apache.drill.exec.planner.physical.visitor.StarColumnConverter
-
- 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, VAL) - Method in class org.apache.drill.exec.expr.AbstractExecExprVisitor
-
- visitValueVectorReadExpression(ValueVectorReadExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
-
- visitValueVectorReadExpression(ValueVectorReadExpression, OutputWidthVisitorState) - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthVisitor
-
- visitValueVectorWriteExpression(ValueVectorWriteExpression, VAL) - Method in class org.apache.drill.exec.expr.AbstractExecExprVisitor
-
- visitValueVectorWriteExpression(ValueVectorWriteExpression, OutputWidthVisitorState) - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthVisitor
-
Records a variable width write expression.
- visitVarDecimalConstant(ValueExpressions.VarDecimalExpression, IdentityHashMap<LogicalExpression, Object>) - Method in class org.apache.drill.exec.compile.sig.ConstantExpressionIdentifier
-
- visitVarDecimalConstant(ValueExpressions.VarDecimalExpression, Void) - Method in class org.apache.drill.exec.expr.CloneVisitor
-
- visitVarDecimalConstant(ValueExpressions.VarDecimalExpression, Integer) - Method in class org.apache.drill.exec.expr.fn.interpreter.InterpreterEvaluator.EvalVisitor
-
- visitVarDecimalConstant(ValueExpressions.VarDecimalExpression, Void) - Method in class org.apache.drill.exec.expr.HashVisitor
-
- visitVarDecimalConstant(ValueExpressions.VarDecimalExpression, Void) - Method in class org.apache.drill.exec.expr.stat.RangeExprEvaluator
-
- visitVarDecimalConstant(ValueExpressions.VarDecimalExpression, OutputWidthVisitorState) - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthVisitor
-
- visitVarDecimalConstant(ValueExpressions.VarDecimalExpression, Set<LogicalExpression>) - Method in class org.apache.drill.exec.store.parquet.ParquetFilterBuilder
-
- 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
-
- visitVarLenReadExpr(OutputWidthExpression.VarLenReadExpr, VAL) - Method in class org.apache.drill.exec.expr.AbstractExecExprVisitor
-
- visitVarLenReadExpr(OutputWidthExpression.VarLenReadExpr, OutputWidthVisitorState) - Method in class org.apache.drill.exec.physical.impl.project.OutputWidthVisitor
-
- visitVector(ValueVector, A) - Method in class org.apache.drill.exec.physical.rowSet.model.ContainerVisitor
-
- 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
-
- VisualizationState() - Constructor for class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor.VisualizationState
-
- visualize(Prel) - Static method in class org.apache.drill.exec.planner.physical.visitor.PrelVisualizerVisitor
-
- vvIn - Variable in class org.apache.drill.exec.physical.impl.svremover.AbstractSV2Copier
-
- vvIn - Variable in class org.apache.drill.exec.physical.impl.svremover.AbstractSV4Copier
-
- vvOut - Variable in class org.apache.drill.exec.physical.impl.svremover.AbstractCopier
-
- 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.