You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafodion.apache.org by db...@apache.org on 2016/02/02 18:04:12 UTC

[4/7] incubator-trafodion git commit: [TRaFODION-1699] Updated web site to rely on Contributor Guide on the wiki. Changed download to point to real binaries hosted on the build-result site. Ran spell checks on all the guides and fixed formatting errors a

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/3063990d/docs/odb_user/src/asciidoc/_chapters/load.adoc
----------------------------------------------------------------------
diff --git a/docs/odb_user/src/asciidoc/_chapters/load.adoc b/docs/odb_user/src/asciidoc/_chapters/load.adoc
index 8e9d13c..3d6a1ee 100644
--- a/docs/odb_user/src/asciidoc/_chapters/load.adoc
+++ b/docs/odb_user/src/asciidoc/_chapters/load.adoc
@@ -39,7 +39,7 @@ This command:
 * Loads the file named `customer.tbl` (`src=customer.tbl`)
 * in the table `TRAFODION.MAURIZIO.CUSTOMER` (`tgt=TRAFODION.MAURIZIO.CUSTOMER`)
 * using `|` (vertical bar) as a field separator (`fs=\|`)
-* using `1000 rows` as rowset buffer (`rows=1000`)
+* using `1000 rows` as row-set buffer (`rows=1000`)
 * using `UPSERT USING LOAD` syntax to achieve better throughput as described in http://trafodion.incubator.apache.org/load.html[Trafodion Data Loading]
 * truncating the target table before loading (`truncate`)
 * using `4 parallel threads` to load the target table (`parallel=4`)
@@ -100,7 +100,7 @@ Default is `\` (back slash).
 You can define the size of this buffer in two different ways: +
  +
 1. number of rows (for example: `rows=100` means 100 rows as IO buffer) +
-2.* buffer size in kB or MB (for example: `rows=k512` (512 kB buffer) or `rows=m20` (20MB buffer)) +
+2.* buffer size in KB or MB (for example: `rows=k512` (512 KB buffer) or `rows=m20` (20MB buffer)) +
  +
 Default value is `100`.
 | `bad=[+]file` | Where to write rejected rows. If you omit this parameter, then rejected rows is printed to standard error together with the error returned by
@@ -116,13 +116,13 @@ If you add a `+` sign in front of the file-name, odb  *appends* to `<file>`inste
  +
 - one thread to read from the input file and +
 - as many threads as the parallel argument to write via ODBC. This option is database independent.
-| `errmax=num` | odb orints up to num error messages per rowset. Normally used with soe to limit the number of error messages printed to the standard error
+| `errmax=num` | odb prints up to num error messages per rowset. Normally used with soe to limit the number of error messages printed to the standard error
 | `commit=auto\|end\|#rows\|x#rs` | Defines how odb commits the inserts. You have the following choices: +
  +
 - `auto` (default): Commit every single insert (see also rows load operator). +
 - `end`: Commit when all rows (assigned to a given thread) have been inserted. +
 - `#rows`: Commit every `#rows` inserted rows. +
-- `x#rs`: Commit every `#rs` rowsets (see `rows`)
+- `x#rs`: Commit every `#rs` rowset (see `rows`)
 | `direct` | Adds `/*+ DIRECT */` hint to the insert statement. To be used with Vertica databases in order to store inserted rows *directly* into
 the Read-Only Storage (ROS). See Vertica’s documentation.
 | `fieldtrunc=\{0-4}` | Defines how odb manages fields longer than the destination target column: +
@@ -133,7 +133,7 @@ the Read-Only Storage (ROS). See Vertica’s documentation.
 - `fieldtrunc=3`: Like `fieldtrunc=0` but tries to load the field even if the target column is NOT a text field. +
 - `fieldtrunc=4`: Like fieldtrunc=3 but no warnings are printed. +
  +
-WARNING: the last two options could bring to unwanted resilts. For example, an input string like `2001-10-2345` is loaded as a valid
+WARNING: the last two options could bring to unwanted results. For example, an input string like `2001-10-2345` is loaded as a valid
 2001-10-23 if the target field is a `DATE`.
 | `em=<char>\|<code>` | Character used to embed binary files. See <<load_default_values, Load Default Values>>. You can define
 the embed character the same way as the field separator. No default value.
@@ -152,7 +152,7 @@ _fits_ into the target tables, Normally used to analyze the first few rows of CS
 - `ifempty` to `false`. +
 - `truncate` to `false`.
 | `maxlen=#bytes` | odb limits the amount of memory allocated in the ODBC buffers for CHAR/VARCHAR fields to `#bytes`.
-| `time` | odb prints a *timeline* (milliseconds from start) for each insert.
+| `time` | odb prints a *time line* (milliseconds from start) for each insert.
 | `bpc=#` | Bytes allocated in the ODBC buffer for each (non wide) CHAR/VARCHAR column length unit. (Default: 1)
 | `bwpc=#` | Bytes allocated in the ODBC buffer for each (wide) CHAR/VARCHAR column length unit. (Default: 4)
 | `Xmltag=[+]tag` | Input file is XML. Load all _XML nodes_ under the one specified with this option. If a plus sign is
@@ -231,7 +231,7 @@ odb provides mapping/transformation capabilities though *mapfiles*. By specifyin
 * Skip input file fields
 * Generate sequences
 * Insert constants
-* Transform dates/timestamp formats
+* Transform dates/timestamps formats
 * Extract substrings
 * Replace input file strings. For example: insert `Maurizio Felici` when you read `MF`
 * Generate random values
@@ -307,7 +307,7 @@ like `SUBSTR:3:6`m then `Tib` is loaded into the database.
 Example: `DCONV:B.d.y` converts `August,24 1991` to `1991-08-24`
 * `TCONV:<FORMAT>`. Converts times from the input file format defined through `<FORMAT>` to `HH:MM:SS` (see `TSCONV` operator).
 * `REPLACE:<READ>:<WRITTEN>`. Loads the string `<WRITTEN>` when the input file fields contains `<READ>`.
-If the input file string doesn’t match `<READ>`, then it is loaded as is.
+If the input file string doesn't match `<READ>`, then it is loaded as is.
 +
 See <<load_mapfiles_ignore, Use mapfiles to Ignore and/or Transform Fields When Loading>>
 * `TOUPPER`. Converts the string read from the input file to uppercase before loading.
@@ -394,7 +394,7 @@ uno,00,48,due,_Antonella_,tre,[underline]#24 Apr 1962#
 * [underline]#Underline text# represents birth date.
 
 You want to load the marked fields into the appropriate column, *_generate_* a unique key for ID and ignore the fields in black text.
-In addition: you need to *_convert date format_* and replace all occurrances of `Lucia` with `Lucy`.
+In addition: you need to *_convert date format_* and replace all occurrences of `Lucia` with `Lucy`.
 
 The following map file accomplishes these goals:
 
@@ -597,7 +597,7 @@ Then:
 
 [[load_binary_files]]
 == Loading Binary Files
-Assuming that your backend database (and your ODBC Driver) supports BLOB data types, or equivalent,
+Assuming that your back-end database (and your ODBC Driver) supports BLOB data types, or equivalent,
 you can use odb to directly load binary (or any other) files into a database column using the `[:em=char]` symbol
 to identify the file to be loaded into that specific database field.
 
@@ -630,7 +630,7 @@ by running a command like this:
 $ odb64luo –u user –p xx –d dsn -l src=myphotos.csv:tgt=pers.myphotos:em=\@
 ```
 
-odb onsiders the string following the “em” character as the path of the file to be loaded in that specific field.
+odb considers the string following the “em” character as the path of the file to be loaded in that specific field.
 
 NOTE: odb does not load rows where the size of the input file is greater than the target database column.
 
@@ -865,7 +865,7 @@ is made of 32 partitions, then odb starts *four* threads (four ODBC connections)
 - thread 1 extracts partitions 8-15 +
 - thread 2 extracts partitions 16-23 +
 - thread 3 extracts partitions 24-31
-| `multi` | This option can be used in conjunction with parallel operator to write as many ouput files as the number of extraction
+| `multi` | This option can be used in conjunction with parallel operator to write as many output files as the number of extraction
 threads. Output file names are built adding four digits at the end of the file identified by the `tgt` operator. +
  +
 For example, with `src=trafodion.mauro.orders:tgt=%t.csv:parallel=4:multi` +
@@ -916,7 +916,7 @@ with `min(emp_id)=1` and `max(emp_id)=1000`, the four threads extract the follow
 `thread #2 emp_id >=501 and emp_id < 751` +
 `thread #3 emp_id >=751 and emp_id < 1001` (odb uses max(emp_id) + 1) +
  +
-If the values are not equally distributed, then data extraction is deskewed.
+If the values are not equally distributed, then data extraction is de-skewed.
 | `pre={@sqlfile}\|{[sqlcmd]` | odb runs a *single instance* of either the `sqlfile` script or `sqlcmd` SQL
 command (enclosed between square brackets) on the *source system* immediately before table extraction. +
  +
@@ -1009,7 +1009,7 @@ Complete list of the Copy Operators:
 - `%s/%S`: Expands to the (lower/upper case) source schema name. +
 - `%c/%C`: Expands to the (lower/upper case) source catalog name.
 | `sql={[sqlcmd]\|@sqlfile\|-file}` | odb uses a generic SQL &#8212; instead of a _real_ table &#8212; as source.
-| `max=num` | This is the max number of records to copy. Default is to copy all ecords in the source table.
+| `max=num` | This is the max number of records to copy. Default is to copy all records in the source table.
 | `rows=<num>\|k<num>\|m<num>` | Defines the size of the I/O buffer for each copy thread. You can
 define the size of this buffer in two different ways: +
  +
@@ -1053,7 +1053,7 @@ You can enclose the where condition between square brackets to avoid a misinterp
  +
 - `auto` (Default) &8212; Commits every single insert (see also rows load operator). `end` commits when all rows (assigned to a given thread) have been inserted. +
 - `#rows` &#8212; Commits every `#rows` copied rows. +
