You are viewing a plain text version of this content. The canonical link for it is here.
Posted to derby-commits@db.apache.org by rh...@apache.org on 2016/07/17 17:11:39 UTC

svn commit: r1753091 [4/5] - in /db/derby/code/trunk/java: client/org/apache/derby/client/am/ client/org/apache/derby/client/net/ drda/org/apache/derby/drda/ drda/org/apache/derby/impl/drda/ drda/org/apache/derby/mbeans/drda/ engine/org/apache/derby/ca...

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/PredicateList.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/PredicateList.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/PredicateList.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/PredicateList.java Sun Jul 17 17:11:36 2016
@@ -1786,7 +1786,7 @@ class PredicateList extends QueryTreeNod
 	/**
 	 * Perform transitive closure on join clauses.  For each table in the query,
 	 * we build a list of equijoin clauses of the form:
-	 *		<ColumnReference> <=> <ColumnReference>
+	 *		ColumnReference relop ColumnReference
 	 * Each join clause is put on 2 lists since it joins 2 tables.
 	 * 
 	 * We then walk the array of lists.  We first walk it as the outer list.  

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/RelationalOperator.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/RelationalOperator.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/RelationalOperator.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/RelationalOperator.java Sun Jul 17 17:11:36 2016
@@ -259,9 +259,9 @@ interface RelationalOperator
 
 	/**
 	 * Generate an expression that evaluates to true if the result of the
-	 * comparison should be negated.  For example, col > 1 generates
-	 * a comparison operator of <= and a negation of true, while col < 1
-	 * generates a comparison operator of < and a negation of false.
+	 * comparison should be negated.  For example, col &gt; 1 generates
+	 * a comparison operator of &lt;= and a negation of true, while col &lt; 1
+	 * generates a comparison operator of &lt; and a negation of false.
 	 *
 	 * @param mb	The method the generated code is to go into
 	 * @param optTable	The Optimizable table the Qualifier will qualify

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ResultColumnList.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ResultColumnList.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ResultColumnList.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ResultColumnList.java Sun Jul 17 17:11:36 2016
@@ -2469,7 +2469,7 @@ class ResultColumnList extends QueryTree
     }
 
 	/**
-	 * Do the 2 RCLs have the same type & length.
+	 * Do the 2 RCLs have the same type and length.
 	 * This is useful for UNIONs when deciding whether a NormalizeResultSet is required.
 	 *
 	 * @param otherRCL	The other RCL.

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ResultSetNode.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ResultSetNode.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ResultSetNode.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ResultSetNode.java Sun Jul 17 17:11:36 2016
@@ -906,8 +906,8 @@ public abstract class ResultSetNode exte
 	 * @param target            the target node for the insert
 	 * @param inOrder           are source cols in same order as target cols?
 	 * @param colMap			int array representation of correspondence between
-	 *							RCLs - colmap[i] = -1 -> missing in current RCL
-	 *								   colmap[i] = j -> targetRCL(i) <-> thisRCL(j+1)
+	 *							RCLs - colmap[i] = -1 -&gt; missing in current RCL
+	 *								   colmap[i] = j -&gt; targetRCL(i) &lt;-&gt; thisRCL(j+1)
 	 * @return a node that replaces this node and whose RCL matches the target
 	 * RCL. May return this node if no changes to the RCL are needed, or if the
 	 * RCL is modified in-place.
@@ -1836,7 +1836,7 @@ public abstract class ResultSetNode exte
 	/**
 	 * Count the number of distinct aggregates in the list.
 	 * By 'distinct' we mean aggregates of the form:
-	 *	<UL><I>SELECT MAX(DISTINCT x) FROM T<\I><\UL>
+	 *	<I>SELECT MAX(DISTINCT x) FROM T</I>
 	 *
 	 * @return number of aggregates
 	 */

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/SubqueryNode.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/SubqueryNode.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/SubqueryNode.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/SubqueryNode.java Sun Jul 17 17:11:36 2016
@@ -1315,7 +1315,7 @@ class SubqueryNode extends ValueNode
 	 *		o  The operator in the new predicate that is added to the subquery
 	 *		   will be a BinaryAllOperatorNode whose bcoNodeType corresponds to 
 	 *		   the negation of the operator that modifies the ALL.
-	 *		   (eg, <> for = ALL, with <> for NOT IN.)
+	 *		   (eg, &lt;&gt; for = ALL, with &lt;&gt; for NOT IN.)
 	 *
 	 * NOTE: This method is called after the underlying subquery has been
 	 * preprocessed, so we build a new Predicate, not just a new expression.

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ValueNode.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ValueNode.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ValueNode.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ValueNode.java Sun Jul 17 17:11:36 2016
@@ -342,7 +342,7 @@ public abstract class ValueNode extends
 	}
 
 	/**
-	 * Generate a SQL->Java->SQL conversion tree above the current node
+	 * Generate a SQL-&gt;Java-&gt;SQL conversion tree above the current node
 	 * and bind the new nodes individually.
 	 * This is useful when doing comparisons, built-in functions, etc. on
 	 * java types which have a direct mapping to system built-in types.
@@ -1164,7 +1164,7 @@ public abstract class ValueNode extends
 
 	/**
 	 * Returns true if this ValueNode is a relational operator. Relational
-	 * Operators are <, <=, =, >, >=, <> as well as IS NULL and IS NOT
+	 * Operators are &lt;, &lt;=, =, &gt;, &gt;=, &lt;&gt; as well as IS NULL and IS NOT
 	 * NULL. This is the preferred way of figuring out if a ValueNode is
 	 * relational or not. 
 	 * @see RelationalOperator

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ValueNodeList.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ValueNodeList.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ValueNodeList.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ValueNodeList.java Sun Jul 17 17:11:36 2016
@@ -86,7 +86,7 @@ class ValueNodeList extends QueryTreeNod
 
 
 	/**
-	 * Generate a SQL->Java->SQL conversion tree any node in the list
+	 * Generate a SQL-&gt;Java-&gt;SQL conversion tree any node in the list
 	 * which is not a system built-in type.
 	 * This is useful when doing comparisons, built-in functions, etc. on
 	 * java types which have a direct mapping to system built-in types.

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/conn/GenericLanguageConnectionContext.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/conn/GenericLanguageConnectionContext.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/conn/GenericLanguageConnectionContext.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/conn/GenericLanguageConnectionContext.java Sun Jul 17 17:11:36 2016
@@ -2884,7 +2884,7 @@ public class GenericLanguageConnectionCo
     /**
       * Reports how many statement levels deep we are.
       *
-      * @return a statement level >= OUTERMOST_STATEMENT
+      * @return a statement level &gt;= OUTERMOST_STATEMENT
       */
     public  int     getStatementDepth()
     { return statementDepth; }

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/conn/GenericStatementContext.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/conn/GenericStatementContext.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/conn/GenericStatementContext.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/conn/GenericStatementContext.java Sun Jul 17 17:11:36 2016
@@ -133,7 +133,7 @@ final class GenericStatementContext
      * returned to the application).
      *
      * When the StatementContext object is assigned with setInUse(),
-     * a CancelQueryTask is scheduled if a timeout > 0 has been set.
+     * a CancelQueryTask is scheduled if a timeout &gt; 0 has been set.
      */
     private static class CancelQueryTask
         extends

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/conn/TempTableInfo.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/conn/TempTableInfo.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/conn/TempTableInfo.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/conn/TempTableInfo.java Sun Jul 17 17:11:36 2016
@@ -142,7 +142,7 @@ At the time of rollback
 	  	declare temp table t2("declared in savepoint level" = 0, "dropped in savepoint level"=-1)
 		  rollback tran
         (temp table t2 will be removed from list of tables and conglomerate associated with it will be dropped)
