You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@drill.apache.org by js...@apache.org on 2015/07/16 23:08:38 UTC

drill git commit: DRILL-1904 - Part 1: Package level docs for the common module and a few packages in exec.

Repository: drill
Updated Branches:
  refs/heads/master 09252c9aa -> 7a2ea2531


DRILL-1904 - Part 1: Package level docs for the common module and a few packages in exec.

Fix line wrapping on package level docs to standardize at 80 character wrap.

Patch updated to address review comments.

Patch updated again to address Sudheesh's review comments.


Project: http://git-wip-us.apache.org/repos/asf/drill/repo
Commit: http://git-wip-us.apache.org/repos/asf/drill/commit/7a2ea253
Tree: http://git-wip-us.apache.org/repos/asf/drill/tree/7a2ea253
Diff: http://git-wip-us.apache.org/repos/asf/drill/diff/7a2ea253

Branch: refs/heads/master
Commit: 7a2ea2531b2abded16033e9271f23b63143369e0
Parents: 09252c9
Author: Jason Altekruse <al...@gmail.com>
Authored: Fri Dec 12 17:13:03 2014 -0800
Committer: Jason Altekruse <al...@gmail.com>
Committed: Thu Jul 16 14:08:14 2015 -0700

----------------------------------------------------------------------
 .../drill/common/config/package-info.java       | 26 ++++++++++++++++
 .../drill/common/exceptions/package-info.java   | 21 +++++++++++++
 .../expression/aggregate/BasicAggregates.java   | 22 --------------
 .../common/expression/fn/package-info.java      | 21 +++++++++++++
 .../drill/common/expression/package-info.java   | 29 ++++++++++++++++++
 .../common/expression/types/package-info.java   | 21 +++++++++++++
 .../expression/visitors/package-info.java       | 24 +++++++++++++++
 .../apache/drill/common/graph/package-info.java | 21 +++++++++++++
 .../common/logical/FormatPluginConfig.java      | 13 ++++++++
 .../common/logical/FormatPluginConfigBase.java  |  7 ++++-
 .../drill/common/logical/data/package-info.java | 21 +++++++++++++
 .../logical/data/visitors/package-info.java     | 21 +++++++++++++
 .../drill/common/logical/package-info.java      | 25 +++++++++++++++
 .../org/apache/drill/common/package-info.java   | 30 ++++++++++++++++++
 .../apache/drill/common/types/package-info.java | 21 +++++++++++++
 .../apache/drill/common/util/package-info.java  | 21 +++++++++++++
 .../drill/exec/store/mongo/package-info.java    | 24 +++++++++++++++
 .../apache/drill/exec/cache/package-info.java   | 27 +++++++++++++++++
 .../apache/drill/exec/client/package-info.java  | 27 +++++++++++++++++
 .../exec/compile/bytecode/package-info.java     | 28 +++++++++++++++++
 .../apache/drill/exec/compile/package-info.java | 32 ++++++++++++++++++++
 .../drill/exec/compile/sig/package-info.java    | 21 +++++++++++++
 .../drill/exec/coord/local/package-info.java    | 21 +++++++++++++
 .../apache/drill/exec/coord/package-info.java   | 24 +++++++++++++++
 .../drill/exec/coord/zk/package-info.java       | 25 +++++++++++++++
 .../apache/drill/exec/disk/package-info.java    | 26 ++++++++++++++++
 .../drill/exec/dotdrill/package-info.java       | 22 ++++++++++++++
 .../drill/exec/exception/package-info.java      | 21 +++++++++++++
 .../org/apache/drill/exec/package-info.java     | 27 +++++++++++++++++
 29 files changed, 646 insertions(+), 23 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/config/package-info.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/config/package-info.java b/common/src/main/java/org/apache/drill/common/config/package-info.java
