You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@drill.apache.org by br...@apache.org on 2016/08/30 22:37:45 UTC

[4/6] drill-site git commit: updates for Drill 1.8 release

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuration-options-introduction/index.html
----------------------------------------------------------------------
diff --git a/docs/configuration-options-introduction/index.html b/docs/configuration-options-introduction/index.html
index f6bb456..f9bef50 100644
--- a/docs/configuration-options-introduction/index.html
+++ b/docs/configuration-options-introduction/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           
@@ -1070,18 +1074,18 @@
 
     </div>
 
-     Feb 6, 2016
+     Aug 12, 2016
 
     <link href="/css/docpage.css" rel="stylesheet" type="text/css">
 
     <div class="int_text" align="left">
       
-        <p>Drill provides many configuration options that you can enable, disable, or
-modify. Modifying certain configuration options can impact Drill
-performance. Many of configuration options reside in the <code>drill-
-env.sh</code> and <code>drill-override.conf</code> files in the
-<code>/conf</code> directory. Drill sources<code>/etc/drill/conf</code> if it exists. Otherwise,
-Drill sources the local <code>&lt;drill_installation_directory&gt;/conf</code> directory.</p>
+        <p>Drill provides many configuration options that you can enable, disable, or modify. Modifying certain configuration options can impact Drill performance. Many of the configuration options reside in the <code>drill-env.sh</code> script and the <code>drill-override.conf</code> configuration file located in the <code>$DRILL_HOME/conf</code> directory. Drill loads these files from <code>/etc/drill/conf</code>, if it exists. Otherwise, Drill loads the files from the <code>$DRILL_HOME/conf</code> directory.  </p>
+
+<div class="admonition note">
+  <p class="first admonition-title">Note</p>
+  <p class="last">As of Drill 1.8, default Drill settings reside in `$DRILL_HOME/bin/drill-config.sh`. You can override many settings by creating an entry in `$DRILL_HOME/conf/drill-env.sh`. The file includes descriptions of the options that you can set.  </p>
+</div>
 
 <p>The sys.options table contains information about system and session options. The sys.boot table contains information about Drill start-up options. The section, <a href="/docs/start-up-options">&quot;Start-up Options&quot;</a>, covers how to configure and view key boot options. The following table lists the system options in alphabetical order and provides a brief description of supported options.</p>
 
@@ -1099,337 +1103,347 @@ Drill sources the local <code>&lt;drill_installation_directory&gt;/conf</code> d
 <tr>
 <td>drill.exec.functions.cast_empty_string_to_null</td>
 <td>FALSE</td>
-<td>In a text file, treat empty fields as NULL values instead of empty string.</td>
+<td>In   a text file, treat empty fields as NULL values instead of empty string.</td>
 </tr>
 <tr>
 <td>drill.exec.storage.file.partition.column.label</td>
 <td>dir</td>
-<td>The column label for directory levels in results of queries of files in a directory. Accepts a string input.</td>
+<td>The   column label for directory levels in results of queries of files in a   directory. Accepts a string input.</td>
 </tr>
 <tr>
 <td>exec.enable_union_type</td>
-<td>false</td>
-<td>Enable support for Avro union type.</td>
+<td>FALSE</td>
+<td>Enable   support for Avro union type.</td>
 </tr>
 <tr>
 <td>exec.errors.verbose</td>
 <td>FALSE</td>
-<td>Toggles verbose output of executable error messages</td>
+<td>Toggles   verbose output of executable error messages</td>
 </tr>
 <tr>
 <td>exec.java_compiler</td>
 <td>DEFAULT</td>
-<td>Switches between DEFAULT, JDK, and JANINO mode for the current session. Uses Janino by default for generated source code of less than exec.java_compiler_janino_maxsize; otherwise, switches to the JDK compiler.</td>
+<td>Switches   between DEFAULT, JDK, and JANINO mode for the current session. Uses Janino by   default for generated source code of less than   exec.java_compiler_janino_maxsize; otherwise, switches to the JDK compiler.</td>
 </tr>
 <tr>
 <td>exec.java_compiler_debug</td>
 <td>TRUE</td>
-<td>Toggles the output of debug-level compiler error messages in runtime generated code.</td>
+<td>Toggles   the output of debug-level compiler error messages in runtime generated code.</td>
 </tr>
 <tr>
 <td>exec.java_compiler_janino_maxsize</td>
 <td>262144</td>
-<td>See the exec.java_compiler option comment. Accepts inputs of type LONG.</td>
+<td>See   the exec.java_compiler option comment. Accepts inputs of type LONG.</td>
 </tr>
 <tr>
 <td>exec.max_hash_table_size</td>
 <td>1073741824</td>
-<td>Ending size in buckets for hash tables. Range: 0 - 1073741824.</td>
+<td>Ending   size in buckets for hash tables. Range: 0 - 1073741824.</td>
 </tr>
 <tr>
 <td>exec.min_hash_table_size</td>
 <td>65536</td>
-<td>Starting size in bucketsfor hash tables. Increase according to available memory to improve performance. Increasing for very large aggregations or joins when you have large amounts of memory for Drill to use. Range: 0 - 1073741824.</td>
+<td>Starting   size in bucketsfor hash tables. Increase according to available memory to   improve performance. Increasing for very large aggregations or joins when you   have large amounts of memory for Drill to use. Range: 0 - 1073741824.</td>
 </tr>
 <tr>
 <td>exec.queue.enable</td>
 <td>FALSE</td>
-<td>Changes the state of query queues. False allows unlimited concurrent queries.</td>
+<td>Changes   the state of query queues. False allows unlimited concurrent queries.</td>
 </tr>
 <tr>
 <td>exec.queue.large</td>
 <td>10</td>
-<td>Sets the number of large queries that can run concurrently in the cluster. Range: 0-1000</td>
+<td>Sets   the number of large queries that can run concurrently in the cluster. Range:   0-1000</td>
 </tr>
 <tr>
 <td>exec.queue.small</td>
 <td>100</td>
-<td>Sets the number of small queries that can run concurrently in the cluster. Range: 0-1001</td>
+<td>Sets   the number of small queries that can run concurrently in the cluster. Range:   0-1001</td>
 </tr>
 <tr>
 <td>exec.queue.threshold</td>
 <td>30000000</td>
-<td>Sets the cost threshold, which depends on the complexity of the queries in queue, for determining whether query is large or small. Complex queries have higher thresholds. Range: 0-9223372036854775807</td>
+<td>Sets   the cost threshold, which depends on the complexity of the queries in queue,   for determining whether query is large or small. Complex queries have higher   thresholds. Range: 0-9223372036854775807</td>
 </tr>
 <tr>
 <td>exec.queue.timeout_millis</td>
 <td>300000</td>
-<td>Indicates how long a query can wait in queue before the query fails. Range: 0-9223372036854775807</td>
+<td>Indicates   how long a query can wait in queue before the query fails. Range:   0-9223372036854775807</td>
 </tr>
 <tr>
 <td>exec.schedule.assignment.old</td>
 <td>FALSE</td>
-<td>Used to prevent query failure when no work units are assigned to a minor fragment, particularly when the number of files is much larger than the number of leaf fragments.</td>
+<td>Used   to prevent query failure when no work units are assigned to a minor fragment,   particularly when the number of files is much larger than the number of leaf   fragments.</td>
 </tr>
 <tr>
 <td>exec.storage.enable_new_text_reader</td>
 <td>TRUE</td>
-<td>Enables the text reader that complies with the RFC 4180 standard for text/csv files.</td>
+<td>Enables   the text reader that complies with the RFC 4180 standard for text/csv files.</td>
 </tr>
 <tr>
 <td>new_view_default_permissions</td>
 <td>700</td>