-- `x#rs` &#8212; Commits every `#rs` rowsets copied. (See `:rows`)
+- `x#rs` &#8212; Commits every `#rs` rowset copied. (See `:rows`)
 | `direct` | Adds `/*+ DIRECT */` hint to the insert statement. To be used with Vertica databases in order to store
 inserted rows _directly_ into the Read-Only Storage (ROS). See Vertica’s documentation.
 | `errmax=num` | odb prints up to num error messages per rowset. Normally used with soe to limit the number of
@@ -1074,12 +1074,12 @@ with `min(emp_id)=1` and `max(emp_id)=1000`, then the four threads extracts the
 `thread #2 emp_id >=501 and emp_id < 751` +
 `thread #3 emp_id >=751 and emp_id < 1001 (odb uses max(emp_id) + 1)` +
  +
-If the values are not equally distributed data extraction is deskewed.
+If the values are not equally distributed data extraction is de-skewed.
 | `pre={@sqlfile}\|{[sqlcmd]}` | odb runs a *single instance* of either a `sqlfile` script or `sqlcmd`
 (enclosed between square brackets) on the *target system* immediately before loading the target table.
 You can, for example, CREATE the target table before loading it. +
  +
-The target table isn'te loaded if SQL execution fails and Stop On Error is set.
+The target table isn't loaded if SQL execution fails and Stop On Error is set.
 | `mpre={@sqlfile}\|{[sqlcmd]}` | Each odb thread runs either a `sqlfile` script or `sqlcmd`
 (enclosed between square brackets) on the *source system* immediately before
 loading the target table. You can use `mpre` to set database specific features for each thread.
@@ -1090,7 +1090,7 @@ You can use `mpre` to set database specific features for each thread.
 (enclosed between square brackets) on the *target system* immediately after the target table has been
 loaded. You can, for example, update database stats after loading a table.
 | `tpar=num` | odb copies `num` tables in parallel when `src` is a list of files to be loaded.
-| `loaders=num` | odb uses `num` load threads for each extract thread. Ddefault is two loaders per extractor,
+| `loaders=num` | odb uses `num` load threads for each extract thread. Default is two loaders per extractor,
 | `fwc` | Force Wide Characters. odb considers SQL_CHAR/SQL_VARCHAR fields as they were defined SQL_WCHAR/SQL_WVARCHAR.
 | `bpwc=#` | odb internally allocates 4 bytes/char for SQL_WCHAR/SQL_WVARCHAR columns.
 You can modify the number of bytes allocated for each char using this parameter.
@@ -1149,7 +1149,7 @@ file.
 <<<
 *Example*
 
-Usinge different _splitby columns_.
+Using different _splitby columns_.
 
 ```
 ~/Devel/odb $ cat tlist2.txt
@@ -1164,12 +1164,12 @@ src=TRAFODION.MAURIZIO.LINEITEM:splitby=L_PARTKEY
 
 == Case-Sensitive Table and Column Names
 
-Your database configuration determiens whether you can use case sensitive table/column names.
+Your database configuration determines whether you can use case sensitive table/column names.
 odb maintains table/column case sensitiveness when they are enclosed in double quotes.
 
 *Example*
 
-The following commans create a `TRAFODION.MAURIZIO.Names` table made of three columns:
+The following commands create a `TRAFODION.MAURIZIO.Names` table made of three columns:
 “name”, “NAME” and “Name”.
 
 ```
@@ -1201,7 +1201,7 @@ in parallel; `:parallel` defines how many _data streams_ to use for each table.
 allocates and start the “right” number of threads.
 
 A rule of thumb when copying/loading or extracting tables is to use as many _data streams_ as:
-`min(number of middletier CPUs, number of source CPUs, number of target CPUs)`
+`min(number of middle-tier CPUs, number of source CPUs, number of target CPUs)`
 
 The number of threads started for each _data stream_ depend on the operation type:
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/3063990d/docs/odb_user/src/asciidoc/_chapters/query_driver.adoc
----------------------------------------------------------------------
diff --git a/docs/odb_user/src/asciidoc/_chapters/query_driver.adoc b/docs/odb_user/src/asciidoc/_chapters/query_driver.adoc
index c4e480f..c331107 100644
--- a/docs/odb_user/src/asciidoc/_chapters/query_driver.adoc
+++ b/docs/odb_user/src/asciidoc/_chapters/query_driver.adoc
@@ -93,8 +93,8 @@ The CSV output columns have the following meaning:
 | `1st Fetch(s)` | Time needed to fetch the first row in seconds.
 | `Fetch(s)`     | Total Fetch time in seconds.
 | `Total(s)`     | Total query elapsed time from prepare to fetch in seconds.
-| `Stimeline`    | Queries start timeline in milliseconds.
-| `Etimeline`    | Queries end timeline in milliseconds.
+| `Stimeline`    | Queries start time line in milliseconds.
+| `Etimeline`    | Queries end time line in milliseconds.
 |===
 
 <<<
@@ -168,7 +168,7 @@ This multiplying factors are defined with a `<number>:` preceding the script pat
 | `odb64luo -P test/queries/* -T 50 - c -q`    | Runs *in parallel* all files under `test/queries/` using 50 threads
 (ODBC connections) (`-T 50`), with CSV output (`-c`) and omitting query output (`-q`).
 | `odb64luo -P 3: test/queries/* -T 3 -c -q`   | Runs *in parallel three times (`3:`)* all files under `test/queries/`
-using thre threads (ODBC connections) (`-T 3`), with CSV output (`-c`) and omitting query output (`-q`).
+using three threads (ODBC connections) (`-T 3`), with CSV output (`-c`) and omitting query output (`-q`).
 Scripts will be assigned to threads using *_standard assignment_*.
 | `odb64luo -P -3: test/queries/* -T 3 -c -q`  | Runs *in parallel three times (`-3:`)* all files under `test/queries/`
 using three threads (ODBC connections) (`-T 3`), with CSV type output (`-c`) and omitting query output (`-q`).

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/3063990d/docs/odb_user/src/asciidoc/_chapters/sql_interpreter.adoc
----------------------------------------------------------------------
diff --git a/docs/odb_user/src/asciidoc/_chapters/sql_interpreter.adoc b/docs/odb_user/src/asciidoc/_chapters/sql_interpreter.adoc
index 6be750c..491afd7 100644
--- a/docs/odb_user/src/asciidoc/_chapters/sql_interpreter.adoc
+++ b/docs/odb_user/src/asciidoc/_chapters/sql_interpreter.adoc
@@ -56,7 +56,7 @@ When you press the up arrow key the whole command (up to semi-colon) will be rea
 command is automatically updated.
 * *CTRL-U/CTRL-L* to change the command case.
 * *CTRL-X* to kill the current command.
-* See online help for the other `mreadline` commands.
+* See on-line help for the other `mreadline` commands.
 +
 <<<
 2. *History is saved* when you exit the SQL Interpreter in a file identified by the `ODB_HIST` environment variable.
@@ -103,7 +103,7 @@ will be just prepared, not executed.
 10.  Different databases use different commands to set default schema(s):
 * Trafodion: `set schema <name>;`
 * MySQL: `use <name>;`
-* Postgresql/Vertica: `set search_path to <name1,name2,…>;`
+* PostgreSQL/Vertica: `set search_path to <name1,name2,…>;`
 * Teradata: `set database <name>;`
 +
 `set chsch <command>` is used to define database specific commands to change your schema. When odb recognize the

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/3063990d/docs/sql_reference/src/asciidoc/_chapters/cqds.adoc
----------------------------------------------------------------------
diff --git a/docs/sql_reference/src/asciidoc/_chapters/cqds.adoc b/docs/sql_reference/src/asciidoc/_chapters/cqds.adoc
index ab7afe7..26f0e7b 100644
--- a/docs/sql_reference/src/asciidoc/_chapters/cqds.adoc
+++ b/docs/sql_reference/src/asciidoc/_chapters/cqds.adoc
@@ -75,14 +75,14 @@ CHARACTER SET UTF8, with _n_ being the value of this CQD.
 
 [cols="25%h,75%"]
 |===
-| Category                    | Historgrams
+| Category                    | Histograms
 | Description                 | Defines the time interval after which timestamps for cached histograms
 are checked to be refreshed.
 | Values                      | Unsigned integer. Unit is seconds. +
  +
 The default value is '3600' (1 hour).
 | Usage       | Histogram statistics are cached so that the compiler can avoid access to
-the metadata tables, thereby reducing compile times. The timestamp of
+the metadata tables, thereby reducing compile times. The time stamp of
 the tables are checked against those of the cached histograms at an
 interval specified by this CQD, in order to see if the cached histograms
 need to be refreshed. +
@@ -118,7 +118,7 @@ recently updated statistics.
 
 [cols="25%h,75%"]
 |===
-| Category                    | Historgrams
+| Category                    | Histograms
 | Description                 | Defines the time interval after which the fake histograms in the cache should be refreshed unconditionally.
 | Values                      | Integer. Unit is seconds. +
  +
@@ -149,7 +149,7 @@ histogram statistics, potentially resulting in poorer plans.
 
 [cols="25%h,75%"]
 |===
-| Category                    | Historgrams
+| Category                    | Histograms
 | Description                 | Influences the compiler to pre-fetch the histograms and save them in cache.
 | Values                      | 'ON'    Pre-fetches the histograms. +
 'OFF'   Does not pre-fetch the histograms. +
@@ -168,7 +168,7 @@ histogram statistics, potentially resulting in poorer plans.
 
 [cols="25%h,75%"]
 |===
-| Category                    | Historgrams
+| Category                    | Histograms
 | Description                 | Specifies the minimum row count for which the optimizer needs histograms, in order to compute better cardinality estimates. The
 optimizer does not issue any missing statistics warnings for tables whose size is smaller than the value of this CQD.
 | Values                      | Integer. +

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/3063990d/docs/sql_reference/src/asciidoc/_chapters/introduction.adoc
----------------------------------------------------------------------
diff --git a/docs/sql_reference/src/asciidoc/_chapters/introduction.adoc b/docs/sql_reference/src/asciidoc/_chapters/introduction.adoc
index 82ae2aa..ea73f2a 100644
--- a/docs/sql_reference/src/asciidoc/_chapters/introduction.adoc
+++ b/docs/sql_reference/src/asciidoc/_chapters/introduction.adoc
@@ -228,7 +228,7 @@ For a list of Control Query Default (CQD) settings for the Hive environment, see
 [[ansi_names_for_hive_tables]]
 === ANSI Names for Hive Tables
 