new file mode 100644
index 0000000..2b2bbb4
--- /dev/null
+++ b/common/src/main/java/org/apache/drill/common/config/package-info.java
@@ -0,0 +1,26 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Internal configuration state definitions.
+ *
+ * Overall structure allows for configurations to be nested within one another
+ * to provide hierarchical organization of configuration options. Drill configurations
+ * are stored in a JSON format in files named drill-override.conf available on the classpath.
+ * See the DrillConfig class for more information on config file loading.
+ */
+package org.apache.drill.common.config;

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/exceptions/package-info.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/exceptions/package-info.java b/common/src/main/java/org/apache/drill/common/exceptions/package-info.java
new file mode 100644
index 0000000..c16c69c
--- /dev/null
+++ b/common/src/main/java/org/apache/drill/common/exceptions/package-info.java
@@ -0,0 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Various exceptions used in logical, physical and execution contexts.
+ */
+package org.apache.drill.common.exceptions;

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/expression/aggregate/BasicAggregates.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/expression/aggregate/BasicAggregates.java b/common/src/main/java/org/apache/drill/common/expression/aggregate/BasicAggregates.java
deleted file mode 100644
index 5f18aaf..0000000
--- a/common/src/main/java/org/apache/drill/common/expression/aggregate/BasicAggregates.java
+++ /dev/null
@@ -1,22 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.drill.common.expression.aggregate;
-
-public class BasicAggregates {
-
-}

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/expression/fn/package-info.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/expression/fn/package-info.java b/common/src/main/java/org/apache/drill/common/expression/fn/package-info.java
new file mode 100644
index 0000000..6af3f5f
--- /dev/null
+++ b/common/src/main/java/org/apache/drill/common/expression/fn/package-info.java
@@ -0,0 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Logical function definitions.
+ */
+package org.apache.drill.common.expression.fn;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/expression/package-info.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/expression/package-info.java b/common/src/main/java/org/apache/drill/common/expression/package-info.java
new file mode 100644
index 0000000..209f990
--- /dev/null
+++ b/common/src/main/java/org/apache/drill/common/expression/package-info.java
@@ -0,0 +1,29 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Logical expression tree representation.
+ *
+ * Drill manages expressions provided in many different parts of SQL queries.
+ * This includes scalar expressions in select, filter and join conditions, as
+ * well as aggregate and window functions. These expressions are represented
+ * logically as ASTs during planning. The classes defined here provide the
+ * different nodes in the expression tree, as well as utilities for building 
+ * and manipulating expressions during parsing and planning.
+ *
+ */
+package org.apache.drill.common.expression;

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/expression/types/package-info.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/expression/types/package-info.java b/common/src/main/java/org/apache/drill/common/expression/types/package-info.java
new file mode 100644
index 0000000..744b174
--- /dev/null
+++ b/common/src/main/java/org/apache/drill/common/expression/types/package-info.java
@@ -0,0 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Logical type definitions.
+ */
+package org.apache.drill.common.expression.types;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/expression/visitors/package-info.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/expression/visitors/package-info.java b/common/src/main/java/org/apache/drill/common/expression/visitors/package-info.java
new file mode 100644
index 0000000..b57362e
--- /dev/null
+++ b/common/src/main/java/org/apache/drill/common/expression/visitors/package-info.java
@@ -0,0 +1,24 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Visitors for validating or optimizing logical expressions.
+ *
+ * These visitors are used to provide feedback to users on invalid expressions
+ * as well as some basic optimizations applied during planning.
+ */
+package org.apache.drill.common.expression.visitors;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/graph/package-info.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/graph/package-info.java b/common/src/main/java/org/apache/drill/common/graph/package-info.java
new file mode 100644
index 0000000..38138d0
--- /dev/null
+++ b/common/src/main/java/org/apache/drill/common/graph/package-info.java
@@ -0,0 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Connected-graph representation shared by logical and physical query graphs.
+ */
+package org.apache.drill.common.graph;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/logical/FormatPluginConfig.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/logical/FormatPluginConfig.java b/common/src/main/java/org/apache/drill/common/logical/FormatPluginConfig.java
index 936e4f2..e7d3d1f 100644
--- a/common/src/main/java/org/apache/drill/common/logical/FormatPluginConfig.java
+++ b/common/src/main/java/org/apache/drill/common/logical/FormatPluginConfig.java
@@ -19,6 +19,19 @@ package org.apache.drill.common.logical;
 
 import com.fasterxml.jackson.annotation.JsonTypeInfo;
 
