bsh |
Generate-fmpp has a dependency on beanshell EvalError.
|
com.codahale.metrics |
|
com.esri.core.geometry |
|
io.netty.buffer |
|
org.apache.calcite.adapter.cassandra |
|
org.apache.calcite.adapter.elasticsearch |
|
org.apache.calcite.jdbc |
|
org.apache.commons.logging.impl |
|
org.apache.drill.common |
Logical (execution-engine-independent) element definitions.
|
org.apache.drill.common.collections |
|
org.apache.drill.common.concurrent |
|
org.apache.drill.common.config |
Internal configuration state definitions.
|
org.apache.drill.common.exceptions |
Various exceptions used in logical, physical and execution contexts.
|
org.apache.drill.common.expression |
Logical expression tree representation.
|
org.apache.drill.common.expression.fn |
Logical function definitions.
|
org.apache.drill.common.expression.parser |
|
org.apache.drill.common.expression.types |
Logical type definitions.
|
org.apache.drill.common.expression.visitors |
Visitors for validating or optimizing logical expressions.
|
org.apache.drill.common.graph |
Connected-graph representation shared by logical and physical query graphs.
|
org.apache.drill.common.logical |
Storage plugin interfaces and logical plan representation.
|
org.apache.drill.common.logical.data |
Logical operators in a query graph.
|
org.apache.drill.common.logical.data.visitors |
Visitors for Drill logical plan graphs.
|
org.apache.drill.common.logical.security |
|
org.apache.drill.common.map |
|
org.apache.drill.common.parser |
|
org.apache.drill.common.scanner |
|
org.apache.drill.common.scanner.persistence |
|
org.apache.drill.common.types |
Logical data types.
|
org.apache.drill.common.util |
Utilities useful across packages.
|
org.apache.drill.common.util.function |
|
org.apache.drill.exec |
Drill execution engine, including: physical operators, runtime code
generation, planning, RPC layer, Value Vector data structures.
|
org.apache.drill.exec.alias |
|
org.apache.drill.exec.cache |
Distributed cache for syncing state and data between Drillbits.
|
org.apache.drill.exec.client |
Java client API for submitting queries and accepting result sets from a Drill
server.
|
org.apache.drill.exec.compile |
Runtime code-generation, compilation and bytecode-manipulation utilities.
|
org.apache.drill.exec.compile.bytecode |
Bytecode manipulation utilities for stitching together runtime-generated code
with prebuilt templates.
|
org.apache.drill.exec.compile.sig |
TODO - write docs for this package
|
org.apache.drill.exec.coord |
Cluster coordination system based on Apache Zookeeper and Curator.
|
org.apache.drill.exec.coord.local |
A single-node "cluster coordinator" used when running Drill locally.
|
org.apache.drill.exec.coord.store |
|
org.apache.drill.exec.coord.zk |
Zookeeper/Curator integration code.
|
org.apache.drill.exec.disk |
Interface for Drill's interaction with the local disk to persist data
temporarily during an operation.
|
org.apache.drill.exec.dotdrill |
Meta-data persistence format, used for views and other cluster-wide
persistent state.
|
org.apache.drill.exec.exception |
Execution-time exceptions.
|
org.apache.drill.exec.expr |
Drill expression materialization and evaluation facilities.
|
org.apache.drill.exec.expr.annotations |
|
org.apache.drill.exec.expr.fn |
|
org.apache.drill.exec.expr.fn.impl |
|
org.apache.drill.exec.expr.fn.impl.conv |
|
org.apache.drill.exec.expr.fn.impl.gaggr |
|
org.apache.drill.exec.expr.fn.impl.gcast |
|
org.apache.drill.exec.expr.fn.impl.hive |
|
org.apache.drill.exec.expr.fn.interpreter |
|
org.apache.drill.exec.expr.fn.output |
|
org.apache.drill.exec.expr.fn.registry |
|
org.apache.drill.exec.expr.holders |
|
org.apache.drill.exec.expr.stat |
|
org.apache.drill.exec.memory |
Memory Allocation, Account and Management
See the README.md file in this directory for detailed information about Drill's memory allocation subsystem.
|
org.apache.drill.exec.metastore |
|
org.apache.drill.exec.metastore.analyze |
|
org.apache.drill.exec.metastore.store |
|
org.apache.drill.exec.metastore.store.parquet |
|
org.apache.drill.exec.metrics |
|
org.apache.drill.exec.oauth |
|
org.apache.drill.exec.ops |
|
org.apache.drill.exec.opt |
|
org.apache.drill.exec.physical |
|
org.apache.drill.exec.physical.base |
|
org.apache.drill.exec.physical.config |
|
org.apache.drill.exec.physical.impl |
|
org.apache.drill.exec.physical.impl.aggregate |
|
org.apache.drill.exec.physical.impl.broadcastsender |
|
org.apache.drill.exec.physical.impl.common |
|
org.apache.drill.exec.physical.impl.filter |
|
org.apache.drill.exec.physical.impl.flatten |
|
org.apache.drill.exec.physical.impl.join |
|
org.apache.drill.exec.physical.impl.limit |
|
org.apache.drill.exec.physical.impl.materialize |
|
org.apache.drill.exec.physical.impl.mergereceiver |
|
org.apache.drill.exec.physical.impl.metadata |
|
org.apache.drill.exec.physical.impl.orderedpartitioner |
|
org.apache.drill.exec.physical.impl.partitionsender |
|
org.apache.drill.exec.physical.impl.producer |
|
org.apache.drill.exec.physical.impl.project |
|
org.apache.drill.exec.physical.impl.protocol |
Defines a revised implementation of the Drill RecordBatch protocol.
|
org.apache.drill.exec.physical.impl.rangepartitioner |
|
org.apache.drill.exec.physical.impl.scan |
Defines the scan operation implementation.
|
org.apache.drill.exec.physical.impl.scan.columns |
Handles the special "columns" column used by the text reader,
and available to similar readers.
|
org.apache.drill.exec.physical.impl.scan.convert |
Standard type conversion tools for the case in which the input
types are the standard Java types already supported by the
ValuesWriter interface.
|
org.apache.drill.exec.physical.impl.scan.file |
Handles optional file metadata columns: implicit columns and
partition columns.
|
org.apache.drill.exec.physical.impl.scan.framework |
Defines the projection, vector continuity and other operations for
a set of one or more readers.
|
org.apache.drill.exec.physical.impl.scan.project |
Provides run-time semantic analysis of the projection list for the
scan operator.
|
org.apache.drill.exec.physical.impl.scan.v3 |
Provides the "version 3" scan framework (which can also be thought of
as EVF version 2).
|
org.apache.drill.exec.physical.impl.scan.v3.file |
|
org.apache.drill.exec.physical.impl.scan.v3.lifecycle |
Implements the details of the scan lifecycle for a set of readers,
primarily the process of resolving the scan output schema from a variety
of input schemas, then running each reader, each of which will produce
some number of batches.
|
org.apache.drill.exec.physical.impl.scan.v3.schema |
Provides run-time semantic analysis of the projection list for the
scan operator.
|
org.apache.drill.exec.physical.impl.sort |
|
org.apache.drill.exec.physical.impl.spill |
Collection of classes shared by operators that implement spill-to-disk.
|
org.apache.drill.exec.physical.impl.statistics |
|
org.apache.drill.exec.physical.impl.svremover |
|
org.apache.drill.exec.physical.impl.TopN |
|
org.apache.drill.exec.physical.impl.trace |
|
org.apache.drill.exec.physical.impl.union |
|
org.apache.drill.exec.physical.impl.unnest |
|
org.apache.drill.exec.physical.impl.unorderedreceiver |
|
org.apache.drill.exec.physical.impl.unpivot |
|
org.apache.drill.exec.physical.impl.validate |
|
org.apache.drill.exec.physical.impl.values |
|
org.apache.drill.exec.physical.impl.window |
|
org.apache.drill.exec.physical.impl.xsort |
|
org.apache.drill.exec.physical.resultSet |
Provides a second-generation row set (AKA "record batch") writer used
by client code to
Define the schema of a result set.
Write data into the vectors backing a row set.
|
org.apache.drill.exec.physical.resultSet.impl |
Handles the details of the result set loader implementation.
|
org.apache.drill.exec.physical.resultSet.model |
The "row set model" provides a "dual" of the vector structure used to create,
allocate and work with a collection of vectors.
|
org.apache.drill.exec.physical.resultSet.model.hyper |
Implementation of a row set model for hyper-batches.
|
org.apache.drill.exec.physical.resultSet.model.single |
This set of classes models the structure of a batch consisting
of single vectors (as contrasted with a hyper batch.) Provides tools
or metdata-based construction, allocation, reading and writing of
the vectors.
|
org.apache.drill.exec.physical.resultSet.project |
|
org.apache.drill.exec.physical.resultSet.util |
|
org.apache.drill.exec.physical.rowSet |
Provides a set of tools to work with row sets.
|
org.apache.drill.exec.planner |
|
org.apache.drill.exec.planner.common |
|
org.apache.drill.exec.planner.cost |
|
org.apache.drill.exec.planner.fragment |
|
org.apache.drill.exec.planner.fragment.contrib |
|
org.apache.drill.exec.planner.index |
|
org.apache.drill.exec.planner.index.generators |
|
org.apache.drill.exec.planner.index.rules |
|
org.apache.drill.exec.planner.logical |
|
org.apache.drill.exec.planner.logical.partition |
|
org.apache.drill.exec.planner.physical |
|
org.apache.drill.exec.planner.physical.explain |
|
org.apache.drill.exec.planner.physical.visitor |
|
org.apache.drill.exec.planner.sql |
|
org.apache.drill.exec.planner.sql.conversion |
|
org.apache.drill.exec.planner.sql.handlers |
|
org.apache.drill.exec.planner.sql.logical |
|
org.apache.drill.exec.planner.sql.parser |
|
org.apache.drill.exec.planner.sql.parser.impl |
|
org.apache.drill.exec.planner.torel |
|
org.apache.drill.exec.planner.types |
|
org.apache.drill.exec.planner.types.decimal |
|
org.apache.drill.exec.proto |
|
org.apache.drill.exec.proto.helper |
|
org.apache.drill.exec.record |
|
org.apache.drill.exec.record.metadata |
Provides a fluent schema builder.
|
org.apache.drill.exec.record.metadata.schema |
|
org.apache.drill.exec.record.metadata.schema.parser |
|
org.apache.drill.exec.record.selection |
|
org.apache.drill.exec.resolver |
|
org.apache.drill.exec.resourcemgr |
This package will contain all the components of resource manager in Drill.
|
org.apache.drill.exec.resourcemgr.config |
This package contains the configuration components of ResourceManagement feature in Drill.
|
org.apache.drill.exec.resourcemgr.config.exception |
|
org.apache.drill.exec.resourcemgr.config.selectionpolicy |
Defines all the selection policy implementation which can be configured with Resource Management.
|
org.apache.drill.exec.resourcemgr.config.selectors |
Defines all the Selectors which can be assigned to a ResourcePool in the ResourceManagement configuration.
|
org.apache.drill.exec.resourcemgr.util |
|
org.apache.drill.exec.rpc |
|
org.apache.drill.exec.rpc.control |
|
org.apache.drill.exec.rpc.data |
|
org.apache.drill.exec.rpc.security |
Communication security.
|
org.apache.drill.exec.rpc.security.kerberos |
|
org.apache.drill.exec.rpc.security.plain |
|
org.apache.drill.exec.rpc.user |
|
org.apache.drill.exec.rpc.user.security |
|
org.apache.drill.exec.schema |
|
org.apache.drill.exec.schema.json.jackson |
|
org.apache.drill.exec.serialization |
|
org.apache.drill.exec.server |
|
org.apache.drill.exec.server.options |
|
org.apache.drill.exec.server.rest |
|
org.apache.drill.exec.server.rest.auth |
|
org.apache.drill.exec.server.rest.header |
|
org.apache.drill.exec.server.rest.profile |
|
org.apache.drill.exec.server.rest.ssl |
|
org.apache.drill.exec.server.rest.stream |
|
org.apache.drill.exec.service |
|
org.apache.drill.exec.ssl |
|
org.apache.drill.exec.store |
|
org.apache.drill.exec.store.avro |
|
org.apache.drill.exec.store.base.filter |
|
org.apache.drill.exec.store.bson |
|
org.apache.drill.exec.store.cassandra |
|
org.apache.drill.exec.store.cassandra.plan |
|
org.apache.drill.exec.store.cassandra.schema |
|
org.apache.drill.exec.store.dfs |
|
org.apache.drill.exec.store.dfs.easy |
|
org.apache.drill.exec.store.direct |
|
org.apache.drill.exec.store.druid |
|
org.apache.drill.exec.store.druid.common |
|
org.apache.drill.exec.store.druid.druid |
|
org.apache.drill.exec.store.druid.rest |
|
org.apache.drill.exec.store.druid.schema |
|
org.apache.drill.exec.store.easy.json |
|
org.apache.drill.exec.store.easy.json.extended |
Provides parsing for Mongo extended types which are generally of the form
{ "$type": value } .
|
org.apache.drill.exec.store.easy.json.loader |
|
org.apache.drill.exec.store.easy.json.parser |
|
org.apache.drill.exec.store.easy.json.reader |
|
org.apache.drill.exec.store.easy.json.values |
|
org.apache.drill.exec.store.easy.sequencefile |
|
org.apache.drill.exec.store.easy.text |
|
org.apache.drill.exec.store.easy.text.reader |
Version 3 of the text reader.
|
org.apache.drill.exec.store.easy.text.writer |
|
org.apache.drill.exec.store.elasticsearch |
|
org.apache.drill.exec.store.elasticsearch.plan |
|
org.apache.drill.exec.store.elasticsearch.schema |
|
org.apache.drill.exec.store.enumerable |
|
org.apache.drill.exec.store.enumerable.plan |
|
org.apache.drill.exec.store.esri |
|
org.apache.drill.exec.store.excel |
|
org.apache.drill.exec.store.hbase |
|
org.apache.drill.exec.store.hbase.config |
|
org.apache.drill.exec.store.hdf5 |
|
org.apache.drill.exec.store.hdf5.writers |
|
org.apache.drill.exec.store.hive |
|
org.apache.drill.exec.store.hive.client |
|
org.apache.drill.exec.store.hive.readers |
|
org.apache.drill.exec.store.hive.readers.inspectors |
|
org.apache.drill.exec.store.hive.schema |
|
org.apache.drill.exec.store.hive.writers |
Package containing writers used to write data from Hive table columns into Drill's value vectors.
|
org.apache.drill.exec.store.hive.writers.complex |
|
org.apache.drill.exec.store.hive.writers.primitive |
|
org.apache.drill.exec.store.http |
|
org.apache.drill.exec.store.http.oauth |
|
org.apache.drill.exec.store.http.paginator |
|
org.apache.drill.exec.store.http.util |
|
org.apache.drill.exec.store.httpd |
|
org.apache.drill.exec.store.iceberg |
|
org.apache.drill.exec.store.iceberg.format |
|
org.apache.drill.exec.store.iceberg.plan |
|
org.apache.drill.exec.store.iceberg.read |
|
org.apache.drill.exec.store.iceberg.snapshot |
|
org.apache.drill.exec.store.image |
|
org.apache.drill.exec.store.ischema |
|
org.apache.drill.exec.store.jdbc |
|
org.apache.drill.exec.store.jdbc.clickhouse |
|
org.apache.drill.exec.store.jdbc.rules |
|
org.apache.drill.exec.store.jdbc.utils |
|
org.apache.drill.exec.store.jdbc.writers |
|
org.apache.drill.exec.store.kafka |
Kafka storage plugin.
|
org.apache.drill.exec.store.kafka.decoders |
|
org.apache.drill.exec.store.kafka.schema |
|
org.apache.drill.exec.store.kudu |
|
org.apache.drill.exec.store.log |
|
org.apache.drill.exec.store.ltsv |
|
org.apache.drill.exec.store.mapr |
|
org.apache.drill.exec.store.mapr.db |
|
org.apache.drill.exec.store.mapr.db.binary |
|
org.apache.drill.exec.store.mapr.db.json |
|
org.apache.drill.exec.store.mapr.db.util |
|
org.apache.drill.exec.store.mapr.streams |
|
org.apache.drill.exec.store.mock |
Defines a mock data source which generates dummy test data for use
in testing.
|
org.apache.drill.exec.store.mongo |
MongoDB storage plugin.
|
org.apache.drill.exec.store.mongo.common |
|
org.apache.drill.exec.store.mongo.config |
|
org.apache.drill.exec.store.mongo.plan |
|
org.apache.drill.exec.store.mongo.schema |
|
org.apache.drill.exec.store.openTSDB |
|
org.apache.drill.exec.store.openTSDB.client |
|
org.apache.drill.exec.store.openTSDB.client.query |
|
org.apache.drill.exec.store.openTSDB.client.services |
|
org.apache.drill.exec.store.openTSDB.dto |
|
org.apache.drill.exec.store.openTSDB.schema |
|
org.apache.drill.exec.store.parquet |
|
org.apache.drill.exec.store.parquet.columnreaders |
|
org.apache.drill.exec.store.parquet.columnreaders.batchsizing |
|
org.apache.drill.exec.store.parquet.compression |
|
org.apache.drill.exec.store.parquet.decimal |
|
org.apache.drill.exec.store.parquet.metadata |
|
org.apache.drill.exec.store.parquet2 |
|
org.apache.drill.exec.store.pcap |
For comments on realization of this format plugin look at :
|
org.apache.drill.exec.store.pcap.decoder |
|
org.apache.drill.exec.store.pcap.dto |
|
org.apache.drill.exec.store.pcap.plugin |
|
org.apache.drill.exec.store.pcap.schema |
|
org.apache.drill.exec.store.pcapng |
|
org.apache.drill.exec.store.pdf |
|
org.apache.drill.exec.store.phoenix |
|
org.apache.drill.exec.store.phoenix.rules |
|
org.apache.drill.exec.store.plan |
|
org.apache.drill.exec.store.plan.rel |
|
org.apache.drill.exec.store.plan.rule |
|
org.apache.drill.exec.store.pojo |
|
org.apache.drill.exec.store.sas |
|
org.apache.drill.exec.store.schedule |
|
org.apache.drill.exec.store.security |
|
org.apache.drill.exec.store.security.oauth |
|
org.apache.drill.exec.store.security.vault |
|
org.apache.drill.exec.store.splunk |
|
org.apache.drill.exec.store.spss |
|
org.apache.drill.exec.store.sys |
|
org.apache.drill.exec.store.sys.store |
|
org.apache.drill.exec.store.sys.store.provider |
|
org.apache.drill.exec.store.sys.zk |
|
org.apache.drill.exec.store.syslog |
|
org.apache.drill.exec.store.table.function |
|
org.apache.drill.exec.store.xml |
|
org.apache.drill.exec.testing |
|
org.apache.drill.exec.testing.store |
|
org.apache.drill.exec.udf.mapr.db |
|
org.apache.drill.exec.udfs |
|
org.apache.drill.exec.udfs.gis |
|
org.apache.drill.exec.util |
|
org.apache.drill.exec.util.concurrent |
|
org.apache.drill.exec.util.filereader |
|
org.apache.drill.exec.util.record |
|
org.apache.drill.exec.vector |
|
org.apache.drill.exec.vector.accessor |
Provides a light-weight, simplified set of column readers and writers that
can be plugged into a variety of row-level readers and writers.
|
org.apache.drill.exec.vector.accessor.impl |
Provides implementations of the API defined in the parent package.
|
org.apache.drill.exec.vector.accessor.reader |
Provides the reader hierarchy as explained in the API package.
|
org.apache.drill.exec.vector.accessor.sql |
|
org.apache.drill.exec.vector.accessor.writer |
Implementation of the vector writers.
|
org.apache.drill.exec.vector.accessor.writer.dummy |
This package provides a "dummy" set of writers.
|
org.apache.drill.exec.vector.complex |
|
org.apache.drill.exec.vector.complex.fn |
|
org.apache.drill.exec.vector.complex.impl |
|
org.apache.drill.exec.vector.complex.reader |
|
org.apache.drill.exec.vector.complex.writer |
|
org.apache.drill.exec.work |
|
org.apache.drill.exec.work.batch |
|
org.apache.drill.exec.work.filter |
|
org.apache.drill.exec.work.foreman |
|
org.apache.drill.exec.work.foreman.rm |
Provides resource management and queuing support for the Drill foreman.
|
org.apache.drill.exec.work.fragment |
|
org.apache.drill.exec.work.metadata |
|
org.apache.drill.exec.work.prepare |
|
org.apache.drill.exec.work.user |
|
org.apache.drill.fmpp.mojo |
|
org.apache.drill.jdbc |
JDBC driver for Drill.
|
org.apache.drill.jdbc.impl |
|
org.apache.drill.jdbc.proxy |
Tracing proxy JDBC driver.
|
org.apache.drill.metastore |
|
org.apache.drill.metastore.components.tables |
|
org.apache.drill.metastore.components.views |
|
org.apache.drill.metastore.config |
|
org.apache.drill.metastore.exceptions |
|
org.apache.drill.metastore.expressions |
|
org.apache.drill.metastore.iceberg |
|
org.apache.drill.metastore.iceberg.components.tables |
|
org.apache.drill.metastore.iceberg.config |
|
org.apache.drill.metastore.iceberg.exceptions |
|
org.apache.drill.metastore.iceberg.operate |
|
org.apache.drill.metastore.iceberg.schema |
|
org.apache.drill.metastore.iceberg.transform |
|
org.apache.drill.metastore.iceberg.write |
|
org.apache.drill.metastore.metadata |
|
org.apache.drill.metastore.mongo |
|
org.apache.drill.metastore.mongo.components.tables |
|
org.apache.drill.metastore.mongo.config |
|
org.apache.drill.metastore.mongo.exception |
|
org.apache.drill.metastore.mongo.operate |
|
org.apache.drill.metastore.mongo.transform |
|
org.apache.drill.metastore.operate |
|
org.apache.drill.metastore.rdbms |
|
org.apache.drill.metastore.rdbms.components.tables |
|
org.apache.drill.metastore.rdbms.config |
|
org.apache.drill.metastore.rdbms.exception |
|
org.apache.drill.metastore.rdbms.operate |
|
org.apache.drill.metastore.rdbms.transform |
|
org.apache.drill.metastore.rdbms.util |
|
org.apache.drill.metastore.statistics |
|
org.apache.drill.metastore.util |
|
org.apache.drill.yarn.appMaster |
Implements the Drill Application Master for YARN.
|
org.apache.drill.yarn.appMaster.http |
|
org.apache.drill.yarn.client |
Implements a "YARN client" for Drill-on-YARN.
|
org.apache.drill.yarn.core |
Holds functionality common to the Drill-on-YARN client and Application Master (AM).
|
org.apache.drill.yarn.zk |
Interface between the Application Master and ZooKeeper.
|
org.apache.iceberg.data |
|
org.apache.logging.log4j.util |
|
org.apache.parquet.hadoop |
|
org.jooq.generated |
|
org.jooq.generated.tables |
|
org.jooq.generated.tables.records |
|