You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by ct...@apache.org on 2016/01/09 04:38:13 UTC

[10/19] accumulo git commit: ACCUMULO-4102 Fix bad javadocs

ACCUMULO-4102 Fix bad javadocs


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

Branch: refs/heads/1.6
Commit: c8c0cf7f90023a49cbb2b790f30819810bed0bf9
Parents: 7cc8137
Author: Christopher Tubbs <ct...@apache.org>
Authored: Fri Jan 8 19:50:42 2016 -0500
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Fri Jan 8 20:48:51 2016 -0500

----------------------------------------------------------------------
 .../core/bloomfilter/DynamicBloomFilter.java    |  4 +--
 .../accumulo/core/client/BatchWriterConfig.java | 10 +++---
 .../core/client/ConditionalWriterConfig.java    |  4 +--
 .../client/mapred/AccumuloFileOutputFormat.java |  4 +--
 .../mapreduce/AccumuloFileOutputFormat.java     |  6 ++--
 .../lib/impl/FileOutputConfigurator.java        |  4 +--
 .../lib/util/FileOutputConfigurator.java        |  4 +--
 .../security/tokens/AuthenticationToken.java    |  2 +-
 .../core/conf/AccumuloConfiguration.java        |  2 +-
 .../org/apache/accumulo/core/data/Range.java    |  8 ++---
 .../file/blockfile/cache/CachedBlockQueue.java  |  2 +-
 .../core/file/blockfile/cache/ClassSize.java    |  4 +--
 .../accumulo/core/file/rfile/bcfile/Utils.java  | 35 +++++++++++---------
 .../user/WholeColumnFamilyIterator.java         |  4 +--
 .../core/metadata/ServicerForMetadataTable.java |  2 +-
 .../core/metadata/ServicerForRootTable.java     |  2 +-
 .../core/metadata/ServicerForUserTables.java    |  2 +-
 .../core/security/ColumnVisibility.java         |  8 ++---
 .../core/security/VisibilityConstraint.java     |  1 -
 .../security/crypto/CryptoModuleParameters.java |  7 +---
 .../examples/simple/filedata/ChunkCombiner.java | 18 +++++-----
 .../apache/accumulo/server/ServerConstants.java |  2 +-
 .../server/security/SecurityOperation.java      |  6 ++--
 .../server/security/SystemCredentialsTest.java  |  2 +-
 .../monitor/servlets/DefaultServlet.java        |  2 +-
 .../monitor/servlets/TablesServlet.java         |  4 +--
 26 files changed, 73 insertions(+), 76 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/bloomfilter/DynamicBloomFilter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/bloomfilter/DynamicBloomFilter.java b/core/src/main/java/org/apache/accumulo/core/bloomfilter/DynamicBloomFilter.java
index 740bdda..11e765a 100644
--- a/core/src/main/java/org/apache/accumulo/core/bloomfilter/DynamicBloomFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/bloomfilter/DynamicBloomFilter.java
@@ -60,8 +60,8 @@ import org.apache.hadoop.util.bloom.Key;
  * <p>
  * A dynamic Bloom filter (DBF) makes use of a <code>s * m</code> bit matrix but each of the <code>s</code> rows is a standard Bloom filter. The creation
  * process of a DBF is iterative. At the start, the DBF is a <code>1 * m</code> bit matrix, i.e., it is composed of a single standard Bloom filter. It assumes