-<td>Sets view permissions using an octal code in the Unix tradition.</td>
+<td>Sets   view permissions using an octal code in the Unix tradition.</td>
 </tr>
 <tr>
 <td>planner.add_producer_consumer</td>
 <td>FALSE</td>
-<td>Increase prefetching of data from disk. Disable for in-memory reads.</td>
+<td>Increase   prefetching of data from disk. Disable for in-memory reads.</td>
 </tr>
 <tr>
 <td>planner.affinity_factor</td>
 <td>1.2</td>
-<td>Factor by which a node with endpoint affinity is favored while creating assignment. Accepts inputs of type DOUBLE.</td>
+<td>Factor   by which a node with endpoint affinity is favored while creating assignment.   Accepts inputs of type DOUBLE.</td>
 </tr>
 <tr>
 <td>planner.broadcast_factor</td>
 <td>1</td>
-<td>A heuristic parameter for influencing the broadcast of records as part of a query.</td>
+<td>A   heuristic parameter for influencing the broadcast of records as part of a   query.</td>
 </tr>
 <tr>
 <td>planner.broadcast_threshold</td>
 <td>10000000</td>
-<td>The maximum number of records allowed to be broadcast as part of a query. After one million records, Drill reshuffles data rather than doing a broadcast to one side of the join. Range: 0-2147483647</td>
+<td>The   maximum number of records allowed to be broadcast as part of a query. After   one million records, Drill reshuffles data rather than doing a broadcast to   one side of the join. Range: 0-2147483647</td>
 </tr>
 <tr>
 <td>planner.disable_exchanges</td>
 <td>FALSE</td>
-<td>Toggles the state of hashing to a random exchange.</td>
+<td>Toggles   the state of hashing to a random exchange.</td>
 </tr>
 <tr>
 <td>planner.enable_broadcast_join</td>
 <td>TRUE</td>
-<td>Changes the state of aggregation and join operators. The broadcast join can be used for hash join, merge join and nested loop join. Use to join a large (fact) table to relatively smaller (dimension) tables. Do not disable.</td>
+<td>Changes   the state of aggregation and join operators. The broadcast join can be used   for hash join, merge join and nested loop join. Use to join a large (fact)   table to relatively smaller (dimension) tables. Do not disable.</td>
 </tr>
 <tr>
 <td>planner.enable_constant_folding</td>
 <td>TRUE</td>
-<td>If one side of a filter condition is a constant expression, constant folding evaluates the expression in the planning phase and replaces the expression with the constant value. For example, Drill can rewrite WHERE age + 5 &lt; 42 as WHERE age &lt; 37.</td>
+<td>If   one side of a filter condition is a constant expression, constant folding   evaluates the expression in the planning phase and replaces the expression   with the constant value. For example, Drill can rewrite WHERE age + 5 &lt; 42   as WHERE age &lt; 37.</td>
 </tr>
 <tr>
 <td>planner.enable_decimal_data_type</td>
 <td>FALSE</td>
-<td>False disables the DECIMAL data type, including casting to DECIMAL and reading DECIMAL types from Parquet and Hive.</td>
+<td>False   disables the DECIMAL data type, including casting to DECIMAL and reading   DECIMAL types from Parquet and Hive.</td>
 </tr>
 <tr>
 <td>planner.enable_demux_exchange</td>
 <td>FALSE</td>
-<td>Toggles the state of hashing to a demulitplexed exchange.</td>
+<td>Toggles   the state of hashing to a demulitplexed exchange.</td>
 </tr>
 <tr>
 <td>planner.enable_hash_single_key</td>
 <td>TRUE</td>
-<td>Each hash key is associated with a single value.</td>
+<td>Each   hash key is associated with a single value.</td>
 </tr>
 <tr>
 <td>planner.enable_hashagg</td>
 <td>TRUE</td>
-<td>Enable hash aggregation; otherwise, Drill does a sort-based aggregation. Does not write to disk. Enable is recommended.</td>
+<td>Enable   hash aggregation; otherwise, Drill does a sort-based aggregation. Does not   write to disk. Enable is recommended.</td>
 </tr>
 <tr>
 <td>planner.enable_hashjoin</td>
 <td>TRUE</td>
-<td>Enable the memory hungry hash join. Drill assumes that a query with have adequate memory to complete and tries to use the fastest operations possible to complete the planned inner, left, right, or full outer joins using a hash table. Does not write to disk. Disabling hash join allows Drill to manage arbitrarily large data in a small memory footprint.</td>
+<td>Enable   the memory hungry hash join. Drill assumes that a query with have adequate   memory to complete and tries to use the fastest operations possible to   complete the planned inner, left, right, or full outer joins using a hash   table. Does not write to disk. Disabling hash join allows Drill to manage   arbitrarily large data in a small memory footprint.</td>
 </tr>
 <tr>
 <td>planner.enable_hashjoin_swap</td>
 <td>TRUE</td>
-<td>Enables consideration of multiple join order sequences during the planning phase. Might negatively affect the performance of some queries due to inaccuracy of estimated row count especially after a filter, join, or aggregation.</td>
+<td>Enables   consideration of multiple join order sequences during the planning phase.   Might negatively affect the performance of some queries due to inaccuracy of   estimated row count especially after a filter, join, or aggregation.</td>
 </tr>
 <tr>
 <td>planner.enable_hep_join_opt</td>
 <td></td>
-<td>Enables the heuristic planner for joins.</td>
+<td>Enables   the heuristic planner for joins.</td>
 </tr>
 <tr>
 <td>planner.enable_mergejoin</td>
 <td>TRUE</td>
-<td>Sort-based operation. A merge join is used for inner join, left and right outer joins. Inputs to the merge join must be sorted. It reads the sorted input streams from both sides and finds matching rows. Writes to disk.</td>
+<td>Sort-based   operation. A merge join is used for inner join, left and right outer joins.   Inputs to the merge join must be sorted. It reads the sorted input streams   from both sides and finds matching rows. Writes to disk.</td>
 </tr>
 <tr>
 <td>planner.enable_multiphase_agg</td>
 <td>TRUE</td>
-<td>Each minor fragment does a local aggregation in phase 1, distributes on a hash basis using GROUP-BY keys partially aggregated results to other fragments, and all the fragments perform a total aggregation using this data.</td>
+<td>Each   minor fragment does a local aggregation in phase 1, distributes on a hash   basis using GROUP-BY keys partially aggregated results to other fragments,   and all the fragments perform a total aggregation using this data.</td>
 </tr>
 <tr>
 <td>planner.enable_mux_exchange</td>
 <td>TRUE</td>
-<td>Toggles the state of hashing to a multiplexed exchange.</td>
+<td>Toggles   the state of hashing to a multiplexed exchange.</td>
 </tr>
 <tr>
 <td>planner.enable_nestedloopjoin</td>
 <td>TRUE</td>
-<td>Sort-based operation. Writes to disk.</td>
+<td>Sort-based   operation. Writes to disk.</td>
 </tr>
 <tr>
 <td>planner.enable_nljoin_for_scalar_only</td>
 <td>TRUE</td>
-<td>Supports nested loop join planning where the right input is scalar in order to enable NOT-IN, Inequality, Cartesian, and uncorrelated EXISTS planning.</td>
+<td>Supports   nested loop join planning where the right input is scalar in order to enable   NOT-IN, Inequality, Cartesian, and uncorrelated EXISTS planning.</td>
 </tr>
 <tr>
 <td>planner.enable_streamagg</td>
 <td>TRUE</td>