-    And if table was dropped in this unit of work ie "dropped in savepoint level" >= "current savepoint level"
+    And if table was dropped in this unit of work ie "dropped in savepoint level" &gt;= "current savepoint level"
       Then we should remove the table from the list of temp tables
 		  eg
 		  start tran ("current savepoint level = 0)

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/AlterTableConstantAction.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/AlterTableConstantAction.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/AlterTableConstantAction.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/AlterTableConstantAction.java Sun Jul 17 17:11:36 2016
@@ -3421,10 +3421,10 @@ class AlterTableConstantAction extends D
 
 	/**
 	 * Return the "semi" row count of a table.  We are only interested in
-	 * whether the table has 0, 1 or > 1 rows.
+	 * whether the table has 0, 1 or &gt; 1 rows.
 	 *
 	 *
-	 * @return Number of rows (0, 1 or > 1) in table.
+	 * @return Number of rows (0, 1 or &gt; 1) in table.
 	 *
 	 * @exception StandardException		Thrown on failure
 	 */

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/DMLVTIResultSet.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/DMLVTIResultSet.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/DMLVTIResultSet.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/DMLVTIResultSet.java Sun Jul 17 17:11:36 2016
@@ -39,7 +39,7 @@ import java.sql.PreparedStatement;
 import java.sql.ResultSet;
 
 /**
- * Base class for Insert, Delete & UpdateVTIResultSet
+ * Base class for Insert, Delete and UpdateVTIResultSet
  */
 abstract class DMLVTIResultSet extends DMLWriteResultSet
 {

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/GenericConstantActionFactory.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/GenericConstantActionFactory.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/GenericConstantActionFactory.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/GenericConstantActionFactory.java Sun Jul 17 17:11:36 2016
@@ -484,7 +484,7 @@ public class GenericConstantActionFactor
 	 *  @param numColumns			Number of columns to read
 	 *  @param dependencyId			UUID for dependency system
 	 *  @param baseRowReadList      Map of columns read in.  1 based.
-	 *	@param baseRowReadMap		BaseRowReadMap[heapColId]->ReadRowColumnId.
+	 *	@param baseRowReadMap		BaseRowReadMap[heapColId]-&gt;ReadRowColumnId.
      *  @param streamStorableHeapColIds Null for non rep. (0 based)
 	 *  @param singleRowSource		Whether or not source is a single row source
 	 *  @param underMerge   True if this is an action of a MERGE statement.

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/InternalTriggerExecutionContext.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/InternalTriggerExecutionContext.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/InternalTriggerExecutionContext.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/InternalTriggerExecutionContext.java Sun Jul 17 17:11:36 2016
@@ -107,7 +107,7 @@ class InternalTriggerExecutionContext
     private Vector<AutoincrementCounter> aiCounters;
 	
 	/**
-     * aiHT is a hash table of auto increment <key, value> pairs. This is used
+     * aiHT is a hash table of auto increment (key, value) pairs. This is used
      * for auto increment values generated by the trigger.
 	 */
     @SuppressWarnings("UseOfObsoleteCollectionType")

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/JarUtil.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/JarUtil.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/JarUtil.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/JarUtil.java Sun Jul 17 17:11:36 2016
@@ -464,7 +464,7 @@ public class JarUtil
     }
 
     /**
-     * Upgrade code: upgrade one jar file to new style (>= 10.9)
+     * Upgrade code: upgrade one jar file to new style (&gt;= 10.9)
      *
      * @param tc transaction controller
      * @param fid the jar file to be upgraded

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/RowChangerImpl.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/RowChangerImpl.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/RowChangerImpl.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/RowChangerImpl.java Sun Jul 17 17:11:36 2016
@@ -108,7 +108,7 @@ class RowChangerImpl	implements	RowChang
 		to be updated.  Only used for updates
 	  @param tc the transaction controller
 	  @param baseRowReadList bit set of columns read from base row. 1 based.
-	  @param baseRowReadMap BaseRowReadMap[heapColId]->ReadRowColumnId. (0 based)
+	  @param baseRowReadMap BaseRowReadMap[heapColId]-&gt;ReadRowColumnId. (0 based)
 	  @exception StandardException		Thrown on error
 	  */
 	public RowChangerImpl(
@@ -272,7 +272,7 @@ class RowChangerImpl	implements	RowChang
 	  Open this RowChanger to avoid fixing indexes that do not change
 	  during update operations. 
 
-	  @param fixOnUpdate fixOnUpdat[ix] == true ==> fix index 'ix' on
+	  @param fixOnUpdate fixOnUpdat[ix] == true ==&gt; fix index 'ix' on
 	  an update operation.
 	  @param lockMode	The lock mode to use
 							(row or table, see TransactionController)

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/RowUtil.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/RowUtil.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/RowUtil.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/RowUtil.java Sun Jul 17 17:11:36 2016
@@ -169,7 +169,7 @@ public class RowUtil
 	  Copy references for an ExecRow's columns to another ExecRow.
 	  For copying from a compact array to a reconstituted array.
 	  E.g. if positions = {2, 4}, and from = {666, 777} then
-	  to => {null, 666, null, 777}.  Will only go as far as to.getArray().length.
+	  to =&gt; {null, 666, null, 777}.  Will only go as far as to.getArray().length.
 
 	  @param to Place the column references here.  Sparse array
 	  @param from Get the column references from here. Compact array
@@ -400,7 +400,7 @@ public class RowUtil
 	}	
 	/**
 	 * Shift a FormatableBitSet N bits toward the zero end.
-	 * e.g. shift({2,4}) -> {1,3}.
+	 * e.g. shift({2,4}) -&gt; {1,3}.
 	 *
 	 * @param bitSet the bit set
 	 * @param n	the number of bits to shift

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/TableScanResultSet.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/TableScanResultSet.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/TableScanResultSet.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/TableScanResultSet.java Sun Jul 17 17:11:36 2016
@@ -48,7 +48,7 @@ import org.apache.derby.iapi.types.RowLo
  * the table's rows satisfying the filter as a result set.
  *
  * There are several things we could do during object
- * construction that are done in the open & next calls, to
+ * construction that are done in the open and next calls, to
  * improve performance.
  *
  */

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/TemporaryRowHolderResultSet.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/TemporaryRowHolderResultSet.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/TemporaryRowHolderResultSet.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/TemporaryRowHolderResultSet.java Sun Jul 17 17:11:36 2016
@@ -1193,7 +1193,7 @@ class TemporaryRowHolderResultSet implem
 	  not in the partial row if validColumns.get(N) returns false.  Column N is
 	  in the partial row if validColumns.get(N) returns true.  If column N is
 	  in the partial row then it maps to DataValueDescriptor[M] where M is the
-      count of calls to validColumns.get(i) that return true where i < N.  If
+      count of calls to validColumns.get(i) that return true where i &lt; N.  If
 	  DataValueDescriptor.length is greater than the number of columns 
       indicated by validColumns the extra entries are ignored.  
 	*/

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/UpdateConstantAction.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/UpdateConstantAction.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/UpdateConstantAction.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/UpdateConstantAction.java Sun Jul 17 17:11:36 2016
@@ -111,7 +111,7 @@ public class UpdateConstantAction extend
 	 *	@param triggerInfo	Array of structures containing trigger info, 
 	 *						if any (may be null)
 	 *  @param baseRowReadList Map of columns read in.  1 based.
-	 *  @param baseRowReadMap BaseRowReadMap[heapColId]->ReadRowColumnId. (0 based)
+	 *  @param baseRowReadMap BaseRowReadMap[heapColId]-&gt;ReadRowColumnId. (0 based)
      *  @param streamStorableHeapColIds Null for non rep. (0 based)
 	 *  @param numColumns	Number of columns being read.
 	 *  @param positionedUpdate	is this a positioned update

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/WriteCursorConstantAction.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/WriteCursorConstantAction.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/WriteCursorConstantAction.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/WriteCursorConstantAction.java Sun Jul 17 17:11:36 2016
@@ -110,7 +110,7 @@ abstract	class WriteCursorConstantAction
 	 *	@param lockMode		The lock mode to use on the target table
 	 *	@param fkInfo	Structure containing foreign key info, if any (may be null)
 	 *	@param triggerInfo	Structure containing trigger info, if any (may be null)
-	 *  @param baseRowReadMap	BaseRowReadMap[heapColId]->ReadRowColumnId. (0 based)
+	 *  @param baseRowReadMap	BaseRowReadMap[heapColId]-&gt;ReadRowColumnId. (0 based)
      *  @param streamStorableHeapColIds Null for non rep. (0 based)
 	 *  @param singleRowSource		Whether or not source is a single row source
 	 *  @param underMerge   True if this action is under a MERGE statement

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/RAMTransaction.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/RAMTransaction.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/RAMTransaction.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/RAMTransaction.java Sun Jul 17 17:11:36 2016
@@ -702,7 +702,7 @@ public class RAMTransaction
      * implementation may only track this info under SanityManager.DEBUG mode.
      * If the implementation does not track the info it will return -1 (so
      * code using this call to verify that no congloms are open should check
-     * for return <= 0 rather than == 0).
+     * for return &lt;= 0 rather than == 0).
      *
      * The return value depends on the "which_to_count" parameter as follows:
      * OPEN_CONGLOMERATE  - return # of openConglomerate() calls not close()'d.

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/StorableFormatId.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/StorableFormatId.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/StorableFormatId.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/StorableFormatId.java Sun Jul 17 17:11:36 2016
@@ -259,9 +259,9 @@ public class StorableFormatId extends Da
 	 *
 	 * @param other		The Orderable to compare this one to.
 	 *