-Hive tables appear in the Trafodion Hive ANSI namespace in a special catalog and schema named `HIVE.HIVE`.
+Hive tables appear in the Trafodion Hive ANSI name space in a special catalog and schema named `HIVE.HIVE`.
 
 To select from a Hive table named `T`, specify an implicit or explicit name, such as `HIVE.HIVE.T`,
 in a Trafodion SQL statement.
@@ -268,7 +268,7 @@ Trafodion performs the following data-type mappings:
 |===
 
 1. The value `_n_` is determined by `CQD HIVE_MAX_STRING_LENGTH`. See <<hive_environment_cqds,Hive Environment CQDs>>.
-2. Hive supports timestamps with nanosecond resolution (precision of 9). Tafodion SQL supports only microsecond resolution (precision 6).
+2. Hive supports timestamps with nanosecond resolution (precision of 9). Trafodion SQL supports only microsecond resolution (precision 6).
 
 [[supported_sql_statements_with_hive_tables]]
 === Supported SQL Statements With Hive Tables
@@ -312,7 +312,7 @@ does not actually lock the data, thereby reducing lock request conflicts. If a l
 place is released.
 
 READ COMMITTED provides the next higher level of data consistency (compared to READ UNCOMMITTED).
-A statement executing with this access option does not allow dirty reads, but both nonrepeatable reads
+A statement executing with this access option does not allow dirty reads, but both non-repeatable reads
 and phantoms are possible.
 
 READ COMMITTED provides sufficient consistency for any process that does not require a repeatable read
@@ -406,7 +406,7 @@ This option, which is ANSI compliant, allows your transaction to access only com
 when READ COMMITTED is the specified isolation level.
 
 READ COMMITTED provides the next level of data consistency. A transaction executing with this isolation level does not
-allow dirty reads, but both nonrepeatable reads and phantoms are possible.
+allow dirty reads, but both non-repeatable reads and phantoms are possible.
 
 READ COMMITTED provides sufficient consistency for any transaction that does not require a repeatable-read capability.
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/3063990d/docs/sql_reference/src/asciidoc/_chapters/olap_functions.adoc
----------------------------------------------------------------------
diff --git a/docs/sql_reference/src/asciidoc/_chapters/olap_functions.adoc b/docs/sql_reference/src/asciidoc/_chapters/olap_functions.adoc
index 32a1efd..e01b45b 100644
--- a/docs/sql_reference/src/asciidoc/_chapters/olap_functions.adoc
+++ b/docs/sql_reference/src/asciidoc/_chapters/olap_functions.adoc
@@ -183,7 +183,7 @@ DISTINCT in a window function will result in the "4341" error message.
 [[avg_window_function]]
 == AVG Window Function
 
-AVG is a window function that returns the average of nonnull values of
+AVG is a window function that returns the average of non-null values of
 the given expression for the current window specified by the
 _inline-window specification_.
 
@@ -420,7 +420,7 @@ equal have the same rank. The value of DENSE_RANK advances 1 when the
 value of the given expression changes.
 
 ```
-DENSERANK() OVER (inline-window-specification)
+DENSE_RANK() OVER (inline-window-specification)
 ```
 
 * `_inline-window-specification_` is:
@@ -735,7 +735,7 @@ ROW_NUMBER is a window function that returns the row number of each row
 of the current window specified by the inline-window-specification.
 
 ```
-ROWNUMBER () OVER (inline-window-specification)
+ROW_NUMBER () OVER (inline-window-specification)
 ```
 
 * `_inline-window-specification_` is:

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/3063990d/docs/sql_reference/src/asciidoc/_chapters/runtime_stats.adoc
----------------------------------------------------------------------
diff --git a/docs/sql_reference/src/asciidoc/_chapters/runtime_stats.adoc b/docs/sql_reference/src/asciidoc/_chapters/runtime_stats.adoc
index 44e15f0..56dc11d 100644
--- a/docs/sql_reference/src/asciidoc/_chapters/runtime_stats.adoc
+++ b/docs/sql_reference/src/asciidoc/_chapters/runtime_stats.adoc
@@ -582,7 +582,7 @@ earlier will be reclaimed to free up space for the upcoming queries. This counte
 | EID Heap Allocated^2^  | Dp2HeapTotal                             | Amount of "heap" memory in KB allocated in the executor in TSEs involved in the query.
 | EID Heap Used2         | Dp2HeapUsed                              | Amount of "heap" memory in KB used in the executor in TSEs involved in the query.
 | Opens                  | Opens                                    | Number of OPEN calls performed by the SQL executor on behalf of this statement.
-| Open Time              | OpenTime                                 | Time (in microseconds) this process spent doing OPENs on behalf of this statement.
+| Open Time              | OpenTime                                 | Time (in microseconds) this process spent doing opens on behalf of this statement.
 | Processes Created      | Newprocess                               | The number of processes (ESPs and MXCMPs) created by the master executor for this statement.
 | Process Create Time    | NewprocessTime                           | The elapsed time taken to create these processes.
 | Table Name             | AnsiName                                 | Name of a table in the query.
@@ -1160,7 +1160,7 @@ RMS Stats Reset Timestamp   2010/12/05 14:32:33.891083
 
 Use the QUERYID_EXTRACT function within an SQL statement to extract
 components of a query ID for use in a SQL query. The query ID, or QID,
-is a unique, clusterwide identifier for a query and
+is a unique, cluster-wide identifier for a query and
 is generated for dynamic SQL statements whenever a SQL string is
 prepared.
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/3063990d/docs/sql_reference/src/asciidoc/_chapters/sql_clauses.adoc
----------------------------------------------------------------------
diff --git a/docs/sql_reference/src/asciidoc/_chapters/sql_clauses.adoc b/docs/sql_reference/src/asciidoc/_chapters/sql_clauses.adoc
index bb3c9c4..7ae2973 100644
--- a/docs/sql_reference/src/asciidoc/_chapters/sql_clauses.adoc
+++ b/docs/sql_reference/src/asciidoc/_chapters/sql_clauses.adoc
@@ -803,7 +803,7 @@ by a table, view, or correlation name; for example, CUSTOMER.CITY.
 +
 specifies the sort order. ASC is the default. For ordering an
 intermediate result table on a column that can contain null, nulls are
-considered equal to one another but greater than all other nonnull
+considered equal to one another but greater than all other non-null
 values.
 +
 You must include a SEQUENCE BY clause if you include a sequence function
@@ -1429,4 +1429,4 @@ The result table of the TRANSPOSE query is:
 | 1 | 10 | 100 | d1 | e1 | f1 | 2       | 10      | xyz
 | 2 | 20 | 200 | d2 | e2 | f2 | 1       | 2       | abc
 | 2 | 20 | 200 | d2 | e2 | f2 | 2       | 20      | xyz
-|=== 
\ No newline at end of file
+|=== 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/3063990d/docs/sql_reference/src/asciidoc/_chapters/sql_functions_and_expressions.adoc
----------------------------------------------------------------------
diff --git a/docs/sql_reference/src/asciidoc/_chapters/sql_functions_and_expressions.adoc b/docs/sql_reference/src/asciidoc/_chapters/sql_functions_and_expressions.adoc
index 5bbf66d..7294d83 100644
--- a/docs/sql_reference/src/asciidoc/_chapters/sql_functions_and_expressions.adoc
+++ b/docs/sql_reference/src/asciidoc/_chapters/sql_functions_and_expressions.adoc
@@ -41,7 +41,7 @@ DOWN to the last day of the result month.
 == Aggregate (Set) Functions
 
 An aggregate (or set) function operates on a group or groups of rows
-retrieved by the SELECT statement or the subquery in which the aggregate
+retrieved by the SELECT statement or the sub query in which the aggregate
 function appears.
 
 
@@ -70,7 +70,7 @@ be weighted.
 
 
 Columns and expressions can be arguments of an aggregate function. The
-expressions cannot contain aggregate functions or subqueries.
+expressions cannot contain aggregate functions or sub queries.
 
 An aggregate function can accept an argument specified as DISTINCT,
 which eliminates duplicate values before the aggregate function is
@@ -89,7 +89,7 @@ See the individual entry for the function.
 
 These functions manipulate character strings and use a character value
 expression as an argument or return a result of a character data type.
-Character string functions treat each single-byte or multibyte character
+Character string functions treat each single-byte or multi-byte character
 in an input string as one character, regardless of the byte length of
 the character.
 
@@ -109,11 +109,11 @@ value. You can also use the concatenation operator (\|\|).
 | <<insert_function,INSERT Function>>                     | Returns a character string where a specified number of characters within
 the character string have been deleted and then a second character
 string has been inserted at a specified start position.
-| <<lcase_function,LCASE Function>>                       | Downshifts alphanumeric characters. You can also use LOWER.
+| <<lcase_function,LCASE Function>>                       | Down-shifts alphanumeric characters. You can also use LOWER.
 | <<left_function,LEFT Function>>                         | Returns the leftmost specified number of characters from a character expression.
 | <<locate_function,LOCATE Function>>                     | Returns the position of a specified substring within a character string.
 You can also use POSITION.
-| <<lower_function,LOWER Function>>                       | Downshifts alphanumeric characters. You can also use LCASE.
+| <<lower_function,LOWER Function>>                       | Down-shifts alphanumeric characters. You can also use LCASE.
 | <<lpad_function,LPAD Function>>                         | Replaces the leftmost specified number of characters in a character
 expression with a padding character.
 | <<ltrim_function,LTRIM Function>>                       | Removes leading spaces from a character string.
@@ -135,9 +135,9 @@ expression with a padding character.
 | <<translate_function,TRANSLATE Function>>               | Translates a character string from a source character set to a target
 character set.
 | <<trim_function,TRIM Function>>                         | Removes leading or trailing characters from a character string.
