Uses of Class
org.apache.drill.common.exceptions.ExecutionSetupException
Package
Description
Various exceptions used in logical, physical and execution contexts.
Execution-time exceptions.
Drill storage plugin.
Kafka storage plugin.
Defines a mock data source which generates dummy test data for use
in testing.
MongoDB storage plugin.
-
Uses of ExecutionSetupException in org.apache.drill.common.exceptions
Modifier and TypeMethodDescriptionstatic ExecutionSetupException
ExecutionSetupException.fromThrowable
(String message, Throwable cause) -
Uses of ExecutionSetupException in org.apache.drill.exec.exception
-
Uses of ExecutionSetupException in org.apache.drill.exec.ops
ModifierConstructorDescriptionFragmentContextImpl
(DrillbitContext dbContext, BitControl.PlanFragment fragment, FunctionImplementationRegistry funcRegistry) Create a FragmentContext instance for non-root fragment.FragmentContextImpl
(DrillbitContext dbContext, BitControl.PlanFragment fragment, QueryContext queryContext, UserClientConnection connection, FunctionImplementationRegistry funcRegistry) Create a FragmentContext instance for root fragment.FragmentContextImpl
(DrillbitContext dbContext, BitControl.PlanFragment fragment, UserClientConnection connection, FunctionImplementationRegistry funcRegistry) TODO: Remove this constructor when removing the SimpleRootExec (DRILL-2097). -
Uses of ExecutionSetupException in org.apache.drill.exec.physical
-
Uses of ExecutionSetupException in org.apache.drill.exec.physical.base
Modifier and TypeMethodDescriptionSchemalessBatchCreator.getBatch
(ExecutorFragmentContext context, SchemalessScan subScan, List<RecordBatch> children) AbstractSubScan.getNewWithChildren
(List<PhysicalOperator> children) PhysicalOperator.getNewWithChildren
(List<PhysicalOperator> children) Regenerate with this node with a new set of children.GroupScan.getSpecificScan
(int minorFragmentId) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.config
Modifier and TypeMethodDescriptionUnnestPOP.getNewWithChildren
(List<PhysicalOperator> children) Values.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl
Modifier and TypeMethodDescriptionBatchCreator.getBatch
(ExecutorFragmentContext context, T config, List<RecordBatch> children) MergingReceiverCreator.getBatch
(ExecutorFragmentContext context, MergingReceiverPOP receiver, List<RecordBatch> children) static RootExec
ImplCreator.getExec
(ExecutorFragmentContext context, FragmentRoot root) Create and return fragment RootExec for given FragmentRoot.static PhysicalOperator
TraceInjector.getExec
(FragmentContext context, FragmentRoot root) OperatorCreatorRegistry.getOperatorCreator
(Class<?> operator) ImplCreator.getRecordBatch
(PhysicalOperator op, ExecutorFragmentContext context) Create a RecordBatch and its children for given PhysicalOperatorRootCreator.getRoot
(ExecutorFragmentContext context, T config, List<RecordBatch> children) TraceInjector.visitOp
(PhysicalOperator op, FragmentContext context) Traverse the physical plan and inject the trace operator after every operator.ModifierConstructorDescriptionScanBatch
(PhysicalOperator subScanConfig, FragmentContext context, List<RecordReader> readers) ScanBatch
(PhysicalOperator subScanConfig, FragmentContext context, List<RecordReader> readerList, boolean isRepeatableScan) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.aggregate
Modifier and TypeMethodDescriptionHashAggBatchCreator.getBatch
(ExecutorFragmentContext context, HashAggregate config, List<RecordBatch> children) StreamingAggBatchCreator.getBatch
(ExecutorFragmentContext context, StreamingAggregate config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.broadcastsender
Modifier and TypeMethodDescriptionBroadcastSenderCreator.getRoot
(ExecutorFragmentContext context, BroadcastSender config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.filter
Modifier and TypeMethodDescriptionFilterBatchCreator.getBatch
(ExecutorFragmentContext context, Filter config, List<RecordBatch> children) RuntimeFilterBatchCreator.getBatch
(ExecutorFragmentContext context, RuntimeFilterPOP config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.flatten
Modifier and TypeMethodDescriptionFlattenBatchCreator.getBatch
(ExecutorFragmentContext context, FlattenPOP config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.join
Modifier and TypeMethodDescriptionHashJoinBatchCreator.getBatch
(ExecutorFragmentContext context, HashJoinPOP config, List<RecordBatch> children) LateralJoinBatchCreator.getBatch
(ExecutorFragmentContext context, LateralJoinPOP config, List<RecordBatch> children) MergeJoinCreator.getBatch
(ExecutorFragmentContext context, MergeJoinPOP config, List<RecordBatch> children) NestedLoopJoinBatchCreator.getBatch
(ExecutorFragmentContext context, NestedLoopJoinPOP config, List<RecordBatch> children) RowKeyJoinBatchCreator.getBatch
(ExecutorFragmentContext context, RowKeyJoinPOP config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.limit
Modifier and TypeMethodDescriptionLimitBatchCreator.getBatch
(ExecutorFragmentContext context, Limit config, List<RecordBatch> children) PartitionLimitBatchCreator.getBatch
(ExecutorFragmentContext context, PartitionLimit config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.metadata
Modifier and TypeMethodDescriptionMetadataControllerBatchCreator.getBatch
(ExecutorFragmentContext context, MetadataControllerPOP config, List<RecordBatch> children) MetadataHandlerBatchCreator.getBatch
(ExecutorFragmentContext context, MetadataHandlerPOP config, List<RecordBatch> children) MetadataHashAggBatchCreator.getBatch
(ExecutorFragmentContext context, MetadataHashAggPOP config, List<RecordBatch> children) MetadataStreamAggBatchCreator.getBatch
(ExecutorFragmentContext context, MetadataStreamAggPOP config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.orderedpartitioner
Modifier and TypeMethodDescriptionOrderedPartitionSenderCreator.getRoot
(ExecutorFragmentContext context, OrderedPartitionSender config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.partitionsender
Modifier and TypeMethodDescriptionPartitionSenderCreator.getRoot
(ExecutorFragmentContext context, HashPartitionSender config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.producer
Modifier and TypeMethodDescriptionProducerConsumerBatchCreator.getBatch
(ExecutorFragmentContext context, ProducerConsumer config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.project
Modifier and TypeMethodDescriptionComplexToJsonBatchCreator.getBatch
(ExecutorFragmentContext context, ComplexToJson flatten, List<RecordBatch> children) ProjectBatchCreator.getBatch
(ExecutorFragmentContext context, Project config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.rangepartitioner
Modifier and TypeMethodDescriptionRangePartitionSenderCreator.getRoot
(ExecutorFragmentContext context, RangePartitionSender config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.setop
Modifier and TypeMethodDescriptionSetOpBatchCreator.getBatch
(ExecutorFragmentContext context, SetOp config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.sort
Modifier and TypeMethodDescriptionSortBatchCreator.getBatch
(ExecutorFragmentContext context, Sort config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.statistics
Modifier and TypeMethodDescriptionStatisticsAggBatchCreator.getBatch
(ExecutorFragmentContext context, StatisticsAggregate config, List<RecordBatch> children) StatisticsMergeBatchCreator.getBatch
(ExecutorFragmentContext context, StatisticsMerge config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.svremover
Modifier and TypeMethodDescriptionSVRemoverCreator.getBatch
(ExecutorFragmentContext context, SelectionVectorRemover config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.TopN
Modifier and TypeMethodDescriptionTopNSortBatchCreator.getBatch
(ExecutorFragmentContext context, TopN config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.trace
Modifier and TypeMethodDescriptionTraceBatchCreator.getBatch
(ExecutorFragmentContext context, Trace config, List<RecordBatch> children) ModifierConstructorDescriptionTraceRecordBatch
(Trace pop, RecordBatch incoming, FragmentContext context) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.union
Modifier and TypeMethodDescriptionUnionAllBatchCreator.getBatch
(ExecutorFragmentContext context, UnionAll config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.unnest
Modifier and TypeMethodDescriptionUnnestBatchCreator.getBatch
(ExecutorFragmentContext context, UnnestPOP config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.unorderedreceiver
Modifier and TypeMethodDescriptionUnorderedReceiverCreator.getBatch
(ExecutorFragmentContext context, UnorderedReceiver receiver, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.unpivot
Modifier and TypeMethodDescriptionUnpivotMapsBatchCreator.getBatch
(ExecutorFragmentContext context, UnpivotMaps config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.validate
Modifier and TypeMethodDescriptionIteratorValidatorCreator.getBatch
(ExecutorFragmentContext context, IteratorValidator config, List<RecordBatch> children) static FragmentRoot
IteratorValidatorInjector.rewritePlanWithIteratorValidator
(FragmentContext context, FragmentRoot root) IteratorValidatorInjector.visitOp
(PhysicalOperator op, FragmentContext context) Traverse the physical plan and inject the IteratorValidator operator after every operator. -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.values
Modifier and TypeMethodDescriptionValuesBatchCreator.getBatch
(ExecutorFragmentContext context, Values subScan, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.window
Modifier and TypeMethodDescriptionWindowFrameBatchCreator.getBatch
(ExecutorFragmentContext context, WindowPOP config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.physical.impl.xsort
Modifier and TypeMethodDescriptionExternalSortBatchCreator.getBatch
(ExecutorFragmentContext context, ExternalSort config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.planner.fragment
Modifier and TypeMethodDescriptionQueryParallelizer.generateWorkUnit
(OptionList options, CoordinationProtos.DrillbitEndpoint foremanNode, UserBitShared.QueryId queryId, Collection<CoordinationProtos.DrillbitEndpoint> activeEndpoints, Fragment rootFragment, UserSession session, BitControl.QueryContextInformation queryContextInfo) This is the only function exposed to the consumer of this parallelizer (currently Foreman) to parallelize the plan.final QueryWorkUnit
SimpleParallelizer.generateWorkUnit
(OptionList options, CoordinationProtos.DrillbitEndpoint foremanNode, UserBitShared.QueryId queryId, Collection<CoordinationProtos.DrillbitEndpoint> activeEndpoints, Fragment rootFragment, UserSession session, BitControl.QueryContextInformation queryContextInfo) The starting function for the whole parallelization and memory computation logic.protected QueryWorkUnit
SimpleParallelizer.generateWorkUnit
(OptionList options, CoordinationProtos.DrillbitEndpoint foremanNode, UserBitShared.QueryId queryId, Fragment rootNode, PlanningSet planningSet, UserSession session, BitControl.QueryContextInformation queryContextInfo) SimpleParallelizer.getSplitFragments
(OptionList options, CoordinationProtos.DrillbitEndpoint foremanNode, UserBitShared.QueryId queryId, Collection<CoordinationProtos.DrillbitEndpoint> activeEndpoints, PhysicalPlanReader reader, Fragment rootFragment, UserSession session, BitControl.QueryContextInformation queryContextInfo) Create multiple physical plans from original query planning, it will allow execute them eventually independentlyMaterializer.visitExchange
(Exchange exchange, Materializer.IndexedFragmentNode iNode) Materializer.visitGroupScan
(GroupScan groupScan, Materializer.IndexedFragmentNode iNode) Materializer.visitLateralJoin
(LateralJoinPOP op, Materializer.IndexedFragmentNode iNode) Materializer.visitOp
(PhysicalOperator op, Materializer.IndexedFragmentNode iNode) Materializer.visitRowKeyJoin
(RowKeyJoinPOP op, Materializer.IndexedFragmentNode iNode) Materializer.visitStore
(Store store, Materializer.IndexedFragmentNode iNode) Materializer.visitSubScan
(SubScan subScan, Materializer.IndexedFragmentNode value) Materializer.visitUnnest
(UnnestPOP unnest, Materializer.IndexedFragmentNode value) -
Uses of ExecutionSetupException in org.apache.drill.exec.planner.fragment.contrib
Modifier and TypeMethodDescriptionSplittingParallelizer.getSplitFragments
(OptionList options, CoordinationProtos.DrillbitEndpoint foremanNode, UserBitShared.QueryId queryId, Collection<CoordinationProtos.DrillbitEndpoint> activeEndpoints, PhysicalPlanReader reader, Fragment rootFragment, UserSession session, BitControl.QueryContextInformation queryContextInfo) Create multiple physical plans from original query planning, it will allow execute them eventually independentlyExchangeRemoverMaterializer.visitExchange
(Exchange exchange, Materializer.IndexedFragmentNode iNode) ExchangeRemoverMaterializer.visitGroupScan
(GroupScan groupScan, Materializer.IndexedFragmentNode iNode) ExchangeRemoverMaterializer.visitOp
(PhysicalOperator op, Materializer.IndexedFragmentNode iNode) OperatorIdVisitor.visitOp
(PhysicalOperator op, Integer parentOpId) ExchangeRemoverMaterializer.visitStore
(Store store, Materializer.IndexedFragmentNode iNode) ExchangeRemoverMaterializer.visitSubScan
(SubScan subScan, Materializer.IndexedFragmentNode value) OperatorIdVisitor.visitSubScan
(SubScan subScan, Integer parentOpId) -
Uses of ExecutionSetupException in org.apache.drill.exec.planner.logical
ModifierConstructorDescriptionFileSystemCreateTableEntry
(FileSystemConfig storageConfig, FormatPluginConfig formatConfig, String location, List<String> partitionColumns, StorageStrategy storageStrategy, StoragePluginRegistry engineRegistry) -
Uses of ExecutionSetupException in org.apache.drill.exec.planner.sql
-
Uses of ExecutionSetupException in org.apache.drill.exec.planner.sql.handlers
Modifier and TypeMethodDescriptionvoid
FindLimit0Visitor.RelDataTypeReader.setup
(OperatorContext context, OutputMutator output) -
Uses of ExecutionSetupException in org.apache.drill.exec.store
Modifier and TypeMethodDescriptionClassicConnectorLocator.create
(String name, StoragePluginConfig pluginConfig) Creates plugin instance with the givenname
and configurationpluginConfig
.StoragePluginRegistry.getFormatPlugin
(StoragePluginConfig storageConfig, FormatPluginConfig formatConfig) Deprecated.StoragePluginRegistryImpl.getFormatPlugin
(StoragePluginConfig storageConfig, FormatPluginConfig formatConfig) StoragePluginRegistry.getPlugin
(StoragePluginConfig config) Deprecated.useStoragePluginRegistry.resolve(StoragePluginConfig, Class)
which provides type safety.StoragePluginRegistryImpl.getPlugin
(StoragePluginConfig config) void
RecordReader.setup
(OperatorContext context, OutputMutator output) Configure the RecordReader with the provided schema and the record batch that should be written to. -
Uses of ExecutionSetupException in org.apache.drill.exec.store.delta.read
Modifier and TypeMethodDescriptionDeltaScanBatchCreator.getBatch
(ExecutorFragmentContext context, DeltaRowGroupScan rowGroupScan, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.dfs
ModifierConstructorDescriptionFileSystemPlugin
(FileSystemConfig config, DrillbitContext context, String name) WorkspaceSchemaFactory
(FileSystemPlugin plugin, String schemaName, String storageEngineName, WorkspaceConfig config, List<FormatMatcher> formatMatchers, com.fasterxml.jackson.databind.ObjectMapper mapper, ScanResult scanResult) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.dfs.easy
Modifier and TypeMethodDescriptionClassicScanBuilder.build()
protected FileScanFramework.FileScanBuilder
EasyFormatPlugin.frameworkBuilder
(EasySubScan scan, OptionSet options) Create the plugin-specific framework that manages the scan.EasyReaderBatchCreator.getBatch
(ExecutorFragmentContext context, EasySubScan config, List<RecordBatch> children) EasyWriterBatchCreator.getBatch
(ExecutorFragmentContext context, EasyWriter config, List<RecordBatch> children) protected CloseableRecordBatch
EasyFormatPlugin.getReaderBatch
(FragmentContext context, EasySubScan scan) EasyFormatPlugin.getRecordReader
(FragmentContext context, DrillFileSystem dfs, FileWork fileWork, List<SchemaPath> columns, String userName) Return a record reader for the specific file format, when using the originalScanBatch
scanner.EasyFormatPlugin.getWriterBatch
(FragmentContext context, RecordBatch incoming, EasyWriter writer) EasyFormatPlugin.newBatchReader
(EasySubScan scan, OptionSet options) For EVF V1, to be removed.ModifierConstructorDescriptionEasySubScan
(String userName, List<CompleteFileWork.FileWorkImpl> files, StoragePluginConfig storageConfig, FormatPluginConfig formatConfig, StoragePluginRegistry engineRegistry, List<SchemaPath> columns, org.apache.hadoop.fs.Path selectionRoot, int partitionDepth, TupleMetadata schema, int limit) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.direct
Modifier and TypeMethodDescriptionDirectBatchCreator.getBatch
(ExecutorFragmentContext context, DirectSubScan config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.drill.plugin
Modifier and TypeMethodDescriptionDrillScanBatchCreator.getBatch
(ExecutorFragmentContext context, DrillSubScan subScan, List<RecordBatch> children) ModifierConstructorDescriptionDrillRecordReader
(ExecutorFragmentContext context, DrillSubScan config) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.druid
Modifier and TypeMethodDescriptionDruidScanBatchCreator.getBatch
(ExecutorFragmentContext context, DruidSubScan subScan, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.easy.json
Modifier and TypeMethodDescriptionprotected FileScanFramework.FileScanBuilder
JSONFormatPlugin.frameworkBuilder
(EasySubScan scan, OptionSet options) void
JSONRecordReader.setup
(OperatorContext context, OutputMutator output) Deprecated. -
Uses of ExecutionSetupException in org.apache.drill.exec.store.enumerable
Modifier and TypeMethodDescriptionEnumerableBatchCreator.getBatch
(ExecutorFragmentContext context, EnumerableSubScan subScan, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.googlesheets
Modifier and TypeMethodDescriptionGoogleSheetsScanBatchCreator.getBatch
(ExecutorFragmentContext context, GoogleSheetsSubScan subScan, List<RecordBatch> children) GoogleSheetsWriterBatchCreator.getBatch
(ExecutorFragmentContext context, GoogleSheetsWriter config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.hbase
Modifier and TypeMethodDescriptionHBaseScanBatchCreator.getBatch
(ExecutorFragmentContext context, HBaseSubScan subScan, List<RecordBatch> children) void
HBaseRecordReader.setup
(OperatorContext context, OutputMutator output) ModifierConstructorDescriptionHBaseGroupScan
(String userName, HBaseScanSpec hbaseScanSpec, HBaseStoragePluginConfig storagePluginConfig, List<SchemaPath> columns, StoragePluginRegistry pluginRegistry) HBaseSubScan
(StoragePluginRegistry registry, String userName, HBaseStoragePluginConfig hbaseStoragePluginConfig, LinkedList<HBaseSubScan.HBaseSubScanSpec> regionScanSpecList, List<SchemaPath> columns) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.hive
Modifier and TypeMethodDescriptionHiveScan.clone
(HiveReadEntry hiveReadEntry) HiveDrillNativeParquetScanBatchCreator.getBatch
(ExecutorFragmentContext context, HiveDrillNativeParquetRowGroupScan rowGroupScan, List<RecordBatch> children) HiveScanBatchCreator.getBatch
(ExecutorFragmentContext context, HiveSubScan config, List<RecordBatch> children) HiveSubScan.getNewWithChildren
(List<PhysicalOperator> children) HiveScan.getSpecificScan
(int minorFragmentId) ModifierConstructorDescriptionHiveDrillNativeParquetRowGroupScan
(StoragePluginRegistry registry, String userName, HiveStoragePluginConfig hiveStoragePluginConfig, List<RowGroupReadEntry> rowGroupReadEntries, List<SchemaPath> columns, HivePartitionHolder hivePartitionHolder, Map<String, String> confProperties, ParquetReaderConfig readerConfig, LogicalExpression filter, TupleMetadata schema) HiveScan
(String userName, HiveReadEntry hiveReadEntry, HiveStoragePluginConfig hiveStoragePluginConfig, List<SchemaPath> columns, Map<String, String> confProperties, StoragePluginRegistry pluginRegistry) HiveScan
(String userName, HiveReadEntry hiveReadEntry, HiveStoragePlugin hiveStoragePlugin, List<SchemaPath> columns, HiveMetadataProvider metadataProvider, Map<String, String> confProperties) HiveStoragePlugin
(HiveStoragePluginConfig config, DrillbitContext context, String name) HiveSubScan
(StoragePluginRegistry registry, String userName, List<List<String>> splits, HiveReadEntry hiveReadEntry, List<String> splitClasses, List<SchemaPath> columns, HiveStoragePluginConfig hiveStoragePluginConfig, Map<String, String> confProperties) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.hive.readers
Modifier and TypeMethodDescriptionprotected boolean
HiveDefaultRecordReader.hasNextValue
(Object valueHolder) Checks and reads next value of input split into valueHolder.void
HiveDefaultRecordReader.setup
(OperatorContext context, OutputMutator output) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.hive.schema
ModifierConstructorDescriptionHiveSchemaFactory
(HiveStoragePlugin plugin, String name, org.apache.hadoop.hive.conf.HiveConf hiveConf) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.http
Modifier and TypeMethodDescriptionHttpScanBatchCreator.getBatch
(ExecutorFragmentContext context, HttpSubScan subScan, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.iceberg.read
Modifier and TypeMethodDescriptionIcebergScanBatchCreator.getBatch
(ExecutorFragmentContext context, IcebergSubScan subScan, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.image
Modifier and TypeMethodDescriptionprotected FileScanFramework.FileScanBuilder
ImageFormatPlugin.frameworkBuilder
(EasySubScan scan, OptionSet options) ImageFormatPlugin.newBatchReader
(EasySubScan scan, OptionSet options) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.ischema
Modifier and TypeMethodDescriptionInfoSchemaBatchCreator.getBatch
(ExecutorFragmentContext context, InfoSchemaSubScan config, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.jdbc
Modifier and TypeMethodDescriptionJdbcInsertWriterBatchCreator.getBatch
(ExecutorFragmentContext context, JdbcInsertWriter config, List<RecordBatch> children) JdbcScanBatchCreator.getBatch
(ExecutorFragmentContext context, JdbcSubScan subScan, List<RecordBatch> children) JdbcWriterBatchCreator.getBatch
(ExecutorFragmentContext context, JdbcWriter config, List<RecordBatch> children) ModifierConstructorDescriptionJdbcGroupScan
(String sql, List<SchemaPath> columns, JdbcStorageConfig config, double rows, String username, StoragePluginRegistry plugins) JdbcSubScan
(String sql, List<SchemaPath> columns, StoragePluginConfig config, String username, StoragePluginRegistry plugins) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.kafka
Modifier and TypeMethodDescriptionKafkaScanBatchCreator.getBatch
(ExecutorFragmentContext context, KafkaSubScan subScan, List<RecordBatch> children) ModifierConstructorDescriptionKafkaGroupScan
(String userName, KafkaStoragePluginConfig kafkaStoragePluginConfig, List<SchemaPath> columns, int records, KafkaScanSpec scanSpec, StoragePluginRegistry pluginRegistry) KafkaSubScan
(StoragePluginRegistry registry, String userName, KafkaStoragePluginConfig kafkaStoragePluginConfig, List<SchemaPath> columns, int records, LinkedList<KafkaPartitionScanSpec> partitionSubScanSpecList) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.kudu
Modifier and TypeMethodDescriptionKuduScanBatchCreator.getBatch
(ExecutorFragmentContext context, KuduSubScan subScan, List<RecordBatch> children) KuduWriterBatchCreator.getBatch
(ExecutorFragmentContext context, KuduWriter config, List<RecordBatch> children) void
KuduRecordReader.setup
(OperatorContext context, OutputMutator output) ModifierConstructorDescriptionKuduGroupScan
(KuduScanSpec kuduScanSpec, KuduStoragePluginConfig kuduStoragePluginConfig, List<SchemaPath> columns, StoragePluginRegistry pluginRegistry) KuduSubScan
(StoragePluginRegistry registry, KuduStoragePluginConfig kuduStoragePluginConfig, LinkedList<KuduSubScan.KuduSubScanSpec> tabletScanSpecList, List<SchemaPath> columns) KuduWriter
(PhysicalOperator child, String name, StoragePluginConfig storageConfig, StoragePluginRegistry engineRegistry) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.mock
Modifier and TypeMethodDescriptionMockScanBatchCreator.getBatch
(ExecutorFragmentContext context, MockSubScanPOP config, List<RecordBatch> children) void
MockRecordReader.setup
(OperatorContext context, OutputMutator output) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.mongo
Modifier and TypeMethodDescriptionMongoScanBatchCreator.getBatch
(ExecutorFragmentContext context, MongoSubScan subScan, List<RecordBatch> children) void
MongoRecordReader.setup
(OperatorContext context, OutputMutator output) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.openTSDB
Modifier and TypeMethodDescriptionOpenTSDBBatchCreator.getBatch
(ExecutorFragmentContext context, OpenTSDBSubScan subScan, List<RecordBatch> children) OpenTSDBSubScan.getNewWithChildren
(List<PhysicalOperator> children) ModifierConstructorDescriptionOpenTSDBGroupScan
(OpenTSDBScanSpec openTSDBScanSpec, OpenTSDBStoragePluginConfig openTSDBStoragePluginConfig, List<SchemaPath> columns, StoragePluginRegistry pluginRegistry) OpenTSDBSubScan
(StoragePluginRegistry registry, OpenTSDBStoragePluginConfig storage, LinkedList<OpenTSDBSubScan.OpenTSDBSubScanSpec> tabletScanSpecList, List<SchemaPath> columns) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.parquet
Modifier and TypeMethodDescriptionprotected abstract DrillFileSystem
AbstractParquetScanBatchCreator.AbstractDrillFileSystemManager.get
(org.apache.hadoop.conf.Configuration config, org.apache.hadoop.fs.Path path) protected DrillFileSystem
ParquetScanBatchCreator.ParquetDrillFileSystemManager.get
(org.apache.hadoop.conf.Configuration config, org.apache.hadoop.fs.Path path) protected ScanBatch
AbstractParquetScanBatchCreator.getBatch
(ExecutorFragmentContext context, AbstractParquetRowGroupScan rowGroupScan, OperatorContext oContext) ParquetScanBatchCreator.getBatch
(ExecutorFragmentContext context, ParquetRowGroupScan rowGroupScan, List<RecordBatch> children) ParquetWriterBatchCreator.getBatch
(ExecutorFragmentContext context, ParquetWriter config, List<RecordBatch> children) ParquetFormatPlugin.getWriterBatch
(FragmentContext context, RecordBatch incoming, ParquetWriter writer) ModifierConstructorDescriptionParquetRowGroupScan
(StoragePluginRegistry registry, String userName, StoragePluginConfig storageConfig, FormatPluginConfig formatConfig, LinkedList<RowGroupReadEntry> rowGroupReadEntries, List<SchemaPath> columns, ParquetReaderConfig readerConfig, org.apache.hadoop.fs.Path selectionRoot, LogicalExpression filter, TupleMetadata schema) ParquetWriter
(PhysicalOperator child, String location, List<String> partitionColumns, StorageStrategy storageStrategy, StoragePluginConfig storageConfig, StoragePluginRegistry engineRegistry) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.parquet.columnreaders
Modifier and TypeMethodDescriptionstatic ColumnReader<?>
ColumnReaderFactory.getNullableColumnReader
(ParquetRecordReader parentReader, org.apache.parquet.column.ColumnDescriptor columnDescriptor, org.apache.parquet.hadoop.metadata.ColumnChunkMetaData columnChunkMetaData, boolean fixedLength, ValueVector valueVec, org.apache.parquet.format.SchemaElement schemaElement) void
ParquetRecordReader.setup
(OperatorContext operatorContext, OutputMutator output) Prepare the Parquet reader.ModifierConstructorDescriptionprotected
ColumnReader
(ParquetRecordReader parentReader, org.apache.parquet.column.ColumnDescriptor descriptor, org.apache.parquet.hadoop.metadata.ColumnChunkMetaData columnChunkMetaData, boolean fixedLength, V v, org.apache.parquet.format.SchemaElement schemaElement) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.parquet2
Modifier and TypeMethodDescriptionvoid
DrillParquetReader.setup
(OperatorContext context, OutputMutator output) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.phoenix
Modifier and TypeMethodDescriptionPhoenixScanBatchCreator.getBatch
(ExecutorFragmentContext context, PhoenixSubScan subScan, List<RecordBatch> children) PhoenixGroupScan.getNewWithChildren
(List<PhysicalOperator> children) PhoenixGroupScan.getSpecificScan
(int minorFragmentId) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.pojo
Modifier and TypeMethodDescriptionstatic PojoWriter
Creates matching writer to the given field type.protected PojoWriter
AbstractPojoRecordReader.initWriter
(Class<?> type, String fieldName, OutputMutator output) Creates writer based input class type and then initiates it.void
AbstractPojoRecordReader.setup
(OperatorContext context, OutputMutator output) protected abstract List<PojoWriter>
AbstractPojoRecordReader.setupWriters
(OutputMutator output) Setups writers for each field in the row.protected List<PojoWriter>
DynamicPojoRecordReader.setupWriters
(OutputMutator output) Initiates writers based on given schema which contains field name and its type.protected List<PojoWriter>
PojoRecordReader.setupWriters
(OutputMutator output) Creates writers based on pojo field class types. -
Uses of ExecutionSetupException in org.apache.drill.exec.store.splunk
Modifier and TypeMethodDescriptionSplunkScanBatchCreator.getBatch
(ExecutorFragmentContext context, SplunkSubScan subScan, List<RecordBatch> children) -
Uses of ExecutionSetupException in org.apache.drill.exec.store.sys
Modifier and TypeMethodDescriptionSystemTableBatchCreator.getBatch
(ExecutorFragmentContext context, SystemTableScan scan, List<RecordBatch> children) PersistentStoreRegistry.newPStoreProvider()
ModifierConstructorDescriptionSystemTableScan
(SystemTable table, int maxRecordsToRead, StoragePluginRegistry engineRegistry) -
Uses of ExecutionSetupException in org.apache.drill.exec.work.foreman
Modifier and TypeClassDescriptionclass
class
class
class
class
class
Modifier and TypeMethodDescriptionvoid
FragmentsRunner.submit()
Submits root and non-root fragments fragments for running.
StoragePluginRegistry.resolveFormat(StoragePluginConfig, FormatPluginConfig, Class)
which provides type safety.