-	 * @return  <0 - this Orderable is less than other.
+	 * @return  &lt;0 - this Orderable is less than other.
 	 * 			 0 - this Orderable equals other.
-	 *			>0 - this Orderable is greater than other.
+	 *			&gt;0 - this Orderable is greater than other.
      *
      *			The code should not explicitly look for -1, or 1.
 	 *

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BTreeController.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BTreeController.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BTreeController.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BTreeController.java Sun Jul 17 17:11:36 2016
@@ -1290,7 +1290,7 @@ public class BTreeController extends Ope
      * unknown condition of the controller following a transaction ending error.
      * Use this call when closing all controllers as part of an abort of a 
      * transaction.
-     * <p)
+     * <p>
      * This call is meant to only be used internally by the Storage system,
      * clients of the storage system should use the simple close() interface.
      * <p>

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BTreeLockingPolicy.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BTreeLockingPolicy.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BTreeLockingPolicy.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BTreeLockingPolicy.java Sun Jul 17 17:11:36 2016
@@ -170,10 +170,10 @@ public interface BTreeLockingPolicy
      * Given the current latched page and slot number, lock the logically
      * previous key in the table.  There are 3 cases:
      * <p>
-     * slotnumber > 1                       - just lock (slotnumber - 1)
-     * (slotnumber == 1) && (leftmost leaf) - this is the first key in the
+     * slotnumber &gt; 1                       - just lock (slotnumber - 1)
+     * (slotnumber == 1) &amp;&amp; (leftmost leaf) - this is the first key in the
      *                                        table, so lock a "magic" FIRSTKEY.
-     * (slotnumber == 1) && !(leftmost leaf)- traverse left in the tree looking
+     * (slotnumber == 1) &amp;&amp; !(leftmost leaf)- traverse left in the tree looking
      *                                        for a previous key.
      * <p>
      * On successful return from this routine appropriate locking will have

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BTreeScan.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BTreeScan.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BTreeScan.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BTreeScan.java Sun Jul 17 17:11:36 2016
@@ -1621,7 +1621,7 @@ public abstract class BTreeScan extends
      * return how many rows were filled in.  If fetchNextSet() returns 0
      * then the scan is complete, (ie. the scan is in the same state as if
      * fetchNext() had returned false).  If the scan is not complete then
-     * fetchNext() will return (1 <= row_count <= N).
+     * fetchNext() will return (1 &lt;= row_count &lt;= N).
      * <p>
      * The current position of the scan is undefined if fetchNextSet()
      * is used (ie. mixing fetch()/fetchNext() and fetchNextSet() calls
@@ -1664,10 +1664,10 @@ public abstract class BTreeScan extends
      * @return The number of qualifying rows found and copied into the 
      *         provided array of rows.  If 0 then the scan is complete, 
      *         otherwise the return value will be: 
-     *         1 <= row_count <= row_array.length
+     *         1 &lt;= row_count &lt;= row_array.length
      *
      * @param row_array         The array of rows to copy rows into.  
-     *                          row_array[].length must >= 1.  This routine
+     *                          row_array[].length must &gt;= 1.  This routine
      *                          assumes that all entries in the array 
      *                          contain complete template rows.
      *

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BranchControlRow.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BranchControlRow.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BranchControlRow.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/BranchControlRow.java Sun Jul 17 17:11:36 2016
@@ -1316,7 +1316,7 @@ public class BranchControlRow extends Co
 	 ** pain, and will slow down applications.  It's only
 	 ** needed for consistency checks, so we may want to
 	 ** have implementations that don't bother to maintain it.
-     ** <P)
+     ** <P>
      ** This
 	 **/
 	private void fixChildrensParents(

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/ControlRow.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/ControlRow.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/ControlRow.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/btree/ControlRow.java Sun Jul 17 17:11:36 2016
@@ -923,7 +923,7 @@ public abstract class ControlRow impleme
     object allocations occur during the execution of this method.
     <P>
     This method performs a binary search on the page and finds the entry i on
-    the page such that entry[i] <= key < entry[i+1].  The result of the search
+    the page such that entry[i] &lt;= key &lt; entry[i+1].  The result of the search
     is filled into the passed in params structure.
 
     @param params the parameters of the search
@@ -1364,9 +1364,9 @@ public abstract class ControlRow impleme
 	 **      the same level of this page.
 	 ** <li> This page is the left sibling of its right sibling,
 	 **      and it's the right sibling of its left sibling.
-	 ** <li> The last row on the left sibling is < the first
+	 ** <li> The last row on the left sibling is &lt; the first
 	 **      row on this page.
-	 ** <li> The first row on the right sibling is > than the
+	 ** <li> The first row on the right sibling is &gt; than the
 	 **      the last row on this page.
 	 ** </menu>
 	 ** Note that these last two are really only true if there
@@ -1407,7 +1407,7 @@ public abstract class ControlRow impleme
 
 	/**
 	 ** Check that all rows on the page are in order.  This
-	 ** means that each key is > than the previous key.
+	 ** means that each key is &gt; than the previous key.
 
     @exception StandardException Standard exception policy.
 	 **/

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/conglomerate/GenericConglomerate.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/conglomerate/GenericConglomerate.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/conglomerate/GenericConglomerate.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/conglomerate/GenericConglomerate.java Sun Jul 17 17:11:36 2016
@@ -194,9 +194,9 @@ public abstract class GenericConglomerat
 	 *
 	 * @param other		The Orderable to compare this one to.
 	 *
-	 * @return  <0 - this Orderable is less than other.
+	 * @return  &lt;0 - this Orderable is less than other.
 	 * 			 0 - this Orderable equals other.
-	 *			>0 - this Orderable is greater than other.
+	 *			&gt;0 - this Orderable is greater than other.
      *
      *			The code should not explicitly look for -1, or 1.
 	 *

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/conglomerate/GenericConglomerateController.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/conglomerate/GenericConglomerateController.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/conglomerate/GenericConglomerateController.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/access/conglomerate/GenericConglomerateController.java Sun Jul 17 17:11:36 2016
@@ -103,7 +103,7 @@ public abstract class GenericConglomerat
      * unknown condition of the controller following a transaction ending error.
      * Use this call when closing all controllers as part of an abort of a 
      * transaction.
-     * <p)
+     * <p>
      * This call is meant to only be used internally by the Storage system,
      * clients of the storage system should use the simple close() interface.
      * <p>

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/AllocPage.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/AllocPage.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/AllocPage.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/AllocPage.java Sun Jul 17 17:11:36 2016
@@ -82,7 +82,7 @@ import org.apache.derby.iapi.services.io
 	(non-first) alloc page have N == 0.
 
 	<PRE>