-| <<ucase_function,UCASE Function>>                       | Upshifts alphanumeric characters. You can also use UPSHIFT or UPPER.
-| <<upper_function,UPPER Function>>                       | Upshifts alphanumeric characters. You can also use UPSHIFT or UCASE.
-| <<upshift_function,UPSHIFT Function>>                   | Upshifts alphanumeric characters. You can also use UPPER or UCASE.
+| <<ucase_function,UCASE Function>>                       | Up-shifts alphanumeric characters. You can also use UPSHIFT or UPPER.
+| <<upper_function,UPPER Function>>                       | Up-shifts alphanumeric characters. You can also use UPSHIFT or UCASE.
+| <<upshift_function,UPSHIFT Function>>                   | Up-shift alphanumeric characters. You can also use UPPER or UCASE.
 |===
 
 See the individual entry for the function.
@@ -241,7 +241,7 @@ returns 0. If value is greater than zero, returns 1.
 | <<sqrt_function,SQRT Function>>       | Returns the square root of a numeric value expression.
 | <<tan_function,TAN Function>>         | Returns the tangent of a numeric value expression, where the expression is an angle expressed in radians.
 | <<tanh_function,TANH Function>>       | Returns the hyperbolic tangent of a numeric value expression, where the expression is an angle expressed in radians.
-| <<zeroifnull_dunction,ZEROIFNULL Function>> | Returns the value of the operand unless it is NULL, in which case it returns zero.
+| <<zeroifnull_function,ZEROIFNULL Function>> | Returns the value of the operand unless it is NULL, in which case it returns zero.
 |===
 
 See the individual entry for the function.
@@ -276,12 +276,12 @@ sequence function.
 
 [cols="25%,75%"]
 |===
-| <<movingcount_function,MOVINGCOUNT Function>>       | Returns the number of nonnull values of a column expression in the current window.
-| <<movingmax_function,MOVINGMAX Function>>           | Returns the maximum of nonnull values of a column expression in the current window.
-| <<movingmin_function,MOVINGMIN Function>>           | Returns the minimum of nonnull values of a column expression in the current window.
-| <<movingstddev_function,MOVINGSTDDEV Function>>     | Returns the standard deviation of nonnull values of a column expression in the current window.
-| <<movingsum_function,MOVINGSUM Function>>           | Returns the sum of nonnull values of a column expression in the current window.
-| <<movingvariance_function,MOVINGVARIANCE Function>> | Returns the variance of nonnull values of a column expression in the current window.
+| <<movingcount_function,MOVINGCOUNT Function>>       | Returns the number of non-null values of a column expression in the current window.
+| <<movingmax_function,MOVINGMAX Function>>           | Returns the maximum of non-null values of a column expression in the current window.
+| <<movingmin_function,MOVINGMIN Function>>           | Returns the minimum of non-null values of a column expression in the current window.
+| <<movingstddev_function,MOVINGSTDDEV Function>>     | Returns the standard deviation of non-null values of a column expression in the current window.
+| <<movingsum_function,MOVINGSUM Function>>           | Returns the sum of non-null values of a column expression in the current window.
+| <<movingvariance_function,MOVINGVARIANCE Function>> | Returns the variance of non-null values of a column expression in the current window.
 |===
 
 Offset sequence function
@@ -298,14 +298,14 @@ Offset sequence function
 
 [cols="25%,75%"]
 |===
-| <<runningavg_function,RUNNINGAVG Function>>             | Returns the average of nonnull values of a column expression up to and including the current row.
+| <<runningavg_function,RUNNINGAVG Function>>             | Returns the average of non-null values of a column expression up to and including the current row.
 | <<runningcount_function,RUNNINGCOUNT Function>>         | Returns the number of rows up to and including the current row.
 | <<runningmax_function,RUNNINGMAX Function>>             | Returns the maximum of values of a column expression up to and including the current row.
 | <<runningmin_function,RUNNINGMIN Function>>             | Returns the minimum of values of a column expression up to and including the current row.
 | <<runningrank_function,RUNNINGRANK Function>>           | Returns the rank of the given value of an intermediate result table ordered by a SEQUENCE BY clause in a SELECT statement.
-| <<runningstddev_function,RUNNINGSTDDEV Function>>       | Returns the standard deviation of nonnull values of a column expression up to and including the current row.
-| <<runningsum_function,RUNNINGSUM Function>>             | Returns the sum of nonnull values of a column expression up to and including the current row.
-| <<runningvariance_function,RUNNINGVARIANCE Function>>   | Returns the variance of nonnull values of a column expression up to and including the current row.
+| <<runningstddev_function,RUNNINGSTDDEV Function>>       | Returns the standard deviation of non-null values of a column expression up to and including the current row.
+| <<runningsum_function,RUNNINGSUM Function>>             | Returns the sum of non-null values of a column expression up to and including the current row.
+| <<runningvariance_function,RUNNINGVARIANCE Function>>   | Returns the variance of non-null values of a column expression up to and including the current row.
 |===
 
 [[other_sequence_functions]]
@@ -313,7 +313,7 @@ Offset sequence function
 
 [cols="25%,75%"]
 |===
-| <<lastnotnull_function,LASTNOTNULL Function>>               | Returns the last nonnull value for the specified column expression. If only null values have been returned, returns null.
+| <<lastnotnull_function,LASTNOTNULL Function>>               | Returns the last non-null value for the specified column expression. If only null values have been returned, returns null.
 | <<rows_since_function,ROWS SINCE Function>>                 | Returns the number of rows counted since the specified condition was last true.
 | <<rows_since_changed_function,ROWS SINCE CHANGED Function>> | Returns the number of rows counted since the specified set of values last changed.
 | <<this_function,THIS Function>>                             | Used in ROWS SINCE to distinguish between the value of the column in the current row and the value of the column in previous rows.
@@ -337,13 +337,13 @@ Use these other functions and expressions in an SQL value expression:
 | <<coalesce_function,COALESCE Function>>                         | Returns the value of the first expression in the list that does not have a NULL value or if all 
 the expressions have NULL values, the function returns a NULL value.
 | <<converttohex_function,CONVERTTOHEX Function>>                 | Converts the specified value expression to hexadecimal for display purposes.
-| <<current_user_function,CURRENT_USER Function>>                 | Returns the database username of the current user who invoked the function.
+| <<current_user_function,CURRENT_USER Function>>                 | Returns the database user name of the current user who invoked the function.
 | <<decode_function,DECODE Function>>                             | Compares _expr_ to each _test_expr_ value one by one in the order provided.
 | <<explain_function,EXPLAIN Function>>                           | Generates a result table describing an access plan for a SELECT, INSERT, DELETE, or UPDATE statement.
 | <<isnull_function,ISNULL Function>>                             | Returns the first argument if it is not null, otherwise it returns the second argument.
 | <<nullif_function,NULLIF Function>>                             | Returns the value of the first operand if the two operands are not equal, otherwise it returns NULL.
 | <<nvl_function,NVL Function>>                                   | Returns the value of the first operand unless it is NULL, in which case it returns the value of the second operand.
-| <<user_function,USER Function>>                                 | Returns either the database username of the current user who invoked the function or the database username 
+| <<user_function,USER Function>>                                 | Returns either the database user name of the current user who invoked the function or the database user name 
 associated with the specified user ID number.
 |===
 
@@ -739,7 +739,7 @@ values are eliminated before the AVG function is applied.
 +
 specifies a numeric or interval value _expression_ that determines the
 values to average. The _expression_ cannot contain an aggregate function
-or a subquery. The DISTINCT clause specifies that the AVG function
+or a sub query. The DISTINCT clause specifies that the AVG function
 operates on distinct values from the one-column table derived from the
 evaluation of _expression_.
 
@@ -969,7 +969,7 @@ specifies the result value expression associated with each _expression_
 in a WHEN clause of a simple CASE, or with each _condition_ in a WHEN
 clause of a searched CASE. All of the _result-expressions_ must have
 comparable data types, and at least one of the
-_result-expressions_ must return nonnull.
+_result-expressions_ must return non-null.
 
 * `_result-expression_`
 +
@@ -1279,7 +1279,7 @@ PREMIER INSURANCE       80 P
 == CHAR_LENGTH Function
 
 The CHAR_LENGTH function returns the number of characters in a string.
-You can also use CHARACTER_LENGTH. Every character, including multibyte
+You can also use CHARACTER_LENGTH. Every character, including multi-byte
 characters, counts as one character.
 
 ```
@@ -1461,7 +1461,7 @@ An operand can be any SQL value expression of data type CHAR or VARCHAR.
 
 A string value can be specified by any character value expression, such
 as a character string literal, character string function, column
-reference, aggregate function, scalar subquery, CASE expression, or CAST
+reference, aggregate function, scalar sub query, CASE expression, or CAST
 expression. The value of the operand must be of type CHAR or VARCHAR.
 
 If you use the CAST expression, you must specify the length of CHAR or
@@ -1761,7 +1761,7 @@ function is applied.
 * `_expression_`
 +
 specifies a value expression that determines the values to count. The
-_expression_ cannot contain an aggregate function or a subquery. The
+_expression_ cannot contain an aggregate function or a sub query. The
 DISTINCT clause specifies that the COUNT function operates on distinct
 values from the one-column table derived from the evaluation of
 _expression_. See <<expressions,Expressions>>.
@@ -1775,7 +1775,7 @@ _expression_. See <<expressions,Expressions>>.
 The operand of COUNT is either * or an expression that includes columns
 from the result table specified by the SELECT statement that contains
 COUNT. However, the expression cannot include an aggregate function or a
-subquery. These expressions are valid:
+sub query. These expressions are valid:
 
 ```
 COUNT (*)
@@ -2007,9 +2007,9 @@ SET ship_timestamp = CURRENT_TIMESTAMP WHERE projcode = 1000;
 [[current_user_function]]
 == CURRENT_USER Function
 
-The CURRENT_USER function returns the database username of the current
+The CURRENT_USER function returns the database user name of the current
 user who invoked the function. The current user is the authenticated
-user who started the session. That database username is used for
+user who started the session. That database user name is used for
 authorization of SQL statements in the current session.
 
 ```
@@ -2028,7 +2028,7 @@ The CURRENT_USER function is similar to the <<user_function,USER Function>>.
 [[examples_of_current_user]]
 === Examples of CURRENT_USER
 
-* This example retrieves the database username for the current user:
+* This example retrieves the database user name for the current user:
 +
 ```
 SELECT CURRENT_USER FROM (values(1)) x(a);