-<td>Sort-based operation. Writes to disk.</td>
+<td>Sort-based   operation. Writes to disk.</td>
+</tr>
+<tr>
+<td>planner.filter.max_selectivity_estimate_factor</td>
+<td>1</td>
+<td>Available as of Drill 1.8. Sets the maximum filter  selectivity estimate. The selectivity can vary between 0 and 1. For more  details, see planner.filter.min_selectivity_estimate_factor.</td>
+</tr>
+<tr>
+<td>planner.filter.min_selectivity_estimate_factor</td>
+<td>0</td>
+<td>Available as of Drill 1.8. Sets the minimum filter   selectivity estimate to increase the parallelization of the major fragment   performing a join. This option is useful for deeply nested queries with   complicated predicates and serves as a workaround when statistics are   insufficient or unavailable. The selectivity can vary between 0 and 1. The   value of this option caps the estimated SELECTIVITY. The estimated ROWCOUNT   is derived by multiplying the estimated SELECTIVITY by the estimated ROWCOUNT   of the upstream operator. The estimated ROWCOUNT displays when you use the   EXPLAIN PLAN INCLUDING ALL ATTRIBUTES FOR command. This option does not   control the estimated ROWCOUNT of downstream operators (post FILTER).   However, estimated ROWCOUNTs may change because the operator ROWCOUNTs depend   on their downstream operators. The FILTER operator relies on the input of its   immediate upstream operator, for example SCAN, AGGREGATE. If two filters are   present in a plan, e
 ach filter may have a different estimated ROWCOUNT based   on the immediate upstream operator&#39;s estimated ROWCOUNT.</td>
 </tr>
 <tr>
 <td>planner.identifier_max_length</td>
 <td>1024</td>
-<td>A minimum length is needed because option names are identifiers themselves.</td>
+<td>A   minimum length is needed because option names are identifiers themselves.</td>
 </tr>
 <tr>
 <td>planner.join.hash_join_swap_margin_factor</td>
 <td>10</td>
-<td>The number of join order sequences to consider during the planning phase.</td>
+<td>The   number of join order sequences to consider during the planning phase.</td>
 </tr>
 <tr>
 <td>planner.join.row_count_estimate_factor</td>
 <td>1</td>
-<td>The factor for adjusting the estimated row count when considering multiple join order sequences during the planning phase.</td>
+<td>The   factor for adjusting the estimated row count when considering multiple join   order sequences during the planning phase.</td>
 </tr>
 <tr>
 <td>planner.memory.average_field_width</td>
 <td>8</td>
-<td>Used in estimating memory requirements.</td>
+<td>Used   in estimating memory requirements.</td>
 </tr>
 <tr>
 <td>planner.memory.enable_memory_estimation</td>
 <td>FALSE</td>
-<td>Toggles the state of memory estimation and re-planning of the query. When enabled, Drill conservatively estimates memory requirements and typically excludes these operators from the plan and negatively impacts performance.</td>
+<td>Toggles   the state of memory estimation and re-planning of the query. When enabled,   Drill conservatively estimates memory requirements and typically excludes   these operators from the plan and negatively impacts performance.</td>
 </tr>
 <tr>
 <td>planner.memory.hash_agg_table_factor</td>
 <td>1.1</td>
-<td>A heuristic value for influencing the size of the hash aggregation table.</td>
+<td>A   heuristic value for influencing the size of the hash aggregation table.</td>
 </tr>
 <tr>
 <td>planner.memory.hash_join_table_factor</td>
 <td>1.1</td>
-<td>A heuristic value for influencing the size of the hash aggregation table.</td>
+<td>A   heuristic value for influencing the size of the hash aggregation table.</td>
 </tr>
 <tr>
 <td>planner.memory.max_query_memory_per_node</td>
-<td>2147483648 bytes</td>
-<td>Sets the maximum amount of direct memory allocated to the sort operator in each query on a node. If a query plan contains multiple sort operators, they all share this memory. If you encounter memory issues when running queries with sort operators, increase the value of this option.</td>
+<td>2147483648   bytes</td>
+<td>Sets   the maximum amount of direct memory allocated to the sort operator in each   query on a node. If a query plan contains multiple sort operators, they all   share this memory. If you encounter memory issues when running queries with   sort operators, increase the value of this option.</td>
 </tr>
 <tr>
 <td>planner.memory.non_blocking_operators_memory</td>
 <td>64</td>
-<td>Extra query memory per node for non-blocking operators. This option is currently used only for memory estimation. Range: 0-2048 MB</td>
+<td>Extra   query memory per node for non-blocking operators. This option is currently   used only for memory estimation. Range: 0-2048 MB</td>
 </tr>
 <tr>
 <td>planner.memory_limit</td>
-<td>268435456 bytes</td>
-<td>Defines the maximum amount of direct memory allocated to a query for planning. When multiple queries run concurrently, each query is allocated the amount of memory set by this parameter.Increase the value of this parameter and rerun the query if partition pruning failed due to insufficient memory.</td>
+<td>268435456   bytes</td>
+<td>Defines   the maximum amount of direct memory allocated to a query for planning. When   multiple queries run concurrently, each query is allocated the amount of   memory set by this parameter.Increase the value of this parameter and rerun   the query if partition pruning failed due to insufficient memory.</td>
 </tr>
 <tr>
 <td>planner.nestedloopjoin_factor</td>
 <td>100</td>
-<td>A heuristic value for influencing the nested loop join.</td>
+<td>A   heuristic value for influencing the nested loop join.</td>
 </tr>
 <tr>
 <td>planner.partitioner_sender_max_threads</td>
 <td>8</td>
-<td>Upper limit of threads for outbound queuing.</td>
+<td>Upper   limit of threads for outbound queuing.</td>
 </tr>
 <tr>
 <td>planner.partitioner_sender_set_threads</td>
 <td>-1</td>
-<td>Overwrites the number of threads used to send out batches of records. Set to -1 to disable. Typically not changed.</td>
+<td>Overwrites   the number of threads used to send out batches of records. Set to -1 to   disable. Typically not changed.</td>
 </tr>
 <tr>
 <td>planner.partitioner_sender_threads_factor</td>
 <td>2</td>
-<td>A heuristic param to use to influence final number of threads. The higher the value the fewer the number of threads.</td>
+<td>A   heuristic param to use to influence final number of threads. The higher the   value the fewer the number of threads.</td>
 </tr>
 <tr>
 <td>planner.producer_consumer_queue_size</td>
 <td>10</td>
-<td>How much data to prefetch from disk in record batches out-of-band of query execution. The larger the queue size, the greater the amount of memory that the queue and overall query execution consumes.</td>
+<td>How   much data to prefetch from disk in record batches out-of-band of query   execution. The larger the queue size, the greater the amount of memory that   the queue and overall query execution consumes.</td>
 </tr>
 <tr>
 <td>planner.slice_target</td>
 <td>100000</td>
-<td>The number of records manipulated within a fragment before Drill parallelizes operations.</td>
+<td>The   number of records manipulated within a fragment before Drill parallelizes   operations.</td>
 </tr>
 <tr>
 <td>planner.width.max_per_node</td>
 <td>3</td>
-<td>Maximum number of threads that can run in parallel for a query on a node. A slice is an individual thread. This number indicates the maximum number of slices per query for the query\u2019s major fragment on a node.</td>
+<td>Maximum   number of threads that can run in parallel for a query on a node. A slice is   an individual thread. This number indicates the maximum number of slices per   query for the query\u2019s major fragment on a node.</td>
 </tr>
 <tr>
 <td>planner.width.max_per_query</td>
 <td>1000</td>