- * that <code>n<sub>r</sub></code> elements are recorded in the initial bit vector, where <code>n<sub>r</sub> <= n</code> (<code>n</code> is the cardinality of
- * the set <code>A</code> to record in the filter).
+ * that <code>n<sub>r</sub></code> elements are recorded in the initial bit vector, where <code>n<sub>r</sub> &lt;= n</code> (<code>n</code> is the cardinality
+ * of the set <code>A</code> to record in the filter).
  * <p>
  * As the size of <code>A</code> grows during the execution of the application, several keys must be inserted in the DBF. When inserting a key into the DBF, one
  * must first get an active Bloom filter in the matrix. A Bloom filter is active when the number of recorded keys, <code>n<sub>r</sub></code>, is strictly less

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/client/BatchWriterConfig.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/BatchWriterConfig.java b/core/src/main/java/org/apache/accumulo/core/client/BatchWriterConfig.java
index 08eb853..320ecf4 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/BatchWriterConfig.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/BatchWriterConfig.java
@@ -49,7 +49,7 @@ public class BatchWriterConfig implements Writable {
   private Integer maxWriteThreads = null;
 
   /**
-   * Sets the maximum memory to batch before writing. The smaller this value, the more frequently the {@link BatchWriter} will write.<br />
+   * Sets the maximum memory to batch before writing. The smaller this value, the more frequently the {@link BatchWriter} will write.<br>
    * If set to a value smaller than a single mutation, then it will {@link BatchWriter#flush()} after each added mutation. Must be non-negative.
    *
    * <p>
@@ -69,11 +69,11 @@ public class BatchWriterConfig implements Writable {
   }
 
   /**
-   * Sets the maximum amount of time to hold the data in memory before flushing it to servers.<br />
+   * Sets the maximum amount of time to hold the data in memory before flushing it to servers.<br>
    * For no maximum, set to zero, or {@link Long#MAX_VALUE} with {@link TimeUnit#MILLISECONDS}.
    *
    * <p>
-   * {@link TimeUnit#MICROSECONDS} or {@link TimeUnit#NANOSECONDS} will be truncated to the nearest {@link TimeUnit#MILLISECONDS}.<br />
+   * {@link TimeUnit#MICROSECONDS} or {@link TimeUnit#NANOSECONDS} will be truncated to the nearest {@link TimeUnit#MILLISECONDS}.<br>
    * If this truncation would result in making the value zero when it was specified as non-zero, then a minimum value of one {@link TimeUnit#MILLISECONDS} will
    * be used.
    *
@@ -101,11 +101,11 @@ public class BatchWriterConfig implements Writable {
   }
 
   /**
-   * Sets the maximum amount of time an unresponsive server will be re-tried. When this timeout is exceeded, the {@link BatchWriter} should throw an exception.<br />
+   * Sets the maximum amount of time an unresponsive server will be re-tried. When this timeout is exceeded, the {@link BatchWriter} should throw an exception.<br>
    * For no timeout, set to zero, or {@link Long#MAX_VALUE} with {@link TimeUnit#MILLISECONDS}.
    *
    * <p>
-   * {@link TimeUnit#MICROSECONDS} or {@link TimeUnit#NANOSECONDS} will be truncated to the nearest {@link TimeUnit#MILLISECONDS}.<br />
+   * {@link TimeUnit#MICROSECONDS} or {@link TimeUnit#NANOSECONDS} will be truncated to the nearest {@link TimeUnit#MILLISECONDS}.<br>
    * If this truncation would result in making the value zero when it was specified as non-zero, then a minimum value of one {@link TimeUnit#MILLISECONDS} will
    * be used.
    *

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriterConfig.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriterConfig.java b/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriterConfig.java
index 360a302..627a580 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriterConfig.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriterConfig.java
@@ -51,11 +51,11 @@ public class ConditionalWriterConfig {
 
   /**
    * Sets the maximum amount of time an unresponsive server will be re-tried. When this timeout is exceeded, the {@link ConditionalWriter} should return the
-   * mutation with an exception.<br />
+   * mutation with an exception.<br>
    * For no timeout, set to zero, or {@link Long#MAX_VALUE} with {@link TimeUnit#MILLISECONDS}.
    *
    * <p>
-   * {@link TimeUnit#MICROSECONDS} or {@link TimeUnit#NANOSECONDS} will be truncated to the nearest {@link TimeUnit#MILLISECONDS}.<br />
+   * {@link TimeUnit#MICROSECONDS} or {@link TimeUnit#NANOSECONDS} will be truncated to the nearest {@link TimeUnit#MILLISECONDS}.<br>
    * If this truncation would result in making the value zero when it was specified as non-zero, then a minimum value of one {@link TimeUnit#MILLISECONDS} will
    * be used.
    *

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloFileOutputFormat.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloFileOutputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloFileOutputFormat.java
index 2f2b4b2..236fae5 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloFileOutputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloFileOutputFormat.java
@@ -41,7 +41,7 @@ import org.apache.hadoop.util.Progressable;
 import org.apache.log4j.Logger;
 
 /**
- * This class allows MapReduce jobs to write output in the Accumulo data file format.<br />
+ * This class allows MapReduce jobs to write output in the Accumulo data file format.<br>
  * Care should be taken to write only sorted data (sorted by {@link Key}), as this is an important requirement of Accumulo data files.
  *
  * <p>
@@ -81,7 +81,7 @@ public class AccumuloFileOutputFormat extends FileOutputFormat<Key,Value> {
   }
 
   /**
-   * Sets the size for data blocks within each file.<br />
+   * Sets the size for data blocks within each file.<br>
    * Data blocks are a span of key/value pairs stored in the file that are compressed and indexed as a group.
    *
    * <p>

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloFileOutputFormat.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloFileOutputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloFileOutputFormat.java
index 500f072..8c389d4 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloFileOutputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloFileOutputFormat.java
@@ -20,7 +20,6 @@ import java.io.IOException;
 import java.util.Arrays;
 
 import org.apache.accumulo.core.client.mapreduce.lib.impl.FileOutputConfigurator;
-import org.apache.accumulo.core.util.HadoopCompatUtil;
 import org.apache.accumulo.core.conf.AccumuloConfiguration;
 import org.apache.accumulo.core.conf.Property;
 import org.apache.accumulo.core.data.ArrayByteSequence;
@@ -29,6 +28,7 @@ import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.file.FileOperations;
 import org.apache.accumulo.core.file.FileSKVWriter;
 import org.apache.accumulo.core.security.ColumnVisibility;
+import org.apache.accumulo.core.util.HadoopCompatUtil;
 import org.apache.commons.collections.map.LRUMap;
 import org.apache.hadoop.conf.Configuration;
 import org.apache.hadoop.fs.Path;
@@ -40,7 +40,7 @@ import org.apache.hadoop.mapreduce.lib.output.FileOutputFormat;
 import org.apache.log4j.Logger;
 
 /**
- * This class allows MapReduce jobs to write output in the Accumulo data file format.<br />
+ * This class allows MapReduce jobs to write output in the Accumulo data file format.<br>
  * Care should be taken to write only sorted data (sorted by {@link Key}), as this is an important requirement of Accumulo data files.
  *
  * <p>
@@ -80,7 +80,7 @@ public class AccumuloFileOutputFormat extends FileOutputFormat<Key,Value> {
   }
 
   /**
-   * Sets the size for data blocks within each file.<br />
+   * Sets the size for data blocks within each file.<br>
    * Data blocks are a span of key/value pairs stored in the file that are compressed and indexed as a group.
    *
    * <p>

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/FileOutputConfigurator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/FileOutputConfigurator.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/FileOutputConfigurator.java
index 882c6d3..f0f67b2 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/FileOutputConfigurator.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/FileOutputConfigurator.java
@@ -39,7 +39,7 @@ public class FileOutputConfigurator extends ConfiguratorBase {
   }
 
   /**
-   * The supported Accumulo properties we set in this OutputFormat, that change the behavior of the RecordWriter.<br />
+   * The supported Accumulo properties we set in this OutputFormat, that change the behavior of the RecordWriter.<br>
    * These properties correspond to the supported public static setter methods available to this class.
    *
    * @param property
@@ -120,7 +120,7 @@ public class FileOutputConfigurator extends ConfiguratorBase {
   }
 
   /**
-   * Sets the size for data blocks within each file.<br />
+   * Sets the size for data blocks within each file.<br>
    * Data blocks are a span of key/value pairs stored in the file that are compressed and indexed as a group.
    *
    * <p>

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/util/FileOutputConfigurator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/util/FileOutputConfigurator.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/util/FileOutputConfigurator.java
index d43ecda..b4f6b8a 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/util/FileOutputConfigurator.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/util/FileOutputConfigurator.java
@@ -39,7 +39,7 @@ public class FileOutputConfigurator extends ConfiguratorBase {
   }
 
   /**
-   * The supported Accumulo properties we set in this OutputFormat, that change the behavior of the RecordWriter.<br />
+   * The supported Accumulo properties we set in this OutputFormat, that change the behavior of the RecordWriter.<br>
    * These properties correspond to the supported public static setter methods available to this class.
    *
    * @param property
@@ -95,7 +95,7 @@ public class FileOutputConfigurator extends ConfiguratorBase {
   }
 
   /**
-   * Sets the size for data blocks within each file.<br />
+   * Sets the size for data blocks within each file.<br>
    * Data blocks are a span of key/value pairs stored in the file that are compressed and indexed as a group.
    *
    * <p>

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/client/security/tokens/AuthenticationToken.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/AuthenticationToken.java b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/AuthenticationToken.java
index 7836ea5..5c20555 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/AuthenticationToken.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/AuthenticationToken.java
@@ -39,7 +39,7 @@ import org.apache.hadoop.io.Writable;
 public interface AuthenticationToken extends Writable, Destroyable, Cloneable {
 
   /**
-   * A utility class to serialize/deserialize {@link AuthenticationToken} objects.<br/>
+   * A utility class to serialize/deserialize {@link AuthenticationToken} objects.<br>
    * Unfortunately, these methods are provided in an inner-class, to avoid breaking the interface API.
    *
    * @since 1.6.0

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/conf/AccumuloConfiguration.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/AccumuloConfiguration.java b/core/src/main/java/org/apache/accumulo/core/conf/AccumuloConfiguration.java
index 33b7aef..5da92cb 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/AccumuloConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/AccumuloConfiguration.java
@@ -80,7 +80,7 @@ public abstract class AccumuloConfiguration implements Iterable<Entry<String,Str
   }
 
   /**
-   * This method returns all properties in a map of string->string under the given prefix property.
+   * This method returns all properties in a map of string-&gt;string under the given prefix property.
    *
    * @param property
    *          the prefix property, and must be of type PropertyType.PREFIX

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/data/Range.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/Range.java b/core/src/main/java/org/apache/accumulo/core/data/Range.java
index b832c33..7ccfe3d 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/Range.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/Range.java
@@ -423,7 +423,7 @@ public class Range implements WritableComparable<Range> {
 
         if (range.infiniteStopKey || (cmp = range.stop.compareTo(currentRange.stop)) > 0 || (cmp == 0 && range.stopKeyInclusive)) {
           currentRange = new Range(currentRange.getStartKey(), currentStartKeyInclusive, range.getEndKey(), range.stopKeyInclusive);
-        }/* else currentRange contains ral.get(i) */
+        } /* else currentRange contains ral.get(i) */
       } else {
         ret.add(currentRange);
         currentRange = range;
@@ -506,12 +506,12 @@ public class Range implements WritableComparable<Range> {
   }
 
   /**
-   * Creates a new range that is bounded by the columns passed in. The stary key in the returned range will have a column >= to the minimum column. The end key
-   * in the returned range will have a column <= the max column.
+   * Creates a new range that is bounded by the columns passed in. The stary key in the returned range will have a column &gt;= to the minimum column. The end
+   * key in the returned range will have a column &lt;= the max column.
    *
    * @return a column bounded range
    * @throws IllegalArgumentException
-   *           if min > max
+   *           if min &gt; max
    */
 
   public Range bound(Column min, Column max) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CachedBlockQueue.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CachedBlockQueue.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CachedBlockQueue.java
index 0c35b98..9b52635 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CachedBlockQueue.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CachedBlockQueue.java
@@ -21,7 +21,7 @@ import java.util.LinkedList;
 import java.util.PriorityQueue;
 
 /**
- * A memory-bound queue that will grow until an element brings total size >= maxSize. From then on, only entries that are sorted larger than the smallest
+ * A memory-bound queue that will grow until an element brings total size &gt;= maxSize. From then on, only entries that are sorted larger than the smallest
  * current entry will be inserted/replaced.
  *
  * <p>

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/ClassSize.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/ClassSize.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/ClassSize.java
index f898a8f..f15e28f 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/ClassSize.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/ClassSize.java
@@ -251,7 +251,7 @@ public class ClassSize {
    *
    * @param num
    *          number to align to 8
-   * @return smallest number >= input that is a multiple of 8
+   * @return smallest number &gt;= input that is a multiple of 8
    */
   public static int align(int num) {
     return (int) (align((long) num));
@@ -262,7 +262,7 @@ public class ClassSize {
    *
    * @param num
    *          number to align to 8
-   * @return smallest number >= input that is a multiple of 8
+   * @return smallest number &gt;= input that is a multiple of 8
    */
   public static long align(long num) {
     // The 7 comes from that the alignSize is 8 which is the number of bytes

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Utils.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Utils.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Utils.java
index 84b861b..46afc0b 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Utils.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Utils.java
@@ -54,18 +54,21 @@ public final class Utils {
    * Encoding a Long integer into a variable-length encoding format.
    * <ul>
    * <li>if n in [-32, 127): encode in one byte with the actual value. Otherwise,
-   * <li>if n in [-20*2^8, 20*2^8): encode in two bytes: byte[0] = n/256 - 52; byte[1]=n&0xff. Otherwise,
-   * <li>if n IN [-16*2^16, 16*2^16): encode in three bytes: byte[0]=n/2^16 - 88; byte[1]=(n>>8)&0xff; byte[2]=n&0xff. Otherwise,
-   * <li>if n in [-8*2^24, 8*2^24): encode in four bytes: byte[0]=n/2^24 - 112; byte[1] = (n>>16)&0xff; byte[2] = (n>>8)&0xff; byte[3]=n&0xff. Otherwise:
-   * <li>if n in [-2^31, 2^31): encode in five bytes: byte[0]=-125; byte[1] = (n>>24)&0xff; byte[2]=(n>>16)&0xff; byte[3]=(n>>8)&0xff; byte[4]=n&0xff;
-   * <li>if n in [-2^39, 2^39): encode in six bytes: byte[0]=-124; byte[1] = (n>>32)&0xff; byte[2]=(n>>24)&0xff; byte[3]=(n>>16)&0xff; byte[4]=(n>>8)&0xff;
-   * byte[5]=n&0xff
-   * <li>if n in [-2^47, 2^47): encode in seven bytes: byte[0]=-123; byte[1] = (n>>40)&0xff; byte[2]=(n>>32)&0xff; byte[3]=(n>>24)&0xff; byte[4]=(n>>16)&0xff;
-   * byte[5]=(n>>8)&0xff; byte[6]=n&0xff;
-   * <li>if n in [-2^55, 2^55): encode in eight bytes: byte[0]=-122; byte[1] = (n>>48)&0xff; byte[2] = (n>>40)&0xff; byte[3]=(n>>32)&0xff; byte[4]=(n>>24)&0xff;
-   * byte[5]=(n>>16)&0xff; byte[6]=(n>>8)&0xff; byte[7]=n&0xff;
-   * <li>if n in [-2^63, 2^63): encode in nine bytes: byte[0]=-121; byte[1] = (n>>54)&0xff; byte[2] = (n>>48)&0xff; byte[3] = (n>>40)&0xff;
-   * byte[4]=(n>>32)&0xff; byte[5]=(n>>24)&0xff; byte[6]=(n>>16)&0xff; byte[7]=(n>>8)&0xff; byte[8]=n&0xff;
+   * <li>if n in [-20*2^8, 20*2^8): encode in two bytes: byte[0] = n/256 - 52; byte[1]=n&amp;0xff. Otherwise,
+   * <li>if n IN [-16*2^16, 16*2^16): encode in three bytes: byte[0]=n/2^16 - 88; byte[1]=(n&gt;&gt;8)&amp;0xff; byte[2]=n&amp;0xff. Otherwise,
+   * <li>if n in [-8*2^24, 8*2^24): encode in four bytes: byte[0]=n/2^24 - 112; byte[1] = (n&gt;&gt;16)&amp;0xff; byte[2] = (n&gt;&gt;8)&amp;0xff;
+   * byte[3]=n&amp;0xff. Otherwise:
+   * <li>if n in [-2^31, 2^31): encode in five bytes: byte[0]=-125; byte[1] = (n&gt;&gt;24)&amp;0xff; byte[2]=(n&gt;&gt;16)&amp;0xff;
+   * byte[3]=(n&gt;&gt;8)&amp;0xff; byte[4]=n&amp;0xff;
+   * <li>if n in [-2^39, 2^39): encode in six bytes: byte[0]=-124; byte[1] = (n&gt;&gt;32)&amp;0xff; byte[2]=(n&gt;&gt;24)&amp;0xff;
+   * byte[3]=(n&gt;&gt;16)&amp;0xff; byte[4]=(n&gt;&gt;8)&amp;0xff; byte[5]=n&amp;0xff
+   * <li>if n in [-2^47, 2^47): encode in seven bytes: byte[0]=-123; byte[1] = (n&gt;&gt;40)&amp;0xff; byte[2]=(n&gt;&gt;32)&amp;0xff;
+   * byte[3]=(n&gt;&gt;24)&amp;0xff; byte[4]=(n&gt;&gt;16)&amp;0xff; byte[5]=(n&gt;&gt;8)&amp;0xff; byte[6]=n&amp;0xff;
+   * <li>if n in [-2^55, 2^55): encode in eight bytes: byte[0]=-122; byte[1] = (n&gt;&gt;48)&amp;0xff; byte[2] = (n&gt;&gt;40)&amp;0xff;
+   * byte[3]=(n&gt;&gt;32)&amp;0xff; byte[4]=(n&gt;&gt;24)&amp;0xff; byte[5]=(n&gt;&gt;16)&amp;0xff; byte[6]=(n&gt;&gt;8)&amp;0xff; byte[7]=n&amp;0xff;
+   * <li>if n in [-2^63, 2^63): encode in nine bytes: byte[0]=-121; byte[1] = (n&gt;&gt;54)&amp;0xff; byte[2] = (n&gt;&gt;48)&amp;0xff; byte[3] =
+   * (n&gt;&gt;40)&amp;0xff; byte[4]=(n&gt;&gt;32)&amp;0xff; byte[5]=(n&gt;&gt;24)&amp;0xff; byte[6]=(n&gt;&gt;16)&amp;0xff; byte[7]=(n&gt;&gt;8)&amp;0xff;
+   * byte[8]=n&amp;0xff;
    * </ul>
    *
    * @param out
@@ -159,10 +162,10 @@ public final class Utils {
   /**
    * Decoding the variable-length integer. Suppose the value of the first byte is FB, and the following bytes are NB[*].
    * <ul>
-   * <li>if (FB >= -32), return (long)FB;
-   * <li>if (FB in [-72, -33]), return (FB+52)<<8 + NB[0]&0xff;
-   * <li>if (FB in [-104, -73]), return (FB+88)<<16 + (NB[0]&0xff)<<8 + NB[1]&0xff;
-   * <li>if (FB in [-120, -105]), return (FB+112)<<24 + (NB[0]&0xff)<<16 + (NB[1]&0xff)<<8 + NB[2]&0xff;
+   * <li>if (FB &gt;= -32), return (long)FB;
+   * <li>if (FB in [-72, -33]), return (FB+52)&lt;&lt;8 + NB[0]&amp;0xff;
+   * <li>if (FB in [-104, -73]), return (FB+88)&lt;&lt;16 + (NB[0]&amp;0xff)&lt;&lt;8 + NB[1]&amp;0xff;
+   * <li>if (FB in [-120, -105]), return (FB+112)&lt;&lt;24 + (NB[0]&amp;0xff)&lt;&lt;16 + (NB[1]&amp;0xff)&lt;&lt;8 + NB[2]&amp;0xff;
    * <li>if (FB in [-128, -121]), return interpret NB[FB+129] as a signed big-endian integer.
    * </ul>
    *

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeColumnFamilyIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeColumnFamilyIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeColumnFamilyIterator.java
index 25f30a8..8e7a385 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeColumnFamilyIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeColumnFamilyIterator.java
@@ -180,9 +180,9 @@ public class WholeColumnFamilyIterator implements SortedKeyValueIterator<Key,Val
   /**
    *
    * @param currentRow
-   *          All keys & cf have this in their row portion (do not modify!).
+   *          All keys and cf have this in their row portion (do not modify!).
    * @param keys
-   *          One key for each key & cf group in the row, ordered as they are given by the source iterator (do not modify!).
+   *          One key for each key and cf group in the row, ordered as they are given by the source iterator (do not modify!).
    * @param values
    *          One value for each key in keys, ordered to correspond to the ordering in keys (do not modify!).
    * @return true if we want to keep the row, false if we want to skip it

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForMetadataTable.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForMetadataTable.java b/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForMetadataTable.java
index b642cb8..af48770 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForMetadataTable.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForMetadataTable.java
@@ -20,7 +20,7 @@ import org.apache.accumulo.core.client.Instance;
 import org.apache.accumulo.core.security.Credentials;
 
 /**
- * A metadata servicer for the metadata table (which holds metadata for user tables).<br />
+ * A metadata servicer for the metadata table (which holds metadata for user tables).<br>
  * The metadata table's metadata is serviced in the root table.
  */
 class ServicerForMetadataTable extends TableMetadataServicer {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForRootTable.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForRootTable.java b/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForRootTable.java
index 205adc9..b279d01 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForRootTable.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForRootTable.java
@@ -26,7 +26,7 @@ import org.apache.accumulo.core.data.KeyExtent;
 import org.apache.accumulo.core.security.Credentials;
 
 /**
- * A metadata servicer for the root table.<br />
+ * A metadata servicer for the root table.<br>
  * The root table's metadata is serviced in zookeeper.
  */
 class ServicerForRootTable extends MetadataServicer {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForUserTables.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForUserTables.java b/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForUserTables.java
index d4827f2..607dfbd 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForUserTables.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForUserTables.java
@@ -20,7 +20,7 @@ import org.apache.accumulo.core.client.Instance;
 import org.apache.accumulo.core.security.Credentials;
 
 /**
- * A metadata servicer for user tables.<br />
+ * A metadata servicer for user tables.<br>
  * Metadata for user tables are serviced in the metadata table.
  */
 class ServicerForUserTables extends TableMetadataServicer {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/security/ColumnVisibility.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/ColumnVisibility.java b/core/src/main/java/org/apache/accumulo/core/security/ColumnVisibility.java
index 842e6f9..26d1cd0 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/ColumnVisibility.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/ColumnVisibility.java
@@ -37,7 +37,7 @@ import org.apache.hadoop.io.WritableComparator;
  * Validate the column visibility is a valid expression and set the visibility for a Mutation. See {@link ColumnVisibility#ColumnVisibility(byte[])} for the
  * definition of an expression.
  *
- * <P>
+ * <p>
  * The expression is a sequence of characters from the set [A-Za-z0-9_-.] along with the binary operators "&amp;" and "|" indicating that both operands are
  * necessary, or the either is necessary. The following are valid expressions for visibility:
  *
@@ -48,7 +48,7 @@ import org.apache.hadoop.io.WritableComparator;
  * orange|(red&amp;yellow)
  * </pre>
  *
- * <P>
+ * <p>
  * The following are not valid expressions for visibility:
  *
  * <pre>
@@ -61,13 +61,13 @@ import org.apache.hadoop.io.WritableComparator;
  * dog|!cat
  * </pre>
  *
- * <P>
+ * <p>
  * In addition to the base set of visibilities, any character can be used in the expression if it is quoted. If the quoted term contains '&quot;' or '\', then
  * escape the character with '\'. The {@link #quote(String)} method can be used to properly quote and escape terms automatically. The following is an example of
  * a quoted term:
  *
  * <pre>
- * &quot;A#C&quot;<span />&amp;<span />B
+ * &quot;A#C&quot; &amp; B
  * </pre>
  */
 public class ColumnVisibility {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/security/VisibilityConstraint.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/VisibilityConstraint.java b/core/src/main/java/org/apache/accumulo/core/security/VisibilityConstraint.java
index 67175c0..d9d13d7 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/VisibilityConstraint.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/VisibilityConstraint.java
@@ -29,7 +29,6 @@ import org.apache.accumulo.core.util.BadArgumentException;
 
 /**
  * A constraint that checks the visibility of columns against the actor's authorizations. Violation codes:
- * <p>
  * <ul>
  * <li>1 = failure to parse visibility expression</li>
  * <li>2 = insufficient authorization</li>

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModuleParameters.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModuleParameters.java b/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModuleParameters.java
index b9bf253..a7bb93d 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModuleParameters.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModuleParameters.java
@@ -195,9 +195,7 @@ public class CryptoModuleParameters {
   /**
    * Sets the name of the random number generator to use. The default for this for the baseline JCE implementation is "SHA1PRNG".
    * <p>
-   *
-   * <p>
-   * For <b>encryption</b>, this value is <b>required</b>. <br>
+   * For <b>encryption</b>, this value is <b>required</b>.<br>
    * For <b>decryption</b>, this value is often obtained from the underlying cipher stream.
    *
    * @param randomNumberGenerator
@@ -275,7 +273,6 @@ public class CryptoModuleParameters {
 
   /**
    * Sets the encrypted version of the plaintext key ({@link CryptoModuleParameters#getPlaintextKey()}). Generally this operation will be done either by:
-   * <p>
    * <ul>
    * <li>the code reading an encrypted stream and coming across the encrypted version of one of these keys, OR
    * <li>the {@link CryptoModuleParameters#getKeyEncryptionStrategyClass()} that encrypted the plaintext key (see
@@ -285,11 +282,9 @@ public class CryptoModuleParameters {
    * For <b>encryption</b>, this value is generally not required, but is usually set by the underlying module during encryption. <br>
    * For <b>decryption</b>, this value is <b>usually required</b>.
    *
-   *
    * @param encryptedKey
    *          the encrypted value of the plaintext key
    */
-
   public void setEncryptedKey(byte[] encryptedKey) {
     this.encryptedKey = encryptedKey;
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/examples/simple/src/main/java/org/apache/accumulo/examples/simple/filedata/ChunkCombiner.java
----------------------------------------------------------------------
diff --git a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/filedata/ChunkCombiner.java b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/filedata/ChunkCombiner.java
index ca77b39..0ffeca0 100644
--- a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/filedata/ChunkCombiner.java
+++ b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/filedata/ChunkCombiner.java
@@ -34,20 +34,20 @@ import org.apache.hadoop.io.Text;
  * This iterator dedupes chunks and sets their visibilities to the combined visibility of the refs columns. For example, it would combine
  *
  * <pre>
- *    row1 refs uid1\0a A&B V0
- *    row1 refs uid2\0b C&D V0
- *    row1 ~chunk 0 A&B V1
- *    row1 ~chunk 0 C&D V1
- *    row1 ~chunk 0 E&F V1
- *    row1 ~chunk 0 G&H V1
+ *    row1 refs uid1\0a A&amp;B V0
+ *    row1 refs uid2\0b C&amp;D V0
+ *    row1 ~chunk 0 A&amp;B V1
+ *    row1 ~chunk 0 C&amp;D V1
+ *    row1 ~chunk 0 E&amp;F V1
+ *    row1 ~chunk 0 G&amp;H V1
  * </pre>
  *
  * into the following
  *
  * <pre>
- *    row1 refs uid1\0a A&B V0
- *    row1 refs uid2\0b C&D V0
- *    row1 ~chunk 0 (A&B)|(C&D) V1
+ *    row1 refs uid1\0a A&amp;B V0
+ *    row1 refs uid2\0b C&amp;D V0
+ *    row1 ~chunk 0 (A&amp;B)|(C&amp;D) V1
  * </pre>
  *
  * {@link VisibilityCombiner} is used to combie the visibilities.

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/server/base/src/main/java/org/apache/accumulo/server/ServerConstants.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/ServerConstants.java b/server/base/src/main/java/org/apache/accumulo/server/ServerConstants.java
index 2b654ca..137a3fe 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/ServerConstants.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/ServerConstants.java
@@ -40,7 +40,7 @@ public class ServerConstants {
   public static final String INSTANCE_ID_DIR = "instance_id";
 
   /**
-   * current version (3) reflects additional namespace operations (ACCUMULO-802) in version 1.6.0 <br />
+   * current version (3) reflects additional namespace operations (ACCUMULO-802) in version 1.6.0<br>
    * (versions should never be negative)
    */
   public static final Integer WIRE_VERSION = 3;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java b/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java
index 6f34247..273c9de 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java
@@ -255,7 +255,7 @@ public class SecurityOperation {
   }
 
   /**
-   * Checks if a user has a system permission<br/>
+   * Checks if a user has a system permission<br>
    * This cannot check if a system user has permission.
    *
    * @return true if a user exists and has permission; false otherwise
@@ -289,7 +289,7 @@ public class SecurityOperation {
   }
 
   /**
-   * Checks if a user has a table permission<br/>
+   * Checks if a user has a table permission<br>
    * This cannot check if a system user has permission.
    *
    * @return true if a user exists and has permission; false otherwise
@@ -312,7 +312,7 @@ public class SecurityOperation {
   }
 
   /**
-   * Checks if a user has a namespace permission<br/>
+   * Checks if a user has a namespace permission<br>
    * This cannot check if a system user has permission.
    *
    * @return true if a user exists and has permission; false otherwise

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/server/base/src/test/java/org/apache/accumulo/server/security/SystemCredentialsTest.java
----------------------------------------------------------------------
diff --git a/server/base/src/test/java/org/apache/accumulo/server/security/SystemCredentialsTest.java b/server/base/src/test/java/org/apache/accumulo/server/security/SystemCredentialsTest.java
index a4db195..a4c5fd6 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/security/SystemCredentialsTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/security/SystemCredentialsTest.java
@@ -54,7 +54,7 @@ public class SystemCredentialsTest {
 
   /**
    * This is a test to ensure the string literal in {@link ConnectorImpl#ConnectorImpl(Instance, Credentials)} is kept up-to-date if we move the
-   * {@link SystemToken}<br/>
+   * {@link SystemToken}<br>
    * This check will not be needed after ACCUMULO-1578
    */
   @Test

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/DefaultServlet.java
----------------------------------------------------------------------
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/DefaultServlet.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/DefaultServlet.java
index bb7e690..ef2f872 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/DefaultServlet.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/DefaultServlet.java
@@ -201,7 +201,7 @@ public class DefaultServlet extends BasicServlet {
     sb.append("</td>\n");
 
     sb.append("</tr></table>\n");
-    sb.append("<br/>\n");
+    sb.append("<br />\n");
 
     sb.append("<p/><table class=\"noborder\">\n");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/c8c0cf7f/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/TablesServlet.java
----------------------------------------------------------------------
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/TablesServlet.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/TablesServlet.java
index 19633b8..224ba91 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/TablesServlet.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/TablesServlet.java
@@ -92,9 +92,9 @@ public class TablesServlet extends BasicServlet {
     tableList.addSortableColumn("Entries<br />In&nbsp;Memory", new NumberType<Long>(),
         "The total number of key/value pairs stored in memory and not yet written to disk");
     tableList.addSortableColumn("Ingest", new NumberType<Long>(), "The number of Key/Value pairs inserted.  Note that deletes are 'inserted'.");
-    tableList.addSortableColumn("Entries<br/>Read", new NumberType<Long>(),
+    tableList.addSortableColumn("Entries<br />Read", new NumberType<Long>(),
         "The number of Key/Value pairs read on the server side.  Not all key values read may be returned to client because of filtering.");
-    tableList.addSortableColumn("Entries<br/>Returned", new NumberType<Long>(),
+    tableList.addSortableColumn("Entries<br />Returned", new NumberType<Long>(),
         "The number of Key/Value pairs returned to clients during queries.  This is <b>not</b> the number of scans.");
     tableList.addSortableColumn("Hold&nbsp;Time", new DurationType(0l, 0l),
         "The amount of time that ingest operations are suspended while waiting for data to be written to disk.");