@@ -2669,7 +2669,7 @@ DAYOFMONTH (datetime-expression)
 * `_datetime-expression_`
 +
 is an expression that evaluates to a datetime value of type DATE or
-TIMESTAMP. See <<datetime_value_expressions,Datetime ValueE xpressions>>.
+TIMESTAMP. See <<datetime_value_expressions,Datetime Value Expressions>>.
 
 [[examples_of_dayofmonth]]
 === Examples of DAYOFMONTH
@@ -2811,7 +2811,7 @@ All the _retval_ values and the _default_ value, if any, must be of
 comparable types.
 
 If _expr_ and a _test-expr_ value are character data, the comparison is
-made using nonpadded comparison semantics.
+made using non-padded comparison semantics.
 
 If _expr_ and a _test-expr_ value are numeric data, the comparison is
 made with a temporary copy of one of the numbers, according to defined
@@ -3538,7 +3538,7 @@ Start/Date Time/Shipped               (EXPR)
 The INSERT function returns a character string where a specified number
 of characters within the character string has been deleted, beginning at
 a specified start position, and where another character string has been
-inserted at the start position. Every character, including multibyte
+inserted at the start position. Every character, including multi-byte
 characters, is treated as one character.
 
 INSERT is a Trafodion SQL extension.
@@ -3712,7 +3712,7 @@ START_DATE (EXPR)
 == LASTNOTNULL Function
 
 The LASTNOTNULL function is a sequence function that returns the last
-nonnull value of a column in an intermediate result table ordered by a
+non-null value of a column in an intermediate result table ordered by a
 SEQUENCE BY clause in a SELECT statement. See <<sequence_by_clause,SEQUENCE BY Clause>>.
 
 LASTNOTNULL is a Trafodion SQL extension.
@@ -3729,7 +3729,7 @@ expression. If only null values have been returned, LASTNOTNULL returns null.
 [[examples_of_lastnotnull]]
 === Examples of LASTNOTNULL
 
-* Return the last nonnull value of a column:
+* Return the last non-null value of a column:
 +
 
 ```
@@ -3751,7 +3751,7 @@ lastnotnull
 [[lcase_function]]
 == LCASE Function
 
-The LCASE function downshifts alphanumeric characters. For
+The LCASE function down-shifts alphanumeric characters. For
 non-alphanumeric characters, LCASE returns the same character. LCASE can
 appear anywhere in a query where a value can be used, such as in a
 select list, an ON clause, a WHERE clause, a HAVING clause, a LIKE
@@ -3771,7 +3771,7 @@ LCASE (character-expression)
 * `_character-expression_`
 +
 is an SQL character value expression that specifies a string of
-characters to downshift. See
+characters to down-shift. See
 <<character_value_expressions,Character Value Expressions>>.
 
 [[examples_of_lcase]]
@@ -3799,7 +3799,7 @@ See <<ucase_function,UCASE Function>>.
 === LEFT Function
 
 The LEFT function returns the leftmost specified number of characters
-from a character expression. Every character, including multibyte
+from a character expression. Every character, including multi-byte
 characters, is treated as one character.
 
 LEFT is a Trafodion SQL extension.
@@ -3860,7 +3860,7 @@ SECRETARY COMNET
 The LOCATE function searches for a given substring in a character
 string. If the substring is found, Trafodion SQL returns the character
 position of the substring within the string. Every character, including
-multibyte characters, is treated as one character. The result returned
+multi-byte characters, is treated as one character. The result returned
 by the LOCATE function is equal to the result returned by the
 <<position_function,Position Function>>.
 
@@ -3985,7 +3985,7 @@ LOG10 (25)
 [[lower_function]]
 == LOWER Function
 
-The LOWER function downshifts alphanumeric characters. For
+The LOWER function down-shifts alphanumeric characters. For
 non-alphanumeric characters, LOWER returns the same character. LOWER can
 appear anywhere in a query where a value can be used, such as in a
 select list, an ON clause, a WHERE clause, a HAVING clause, a LIKE
@@ -4003,13 +4003,13 @@ LOWER (character-expression)
 * `_character-expression_`
 +
 is an SQL character value expression that specifies a string of
-characters to downshift.
+characters to down-shift.
 See <<character_value_expressions,Character Value Expressions>>.
 
 [[considerations_for_lower]]
 === Considerations for LOWER
 
-For a UTF8 character expression, the LOWER function downshifts all the
+For a UTF8 character expression, the LOWER function down-shifts all the
 uppercase or title case characters in a given string to lowercase and
 returns a character string with the same data type and character set as
 the argument.
@@ -4047,7 +4047,7 @@ See <<upper_function,UPPER Function>>.
 === LPAD Function
 
 The LPAD function pads the left side of a string with the specified
-string. Every character in the string, including multibyte characters,
+string. Every character in the string, including multi-byte characters,
 is treated as one character.
 
 LPAD is a Trafodion SQL extension.
@@ -4170,7 +4170,7 @@ applied.
 +
 specifies an expression that determines the values to include in the
 computation of the maximum. The _expression_ cannot contain an aggregate
-function or a subquery. The DISTINCT clause specifies that the
+function or a sub query. The DISTINCT clause specifies that the
 MAX/MAXIMUM function operates on distinct values from the one-column
 table derived from the evaluation of _expression_. All nulls are
 eliminated before the function is applied to the set of values. If the
@@ -4231,7 +4231,7 @@ duplicate values are eliminated before the MIN function is applied.
 +
 specifies an expression that determines the values to include in the
 computation of the minimum. The _expression_ cannot contain an aggregate
-function or a subquery. The DISTINCT clause specifies that the MIN
+function or a sub query. The DISTINCT clause specifies that the MIN
 function operates on distinct values from the one-column table derived
 from the evaluation of _expression_. All nulls are eliminated before
 the function is applied to the set of values. If the result table is
@@ -4419,7 +4419,7 @@ Start/Date Time/Shipped               (EXPR)
 == MOVINGAVG Function
 
 The MOVINGAVG function is a sequence function that returns the average
-of nonnull values of a column in the current window of an intermediate
+of non-null values of a column in the current window of an intermediate
 result table ordered by a SEQUENCE BY clause in a SELECT statement. See
 <<sequence_by_clause,SEQUENCE BY Clause>>.
 
@@ -4465,7 +4465,7 @@ the result table, negative, or NULL.
 [[examples_of_movingavg]]
 === Examples of MOVINGAVG
 
-* Return the average of nonnull values of a column in the current window
+* Return the average of non-null values of a column in the current window
 of three rows:
 +
 ```
@@ -4497,7 +4497,7 @@ MOVINGAVG3
 == MOVINGCOUNT Function
 
 The MOVINGCOUNT function is a sequence function that returns the number
-of nonnull values of a column in the current window of an intermediate
+of non-null values of a column in the current window of an intermediate
 result table ordered by a SEQUENCE BY clause in a SELECT statement. See
 <<sequence_by_clause,SEQUENCE BY Clause>>.
 
@@ -4551,7 +4551,7 @@ values are counted.
 [[examples_of_movingcount]]
 === Examples of MOVINGCOUNT
 
-* Return the number of nonnull values of a column in the current window of
+* Return the number of non-null values of a column in the current window of
 three rows:
 +
 ```
@@ -4574,7 +4574,7 @@ MOVINGCOUNT3
 == MOVINGMAX Function
 
 The MOVINGMAX function is a sequence function that returns the maximum
-of nonnull values of a column in the current window of an intermediate
+of non-null values of a column in the current window of an intermediate
 result table ordered by a SEQUENCE BY clause in a SELECT statement. See
 <<sequence_by_clause,SEQUENCE BY Clause>>.
 
@@ -4620,7 +4620,7 @@ the result table, negative, or NULL.
 [[examples_of_movingmax]]
 === Examples of MOVINGMAX
 
-* Return the maximum of nonnull values of a column in the current window
+* Return the maximum of non-null values of a column in the current window
 of three rows:
 +
 ```
@@ -4643,7 +4643,7 @@ MOVINGMAX3
 == MOVINGMIN Function
 
 The MOVINGMIN function is a sequence function that returns the minimum
-of nonnull values of a column in the current window of an intermediate
+of non-null values of a column in the current window of an intermediate
 result table ordered by a SEQUENCE BY clause in a SELECT statement. See
 <<sequence_by_clause,SEQUENCE BY Clause>>.
 
@@ -4678,7 +4678,7 @@ RUNNINGMIN:
 ** The _integer-expression_ is out of range, and _max-rows_ is not
 specified. This condition includes the case in which both
 _integer-expression_ and _max-rows_ are larger than the result table.
-** The minimum of i_nteger-expression_ and _max-rows_ is out of range.
+** The minimum of _integer-expression_ and _max-rows_ is out of range.
 In this case, _integer-expression_ could be within range, but _max-rows_
 might be the minimum value of the two and be out of range (for example,
 a negative number).
@@ -4689,7 +4689,7 @@ the result table, negative, or NULL.
 [[examples_of_movingmin]]
 === Examples of MOVINGMIN
 
-* Return the minimum of nonnull values of a column in the current window
+* Return the minimum of non-null values of a column in the current window
 of three rows:
 +
 ```
@@ -4712,7 +4712,7 @@ MOVINGMIN3
 == MOVINGSTDDEV Function
 
 The MOVINGSTDDEV function is a sequence function that returns the
-standard deviation of nonnull values of a column in the current window
+standard deviation of non-null values of a column in the current window
 of an intermediate result table ordered by a SEQUENCE BY clause in a
 SELECT statement. See <<sequence_by_clause,SEQUENCE BY Clause>>.
 
@@ -4758,7 +4758,7 @@ the result table, negative, or NULL.
 [[examples_of_movingstddev]]
 === Examples of MOVINGSTDDEV
 
-* Return the standard deviation of nonnull values of a column in the
+* Return the standard deviation of non-null values of a column in the
 current window of three rows:
 +
 ```
@@ -4798,7 +4798,7 @@ FROM mining.seqfcn SEQUENCE BY ts;
 == MOVINGSUM Function
 
 The MOVINGSUM function is a sequence function that returns the sum of
-nonnull values of a column in the current window of an intermediate
+non-null values of a column in the current window of an intermediate
 result table ordered by a SEQUENCE BY clause in a SELECT statement. See
 <<sequence_by_clause,SEQUENCE BY Clause>>.
 