-<td>Same as max per node but applies to the query as executed by the entire cluster. For example, this value might be the number of active Drillbits, or a higher number to return results faster.</td>
+<td>Same   as max per node but applies to the query as executed by the entire cluster.   For example, this value might be the number of active Drillbits, or a higher   number to return results faster.</td>
 </tr>
 <tr>
 <td>security.admin.user_groups</td>
 <td>n/a</td>
-<td>Unsupported as of 1.4. A comma-separated list of administrator groups for Web Console security.</td>
+<td>Unsupported   as of 1.4. A comma-separated list of administrator groups for Web Console   security.</td>
 </tr>
 <tr>
 <td>security.admin.users</td>
-<td><a name></td>
-<td>Unsupported as of 1.4. A comma-separated list of user names who you want to give administrator privileges.</td>
+<td></td>
+<td>Unsupported   as of 1.4. A comma-separated list of user names who you want to give   administrator privileges.</td>
 </tr>
 <tr>
 <td>store.format</td>
 <td>parquet</td>
-<td>Output format for data written to tables with the CREATE TABLE AS (CTAS) command. Allowed values are parquet, json, psv, csv, or tsv.</td>
+<td>Output   format for data written to tables with the CREATE TABLE AS (CTAS) command.   Allowed values are parquet, json, psv, csv, or tsv.</td>
 </tr>
 <tr>
 <td>store.hive.optimize_scan_with_native_readers</td>
 <td>FALSE</td>
-<td>Optimize reads of Parquet-backed external tables from Hive by using Drill native readers instead of the Hive Serde interface. (Drill 1.2 and later)</td>
+<td>Optimize   reads of Parquet-backed external tables from Hive by using Drill native   readers instead of the Hive Serde interface. (Drill 1.2 and later)</td>
 </tr>
 <tr>
 <td>store.json.all_text_mode</td>
 <td>FALSE</td>
-<td>Drill reads all data from the JSON files as VARCHAR. Prevents schema change errors.</td>
+<td>Drill   reads all data from the JSON files as VARCHAR. Prevents schema change errors.</td>
 </tr>
 <tr>
 <td>store.json.extended_types</td>
 <td>FALSE</td>
-<td>Turns on special JSON structures that Drill serializes for storing more type information than the four basic JSON types.</td>
+<td>Turns   on special JSON structures that Drill serializes for storing more type   information than the four basic JSON types.</td>
 </tr>
 <tr>
 <td>store.json.read_numbers_as_double</td>
 <td>FALSE</td>
-<td>Reads numbers with or without a decimal point as DOUBLE. Prevents schema change errors.</td>
+<td>Reads   numbers with or without a decimal point as DOUBLE. Prevents schema change   errors.</td>
 </tr>
 <tr>
 <td>store.mongo.all_text_mode</td>
 <td>FALSE</td>
-<td>Similar to store.json.all_text_mode for MongoDB.</td>
+<td>Similar   to store.json.all_text_mode for MongoDB.</td>
 </tr>
 <tr>
 <td>store.mongo.read_numbers_as_double</td>
 <td>FALSE</td>
-<td>Similar to store.json.read_numbers_as_double.</td>
+<td>Similar   to store.json.read_numbers_as_double.</td>
 </tr>
 <tr>
 <td>store.parquet.block-size</td>
 <td>536870912</td>
-<td>Sets the size of a Parquet row group to the number of bytes less than or equal to the block size of MFS, HDFS, or the file system.</td>
+<td>Sets   the size of a Parquet row group to the number of bytes less than or equal to   the block size of MFS, HDFS, or the file system.</td>
 </tr>
 <tr>
 <td>store.parquet.compression</td>
 <td>snappy</td>
-<td>Compression type for storing Parquet output. Allowed values: snappy, gzip, none</td>
+<td>Compression   type for storing Parquet output. Allowed values: snappy, gzip, none</td>
 </tr>
 <tr>
 <td>store.parquet.enable_dictionary_encoding</td>
 <td>FALSE</td>
-<td>For internal use. Do not change.</td>
+<td>For   internal use. Do not change.</td>
 </tr>
 <tr>
 <td>store.parquet.dictionary.page-size</td>
@@ -1439,22 +1453,22 @@ Drill sources the local <code>&lt;drill_installation_directory&gt;/conf</code> d
 <tr>
 <td>store.parquet.use_new_reader</td>
 <td>FALSE</td>
-<td>Not supported in this release.</td>
+<td>Not   supported in this release.</td>
 </tr>
 <tr>
 <td>store.partition.hash_distribute</td>
 <td>FALSE</td>
-<td>Uses a hash algorithm to distribute data on partition keys in a CTAS partitioning operation. An alpha option--for experimental use at this stage. Do not use in production systems.</td>
+<td>Uses   a hash algorithm to distribute data on partition keys in a CTAS partitioning   operation. An alpha option--for experimental use at this stage. Do not use in   production systems.</td>
 </tr>
 <tr>
 <td>store.text.estimated_row_size_bytes</td>
 <td>100</td>
-<td>Estimate of the row size in a delimited text file, such as csv. The closer to actual, the better the query plan. Used for all csv files in the system/session where the value is set. Impacts the decision to plan a broadcast join or not.</td>
+<td>Estimate   of the row size in a delimited text file, such as csv. The closer to actual,   the better the query plan. Used for all csv files in the system/session where   the value is set. Impacts the decision to plan a broadcast join or not.</td>
 </tr>
 <tr>
 <td>window.enable</td>
 <td>TRUE</td>