-                             <-- borrowed ->
+                             [ borrowed ]
 	+----------+-------------+---+---------+-------------------+-------------+--------+
 	| FormatId | page header | N | N bytes | alloc extend rows | slot offset |checksum|
 	+----------+-------------+---+---------+-------------------+-------------+--------+
@@ -98,7 +98,7 @@ import org.apache.derby.iapi.services.io
 	first physical byte of the container.  Subsequent allocation pages are
 	chained via the nextAllocPageOffset.  Each allocation page is expected to
 	manage at least 1000 user pages (for 1K page size) so this chaining may not
-	be a severe performance hit.  The logical -> physical mapping of an
+	be a severe performance hit.  The logical -&gt; physical mapping of an
 	allocation page is stored in the previous allocation page.  The container
 	object will need to maintain this mapping.
 	<P>
@@ -1074,7 +1074,7 @@ public class AllocPage extends StoredPag
      *     truncated.  The next allocate looks at actual size of file as
      *     does the right thing.
      *
-     * <p)
+     * <p>
      * MT - expect Container level X lock
      *
 	 * @exception  StandardException  Standard exception policy.

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/BasePage.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/BasePage.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/BasePage.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/BasePage.java Sun Jul 17 17:11:36 2016
@@ -129,8 +129,8 @@ abstract class BasePage implements Page,
      * There are 3 latch states for a page:
      *
      * UNLATCHED - (owner == null) 
-     * PRELATCH  - (owner != null) && preLatch
-     * LATCHED   - (owner != null) && !preLatch
+     * PRELATCH  - (owner != null) &amp;&amp; preLatch
+     * LATCHED   - (owner != null) &amp;&amp; !preLatch
      *
      * A page may be "cleaned" while it is either UNLATCHED, or PRELATCH, but
      * it must wait for it to be not LATCHED.
@@ -173,7 +173,7 @@ abstract class BasePage implements Page,
 		Values for pageStatus flag 
 
 		page goes thru the following transition:
-		VALID_PAGE <-> deallocated page -> free page <-> VALID_PAGE
+		VALID_PAGE &lt;-&gt; deallocated page -&gt; free page &lt;-&gt; VALID_PAGE
 
 		deallocated and free page are both INVALID_PAGE as far as BasePage is concerned.
 		When a page is deallocated, it transitioned from VALID to INVALID.
@@ -1474,7 +1474,7 @@ abstract class BasePage implements Page,
      * Also used by access methods after undo of an insert.
      * <p>
      * Will return true if the number of non-deleted rows on the page is
-     * <= "num_non_deleted_rows".  For instance 0 means schedule reclaim
+     * &lt;= "num_non_deleted_rows".  For instance 0 means schedule reclaim
      * only if all rows are deleted, 1 if all rows but one are deleted.  
      * <p>
      * Will return true if the row just deleted is either a long row or long

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/EncryptOrDecryptData.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/EncryptOrDecryptData.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/EncryptOrDecryptData.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/EncryptOrDecryptData.java Sun Jul 17 17:11:36 2016
@@ -52,7 +52,7 @@ import java.security.PrivilegedAction;
  *       temporary file(n<cid>.dat) in the data segment itself.
  *   3. Rename the current container file (c<cid>.dat) to
  *                                         another file (o<cid>.dat)
- *   4. Rename the new encrypted version of the file (n<cid).dat) to be
+ *   4. Rename the new encrypted version of the file (n&lt;cid).dat) to be
  *                                    the current container file (c<cid>.dat).
  *   5. All the old version of  the container (o<cid>.dat) files are removed
  *      after a successful checkpoint with a new key or on a rollback.

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/OverflowInputStream.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/OverflowInputStream.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/OverflowInputStream.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/OverflowInputStream.java Sun Jul 17 17:11:36 2016
@@ -47,7 +47,7 @@ InputStream.
 Any time store fetches a long column, the value is returned as a stream.
 A long column is any column that at some point was longer than a page, so
 a long column in one table may not be long in another depending on page size.
-<p)
+<p>
 When the column is fetched a new OverflowInputStream is created and then
 the datatype's stream is set using:
  ((StreamStorable)sColumn).setStream(OverflowInputStream);

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/RAFContainer4.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/RAFContainer4.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/RAFContainer4.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/RAFContainer4.java Sun Jul 17 17:11:36 2016
@@ -565,26 +565,33 @@ class RAFContainer4 extends RAFContainer
     }
 
     /**
+     * <p>
      * This method handles what to do when, during a NIO operation we receive a
      * {@code ClosedChannelException}. Note the specialization hierarchy:
-     * <p/>
-     * {@code ClosedChannelException} -> {@code AsynchronousCloseException} ->
+     * </p>
+     * <p>
+     * {@code ClosedChannelException} -&gt; {@code AsynchronousCloseException} -&gt;
      * {@code ClosedByInterruptException}
-     * <p/>
+     * </p>
+     * <p>
      * If {@code e} is a ClosedByInterruptException, we normally start
      * container recovery, i.e. we need to reopen the random access file so we
      * get get a new interruptible channel and continue IO.
-     * <p/>
+     * </p>
+     * <p>
      * If {@code e} is a {@code AsynchronousCloseException} or a plain {@code
      * ClosedChannelException}, the behavior depends of {@code stealthMode}:
-     * <p/>
+     * </p>
+     * <p>
      * If {@code stealthMode == false}, the method will wait for
      * another thread tp finish recovering the IO channel before returning.
-     * <p/>
+     * </p>
+     * <p>
      * If {@code stealthMode == true}, the method throws {@code
      * InterruptDetectedException}, allowing retry at a higher level in the
      * code.  The reason for this is that we sometimes need to release monitors
      * on objects needed by the recovery thread.
+     * </p>
      *
      * @param e Should be an instance of {@code ClosedChannelException}.
      * @param stealthMode If {@code true}, do retry at a higher level

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/StoredPage.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/StoredPage.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/StoredPage.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/StoredPage.java Sun Jul 17 17:11:36 2016
@@ -135,7 +135,7 @@ import org.apache.derby.iapi.util.ByteAr
   their slots are also moved down.
   A page has no empty slot (an empty page has no slot)
 
-   <BR><B>Record & Field Format</B>
+   <BR><B>Record and Field Format</B>
 
   Record Header format is defined in the StoredRecordHeader class.
   
@@ -1288,7 +1288,7 @@ public class StoredPage extends CachedPa
      * Is this page unfilled?
      * <p>
      * Returns true if page is relatively unfilled, 
-     * which means the page is < 1/2 full and has enough space to insert an
+     * which means the page is &lt; 1/2 full and has enough space to insert an
      * "average" sized row onto the page.
      * <p>
      *
@@ -7683,7 +7683,7 @@ public class StoredPage extends CachedPa
         This method ensures there is enough room to replace the
         old data of length oldLength at the given offset, with the new data of length
         newLength. This method does put any new data on the page, it moves old data around
-        and zeros out any old data when newLength < oldLength. This method does
+        and zeros out any old data when newLength &lt; oldLength. This method does
         update the information in the slot table.
 
         The passed in offset is the correct place to put the data

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/StoredRecordHeader.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/StoredRecordHeader.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/StoredRecordHeader.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/data/StoredRecordHeader.java Sun Jul 17 17:11:36 2016
@@ -78,7 +78,7 @@ public final class StoredRecordHeader
      * RECORD_VALID_MASK        - A mask of valid bits that can be set 
      *                            currently, such that the following assert can
      *                            be made: 
-     *                              ASSERT((status & ~RECORD_VALID_MASK) == 0))
+     *                              ASSERT((status &amp; ~RECORD_VALID_MASK) == 0))
      **/
     private static final byte RECORD_DELETED = 0x01;
     private static final byte RECORD_OVERFLOW = 0x02;

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/log/LogAccessFile.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/log/LogAccessFile.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/log/LogAccessFile.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/log/LogAccessFile.java Sun Jul 17 17:11:36 2016
@@ -59,7 +59,7 @@ import org.apache.derby.iapi.util.Interr
     the buffers. 
 
     Log Buffers are used in circular fashion, each buffer moves through following stages: 