@@ -4832,7 +4832,7 @@ _integer-expression_ and _max-rows_.
 RUNNINGSUM:
 ** The _integer-expression_ is out of range, and _max-rows_ is not
 specified. This condition includes the case in which both
-i_nteger-expression_ and _max-rows_ are larger than the result table.
+_integer-expression_ and _max-rows_ are larger than the result table.
 ** The minimum of _integer-expression_ and _max-rows_ is out of range.
 In this case, _integer-expression_ could be within range, but _max-rows_
 might be the minimum value of the two and be out of range (for example,
@@ -4844,7 +4844,7 @@ the result table, negative, or NULL.
 [[examples_of_movingsum]]
 === Examples of MOVINGSUM
 
-* Return the sum of nonnull values of a column in the current window of
+* Return the sum of non-null values of a column in the current window of
 three rows:
 +
 ```
@@ -4867,7 +4867,7 @@ MOVINGSUM3
 == MOVINGVARIANCE Function
 
 The MOVINGVARIANCE function is a sequence function that returns the
-variance of nonnull values of a column in the current window of an
+variance of non-null values of a column in the current window of an
 intermediate result table ordered by a SEQUENCE BY clause in a SELECT
 statement. See <<sequence_by_clause,SEQUENCE BY Clause>>.
 
@@ -4913,7 +4913,7 @@ the result table, negative, or NULL.
 [[examples_of_movingvariance]]
 === Examples of MOVINGVARIANCE
 
-* Return the variance of nonnull values of a column in the current window
+* Return the variance of non-null values of a column in the current window
 of three rows:
 +
 ```
@@ -5054,7 +5054,7 @@ comparable data types.
 If _operand_ is a null value, NVL returns _new-operand_. If _operand_
 is not a null value, NVL returns _operand_.
 
-The _operand_ and _new-operand_ can be a column name, subquery,
+The _operand_ and _new-operand_ can be a column name, sub query,
 Trafodion SQL string functions, math functions, or constant values.
 
 [[examples_of_nvl]]
@@ -5144,7 +5144,7 @@ column as the actual number of storage bytes.
 
 The OCTET_LENGTH and CHAR_LENGTH functions are similar. The OCTET_LENGTH
 function returns the number of bytes, rather than the number of
-characters, in the string. This distinction is important for multibyte
+characters, in the string. This distinction is important for multi-byte
 implementations. For an example of selecting a double-byte column, see
 <<examples_of_octet_length,Example of OCTET_LENGTH>>.
 
@@ -5243,7 +5243,7 @@ PI()
 The POSITION function searches for a given substring in a character
 string. If the substring is found, Trafodion SQL returns the character
 position of the substring within the string. Every character, including
-multibyte characters, is treated as one character. The result returned
+multi-byte characters, is treated as one character. The result returned
 by the POSITION function is equal to the result returned by the
 <<locate_function,LOCATE Function>>.
 
@@ -5698,7 +5698,7 @@ SYSTEM ANAL TDMNET
 == RIGHT Function
 
 The RIGHT function returns the rightmost specified number of characters
-from a character expression. Every character, including multibyte
+from a character expression. Every character, including multi-byte
 characters, is treated as one character.
 
 RIGHT is a Trafodion SQL extension.
@@ -5968,7 +5968,7 @@ FROM mining.seqfcn SEQUENCE BY ts;
 == RPAD Function
 
 The RPAD function pads the right side of a string with the specified
-string. Every character in the string, including multibyte characters,
+string. Every character in the string, including multi-byte characters,
 is treated as one character.
 
 RPAD is a Trafodion SQL extension.
@@ -6080,7 +6080,7 @@ See <<trim_function,TRIM Function>> and <<ltrim_function,LTRIM Function>>.
 == RUNNINGAVG Function
 
 The RUNNINGAVG function is a sequence function that returns the average
-of nonnull values of a column up to and including the current row of an
+of non-null values of a column up to and including the current row of an
 intermediate result table ordered by a SEQUENCE BY clause in a SELECT
 statement. See <<sequence_by_clause,SEQUENCE BY Clause>>.
 
@@ -6155,7 +6155,7 @@ the intermediate result table up to and including the current row.
 +
 specifies a derived column determined by the evaluation of the column
 expression. If _column-expression_ is the argument, RUNNINGCOUNT returns
-the number of rows containing nonnull values of _column-expression_ in the
+the number of rows containing non-null values of _column-expression_ in the
 intermediate result table up to and including the current row.
 
 
@@ -6285,7 +6285,7 @@ min_i1
 === RUNNINGSTDDEV Function
 
 The RUNNINGSTDDEV function is a sequence function that returns the
-standard deviation of nonnull values of a column up to and including the
+standard deviation of non-null values of a column up to and including the
 current row of an intermediate result table ordered by a SEQUENCE BY
 clause in a SELECT statement.
 See <<sequence_by_clause,SEQUENCE BY Clause>>.
@@ -6301,7 +6301,7 @@ RUNNINGSTDDEV (_column-expression_)
 specifies a derived column determined by the evaluation of the column
 expression.
 +
-RUNNINGSTDDEV returns the standard deviation of nonnull values of
+RUNNINGSTDDEV returns the standard deviation of non-null values of
 _column-expression_ up to and including the current row.
 
 [[considerations_for_runningstddev]]
@@ -6360,7 +6360,7 @@ FROM mining.seqfcn SEQUENCE BY ts;
 == RUNNINGSUM Function
 
 The RUNNINGSUM function is a sequence function that returns the sum of
-nonnull values of a column up to and including the current row of an
+non-null values of a column up to and including the current row of an
 intermediate result table ordered by a SEQUENCE BY clause in a SELECT
 statement. See <<sequence_by_clause,SEQUENCE BY Clause>>.
 
@@ -6375,13 +6375,13 @@ RUNNINGSUM (column-expression)
 specifies a derived column determined by the evaluation of the column
 expression.
 +
-RUNNINGSUM returns the sum of nonnull values of _column-expression_ up
+RUNNINGSUM returns the sum of non-null values of _column-expression_ up
 to and including the current row.
 
 [[examples_of_runningsum]]
 === Examples of RUNNINGSUM
 
-* Return the sum of nonnull values of _i1_ up to and including the current
+* Return the sum of non-null values of _i1_ up to and including the current
 row:
 +
 ```
@@ -6404,7 +6404,7 @@ sum_i1
 == RUNNINGVARIANCE Function
 
 The RUNNINGVARIANCE function is a sequence function that returns the
-variance of nonnull values of a column up to and including the current
+variance of non-null values of a column up to and including the current
 row of an intermediate result table ordered by a SEQUENCE BY clause in a
 SELECT statement. See <<sequence_by_clause,SEQUENCE BY Clause>>.
 
@@ -6419,13 +6419,13 @@ RUNNINGVARIANCE (column-expression)
 specifies a derived column determined by the evaluation of the column
 expression.
 +
-RUNNINGVARIANCE returns the variance of nonnull values of
+RUNNINGVARIANCE returns the variance of non-null values of
 _column-expression_ up to and including the current row.
 
 [[examples_of_runningvariance]]
 === Examples of RUNNINGVARIANCE
 
-* Return the variance of nonnull values of _i1_ up to and including the
+* Return the variance of non-null values of _i1_ up to and including the
 current row:
 +
 ```
@@ -6684,7 +6684,7 @@ If DISTINCT is specified, you cannot specify _weight_.
 +
 specifies a numeric value expression that determines the values for
 which to compute the standard deviation. The _expression_ cannot contain
-an aggregate function or a subquery. The DISTINCT clause specifies that
+an aggregate function or a sub query. The DISTINCT clause specifies that
 the STDDEV function operates on distinct values from the one-column
 table derived from the evaluation of _expression_.
 
@@ -6692,7 +6692,7 @@ table derived from the evaluation of _expression_.
 +
 specifies a numeric value expression that determines the weights of the
 values for which to compute the standard deviation. _weight_ cannot
-contain an aggregate function or a subquery. _weight_ is defined on
+contain an aggregate function or a sub query. _weight_ is defined on
 the same table as _expression_. The one-column table derived from the
 evaluation of _expression_ and the one-column table derived from the
 evaluation of _weight_ must have the same cardinality.
@@ -6812,7 +6812,7 @@ value with an exact numeric data type and a scale of zero.
 * `_length_`
 +
 specifies the number of characters to extract from _character-expr_.
-Keep in mind that every character, including multibyte characters,
+Keep in mind that every character, including multi-byte characters,
 counts as one character. _length_ is the length of the extracted
 substring and must be a value greater than or equal to zero of exact
 numeric data type and with a scale of zero. The _length_ field is
@@ -6858,8 +6858,8 @@ start position to the end of the string is returned.
 * If the start position is greater than the length of the character
 expression, an empty string ('') is returned.
 * The resulting substring is always of type VARCHAR. If the source
-character string is an upshifted CHAR or VARCHAR string, the result is
-an upshifted VARCHAR type.
+character string is an up-shifted CHAR or VARCHAR string, the result is
+an up-shifted VARCHAR type.
 
 <<<
 [[examples_of_substring]]
@@ -6935,7 +6935,7 @@ values are eliminated before the SUM function is applied.
 +
 specifies a numeric or interval value expression that determines the
 values to sum. The _expression_ cannot contain an aggregate function or
-a subquery. The DISTINCT clause specifies that the SUM function operates
+a sub query. The DISTINCT clause specifies that the SUM function operates
 on distinct values from the one-column table derived from the evaluation
 of _expression_. All nulls are eliminated before the function is
 applied to the set of values. If the result table is empty, SUM returns
@@ -7308,7 +7308,7 @@ is one of these translation names:
 |===
 | Translation Name | Source Character Set | Target Character Set | Comments
 | ISO88591TOUTF8   | ISO88591             | UTF8                 | Translates ISO8859-1 characters to UTF8 characters. No data loss is possible.
-| UTF8TOISO88591   | UTF8                 | ISO88591             | ranslates UTF8 characters to ISO88591 characters. Trafodion SQL will
+| UTF8TOISO88591   | UTF8                 | ISO88591             | Translates UTF8 characters to ISO88591 characters. Trafodion SQL will
 display an error if it encounters a Unicode character that cannot be converted to the target character set.
 |===
 
@@ -7336,7 +7336,7 @@ Trafodion SQL returns an error.
 == TRIM Function
 
 The TRIM function removes leading and trailing characters from a
-character string. Every character, including multibyte characters, is
+character string. Every character, including multi-byte characters, is
 treated as one character.
 
 ```
@@ -7374,8 +7374,8 @@ to trim characters. See <<character_value_expressions,Character Value Expression
 
 The result is always of type VARCHAR, with maximum length equal to the
 fixed length or maximum variable length of _trim-source_. If the
-source character string is an upshifts CHAR or VARCHAR string, the
-result is an upshifts VARCHAR type.
+source character string is an up-shifts CHAR or VARCHAR string, the
+result is an up-shifts VARCHAR type.
 
 <<<
 [[examples_of_trim]]
@@ -7399,7 +7399,7 @@ TRIM(first_name) || ' ' || TRIM (last_name)
 [[ucase_function]]
 == UCASE Function
 
-The UCASE function upshifts alphanumeric characters. For
+The UCASE function up-shifts alphanumeric characters. For
 non-alphanumeric characters, UCASE returns the same character. UCASE can
 appear anywhere in a query where a value can be used, such as in a
 select list, an ON clause, a WHERE clause, a HAVING clause, a LIKE
@@ -7425,7 +7425,7 @@ characters to upshift. See <<character_value_expressions,Character Value Express
 [[considerations_for_ucase]]
 === Considerations for UCASE
 
-For a UTF8 character_expression, the UCASE function upshifts all
+For a UTF8 character_expression, the UCASE function up-shifts all
 lowercase or title case characters to uppercase and returns a character
 string. If the argument is of type CHAR(_n_) or VARCHAR(_n_), the
 result is of type VARCHAR(min(3_n_, 2048)), where the maximum length
@@ -7463,7 +7463,7 @@ See <<lcase_function,LCASE Function>>.
 [[upper_function]]
 === UPPER Function
 
-The UPPER function upshifts alphanumeric characters. For
+The UPPER function up-shifts alphanumeric characters. For
 non-alphanumeric characters, UCASE returns the same character. UPPER can
 appear anywhere in a query where a value can be used, such as in a
 select list, an ON clause, a WHERE clause, a HAVING clause, a LIKE
@@ -7511,7 +7511,7 @@ see <<upshift_function,UPSHIFT Function>>.
 [[upshift_function]]
 === UPSHIFT Function
 
-The UPSHIFT function upshifts alphanumeric characters. For
+The UPSHIFT function up-shifts alphanumeric characters. For
 non-alphanumeric characters, UCASE returns the same character. UPSHIFT
 can appear anywhere in a query where a value can be used, such as in a
 select list, an ON clause, a WHERE clause, a HAVING clause, a LIKE
@@ -7584,12 +7584,12 @@ WHERE UPSHIFT(D1.deptname) = UPSHIFT(D2.deptname);
 [[user_function]]
 == USER Function
 
-The USER function returns either the database username associated with
-the specified user ID number or the database username of the current
+The USER function returns either the database user name associated with
+the specified user ID number or the database user name of the current
 user who invoked the function. The current user
 
 is the authenticated user who started the session. That database
-username is used for authorization of SQL statements in the current
+user name is used for authorization of SQL statements in the current
 session.
 
 ```
@@ -7598,7 +7598,7 @@ USER [(user-id)]
 
 * `_user-id_`
 +
-is the 32-bit number associated with a database username.
+is the 32-bit number associated with a database user name.
 +
 The USER function is similar to the <<authname_function,AUTHNAME Function>>
 and the <<current_user_function,CURRENT USER Function>>.
@@ -7612,7 +7612,7 @@ and the <<current_user_function,CURRENT USER Function>>.
 [[examples_of_user]]
 === Examples of USER
 
-* This example shows the database username of the current user who is
+* This example shows the database user name of the current user who is
 logged in to the session:
 +
 ```
@@ -7626,7 +7626,7 @@ TSHAW
 ```
 
 <<<
-* This example shows the database username associated with the user ID number, 33333:
+* This example shows the database user name associated with the user ID number, 33333:
 +
 ```
 SELECT USER (33333) FROM (values(1)) x(a);
@@ -7661,7 +7661,7 @@ If DISTINCT is specified, you cannot specify _weight_.
 +
 specifies a numeric value expression that determines the values for
 which to compute the variance. _expression_ cannot contain an aggregate
-function or a subquery. The DISTINCT clause specifies that the VARIANCE
+function or a sub query. The DISTINCT clause specifies that the VARIANCE
 function operates on distinct values from the one-column table derived
 from the evaluation of _expression_.
 
@@ -7669,7 +7669,7 @@ from the evaluation of _expression_.
 +
 specifies a numeric value expression that determines the weights of the
 values for which to compute the variance. _weight_ cannot contain an
-aggregate function or a subquery. _weight_ is defined on the same table
+aggregate function or a sub query. _weight_ is defined on the same table
 as _expression_. The one-column table derived from the evaluation of
 _expression_ and the one-column table derived from the evaluation of
 _weight_ must have the same cardinality.

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/3063990d/docs/sql_reference/src/asciidoc/_chapters/sql_language_elements.adoc
----------------------------------------------------------------------
diff --git a/docs/sql_reference/src/asciidoc/_chapters/sql_language_elements.adoc b/docs/sql_reference/src/asciidoc/_chapters/sql_language_elements.adoc
index b8474ae..3a51658 100644
--- a/docs/sql_reference/src/asciidoc/_chapters/sql_language_elements.adoc
+++ b/docs/sql_reference/src/asciidoc/_chapters/sql_language_elements.adoc
@@ -40,11 +40,11 @@ or delimited case-insensitive identifier that can have a maximum of 128 characte
 Internally, the authorization ID is associated with a 32-bit number that the database generates and uses for
 efficient access and storage.
 
-All authorization IDs share the same namespace. An authorization ID can be a database username or a role name.
+All authorization IDs share the same name space. An authorization ID can be a database user name or a role name.
 Therefore, a database user and a role cannot share the same name.
 
 An authorization ID can be the PUBLIC authorization ID, which represents all present and future authorization IDs.
-An authorization ID cannot be SYSTEM, which is the implicit grantor of privileges to the creator of bjects.
+An authorization ID cannot be SYSTEM, which is the implicit grantor of privileges to the creator of objects.
 
 [[character_sets]]
 == Character Sets
@@ -171,7 +171,7 @@ For more information on Trafodion SQL commands, see <<create_table_statement,CRE
 
 When you create a constraint, you can specify a name for it or allow a name to be generated by Trafodion SQL.
 You can optionally specify both column and table constraint names. Constraint names are ANSI logical names.
-See <<database_object_names,Database Object Names>>. Constraint names are in the same namespace as tables and
+See <<database_object_names,Database Object Names>>. Constraint names are in the same name space as tables and
 views, so a constraint name cannot have the same name s a table or view.
 
 The name you specify can be fully qualified or not. If you specify the schema parts of the name, they must match
@@ -185,7 +185,7 @@ system-generated unique identifier.
 [[correlation_names]]
 == Correlation Names
 
-A correlation name is a name you can associate with a table reference that is a table, view, or subquery in a SELECT
+A correlation name is a name you can associate with a table reference that is a table, view, or sub query in a SELECT
 statement to:
 
 * Distinguish a table or view from another table or view referred to in a statement
@@ -235,7 +235,7 @@ WHERE orders.custnum = c.custnum AND orders.custnum = 543;
 [[database_objects]]
 == Database Objects
 
-A database object is an SQL entity that exists in a namespace. SQL statements can access Trafodion SQL database objects.
+A database object is an SQL entity that exists in a name space. SQL statements can access Trafodion SQL database objects.
 The subsections listed below describe these Trafodion SQL database objects.
 
 * <<constraints,Constraints>>
@@ -288,7 +288,7 @@ correlation name.
 Trafodion SQL objects are organized in a hierarchical manner. Database objects exist in schemas, which are themselves
 contained in a catalog called TRAFODION. A catalog is a collection of schemas. Schema names must be unique within the catalog.
 
-Multiple objects with the same name can exist provided that each belongs to a different namespace. Trafodion SQL supports these
+Multiple objects with the same name can exist provided that each belongs to a different name space. Trafodion SQL supports these
 namespaces:
 
 * Index
@@ -297,7 +297,7 @@ namespaces:
 * Schema label
 * Table value object (table, view, constraint)
 
-Objects in one schema can refer to objects in a different schema. Objects of a given namespace are required to have
+Objects in one schema can refer to objects in a different schema. Objects of a given name space are required to have
 unique names within a given schema.
 
 <<<
@@ -387,7 +387,7 @@ FRACTION in 4 bytes +
 | | TIME                         | Time of day, 24 hour clock, no time precision. Format as HH:MM:SS; actual database storage size is 3 bytes
 | | TIME (with time precision)   | Time of day, 24 hour clock, with time precision | Format as HH:MM:SS.FFFFFF; actual database storage size is 7 bytes
 | | TIMESTAMP                    | Point in time, no time precision | Format as YYYY-MM-DD HH:MM:SS; actual database storage size is 7 bytes
-| | TIMESTAMP (with time precision) Point in time, with time precision | Format as YYYY-MM-DD HH:MM:SS.FFFFFF; actual database storage size is 1b ytes
+| | TIMESTAMP (with time precision) Point in time, with time precision | Format as YYYY-MM-DD HH:MM:SS.FFFFFF; actual database storage size is 1 byte
 | Interval | INTERVAL | Duration of time; value is in the YEAR/MONTH range or the DAY/HOUR/MINUTE/YEAR/SECOND/FRACTION range
 | YEAR no constraint^6^ +
 MONTH 0-1 +
@@ -716,9 +716,9 @@ the Gregorian calendar and a 24-hour clock in local civil time (LCT). A
 datetime item can represent a date, a time, or a date and time.
 
 When a numeric value is added to or subtracted from a date type, the
-numeric value is automatically CASTed to an INTERVAL DAY value. When a
+numeric value is automatically casted to an INTERVAL DAY value. When a
 numeric value is added to or subtracted from a time type or a timestamp
-type, the numeric value is automatically CASTed to an INTERVAL SECOND
+type, the numeric value is automatically casted to an INTERVAL SECOND
 value. For information on CAST, see <<cast
 expression,CAST
 Expression>>.
@@ -1084,7 +1084,7 @@ expression.
 A value expression can be a character string literal, a numeric literal,
 a dynamic parameter, or a column name that specifies the value of the
 column in a row of a table. A value expression can also include
-functions and scalar subqueries.
+functions and scalar sub queries.
 
 <<<
 [[character_value_expressions]]
@@ -1123,7 +1123,7 @@ Character (or string) value expressions are built from operands that can be:
 * Character string functions
 * Column references with character values
 * Dynamic parameters
-* Aggregate functions, sequence functions, scalar subqueries, CASE expressions, or CAST expressions that return character values
+* Aggregate functions, sequence functions, scalar sub queries, CASE expressions, or CAST expressions that return character values
 
 <<<
 [[examples_of_character_value_expressions]]
@@ -1214,7 +1214,7 @@ Datetime value expressions are built from operands that can be:
 * Column references with datetime or interval values
 * Dynamic parameters
 * Datetime or interval value functions
-* Any aggregate functions, sequence functions, scalar subqueries, CASE
+* Any aggregate functions, sequence functions, scalar sub queries, CASE
 expressions, or CAST expressions that return datetime or interval values
 
 [[considerations_for_datetime_value_expressions]]
@@ -1265,9 +1265,9 @@ a datetime value expression only in these combinations:
 
 
 When a numeric value is added to or subtracted from a DATE type, the
-numeric value is automatically CASTed to an INTERVAL DAY value. When a
+numeric value is automatically casted to an INTERVAL DAY value. When a
 numeric value is added to or subtracted from a time type or a timestamp
-type, the numeric value is automatically CASTed to an INTERVAL SECOND
+type, the numeric value is automatically casted to an INTERVAL SECOND
 value. For information on CAST, see <<cast expression,CAST Expression>>.
 For more information on INTERVALS, see 
 <<interval_value_expressions,Interval Value Expressions>>
@@ -1447,7 +1447,7 @@ Interval value expressions are built from operands that can be:
 * Column references with datetime or interval values
 * Dynamic parameters
 * Datetime or interval value functions
-* Aggregate functions, sequence functions, scalar subqueries, CASE expressions, or CAST expressions that return interval values
+* Aggregate functions, sequence functions, scalar sub queries, CASE expressions, or CAST expressions that return interval values
 
 
 For _interval-term_, _datetime-expression_, and _datetime-primary_, see <<datetime_value_[expressions,Datetime Value Expressions>>.
@@ -1685,7 +1685,7 @@ built from operands that can be:
 * Column references with numeric values
 * Dynamic parameters
 * Numeric value functions
-* Aggregate functions, sequence functions, scalar subqueries, CASE expressions, or CAST expressions that return numeric values
+* Aggregate functions, sequence functions, scalar sub queries, CASE expressions, or CAST expressions that return numeric values
 
 <<<
 [[considerations_for_numeric_value_expressions]]
@@ -1795,7 +1795,7 @@ These are examples of numeric value expressions:
 SQL identifiers are names used to identify tables, views, columns, and
 other SQL entities. The two types of identifiers are regular and
 delimited. A delimited identifier is enclosed in double quotes (").
-Case-insensitive delimited identifiers are used only for usernames and
+Case-insensitive delimited identifiers are used only for user names and
 role names. Either regular, delimited, or case-sensitive delimited
 identifiers can contain up to 128 characters.
 
@@ -1815,13 +1815,13 @@ quote characters (") and consist of alphanumeric characters, including
 the underscore character (_) or a dash (-). Unlike regular identifiers,
 delimited identifiers are case-sensitive. Trafodion SQL does not support
 spaces or special characters in delimited identifiers given the
-constraints of the underlying HBase filesystem. You can use reserved
+constraints of the underlying HBase file system. You can use reserved
 words as delimited identifiers.
 
 [[case_insensitive_delimited_identifiers]]
 === Case-Insensitive Delimited Identifiers
 
-Case-insensitive delimited identifiers, which are used for usernames and
+Case-insensitive delimited identifiers, which are used for user names and
 roles, are character strings that appear within double quote characters
 (") and consist of alphanumeric characters
 (A through Z and a through z), digits (0 through 9), underscores (_), dashes (-), periods (.), at
@@ -1893,7 +1893,7 @@ Each row in a Trafodion SQL index contains:
 * The clustering key of the underlying table (the user-defined
 clustering key)
 
-An index name is an SQL identifier. Indexes have their own namespace
+An index name is an SQL identifier. Indexes have their own name space
 within a schema, so an index name might be the same as a table or
 constraint name. However, no two indexes in a schema can have the same
 name.
@@ -1944,7 +1944,7 @@ table rows. Each row in a Trafodion SQL index contains:
 * The clustering (primary) key of the underlying table (the user-defined clustering key)
 
 
-For a nonunique index, the clustering key of the index is composed of
+For a non-unique index, the clustering key of the index is composed of
 both items. The clustering key cannot exceed 2048 bytes. Because the
 clustering key includes all the columns in the table, each row is also
 limited to 2048 bytes.
@@ -2468,7 +2468,7 @@ clauses are:
 |===
 | DISTINCT | Nulls are considered duplicates; therefore, a result has at most one null.
 | GROUP BY | The result has at most one null group.
-| ORDER BY | Nulls are considered greater than nonnull values.
+| ORDER BY | Nulls are considered greater than non-null values.
 |===
 
 [[null-and-expression-evaluation-comparison]]
@@ -2503,7 +2503,7 @@ rows from tables or views.
 | <<between_predicate,BETWEEN Predicate>> | Determines whether a sequence of values is within a range of sequences of values.
 | <<comparison_predicates,Comparison Predicates>> +
 ( =, <>, <, >, <&#61;, >&#61;  ) | Compares the values of sequences of expressions, or compares the values
-of sequences of row values that are the result of row subqueries.
+of sequences of row values that are the result of row sub queries.
 | <<exists_predicate,EXISTS Predicate>> | Determines whether any rows are selected by a subquery. If the subquery
 finds at least one row that satisfies its search condition, the
 predicate evaluates to true. Otherwise, if the result table of the
@@ -2658,7 +2658,7 @@ EMPNUM FIRST_NAME      LAST_NAME
 
 A comparison predicate compares the values of sequences of expressions,
 or the values of sequences of row values that are the result of row
-subqueries.
+sub queries.
 
 ```
 row-value-constructor comparison-op row-value-constructor
@@ -2720,7 +2720,7 @@ values with the same ordinal position in the two lists.) See
 
 Trafodion SQL determines whether a relationship is true or false by
 comparing values in corresponding positions in sequence, until it finds