-<td>Enable or disable window functions in Drill 1.1 and later.</td>
+<td>Enable   or disable window functions in Drill 1.1 and later.</td>
 </tr>
 </tbody></table>
 

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuration-options/index.html
----------------------------------------------------------------------
diff --git a/docs/configuration-options/index.html b/docs/configuration-options/index.html
index 32f376a..29f8d94 100644
--- a/docs/configuration-options/index.html
+++ b/docs/configuration-options/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configure-drill-introduction/index.html
----------------------------------------------------------------------
diff --git a/docs/configure-drill-introduction/index.html b/docs/configure-drill-introduction/index.html
index 3c113d4..e655825 100644
--- a/docs/configure-drill-introduction/index.html
+++ b/docs/configure-drill-introduction/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configure-drill/index.html
----------------------------------------------------------------------
diff --git a/docs/configure-drill/index.html b/docs/configure-drill/index.html
index 856ff72..2049df4 100644
--- a/docs/configure-drill/index.html
+++ b/docs/configure-drill/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-a-multitenant-cluster-introduction/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-a-multitenant-cluster-introduction/index.html b/docs/configuring-a-multitenant-cluster-introduction/index.html
index 183a675..744998c 100644
--- a/docs/configuring-a-multitenant-cluster-introduction/index.html
+++ b/docs/configuring-a-multitenant-cluster-introduction/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-a-multitenant-cluster/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-a-multitenant-cluster/index.html b/docs/configuring-a-multitenant-cluster/index.html
index 18952ed..6bd4a22 100644
--- a/docs/configuring-a-multitenant-cluster/index.html
+++ b/docs/configuring-a-multitenant-cluster/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-drill-memory/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-drill-memory/index.html b/docs/configuring-drill-memory/index.html
index a1fbe8f..8b6615c 100644
--- a/docs/configuring-drill-memory/index.html
+++ b/docs/configuring-drill-memory/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-inbound-impersonation/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-inbound-impersonation/index.html b/docs/configuring-inbound-impersonation/index.html
index 31f8af4..618e9ff 100644
--- a/docs/configuring-inbound-impersonation/index.html
+++ b/docs/configuring-inbound-impersonation/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-jreport-with-drill/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-jreport-with-drill/index.html b/docs/configuring-jreport-with-drill/index.html
index f132cb1..3d5b565 100644
--- a/docs/configuring-jreport-with-drill/index.html
+++ b/docs/configuring-jreport-with-drill/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-multitenant-resources/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-multitenant-resources/index.html b/docs/configuring-multitenant-resources/index.html
index 8557d2c..185c063 100644
--- a/docs/configuring-multitenant-resources/index.html
+++ b/docs/configuring-multitenant-resources/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-odbc-on-linux/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-odbc-on-linux/index.html b/docs/configuring-odbc-on-linux/index.html
index 2846a0b..5bbcf80 100644
--- a/docs/configuring-odbc-on-linux/index.html
+++ b/docs/configuring-odbc-on-linux/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-odbc-on-mac-os-x/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-odbc-on-mac-os-x/index.html b/docs/configuring-odbc-on-mac-os-x/index.html
index 51a5356..f9979af 100644
--- a/docs/configuring-odbc-on-mac-os-x/index.html
+++ b/docs/configuring-odbc-on-mac-os-x/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-odbc-on-windows/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-odbc-on-windows/index.html b/docs/configuring-odbc-on-windows/index.html
index 308a61f..ae8cea3 100644
--- a/docs/configuring-odbc-on-windows/index.html
+++ b/docs/configuring-odbc-on-windows/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-odbc/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-odbc/index.html b/docs/configuring-odbc/index.html
index 54dd1bb..5190576 100644
--- a/docs/configuring-odbc/index.html
+++ b/docs/configuring-odbc/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-resources-for-a-shared-drillbit/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-resources-for-a-shared-drillbit/index.html b/docs/configuring-resources-for-a-shared-drillbit/index.html
index 14be8ee..bb8631f 100644
--- a/docs/configuring-resources-for-a-shared-drillbit/index.html
+++ b/docs/configuring-resources-for-a-shared-drillbit/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-the-drill-shell/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-the-drill-shell/index.html b/docs/configuring-the-drill-shell/index.html
index 40a1054..6b8b0ac 100644
--- a/docs/configuring-the-drill-shell/index.html
+++ b/docs/configuring-the-drill-shell/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-tibco-spotfire-server-with-drill/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-tibco-spotfire-server-with-drill/index.html b/docs/configuring-tibco-spotfire-server-with-drill/index.html
index 45c8054..df0e05b 100644
--- a/docs/configuring-tibco-spotfire-server-with-drill/index.html
+++ b/docs/configuring-tibco-spotfire-server-with-drill/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-user-authentication/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-user-authentication/index.html b/docs/configuring-user-authentication/index.html
index 5ba11c8..c043fdc 100644
--- a/docs/configuring-user-authentication/index.html
+++ b/docs/configuring-user-authentication/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-user-impersonation-with-hive-authorization/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-user-impersonation-with-hive-authorization/index.html b/docs/configuring-user-impersonation-with-hive-authorization/index.html
index 6cc1833..2c393c4 100644
--- a/docs/configuring-user-impersonation-with-hive-authorization/index.html
+++ b/docs/configuring-user-impersonation-with-hive-authorization/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-user-impersonation/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-user-impersonation/index.html b/docs/configuring-user-impersonation/index.html
index 6cf50a8..1d44d02 100644
--- a/docs/configuring-user-impersonation/index.html
+++ b/docs/configuring-user-impersonation/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/configuring-web-console-and-rest-api-security/index.html
----------------------------------------------------------------------
diff --git a/docs/configuring-web-console-and-rest-api-security/index.html b/docs/configuring-web-console-and-rest-api-security/index.html
index 897f60d..c551eb4 100644
--- a/docs/configuring-web-console-and-rest-api-security/index.html
+++ b/docs/configuring-web-console-and-rest-api-security/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/connect-a-data-source-introduction/index.html
----------------------------------------------------------------------
diff --git a/docs/connect-a-data-source-introduction/index.html b/docs/connect-a-data-source-introduction/index.html
index 803b2f4..1f6ea09 100644
--- a/docs/connect-a-data-source-introduction/index.html
+++ b/docs/connect-a-data-source-introduction/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/connect-a-data-source/index.html
----------------------------------------------------------------------
diff --git a/docs/connect-a-data-source/index.html b/docs/connect-a-data-source/index.html
index 5f5231c..1d68301 100644
--- a/docs/connect-a-data-source/index.html
+++ b/docs/connect-a-data-source/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/connecting-drill-explorer-to-data/index.html
----------------------------------------------------------------------
diff --git a/docs/connecting-drill-explorer-to-data/index.html b/docs/connecting-drill-explorer-to-data/index.html
index 69c784b..644a38c 100644
--- a/docs/connecting-drill-explorer-to-data/index.html
+++ b/docs/connecting-drill-explorer-to-data/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/contribute-to-drill/index.html
----------------------------------------------------------------------
diff --git a/docs/contribute-to-drill/index.html b/docs/contribute-to-drill/index.html
index abe9bcb..2a9b370 100644
--- a/docs/contribute-to-drill/index.html
+++ b/docs/contribute-to-drill/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/controlling-parallelization-to-balance-performance-with-multi-tenancy/index.html
----------------------------------------------------------------------
diff --git a/docs/controlling-parallelization-to-balance-performance-with-multi-tenancy/index.html b/docs/controlling-parallelization-to-balance-performance-with-multi-tenancy/index.html
index dd19ba2..2595b37 100644
--- a/docs/controlling-parallelization-to-balance-performance-with-multi-tenancy/index.html
+++ b/docs/controlling-parallelization-to-balance-performance-with-multi-tenancy/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/core-modules/index.html
----------------------------------------------------------------------
diff --git a/docs/core-modules/index.html b/docs/core-modules/index.html
index 0f65d75..b4ef315 100644
--- a/docs/core-modules/index.html
+++ b/docs/core-modules/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/create-table-as-ctas/index.html
----------------------------------------------------------------------
diff --git a/docs/create-table-as-ctas/index.html b/docs/create-table-as-ctas/index.html
index b4fd97d..57badf9 100644
--- a/docs/create-table-as-ctas/index.html
+++ b/docs/create-table-as-ctas/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/create-view/index.html
----------------------------------------------------------------------
diff --git a/docs/create-view/index.html b/docs/create-view/index.html
index 616de43..f590b6e 100644
--- a/docs/create-view/index.html
+++ b/docs/create-view/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/custom-function-interfaces/index.html
----------------------------------------------------------------------
diff --git a/docs/custom-function-interfaces/index.html b/docs/custom-function-interfaces/index.html
index 8f1298c..0259f02 100644
--- a/docs/custom-function-interfaces/index.html
+++ b/docs/custom-function-interfaces/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/data-sources-and-file-formats-introduction/index.html
----------------------------------------------------------------------
diff --git a/docs/data-sources-and-file-formats-introduction/index.html b/docs/data-sources-and-file-formats-introduction/index.html
index 02645e6..bbc6a33 100644
--- a/docs/data-sources-and-file-formats-introduction/index.html
+++ b/docs/data-sources-and-file-formats-introduction/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/data-sources-and-file-formats/index.html
----------------------------------------------------------------------
diff --git a/docs/data-sources-and-file-formats/index.html b/docs/data-sources-and-file-formats/index.html
index ecbbfae..939a17d 100644
--- a/docs/data-sources-and-file-formats/index.html
+++ b/docs/data-sources-and-file-formats/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/data-type-conversion/index.html
----------------------------------------------------------------------
diff --git a/docs/data-type-conversion/index.html b/docs/data-type-conversion/index.html
index 8526c8d..94a4304 100644
--- a/docs/data-type-conversion/index.html
+++ b/docs/data-type-conversion/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/data-types/index.html
----------------------------------------------------------------------
diff --git a/docs/data-types/index.html b/docs/data-types/index.html
index ebbf599..c2fb40d 100644
--- a/docs/data-types/index.html
+++ b/docs/data-types/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/date-time-and-timestamp/index.html
----------------------------------------------------------------------
diff --git a/docs/date-time-and-timestamp/index.html b/docs/date-time-and-timestamp/index.html
index a6d09a1..4848c6d 100644
--- a/docs/date-time-and-timestamp/index.html
+++ b/docs/date-time-and-timestamp/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/date-time-functions-and-arithmetic/index.html
----------------------------------------------------------------------
diff --git a/docs/date-time-functions-and-arithmetic/index.html b/docs/date-time-functions-and-arithmetic/index.html
index ba9d222..597bf1d 100644
--- a/docs/date-time-functions-and-arithmetic/index.html
+++ b/docs/date-time-functions-and-arithmetic/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/deploying-and-using-a-hive-udf/index.html
----------------------------------------------------------------------
diff --git a/docs/deploying-and-using-a-hive-udf/index.html b/docs/deploying-and-using-a-hive-udf/index.html
index 2f6d16c..9aa02b0 100644
--- a/docs/deploying-and-using-a-hive-udf/index.html
+++ b/docs/deploying-and-using-a-hive-udf/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/describe/index.html
----------------------------------------------------------------------
diff --git a/docs/describe/index.html b/docs/describe/index.html
index fe65a52..b09cb27 100644
--- a/docs/describe/index.html
+++ b/docs/describe/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           
@@ -1070,33 +1074,58 @@
 
     </div>
 