-	freeBuffers --> dirtyBuffers --> freeBuffers. Movement of buffers from one
+	freeBuffers --&gt; dirtyBuffers --&gt; freeBuffers. Movement of buffers from one
     stage to 	another stage is synchronized using	the object(this) of this class. 
 
 	A Checksum log record that has the checksum value for the data that is

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/log/LogCounter.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/log/LogCounter.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/log/LogCounter.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/log/LogCounter.java Sun Jul 17 17:11:36 2016
@@ -39,7 +39,7 @@ import java.io.ObjectOutput;
 	hence the getValueAsLong() method. Outside the LogFactory the instant
 	is passed around as a LogCounter (through its LogInstant interface).
 
-	The way the long is encoded is such that < == > correctly tells if
+	The way the long is encoded is such that &lt; == &gt; correctly tells if
 	one log instant is lessThan, equals or greater than another.
 
 */

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/log/LogToFile.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/log/LogToFile.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/log/LogToFile.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/log/LogToFile.java Sun Jul 17 17:11:36 2016
@@ -505,7 +505,7 @@ public final class LogToFile implements
 	 * there was no support to do write sync until jdk1.4 and then
 	 * there was write sync jvm bug in jdk1.4.1, only in jdk1.4.2 write 
 	 * sync(rws and rwd modes) mechanism can be used correctly.
-	 * Default in JVMS >= jdk1.4.2 is write sync(see the boot method for jvm checks).
+	 * Default in JVMS &gt;= jdk1.4.2 is write sync(see the boot method for jvm checks).
 	 *
 	 * Write sync mechanism support is added  for performance reasons. 
 	 * On commits, logging system has to make sure the log for committed
@@ -1435,7 +1435,7 @@ public final class LogToFile implements
 			4               |--------------------------------------(end of log)
 			5                                       |-^-|
 			.                                   Checkpoint Log Record
-			---A--->|<-------B--------->|<-------------C-----------
+			---A---&gt;|&lt;-------B---------&gt;|&lt;-------------C-----------
 		</PRE>
 
 		<P>

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/xact/TransactionTable.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/xact/TransactionTable.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/xact/TransactionTable.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/xact/TransactionTable.java Sun Jul 17 17:11:36 2016
@@ -574,7 +574,7 @@ public class TransactionTable implements
      * @param recovered  <code> true </code> to search  for transaction 
      *                  that are in prepared during recovery.  
      *                  recovered tranaction. 
-     *                  <code> false > to search for just prepared 
+     *                  <code> false &gt; to search for just prepared 
      *                  transactons. 
      * @return         <code> true if there is a prepared transaction and
      *                  recovered when <code> recovered </code> argument is 

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/xact/XactId.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/xact/XactId.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/xact/XactId.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/raw/xact/XactId.java Sun Jul 17 17:11:36 2016
@@ -132,8 +132,8 @@ public class XactId implements Transacti
 	
 	/**
 		Return	0 if a == b, 
-				+ve number if a > b
-				-ve number if a < b
+				+ve number if a &gt; b
+				-ve number if a &lt; b
 	*/
 	public static long compare(TransactionId a, TransactionId b)
 	{

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/replication/buffer/ReplicationLogBuffer.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/replication/buffer/ReplicationLogBuffer.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/replication/buffer/ReplicationLogBuffer.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/replication/buffer/ReplicationLogBuffer.java Sun Jul 17 17:11:36 2016
@@ -41,7 +41,7 @@ import org.apache.derby.iapi.store.repli
  * elements that contains dirty log are in dirtyBuffers. Chunks of log records
  * are appended to the buffer element in currentDirtyBuffer. Hence,
  * the life cycle of buffer elements is:
- * freeBuffers -> currentDirtyBuffer -> dirtyBuffers -> freeBuffers
+ * freeBuffers -&gt; currentDirtyBuffer -&gt; dirtyBuffers -&gt; freeBuffers
  *
  * To append chunks of log records to the buffer, use appendLog(...)
  *

Modified: db/derby/code/trunk/java/engine/org/apache/derby/impl/store/replication/master/AsynchronousLogShipper.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/impl/store/replication/master/AsynchronousLogShipper.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/impl/store/replication/master/AsynchronousLogShipper.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/impl/store/replication/master/AsynchronousLogShipper.java Sun Jul 17 17:11:36 2016
@@ -156,7 +156,7 @@ public class AsynchronousLogShipper exte
      * max(MAX, DEFAULT_NUMBER_LOG_BUFFERS*MIN) is the maximum delay between a 
      * log record is committed at the master until it is replicated  to the 
      * slave. Hence the default latency should be atleast greater than the maximum
-     * latency offered by the choice of MIN, hence MAX > DEFAULT_NUMBER_LOG_BUFFERS*MIN.
+     * latency offered by the choice of MIN, hence MAX &gt; DEFAULT_NUMBER_LOG_BUFFERS*MIN.
      */
     private static final long MAX = 5000;
 
@@ -376,7 +376,7 @@ public class AsynchronousLogShipper exte
      * action to be taken when a notification from the log shipper is received,
      * 
      * a) Get FI from log buffer
-     * b) If FI >= FI_HIGH
+     * b) If FI &gt;= FI_HIGH
      *     b.1) notify the log shipper thread.
      * c) Else If the time elapsed since last ship is greater than
      *    minShippingInterval
@@ -402,9 +402,9 @@ public class AsynchronousLogShipper exte
      * information obtained from the log buffer. This method uses the following
      * steps to arrive at the shipping interval,
      * 
-     * a) FI >= FI_HIGH return -1 (signifies that the waiting time should be 0)
-     * b) FI >  FI_LOW and FI < FI_HIGH return minShippingInterval
-     * c) FI <= FI_LOW return maxShippingInterval.
+     * a) FI &gt;= FI_HIGH return -1 (signifies that the waiting time should be 0)
+     * b) FI &gt;  FI_LOW and FI &lt; FI_HIGH return minShippingInterval
+     * c) FI &lt;= FI_LOW return maxShippingInterval.
      * 
      * @return the shipping interval based on the fill information.
      */