-the first nonequal pair.
+the first non-equal pair.
 
 You cannot use a comparison predicate in a WHERE or HAVING clause to
 compare row value constructors when the value expressions in one row
@@ -2734,7 +2734,7 @@ X=(X1,X2,...,Xn), Y=(Y1,Y2,...,Yn).
 
 Predicate X=Y is true if for all i=1,&#8230;,n: Xi=Yi. For this predicate,
 Trafodion SQL must look through all values. Predicate X = Y is false if
-for some i Xi<>Yi. When SQL finds nonequal components, it stops and does
+for some i Xi<>Yi. When SQL finds non-equal components, it stops and does
 not look at remaining components.
 
 Predicate X<>Y is true if X=Y is false. If X1<>Y1, Trafodion SQL does
@@ -2762,7 +2762,7 @@ if all components are equal, or X=Y.
 
 Predicate X<&#61;Y is true if X<Y is true or X=Y is true. In this scenario,
 Trafodion SQL might need to look through all components and return true
-if they are all equal. It stops at the first nonequal components,
+if they are all equal. It stops at the first non-equal components,
 Xm<>Ym. If Xm<Ym, the predicate is true. Otherwise, it is false.
 
 [[comparing_character_data]]
@@ -2800,8 +2800,8 @@ values must be both year-month intervals or both day-time intervals.
 [[comparing_multiple_values]]
 ===== Comparing Multiple Values
 