-     
+     Aug 4, 2016
 
     <link href="/css/docpage.css" rel="stylesheet" type="text/css">
 
     <div class="int_text" align="left">
       
-        <p>The DESCRIBE command returns information about columns in a table or view.</p>
+        <p>The DESCRIBE command returns information about columns in a table, view, or schema.</p>
 
 <h2 id="syntax">Syntax</h2>
 
 <p>The DESCRIBE command supports the following syntax:</p>
 <div class="highlight"><pre><code class="language-text" data-lang="text">DESCRIBE [workspace.]table_name|view_name
+DESCRIBE SCHEMA|DATABASE &lt;name&gt;[.workspace]
 </code></pre></div>
+<h2 id="parameters">Parameters</h2>
+
+<p><em>workspace</em><br>
+The location, within a schema, where a table or view exists.  </p>
+
+<p><em>view_name</em><br>
+The unique name of a view.  </p>
+
+<p><em>table_name</em><br>
+The unique name of a table.  </p>
+
+<p><em>schema/database</em><br>
+A configured storage plugin instance with or without a configured workspace. </p>
+
 <h2 id="usage-notes">Usage Notes</h2>
 
-<p>You can issue the DESCRIBE command against views created in a workspace and
-tables created in Hive and HBase. You can issue the DESCRIBE command
-on a table or view from any schema. For example, if you are working in the
-<code>dfs.myworkspace</code> schema, you can issue the DESCRIBE command on a view or
-table in another schema. Currently, DESCRIBE does not support tables created
-in a file system.</p>
+<p>Drill only supports SQL data types. Verify that all data types in an external data source, such as Hive or HBase, map to supported data types in Drill. See <a href="/docs/data-types/">Data Types</a> for more information.  </p>
 
-<p>Drill only supports SQL data types. Verify that all data types in an external
-data source, such as Hive or HBase, map to supported data types in Drill. See
-Drill Data Type Mapping for more information.</p>
+<h3 id="describe">DESCRIBE</h3>
 
-<h2 id="example">Example</h2>
+<ul>
+<li>You can issue the DESCRIBE command against views created in a workspace, tables created in Hive and HBase, or schemas.<br></li>
+<li>You can issue the DESCRIBE command on a table or view from any schema. For example, if you are working in the dfs.myworkspace schema, you can issue the DESCRIBE command on a view or table in another schema, such hive or dfs.devworkspace.<br></li>
+<li>Currently, DESCRIBE does not support tables created in a file system.</li>
+</ul>
+
+<h3 id="describe-schema">DESCRIBE SCHEMA</h3>
+
+<ul>
+<li>You can issue the DESCRIBE SCHEMA command on any schema. However, you can only include workspaces for file schemas, such as <code>dfs.myworkspace</code>.<br></li>
+<li>When you issue the DESCRIBE SCHEMA command on a particular schema, Drill returns all of the schema properties. The schema properties correlate with the configuration information in the Storage tab of the Drill Web Console for that schema.<br></li>
+<li>When you issue DESCRIBE SCHEMA against a schema and workspace, such as <code>dfs.myworkspace</code>, Drill returns the workspace properties in addition to all of the schema properties.<br></li>
+<li>When you issue DESCRIBE SCHEMA against the <code>dfs</code> schema, Drill also returns the properties of the \u201cdefault\u201d workspace. Issuing DESCRIBE SCHEMA against <code>dfs</code> or <code>dfs.`default`</code> returns the same results. </li>
+</ul>
+
+<h2 id="examples">Examples</h2>
+
+<h3 id="describe">DESCRIBE</h3>
 
 <p>The following example demonstrates the steps that you can follow when you want
 to use the DESCRIBE command to see column information for a view and for Hive
@@ -1164,8 +1193,36 @@ and HBase tables.</p>
 | agg_rev   | VARCHAR   | NO        |
 | membership  | VARCHAR | NO        |
 +-------------+------------+-------------+
-7 rows selected (0.403 seconds)
+7 rows selected (0.403 seconds)  
+</code></pre></div>
+<ol>
+<li><p>Issue the DESCRIBE SCHEMA command on <code>dfs.tmp</code> (the <code>dfs</code> schema and <code>tmp</code> workspace configured within the <code>dfs</code> schema) from the current schema.  </p>
+
+<p>0: jdbc:drill:zk=drilldemo:5181&gt; describe schema dfs.tmp;  </p>
+<div class="highlight"><pre><code class="language-text" data-lang="text">  {
+    &quot;type&quot; : &quot;file&quot;,
+    &quot;enabled&quot; : true,
+    &quot;connection&quot; : &quot;file:///&quot;,
+    &quot;config&quot; : null,
+    &quot;formats&quot; : {
+      &quot;psv&quot; : {
+        &quot;type&quot; : &quot;text&quot;,
+        &quot;extensions&quot; : [ &quot;tbl&quot; ],
+        &quot;delimiter&quot; : &quot;|&quot;
+      },
+      &quot;csv&quot; : {
+        &quot;type&quot; : &quot;text&quot;,
+        &quot;extensions&quot; : [ &quot;csv&quot;, &quot;bcp&quot; ],
+        &quot;delimiter&quot; : &quot;,&quot;
+      },
+     ... 
+    },
+    &quot;location&quot; : &quot;/tmp&quot;,
+    &quot;writable&quot; : true,
+    &quot;defaultInputFormat&quot; : null
+  }  
 </code></pre></div></li>