Modified: db/derby/code/trunk/java/engine/org/apache/derby/jdbc/package.html
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/jdbc/package.html?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/jdbc/package.html (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/jdbc/package.html Sun Jul 17 17:11:36 2016
@@ -108,7 +108,7 @@ The JDBC specicification is in theory a
 </TABLE>
 
 <HR/>
-<A name="implblob"/A>
+<A name="implblob"></A>
 <H3>java.sql.Blob</H3>
 <H4>Clarification for getBytes(int pos, int length)</H4>
 If the pos (position) argument is greater than the length of the BLOB then an exception is thrown.
@@ -117,7 +117,7 @@ This matches the semantics of the SQL SU
 If the pattern argument has length zero, then the value of start argument will be returned.
 This matches the semantics of the SQL LOCATE function.
 <HR/>
-<A name="implclob"/A>
+<A name="implclob"></A>
 <H3>java.sql.Clob</H3>
 <H4>Clarification for getSubString(int pos, int length)</H4>
 If the pos (position) argument is greater than the length of the CLOB then an exception is thrown.
@@ -126,12 +126,12 @@ This matches the semantics of the SQL SU
 If the searchstr argument has length zero (the empty string), then the value of start argument
 will be returned. This matches the semantics of the SQL LOCATE function.
 <HR/>
-<A name="implconnection"/A>
+<A name="implconnection"></A>
 <H3>java.sql.Connection</H3>
 <H4>Clarification for createStatement(), prepareStatement() and prepareCall()</H4>
 CONCUR_UPDATABLE concurrency is supported for TYPE_FORWARD_ONLY and TYPE_SCROLL_INSENSITIVE ResultSet types only.
 <HR/>
-<A name="implpreparedstatement"/A>
+<A name="implpreparedstatement"></A>
 <H3>java.sql.PreparedStatement</H3>
 <H4>Clarification for  setAsciiStream(),setBinaryStream(),setCharacterStream()</H4>
 In Derby, the stream must have the exact amount of data as the length argument,
@@ -148,7 +148,7 @@ Stream parameter values are not re-used
 the statement execution will fail with
 'Stream has already been read and end-of-file reached and cannot be re-used.'.
 <HR/>
-<A name="implresultset"/A>
+<A name="implresultset"></A>
 <H3>java.sql.ResultSet</H3>
 <H4>Extension for getXXX()</H4>
 Support for data conversion using the getXXX() methods matches Table B-6 of [JDBC3] with this extension:
@@ -172,7 +172,7 @@ there is no advantage in using this meth
 An ASCII character is defined as an eight bit character (range 0x00 to 0xff),
 see CHAR() function definition by [JDBC3] in appendix C.2.
 <P>
-For character types (Types.CHAR, Types.VARCHAR & Types.LONGVARCHAR),
+For character types (Types.CHAR, Types.VARCHAR and Types.LONGVARCHAR),
 each character in the value is translated to one byte in the ASCII stream:
 <UL>
 <LI> Unicode characters in the range 0x0000 to 0x00ff,
@@ -226,7 +226,7 @@ byte[] data = {0x34, 0x87, 0xc2, 0x1f} t
 <LI>getString() returns a String with eight characters "3487c21f"
 </UL>
 <HR/>
-<A name="implsqldate"/A>
+<A name="implsqldate"></A>
 <H3>Derby's SQL DATE interactions with JDBC</H3>
 <P>Derby&rsquo;s SQL DATE type represents a date in the form yyyy-mm-dd with no associated time zone information.</P>
 <H4>java.sql.Date</H4>
@@ -313,7 +313,7 @@ byte[] data = {0x34, 0x87, 0xc2, 0x1f} t
 <P>If the format of the string matches one of the built in formats then a conversion to a java.sql.Date matches that of a SQL DATE value with value yyyy-mm-dd.</P>
 <P>If the string does not match any of the built in formats Derby attempts to use the Java locale specific parser to interpret the string as a date.</P>
 <HR/>
-<A name="implsqltime"/A>
+<A name="implsqltime"></A>
 <H3>Derby's SQL TIME interactions with JDBC</H3>
 <P>Derby&rsquo;s SQL TIME type represents a time of day in the form hh:mm:ss with no associated time zone information.</P>
 <H4>java.sql.Time</H4>
@@ -402,7 +402,7 @@ byte[] data = {0x34, 0x87, 0xc2, 0x1f} t
 <P>If the format of the string matches one of the built in formats then a conversion to a java.sql.Time matches that of a SQL TIME value with value hh:mm:ss.</P>
 <P>If the string does not match any of the built in formats Derby attempts to use the Java locale specific parser to interpret the string as a date.</P>
 <HR/>
-<A name="implsqltimestamp"/A>
+<A name="implsqltimestamp"></A>
 <H3>Derby's SQL TIMESTAMP interactions with JDBC</H3>
 <P>Derby&rsquo;s SQL TIMESTAMP type represents a time of day in the form yyyy-mm-dd hh:mm:ss.fffffffff (nanosecond granularity) with no associated time zone information.</P>
 <H4>java.sql.Timestamp</H4>

Modified: db/derby/code/trunk/java/engine/org/apache/derby/vti/DeferModification.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/vti/DeferModification.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/vti/DeferModification.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/vti/DeferModification.java Sun Jul 17 17:11:36 2016
@@ -29,7 +29,7 @@ import java.sql.SQLException;
  * Consider the following statement:<br>
  * UPDATE NEW myVTI(...)
  *  SET cost = cost + 10
- *  WHERE cost < 15
+ *  WHERE cost &lt; 15
  *<p>
  * Updating a column that is used in the WHERE clause might or might not give the VTI implementation trouble;
  * the update might cause the same row to be selected more than once. This problem can be solved by building the

Modified: db/derby/code/trunk/java/engine/org/apache/derby/vti/RestrictedVTI.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/vti/RestrictedVTI.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/vti/RestrictedVTI.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/vti/RestrictedVTI.java Sun Jul 17 17:11:36 2016
@@ -41,7 +41,7 @@ import java.sql.SQLException;
  * because they don't have to fetch all columns and rows. This can mean
  * performance boosts for queries which only need a subset of the Table
  * Function's columns and for queries which compare those columns to constant
- * expressions using the <, <=, =, >, >=, and != operators. This can also mean
+ * expressions using the &lt;, &lt;=, =, &gt;, &gt;=, and != operators. This can also mean
  * performance boosts for LIKE and BETWEEN operations on Table Function
  * columns. For more information, see the commentary on
  * <a href="https://issues.apache.org/jira/browse/DERBY-4357">DERBY-4357</a>.

Modified: db/derby/code/trunk/java/engine/org/apache/derby/vti/Restriction.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/engine/org/apache/derby/vti/Restriction.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/engine/org/apache/derby/vti/Restriction.java (original)
+++ db/derby/code/trunk/java/engine/org/apache/derby/vti/Restriction.java Sun Jul 17 17:11:36 2016
@@ -114,7 +114,7 @@ public abstract class Restriction implem
        * </p>
        *
        * <blockquote><pre>
-       *  <     =     <=     >      >=    IS NULL    IS NOT NULL
+       *  &lt;     =     &lt;=     &gt;      &gt;=    IS NULL    IS NOT NULL
        * </pre></blockquote>
        */
     public static class ColumnQualifier extends Restriction
@@ -128,19 +128,19 @@ public abstract class Restriction implem
         /** Derby serializes these objects in PreparedStatements */
         public static final long serialVersionUID = -8205388794606605844L;
         
-        /**	 Ordering operation constant representing '<' **/
+        /**	 Ordering operation constant representing '&lt;' **/
         public static final int ORDER_OP_LESSTHAN = 0;
 
         /**	 Ordering operation constant representing '=' **/
         public static final int ORDER_OP_EQUALS = 1;
 
-        /**	 Ordering operation constant representing '<=' **/
+        /**	 Ordering operation constant representing '&lt;=' **/
         public static final int ORDER_OP_LESSOREQUALS = 2;
 
-        /**	 Ordering operation constant representing '>' **/
+        /**	 Ordering operation constant representing '&gt;' **/
         public static final int ORDER_OP_GREATERTHAN = 3;
 
-        /**	 Ordering operation constant representing '>=' **/
+        /**	 Ordering operation constant representing '&gt;=' **/
         public static final int ORDER_OP_GREATEROREQUALS = 4;
 
         /**	 Ordering operation constant representing 'IS NULL' **/

Modified: db/derby/code/trunk/java/shared/org/apache/derby/shared/common/sanity/AssertFailure.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/shared/org/apache/derby/shared/common/sanity/AssertFailure.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/shared/org/apache/derby/shared/common/sanity/AssertFailure.java (original)
+++ db/derby/code/trunk/java/shared/org/apache/derby/shared/common/sanity/AssertFailure.java Sun Jul 17 17:11:36 2016
@@ -43,7 +43,7 @@ import java.security.PrivilegedException
  * and we have the right permissions.
  *
  * If the JVM doesn't have the method Thread.getAllStackTraces i.e, we are on a
- * JVM < 1.5, or if we don't have the permissions java.lang.RuntimePermission
+ * JVM &lt; 1.5, or if we don't have the permissions java.lang.RuntimePermission
  * "getStackTrace" and "modifyThreadGroup", a message saying so is stored
  * instead.
  *
@@ -146,7 +146,7 @@ public class AssertFailure extends Runti
      * The result is returned as a string, ready to print.
      *
      * If the JVM doesn't have the method Thread.getAllStackTraces
-     * i.e, we are on a JVM < 1.5, or  if we don't have the permissions:
+     * i.e, we are on a JVM &lt; 1.5, or  if we don't have the permissions:
      * java.lang.RuntimePermission "getStackTrace" and "modifyThreadGroup",
      * a message saying so is returned instead.
      *

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/harness/HandleResult.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/harness/HandleResult.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/harness/HandleResult.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/harness/HandleResult.java Sun Jul 17 17:11:36 2016
@@ -29,7 +29,7 @@ import java.io.IOException;
 
 /**
   Class: HandleResult
-  Purpose: To capture stdout & stderr to a file
+  Purpose: To capture stdout and stderr to a file
   (PrintWriter is used for writing the output)
 */
 

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/harness/MultiTest.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/harness/MultiTest.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/harness/MultiTest.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/harness/MultiTest.java Sun Jul 17 17:11:36 2016
@@ -426,7 +426,7 @@ public class MultiTest
 	** Given the command file, infer the test name.
 	** Takes the portion of the file name between
 	** the last '.' and the last '/'.  e.g.
-	** x/y/Name.suffix -> Name
+	** x/y/Name.suffix -&gt; Name
 	**
 	*/
 	private static String getTestName(String cmdFile)

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/harness/ProcessStreamResult.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/harness/ProcessStreamResult.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/harness/ProcessStreamResult.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/harness/ProcessStreamResult.java Sun Jul 17 17:11:36 2016
@@ -164,11 +164,11 @@ public class ProcessStreamResult impleme
      * timeout period.
      * 
      * Behavior is as follows:
-     * 1) If timeout is set to a valid value (>0) - in this case, if myThread has not
+     * 1) If timeout is set to a valid value (&gt;0) - in this case, if myThread has not
      * finished its work by the time this method was called, then it will wait
      * till the timeout has elapsed or if the myThread has finished its work.
      * 