-Use multivalue predicates whenever possible; they are generally more
-efficient than equivalent conditions without multivalue predicates.
+Use multi-value predicates whenever possible; they are generally more
+efficient than equivalent conditions without multi-value predicates.
 
 [[examples_of_comparison_predicates]]
 ==== Examples of Comparison Predicates
@@ -2842,7 +2842,7 @@ same last name, alphabetically by first name:
 +
 REEVES, ANNE meets this criteria, but MOSS, ANNE does not.
 +
-This multivalue predicate is equivalent to this condition with three
+This multi-value predicate is equivalent to this condition with three
 comparison predicates:
 +
 ```
@@ -3715,7 +3715,7 @@ reconnect to a session to see the updated set of privileges. For more
 information about privileges, see <<privileges,Privileges>>.
 
 A role name is an authorization ID. A role name cannot be identical to a
-registered database username. For more information, see
+registered database user name. For more information, see
 <<authorization_ids,Authorization IDs>>.
 
 To manage roles, see these SQL statements:
@@ -3752,7 +3752,7 @@ DROP SCHEMA statement. For more information, see the
 <<drop_schema_statement,DROP SCHEMA Statement>>.
 
 <<<
-[[search_condiation]]
+[[search_condition]]
 == Search Condition
 
 A search condition is used to choose rows from tables or views,
@@ -3947,7 +3947,7 @@ WHERE y = 2))
 The maximum level of nested subqueries might depend on:
 
 * The complexity of the subqueries.
-* Whether the subquery is correlated and if so, whether it can be unnested.
+* Whether the subquery is correlated and if so, whether it can be un-nested.
 * Amount of available memory.
 
 Other factors may affect the maximum level of subqueries.
@@ -4061,7 +4061,7 @@ or both, from one or more base tables or other views.
 === SQL Views
 
 A view’s name must be unique among table and view names within the
-schema that contains it. Single table views can be updatable. Multitable
+schema that contains it. Single table views can be updatable. Multi-table
 views are not updatable.
 
 For information about SQL views, see <<create_view_statement,CREATE VIEW Statement>>