+</ol></li>
 </ol>
 
     

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/design-docs/index.html
----------------------------------------------------------------------
diff --git a/docs/design-docs/index.html b/docs/design-docs/index.html
index d839de1..57cf3c1 100644
--- a/docs/design-docs/index.html
+++ b/docs/design-docs/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/develop-custom-functions-introduction/index.html
----------------------------------------------------------------------
diff --git a/docs/develop-custom-functions-introduction/index.html b/docs/develop-custom-functions-introduction/index.html
index 9176384..63206cf 100644
--- a/docs/develop-custom-functions-introduction/index.html
+++ b/docs/develop-custom-functions-introduction/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/develop-custom-functions/index.html
----------------------------------------------------------------------
diff --git a/docs/develop-custom-functions/index.html b/docs/develop-custom-functions/index.html
index 3baa4d4..78f00d3 100644
--- a/docs/develop-custom-functions/index.html
+++ b/docs/develop-custom-functions/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/develop-drill/index.html
----------------------------------------------------------------------
diff --git a/docs/develop-drill/index.html b/docs/develop-drill/index.html
index 2bd9061..d8ba583 100644
--- a/docs/develop-drill/index.html
+++ b/docs/develop-drill/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/developer-information/index.html
----------------------------------------------------------------------
diff --git a/docs/developer-information/index.html b/docs/developer-information/index.html
index abfd92d..6802150 100644
--- a/docs/developer-information/index.html
+++ b/docs/developer-information/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/developing-a-simple-function/index.html
----------------------------------------------------------------------
diff --git a/docs/developing-a-simple-function/index.html b/docs/developing-a-simple-function/index.html
index 2175c4d..29b30b4 100644
--- a/docs/developing-a-simple-function/index.html
+++ b/docs/developing-a-simple-function/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/developing-an-aggregate-function/index.html
----------------------------------------------------------------------
diff --git a/docs/developing-an-aggregate-function/index.html b/docs/developing-an-aggregate-function/index.html
index eb1b869..aeca8f5 100644
--- a/docs/developing-an-aggregate-function/index.html
+++ b/docs/developing-an-aggregate-function/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/distributed-mode-prerequisites/index.html
----------------------------------------------------------------------
diff --git a/docs/distributed-mode-prerequisites/index.html b/docs/distributed-mode-prerequisites/index.html
index 72a520b..64c8931 100644
--- a/docs/distributed-mode-prerequisites/index.html
+++ b/docs/distributed-mode-prerequisites/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/drill-default-input-format/index.html
----------------------------------------------------------------------
diff --git a/docs/drill-default-input-format/index.html b/docs/drill-default-input-format/index.html
index 83d31be..10ec17e 100644
--- a/docs/drill-default-input-format/index.html
+++ b/docs/drill-default-input-format/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/drill-explorer-introduction/index.html
----------------------------------------------------------------------
diff --git a/docs/drill-explorer-introduction/index.html b/docs/drill-explorer-introduction/index.html
index ca4cdf9..4c5efe5 100644
--- a/docs/drill-explorer-introduction/index.html
+++ b/docs/drill-explorer-introduction/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/drill-in-10-minutes/index.html
----------------------------------------------------------------------
diff --git a/docs/drill-in-10-minutes/index.html b/docs/drill-in-10-minutes/index.html
index 6055b1d..e5295dc 100644
--- a/docs/drill-in-10-minutes/index.html
+++ b/docs/drill-in-10-minutes/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           
@@ -1068,7 +1072,7 @@
 
     </div>
 
-     Jun 29, 2016
+     Aug 30, 2016
 
     <link href="/css/docpage.css" rel="stylesheet" type="text/css">
 
@@ -1120,11 +1124,11 @@ Java HotSpot(TM) 64-Bit Server VM (build 24.79-b02, mixed mode)
 
 <ol>
 <li>In a terminal window, change to the directory where you want to install Drill.<br></li>
-<li>Download the latest version of Apache Drill <a href="http://www.apache.org/dyn/closer.lua?filename=drill/drill-1.7.0/apache-drill-1.7.0.tar.gz&amp;action=download">here</a> or from the <a href="http://www.apache.org/dyn/closer.cgi/drill/drill-1.7.0/apache-drill-1.7.0.tar.gz">Apache Drill mirror site</a> with the command appropriate for your system:<br>
+<li>Download the latest version of Apache Drill <a href="http://apache.mirrors.hoobly.com/drill/drill-1.8.0/apache-drill-1.8.0.tar.gz">here</a> or from the <a href="http://www.apache.org/dyn/closer.cgi/drill/drill-1.8.0/apache-drill-1.8.0.tar.gz">Apache Drill mirror site</a> with the command appropriate for your system:<br>
 
 <ul>
-<li><code>wget http://apache.mesi.com.ar/drill/drill-1.7.0/apache-drill-1.7.0.tar.gz</code><br></li>
-<li><code>curl -o apache-drill-1.7.0.tar.gz http://apache.mesi.com.ar/drill/drill-1.7.0/apache-drill-1.7.0.tar.gz</code><br></li>
+<li><code>wget http://apache.mirrors.hoobly.com/drill/drill-1.8.0/apache-drill-1.8.0.tar.gz</code><br></li>
+<li><code>curl -o apache-drill-1.8.0.tar.gz http://apache.mirrors.hoobly.com/drill/drill-1.8.0/apache-drill-1.8.0.tar.gz</code><br></li>
 </ul></li>
 <li>Copy the downloaded file to the directory where you want to install Drill.<br></li>
 <li>Extract the contents of the Drill .tar.gz file. Use <code>sudo</code> if necessary:<br>
@@ -1157,7 +1161,7 @@ Java HotSpot(TM) 64-Bit Server VM (build 24.79-b02, mixed mode)
 <p>You can install Drill on Windows. First, set the JAVA_HOME environment variable, and then install Drill. Complete the following steps to install Drill:</p>
 
 <ol>
-<li>Download the latest version of Apache Drill <a href="http://www.apache.org/dyn/closer.lua?filename=drill/drill-1.6.0/apache-drill-1.6.0.tar.gz&amp;action=download">here</a> or go to the <a href="http://www.apache.org/dyn/closer.cgi/drill/drill-1.6.0/apache-drill-1.6.0.tar.gz">Apache Drill mirror site</a>.<br></li>
+<li>Download the latest version of Apache Drill <a href="http://apache.mirrors.hoobly.com/drill/drill-1.8.0/apache-drill-1.8.0.tar.gz">here</a> or from the <a href="http://www.apache.org/dyn/closer.cgi/drill/drill-1.8.0/apache-drill-1.8.0.tar.gz">Apache Drill mirror site</a>.<br></li>
 <li>Move the <code>apache-drill-&lt;version&gt;.tar.gz</code> file to a directory where you want to install Drill.<br></li>
 <li>Unzip the <code>TAR.GZ</code> file using a third-party tool. If the tool you use does not unzip the TAR file as well as the <code>TAR.GZ</code> file, unzip the <code>apache-drill-&lt;version&gt;.tar</code> to extract the Drill software. The extraction process creates the installation directory named apache-drill-<version> containing the Drill software. </li>
 </ol>

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/drill-introduction/index.html
----------------------------------------------------------------------
diff --git a/docs/drill-introduction/index.html b/docs/drill-introduction/index.html
index b658a80..e51e2be 100644
--- a/docs/drill-introduction/index.html
+++ b/docs/drill-introduction/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/drill-plan-syntax/index.html
----------------------------------------------------------------------
diff --git a/docs/drill-plan-syntax/index.html b/docs/drill-plan-syntax/index.html
index 770ab13..b7e3437 100644
--- a/docs/drill-plan-syntax/index.html
+++ b/docs/drill-plan-syntax/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/drill-query-execution/index.html
----------------------------------------------------------------------
diff --git a/docs/drill-query-execution/index.html b/docs/drill-query-execution/index.html
index 0095454..99392a5 100644
--- a/docs/drill-query-execution/index.html
+++ b/docs/drill-query-execution/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           

http://git-wip-us.apache.org/repos/asf/drill-site/blob/67bee382/docs/drop-table/index.html
----------------------------------------------------------------------
diff --git a/docs/drop-table/index.html b/docs/drop-table/index.html
index 454275e..ed13fea 100644
--- a/docs/drop-table/index.html
+++ b/docs/drop-table/index.html
@@ -951,6 +951,10 @@
           <ul style="display: none">
           
             