-     * 2)If timeout is not set ( <= 0) - in this case, if myThread has not
+     * 2)If timeout is not set ( &lt;= 0) - in this case, if myThread has not
      * finished its work by the time this method was called, then it will wait
      * till myThread has finished its work.
      * 

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbc4/BlobTest.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbc4/BlobTest.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbc4/BlobTest.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbc4/BlobTest.java Sun Jul 17 17:11:36 2016
@@ -504,10 +504,10 @@ public class BlobTest
     /**
      * Tests the exceptions thrown by the getBinaryStream
      * (long pos, long length) for the following conditions
-     * a) pos <= 0
-     * b) pos > (length of LOB)
-     * c) length < 0
-     * d) pos + length > (length of LOB).
+     * a) pos &lt;= 0
+     * b) pos &gt; (length of LOB)
+     * c) length &lt; 0
+     * d) pos + length &gt; (length of LOB).
      *
      * @throws SQLException.
      */

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbc4/ClobTest.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbc4/ClobTest.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbc4/ClobTest.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbc4/ClobTest.java Sun Jul 17 17:11:36 2016
@@ -578,10 +578,10 @@ public class ClobTest
     /**
      * Tests the exceptions thrown by the getCharacterStream
      * (long pos, long length) for the following conditions
-     * a) pos <= 0
-     * b) pos > (length of LOB)
-     * c) length < 0
-     * d) pos + length > (length of LOB).
+     * a) pos &lt;= 0
+     * b) pos &gt; (length of LOB)
+     * c) length &lt; 0
+     * d) pos + length &gt; (length of LOB).
      *
      * @throws SQLException
      */

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/CacheSessionDataTest.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/CacheSessionDataTest.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/CacheSessionDataTest.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/CacheSessionDataTest.java Sun Jul 17 17:11:36 2016
@@ -390,7 +390,7 @@ public class CacheSessionDataTest extend
      * Sets the current schema to the name given as argument and returns the
      * schema transition.
      * @param nextSchema schema to transition to
-     * @return a string of the form oldSchema->newSchema
+     * @return a string of the form oldSchema-&gt;newSchema
      * @throws java.sql.SQLException
      */
     public static String getSchemaTransition(String nextSchema)
@@ -412,8 +412,8 @@ public class CacheSessionDataTest extend
     
     /**
      * Utility that cycles through the legal isolation levels in the following
-     * order: read uncommitted -> read committed -> repeatable read -> 
-     * serializable -> read uncommitted -> ...
+     * order: read uncommitted -&gt; read committed -&gt; repeatable read -&gt; 
+     * serializable -&gt; read uncommitted -&gt; ...
      * @return IsoLevel object representing the isolation level.
      */
     private static IsoLevel cycleIsolation() {

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/CharacterStreamsTest.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/CharacterStreamsTest.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/CharacterStreamsTest.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/CharacterStreamsTest.java Sun Jul 17 17:11:36 2016
@@ -36,8 +36,8 @@ import org.apache.derbyTesting.junit.Tes
 
 /**
  * Tests the following PreparedStatement methods:
- *   -> setCharacterStream(int parameterIndex, InputStream x, int length)
- *   -> setAsciiStream(int parameterIndex, Reader reader, int length)
+ *   -&gt; setCharacterStream(int parameterIndex, InputStream x, int length)
+ *   -&gt; setAsciiStream(int parameterIndex, Reader reader, int length)
  */
 public class CharacterStreamsTest extends BaseJDBCTestCase {
 

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/J2EEDataSourceTest.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/J2EEDataSourceTest.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/J2EEDataSourceTest.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/J2EEDataSourceTest.java Sun Jul 17 17:11:36 2016
@@ -924,7 +924,7 @@ public class J2EEDataSourceTest extends
      * Tests that a pooled connection can successfully be reused
      * (a new connection obtained from it) during the processing
      * of its close event by its listener.
-     * Sections 11.2 & 12.5 of JDBC 4 specification indicate that the
+     * Sections 11.2 and 12.5 of JDBC 4 specification indicate that the
      * connection can be returned to the pool when the
      * ConnectionEventListener.connectionClosed() is called.
      */

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/ParameterMappingTest.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/ParameterMappingTest.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/ParameterMappingTest.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/ParameterMappingTest.java Sun Jul 17 17:11:36 2016
@@ -4926,7 +4926,7 @@ public class ParameterMappingTest extend
      * non-zero fraction to see what happens to the discarded fractional
      * part (scale == 1): Conversions to long should round off in the
      * direction of zero for both positive and negative numbers with a
-     * fractional part >< 0, cf. RoundingMode.DOWN used in the asserts
+     * fractional part &gt;&lt; 0, cf. RoundingMode.DOWN used in the asserts
      * below.
      */
     public void testDerby5536() throws SQLException {

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/ResultSetMiscTest.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/ResultSetMiscTest.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/ResultSetMiscTest.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/ResultSetMiscTest.java Sun Jul 17 17:11:36 2016
@@ -451,7 +451,7 @@ public class ResultSetMiscTest extends B
     }
 
     /**
-     * Test fix for Bug4810 -Connection.commit() & rollback() do not
+     * Test fix for Bug4810 -Connection.commit() and rollback() do not
      * commit/rollback in auto-commit mode.
      */
     public void testBug4810() throws SQLException {

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/SURTest.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/SURTest.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/SURTest.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/jdbcapi/SURTest.java Sun Jul 17 17:11:36 2016
@@ -1400,7 +1400,7 @@ public class SURTest extends SURBaseTest
      * passed down to ScrollInsensitiveResultSet.updateRow does not always
      * contain all the rows of the basetable, cf. the logic of RowChangerImpl.
      * When an explicit list of columns is given as in FOR UPDATE OF
-     * <column-list>, the ExecRow may contains a subset of the the base table
+     * &lt;column-list&gt;, the ExecRow may contains a subset of the the base table
      * columns and ScrollInsensitiveResultSet was not ready to handle that.
      *
      * Test some of the cases which went wrong before the fix.

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/BigDataTest.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/BigDataTest.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/BigDataTest.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/BigDataTest.java Sun Jul 17 17:11:36 2016
@@ -359,7 +359,7 @@ public class BigDataTest extends BaseJDB
     }
 
     /**
-     * try a column which is > 32767
+     * try a column which is &gt; 32767
      * 
      * @throws SQLException
      */
@@ -376,7 +376,7 @@ public class BigDataTest extends BaseJDB
     }
 
     /**
-     * try several columns > 32767.
+     * try several columns &gt; 32767.
      * 
      * @throws SQLException
      */

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/CollationTest.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/CollationTest.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/CollationTest.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/CollationTest.java Sun Jul 17 17:11:36 2016
@@ -438,7 +438,7 @@ public void testPolishCollation() throws
       }    
   
 /**
- * Test in list with constant and non constant elements & Norwegian collation
+ * Test in list with constant and non constant elements and Norwegian collation
  * DERBY-6025(Wrong results with IN lists and indexes in territory based 
  *   collation)
  */

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/CollationTest2.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/CollationTest2.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/CollationTest2.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/CollationTest2.java Sun Jul 17 17:11:36 2016
@@ -179,7 +179,7 @@ public class CollationTest2 extends Base
      * <p>
      * Insert all data to tested against into LIKE_NAMES. A customer table
      * will be filled with this data.