+/**
+ * Interface for defining a Drill format plugin.
+ *
+ * Format plugins are contained within storage plugins to describe particular
+ * data formats available in a given storage system. These formats are not
+ * necessarily tied to how the data is stored. One current use of this
+ * abstraction is describing different file formats like CSV and JSON that
+ * can be stored in a filesystem. Some storage systems like databases may only
+ * have a single format in which the data is actually stored. This interface
+ * enables flexibility for configuring the different data formats that will
+ * live under one storage system. The storage systems themselves are described
+ * in {@see StoragePluginConfig}s.
+ */
 @JsonTypeInfo(use = JsonTypeInfo.Id.NAME, include = JsonTypeInfo.As.PROPERTY, property="type")
 public interface FormatPluginConfig {
   static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(FormatPluginConfig.class);

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/logical/FormatPluginConfigBase.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/logical/FormatPluginConfigBase.java b/common/src/main/java/org/apache/drill/common/logical/FormatPluginConfigBase.java
index 0704085..e5cf80b 100644
--- a/common/src/main/java/org/apache/drill/common/logical/FormatPluginConfigBase.java
+++ b/common/src/main/java/org/apache/drill/common/logical/FormatPluginConfigBase.java
@@ -26,7 +26,12 @@ import org.apache.drill.common.util.PathScanner;
 public abstract class FormatPluginConfigBase implements FormatPluginConfig{
   static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(FormatPluginConfigBase.class);
 
-
+  /**
+   * Use reflection to scan for implementations of {@see FormatPlugin}.
+   *
+   * @param config - Drill configuration object, used to find the packages to scan
+   * @return - list of classes that implement the interface.
+   */
   public synchronized static Class<?>[] getSubTypes(DrillConfig config){
     List<String> packages = config.getStringList(CommonConstants.STORAGE_PLUGIN_CONFIG_SCAN_PACKAGES);
     Class<?>[] sec = PathScanner.scanForImplementationsArr(FormatPluginConfig.class, packages);

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/logical/data/package-info.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/logical/data/package-info.java b/common/src/main/java/org/apache/drill/common/logical/data/package-info.java
new file mode 100644
index 0000000..fc76c0d
--- /dev/null
+++ b/common/src/main/java/org/apache/drill/common/logical/data/package-info.java
@@ -0,0 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Logical operators in a query graph.
+ */
+package org.apache.drill.common.logical.data;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/logical/data/visitors/package-info.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/logical/data/visitors/package-info.java b/common/src/main/java/org/apache/drill/common/logical/data/visitors/package-info.java
new file mode 100644
index 0000000..9b82bb3
--- /dev/null
+++ b/common/src/main/java/org/apache/drill/common/logical/data/visitors/package-info.java
@@ -0,0 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Visitors for Drill logical plan graphs.
+ */
+package org.apache.drill.common.logical.data.visitors;

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/logical/package-info.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/logical/package-info.java b/common/src/main/java/org/apache/drill/common/logical/package-info.java
new file mode 100644
index 0000000..1f88f06
--- /dev/null
+++ b/common/src/main/java/org/apache/drill/common/logical/package-info.java
@@ -0,0 +1,25 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Storage plugin interfaces and logical plan representation.
+ *
+ * This package includes the interface for storage and format plugins for Drill
+ * as well as the top level class for representing a Drill logical plan and a
+ * builder for constructing plans.
+ */
+package org.apache.drill.common.logical;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/package-info.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/package-info.java b/common/src/main/java/org/apache/drill/common/package-info.java
new file mode 100644
index 0000000..4de8489
--- /dev/null
+++ b/common/src/main/java/org/apache/drill/common/package-info.java
@@ -0,0 +1,30 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Logical (execution-engine-independent) element definitions.
+ *
+ * Drill has several representations of a query including SQL, logical plans and
+ * physical plans. All of the logical constructs of Drill are separated from
+ * their physical implementations in the Java execution engine. The components
+ * of this package can be used to share common logical constructs between the
+ * current engine and any other future alternative physical implementations of
+ * the same logical constructs. This is the same for the logical expression
+ * constructs defined within this package.
+ *
+ */
+package org.apache.drill.common;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/types/package-info.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/types/package-info.java b/common/src/main/java/org/apache/drill/common/types/package-info.java
new file mode 100644
index 0000000..1334c6f
--- /dev/null
+++ b/common/src/main/java/org/apache/drill/common/types/package-info.java
@@ -0,0 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Logical data types.
+ */
+package org.apache.drill.common.types;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/common/src/main/java/org/apache/drill/common/util/package-info.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/util/package-info.java b/common/src/main/java/org/apache/drill/common/util/package-info.java
new file mode 100644
index 0000000..1d7d418
--- /dev/null
+++ b/common/src/main/java/org/apache/drill/common/util/package-info.java
@@ -0,0 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Utilities useful across packages.
+ */
+package org.apache.drill.common.util;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/contrib/storage-mongo/src/main/java/org/apache/drill/exec/store/mongo/package-info.java
----------------------------------------------------------------------
diff --git a/contrib/storage-mongo/src/main/java/org/apache/drill/exec/store/mongo/package-info.java b/contrib/storage-mongo/src/main/java/org/apache/drill/exec/store/mongo/package-info.java
new file mode 100644
index 0000000..e23eb53
--- /dev/null
+++ b/contrib/storage-mongo/src/main/java/org/apache/drill/exec/store/mongo/package-info.java
@@ -0,0 +1,24 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * MongoDB storage plugin.
+ *
+ * Enables querying MongoDB as a data store, including some optimizations
+ * like filter pushdown.
+ */
+package org.apache.drill.exec.store.mongo;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/exec/java-exec/src/main/java/org/apache/drill/exec/cache/package-info.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/cache/package-info.java b/exec/java-exec/src/main/java/org/apache/drill/exec/cache/package-info.java
new file mode 100644
index 0000000..cc17d31
--- /dev/null
+++ b/exec/java-exec/src/main/java/org/apache/drill/exec/cache/package-info.java
@@ -0,0 +1,27 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Distributed cache for syncing state and data between Drillbits.
+ *
+ * The distributed cache defined in this package can be used to make data
+ * available to all of the nodes in a Drill cluster. This is useful in cases
+ * where most of the work of a given operation can be separated into independent
+ * tasks, but some common information must be available to and mutable by all of
+ * the nodes currently involved in the operation.
+ */
+package org.apache.drill.exec.cache;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/exec/java-exec/src/main/java/org/apache/drill/exec/client/package-info.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/client/package-info.java b/exec/java-exec/src/main/java/org/apache/drill/exec/client/package-info.java
new file mode 100644
index 0000000..5676336
--- /dev/null
+++ b/exec/java-exec/src/main/java/org/apache/drill/exec/client/package-info.java
@@ -0,0 +1,27 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Java client API for submitting queries and accepting result sets from a Drill
+ * server.
+ *
+ * Data returned to this client is stored in the default columnar Value Vector
+ * data structures used by Drill internally. For users of Drill requiring a more
+ * traditional database interface to consume from an application, a JDBC driver
+ * is available as well; see the {@see org.apache.drill.jdbc} package.
+ */
+package org.apache.drill.exec.client;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/exec/java-exec/src/main/java/org/apache/drill/exec/compile/bytecode/package-info.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/compile/bytecode/package-info.java b/exec/java-exec/src/main/java/org/apache/drill/exec/compile/bytecode/package-info.java
new file mode 100644
index 0000000..4ef3699
--- /dev/null
+++ b/exec/java-exec/src/main/java/org/apache/drill/exec/compile/bytecode/package-info.java
@@ -0,0 +1,28 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Bytecode manipulation utilities for stitching together runtime-generated code
+ * with prebuilt templates.
+ *
+ * Also includes a number of performance optimizations, including scalar
+ * replacement for small data-only objects to avoid object churn and
+ * indirection. The object definitions are convenient for defining user-facing
+ * APIs, such as Drill's UDF interface, but end up slowing down execution
+ * significantly.
+ */
+package org.apache.drill.exec.compile.bytecode;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/exec/java-exec/src/main/java/org/apache/drill/exec/compile/package-info.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/compile/package-info.java b/exec/java-exec/src/main/java/org/apache/drill/exec/compile/package-info.java
new file mode 100644
index 0000000..85227d9
--- /dev/null
+++ b/exec/java-exec/src/main/java/org/apache/drill/exec/compile/package-info.java
@@ -0,0 +1,32 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Runtime code-generation, compilation and bytecode-manipulation utilities.
+ *
+ * To achieve optimal performance in a dynamic schema environment, Drill
+ * includes a complete code generation system for generating type-specific Java
+ * code for most of its physical operators. This generated code is used for
+ * scalar expression evaluation as well as value transfers between record
+ * batches. As a new schema arrives at an operator, the schema change will be
+ * detected and prompt runtime code generation. This runtime-generated code will
+ * evaluate the expressions needed for the operator to process the incoming
+ * data. As the same code will often be run on a number of nodes in the cluster,
+ * compiled classes are stored in the distributed cache to avoid the need to re-
+ * compile and JIT-optimize the same code on every machine.
+ */
+package org.apache.drill.exec.compile;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/exec/java-exec/src/main/java/org/apache/drill/exec/compile/sig/package-info.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/compile/sig/package-info.java b/exec/java-exec/src/main/java/org/apache/drill/exec/compile/sig/package-info.java
new file mode 100644
index 0000000..32b5225
--- /dev/null
+++ b/exec/java-exec/src/main/java/org/apache/drill/exec/compile/sig/package-info.java
@@ -0,0 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * TODO - write docs for this package
+ */
+package org.apache.drill.exec.compile.sig;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/exec/java-exec/src/main/java/org/apache/drill/exec/coord/local/package-info.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/coord/local/package-info.java b/exec/java-exec/src/main/java/org/apache/drill/exec/coord/local/package-info.java
new file mode 100644
index 0000000..6151983
--- /dev/null
+++ b/exec/java-exec/src/main/java/org/apache/drill/exec/coord/local/package-info.java
@@ -0,0 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * A single-node "cluster coordinator" used when running Drill locally.
+ */
+package org.apache.drill.exec.coord.local;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/exec/java-exec/src/main/java/org/apache/drill/exec/coord/package-info.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/coord/package-info.java b/exec/java-exec/src/main/java/org/apache/drill/exec/coord/package-info.java
new file mode 100644
index 0000000..18b8737
--- /dev/null
+++ b/exec/java-exec/src/main/java/org/apache/drill/exec/coord/package-info.java
@@ -0,0 +1,24 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Cluster coordination system based on Apache Zookeeper and Curator.
+ *
+ * Zookeeper is a cluster coordination service used by Drill to maintain cluster
+ * membership information and some basic information about the cluster's state.
+ */
+package org.apache.drill.exec.coord;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/exec/java-exec/src/main/java/org/apache/drill/exec/coord/zk/package-info.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/coord/zk/package-info.java b/exec/java-exec/src/main/java/org/apache/drill/exec/coord/zk/package-info.java
new file mode 100644
index 0000000..9ae3cae
--- /dev/null
+++ b/exec/java-exec/src/main/java/org/apache/drill/exec/coord/zk/package-info.java
@@ -0,0 +1,25 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Zookeeper/Curator integration code.
+ *
+ * Zookeeper is a cluster coordination service used by Drill to maintain cluster
+ * membership information. Curator is a library built on top of Zookeeper that
+ * handles some of the lower level details of using Zookeeper.
+ */
+package org.apache.drill.exec.coord.zk;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/exec/java-exec/src/main/java/org/apache/drill/exec/disk/package-info.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/disk/package-info.java b/exec/java-exec/src/main/java/org/apache/drill/exec/disk/package-info.java
new file mode 100644
index 0000000..e1897df
--- /dev/null
+++ b/exec/java-exec/src/main/java/org/apache/drill/exec/disk/package-info.java
@@ -0,0 +1,26 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Interface for Drill's interaction with the local disk to persist data
+ * temporarily during an operation.
+ *
+ * This interface is used by blocking operators that support "spilling to disk".
+ * These operators can go beyond the limits of a single machine's memory when
+ * performing an operation like a sort on a large dataset.
+ */
+package org.apache.drill.exec.disk;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/exec/java-exec/src/main/java/org/apache/drill/exec/dotdrill/package-info.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/dotdrill/package-info.java b/exec/java-exec/src/main/java/org/apache/drill/exec/dotdrill/package-info.java
new file mode 100644
index 0000000..cde44df
--- /dev/null
+++ b/exec/java-exec/src/main/java/org/apache/drill/exec/dotdrill/package-info.java
@@ -0,0 +1,22 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Meta-data persistence format, used for views and other cluster-wide
+ * persistent state.
+ */
+package org.apache.drill.exec.dotdrill;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/exec/java-exec/src/main/java/org/apache/drill/exec/exception/package-info.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/exception/package-info.java b/exec/java-exec/src/main/java/org/apache/drill/exec/exception/package-info.java
new file mode 100644
index 0000000..2e1325f
--- /dev/null
+++ b/exec/java-exec/src/main/java/org/apache/drill/exec/exception/package-info.java
@@ -0,0 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Execution-time exceptions.
+ */
+package org.apache.drill.exec.exception;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/7a2ea253/exec/java-exec/src/main/java/org/apache/drill/exec/package-info.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/package-info.java b/exec/java-exec/src/main/java/org/apache/drill/exec/package-info.java
new file mode 100644
index 0000000..0572a5e
--- /dev/null
+++ b/exec/java-exec/src/main/java/org/apache/drill/exec/package-info.java
@@ -0,0 +1,27 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Drill execution engine, including: physical operators, runtime code
+ * generation, planning, RPC layer, Value Vector data structures.
+ *
+ * The Drill execution engine is a distributed query system, designed primarily
+ * for running interactive SQL queries on Big Data. For more
+ * information see the project architecture page on the wiki @See 
+ * <a href="http://drill.apache.org/architecture/"> Drill Architecture</a>
+ */
+package org.apache.drill.exec;