+              <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-8-0-release-notes/">Apache Drill 1.8.0 Release Notes</a></li>
+            
+          
+            
               <li class="toctree-l2"><a class="reference internal" href="/docs/apache-drill-1-7-0-release-notes/">Apache Drill 1.7.0 Release Notes</a></li>
             
           
@@ -1070,20 +1074,29 @@
 
     </div>
 
-     
+     Aug 4, 2016
 
     <link href="/css/docpage.css" rel="stylesheet" type="text/css">
 
     <div class="int_text" align="left">
       
-        <p>As of Drill 1.2, you can use the DROP TABLE command to remove tables (files or directories) from a file system when the file system is configured as a DFS storage plugin. See <a href="/docs/storage-plugin-registration/">Storage Plugin Registration</a>. Currently, you can only issue the DROP TABLE command against file system data sources.</p>
+        <p>As of Drill 1.2, you can use the DROP TABLE command to remove tables (files or directories) from a file system when the file system is configured as a DFS storage plugin. See <a href="/docs/storage-plugin-registration/">Storage Plugin Registration</a>. As of Drill 1.8, you can include the IF EXISTS parameter with the DROP TABLE command. Currently, you can only issue the DROP TABLE command against file system data sources.</p>
 
 <h2 id="syntax">Syntax</h2>
 
 <p>The DROP TABLE command supports the following syntax: </p>
-<div class="highlight"><pre><code class="language-text" data-lang="text">   DROP TABLE [workspace.]name;
+<div class="highlight"><pre><code class="language-text" data-lang="text">DROP TABLE [IF EXISTS] [workspace.]name;  
 </code></pre></div>
-<p><em>name</em> is a unique directory or file name, optionally prefaced by a storage plugin name, such as dfs, and a workspace, such as tmp using dot notation.</p>
+<h2 id="parameters">Parameters</h2>
+
+<p>IF EXISTS<br>
+Drill does not throw an error if the table does not exist. Instead, Drill returns &quot;<code>Table [name] not found.</code>&quot;  </p>
+
+<p><em>workspace</em><br>
+The location of the table in subdirectories of a local or distributed file system.</p>
+
+<p><em>name</em><br>
+A unique directory or file name, optionally prefaced by a storage plugin name, such as <code>dfs</code>, and a workspace, such as <code>tmp</code> using dot notation.  </p>
 
 <h2 id="usage-notes">Usage Notes</h2>
 
@@ -1281,7 +1294,7 @@
 <h3 id="example-4:-dropping-a-table-that-does-not-exist">Example 4: Dropping a table that does not exist</h3>
 
 <p>The following example shows the result of dropping a table that does not exist because it was either already dropped or never existed. </p>
-<div class="highlight"><pre><code class="language-text" data-lang="text">   0: jdbc:drill:zk=local&gt; use use dfs.tmp;
+<div class="highlight"><pre><code class="language-text" data-lang="text">   0: jdbc:drill:zk=local&gt; use dfs.tmp;
    +-------+--------------------------------------+
    |  ok   |               summary                |
    +-------+--------------------------------------+
@@ -1292,9 +1305,46 @@
    0: jdbc:drill:zk=local&gt; drop table name_key;
 
    Error: VALIDATION ERROR: Table [name_key] not found
-   [Error Id: fc6bfe17-d009-421c-8063-d759d7ea2f4e on 10.250.56.218:31010] (state=,code=0)
+   [Error Id: fc6bfe17-d009-421c-8063-d759d7ea2f4e on 10.250.56.218:31010] (state=,code=0)  
+</code></pre></div>
+<h3 id="example-5:-dropping-a-table-that-does-not-exist-using-the-if-exists-parameter">Example 5: Dropping a table that does not exist using the IF EXISTS parameter</h3>
+
+<p>The following example shows the result of dropping a table that does not exist (because it was already dropped or never existed) using the IF EXISTS parameter with the DROP TABLE command:  </p>
+<div class="highlight"><pre><code class="language-text" data-lang="text">   0: jdbc:drill:zk=local&gt; use dfs.tmp;
+   +-------+--------------------------------------+
+   |  ok   |               summary                |
+   +-------+--------------------------------------+
+   | true  | Default schema changed to &#39;dfs.tmp&#39;  |
+   +-------+--------------------------------------+
+   1 row selected (0.289 seconds)  
+
+   0: jdbc:drill:zk=local&gt; drop table if exists name_key;
+   +-------+-----------------------------+
+   |  ok   |         summary             |
+   +-------+-----------------------------+
+   | true  | Table &#39;name_key&#39; not found  |
+   +-------+-----------------------------+
+   1 row selected (0.083 seconds)  
+</code></pre></div>
+<h3 id="example-6:-dropping-a-table-that-exists-using-the-if-exists-parameter">Example 6: Dropping a table that exists using the IF EXISTS parameter</h3>
+
+<p>The following example shows the result of dropping a table that exists using the IF EXISTS parameter with the DROP TABLE command.  </p>
+<div class="highlight"><pre><code class="language-text" data-lang="text">   0: jdbc:drill:zk=local&gt; use dfs.tmp;
+   +-------+--------------------------------------+
+   |  ok   |               summary                |
+   +-------+--------------------------------------+
+   | true  | Default schema changed to &#39;dfs.tmp&#39;  |
+   +-------+--------------------------------------+
+   1 row selected (0.289 seconds)
+
+   0: jdbc:drill:zk=local&gt; drop table if exists name_key;
+   +-------+---------------------------+
+   |  ok   |        summary            |
+   +-------+---------------------------+
+   | true  | Table &#39;name_key&#39; dropped  |
+   +-------+---------------------------+  
 </code></pre></div>
-<h3 id="example-5:-dropping-a-table-without-permissions">Example 5: Dropping a table without permissions</h3>
+<h3 id="example-7:-dropping-a-table-without-permissions">Example 7: Dropping a table without permissions</h3>
 
 <p>The following example shows the result of dropping a table without the appropriate permissions in the file system.</p>
 <div class="highlight"><pre><code class="language-text" data-lang="text">   0: jdbc:drill:zk=local&gt; drop table name_key;
@@ -1302,7 +1352,7 @@
    Error: PERMISSION ERROR: Unauthorized to drop table
    [Error Id: 36f6b51a-786d-4950-a4a7-44250f153c55 on 10.10.30.167:31010] (state=,code=0)  
 </code></pre></div>
-<h3 id="example-6:-dropping-and-querying-a-table-concurrently">Example 6: Dropping and querying a table concurrently</h3>
+<h3 id="example-8:-dropping-and-querying-a-table-concurrently">Example 8: Dropping and querying a table concurrently</h3>
 
 <p>The result of this scenario depends on the delta in time between one user dropping a table and another user issuing a query against the table. Results can also vary. In some instances the drop may succeed and the query fails completely or the query completes partially and then the table is dropped returning an exception in the middle of the query results.</p>
 
@@ -1324,7 +1374,7 @@
    Fragment 1:0
    [Error Id: 6e3c6a8d-8cfd-4033-90c4-61230af80573 on 10.10.30.167:31010] (state=,code=0)
 </code></pre></div>
-<h3 id="example-7:-dropping-a-table-with-different-file-formats">Example 7: Dropping a table with different file formats</h3>
+<h3 id="example-9:-dropping-a-table-with-different-file-formats">Example 9: Dropping a table with different file formats</h3>
 
 <p>The following example shows the result of dropping a table when multiple file formats exists in the directory. In this scenario, the <code>sales_dir</code> table resides in the <code>dfs.sales</code> workspace and contains Parquet, CSV, and JSON files.</p>