-     * {p>
+     * <p>
      * Insert test cases for like string into the LIKE_TEST_CASES, results
      * are expected only to return a single row.
      * <p>
@@ -987,7 +987,7 @@ public class CollationTest2 extends Base
     /**
      * Check simple boolean compare of string constant to column value.
      * <p>
-     * Check <, <=, =, >=, > of constant to column, ie. of the form
+     * Check &lt;, &lt;=, =, &gt;=, &gt; of constant to column, ie. of the form
      *     select * from table where col boolean constant
      *
      *
@@ -1125,7 +1125,7 @@ public class CollationTest2 extends Base
     /**
      * Check simple boolean compare of string constant to column value.
      * <p>
-     * Check <, <=, =, >=, > of constant to column, ie. of the form
+     * Check &lt;, &glt;=, =, &gt;=, &gt; of constant to column, ie. of the form
      *     select * from table where col boolean constant
      *
      *

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/GroupByTest.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/GroupByTest.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/GroupByTest.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/GroupByTest.java Sun Jul 17 17:11:36 2016
@@ -1477,7 +1477,7 @@ public class GroupByTest extends BaseJDB
 	 *  
 	 * The tests below show that GROUP BY and HAVING clauses are able to use a 
 	 *  column which is not part of the SELECT list. This happens for USING
-	 *  clause & NATURAL joins with queries using INNER JOINS and OUTER JOINS.
+	 *  clause and NATURAL joins with queries using INNER JOINS and OUTER JOINS.
 	 *  When using the JOIN with ON clause, we do not run into this problem 
 	 *  because we are expected to qualify the JOIN column with table name 
 	 *  in the SELECT list when using thw ON clause.

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/InListMultiProbeTest.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/InListMultiProbeTest.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/InListMultiProbeTest.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/InListMultiProbeTest.java Sun Jul 17 17:11:36 2016
@@ -58,7 +58,7 @@ import org.apache.derbyTesting.junit.Tes
  *   3. The number of elements in the IN list is significantly less
  *      than the number of rows in the target table (in this test
  *      the data rows are not unique w.r.t the IN list values, so
- *      the size of the IN list should generally be <= 1/10th of the
+ *      the size of the IN list should generally be &lt;= 1/10th of the
  *      number rows in the table).
  *
  * If all three of these are true then we expect that Derby will perform
@@ -1485,7 +1485,7 @@ public class InListMultiProbeTest extend
 
     /**
      * Select all rows from DATA_TABLE and store them into an in-memory
-     * map of "foreign_uuid -> rows".  So any given foreign_key_uuid can
+     * map of "foreign_uuid -&gt; rows".  So any given foreign_key_uuid can
      * be mapped to one or more rows from the table.
      *
      * We use the in-memory map to verify that all queries executed

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/LangProcedureTest.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/LangProcedureTest.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/LangProcedureTest.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/LangProcedureTest.java Sun Jul 17 17:11:36 2016
@@ -1070,7 +1070,7 @@ public class LangProcedureTest extends B
      -auto commit is true
      -lock count before execution 0
      -lock count after execution 1
-     -lock count after next on first rs 3 -> 2 now FIXME: explain
+     -lock count after next on first rs 3 -&gt; 2 now FIXME: explain
      -lock count after first getMoreResults() 2
      -lock count after next on second rs 7
      -lock count after second getMoreResults() 0
@@ -1078,7 +1078,7 @@ public class LangProcedureTest extends B
      -auto commit is false
      -lock count before execution 0
      -lock count after execution 1
-     -lock count after next on first rs 3 -> 2 now FIXME: explain
+     -lock count after next on first rs 3 -&gt; 2 now FIXME: explain
      -lock count after first getMoreResults() 2
      -lock count after next on second rs 7
      -lock count after second getMoreResults() 7
@@ -1086,7 +1086,7 @@ public class LangProcedureTest extends B
      -auto commit is true
      -lock count before execution 0
      -lock count after execution 1
-     -lock count after next on first rs 3 -> 2 now FIXME: explain
+     -lock count after next on first rs 3 -&gt; 2 now FIXME: explain
      -executing statement to force auto commit on open call statement
      -lock count after statement execution 0
      -lock count after first getMoreResults() 0

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/LobMode.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/LobMode.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/LobMode.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/LobMode.java Sun Jul 17 17:11:36 2016
@@ -46,8 +46,8 @@ import org.apache.derby.agg.Aggregator;
  * because they do not satisfy its type bounds. That is because they inherit the
  * Comparable implementation of java.util.Date rather than implementing
  * their own more specific version of Comparable. That is,
- * java.sql.Date implements Comparable<java.util.Date> rather than
- * Comparable<java.sql.Date>.
+ * java.sql.Date implements Comparable&lt;java.util.Date&gt; rather than
+ * Comparable&lt;java.sql.Date&gt;.
  * </p>
  */
 public  class   LobMode<V>    implements  Aggregator<V,V,LobMode<V>>

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/OrderByAndOffsetFetchInSubqueries.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/OrderByAndOffsetFetchInSubqueries.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/OrderByAndOffsetFetchInSubqueries.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/OrderByAndOffsetFetchInSubqueries.java Sun Jul 17 17:11:36 2016
@@ -1274,7 +1274,7 @@ public class OrderByAndOffsetFetchInSubq
      * One of the productions of {@code <query expression body>}, is
      *
      * <pre>
-     *    <left paren> <query expression body
+     *    &lt;left paren&gt; &lt;query expression body&gt;
      *    [ <order by clause> ] [ <result offset clause> ]
      *    [ <fetch first clause> ] <right paren>
      * </pre>

Modified: db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/OuterJoinTest.java
URL: http://svn.apache.org/viewvc/db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/OuterJoinTest.java?rev=1753091&r1=1753090&r2=1753091&view=diff
==============================================================================
--- db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/OuterJoinTest.java (original)
+++ db/derby/code/trunk/java/testing/org/apache/derbyTesting/functionTests/tests/lang/OuterJoinTest.java Sun Jul 17 17:11:36 2016
@@ -2918,7 +2918,7 @@ public final class OuterJoinTest extends
    /**
     * This fixture would give:
     * <pre>
-    *   ASSERT FAILED sourceResultSetNumber expected to be >= 0 for T2.X
+    *   ASSERT FAILED sourceResultSetNumber expected to be &gt;= 0 for T2.X
     * </pre>
     * error in sane mode prior to DERBY-4736 due to a missing rebinding
     * operation as a result a the LOJ reordering.  Schema and query originally