You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by ec...@apache.org on 2014/01/09 00:33:06 UTC

[3/4] ACCUMULO-2160 fixed up a lot of findbugs/pmd complaints

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java
index dc99d5e..5586d9c 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java
@@ -397,14 +397,14 @@ public class TabletServerBatchWriter {
       log.trace(String.format("Total bin time       : %,10.2f secs %6.2f%s", totalBinTime.get() / 1000.0,
           100.0 * totalBinTime.get() / (finishTime - startTime), "%"));
       log.trace(String.format("Average bin rate     : %,10.2f mutations/sec", totalBinned.get() / (totalBinTime.get() / 1000.0)));
-      log.trace(String.format("tservers per batch   : %,8.2f avg  %,6d min %,6d max", (tabletServersBatchSum / (double) numBatches), minTabletServersBatch,
+      log.trace(String.format("tservers per batch   : %,8.2f avg  %,6d min %,6d max", tabletServersBatchSum / (double) numBatches, minTabletServersBatch,
           maxTabletServersBatch));
-      log.trace(String.format("tablets per batch    : %,8.2f avg  %,6d min %,6d max", (tabletBatchSum / (double) numBatches), minTabletBatch, maxTabletBatch));
+      log.trace(String.format("tablets per batch    : %,8.2f avg  %,6d min %,6d max", tabletBatchSum / (double) numBatches, minTabletBatch, maxTabletBatch));
       log.trace("");
       log.trace("SYSTEM STATISTICS");
       log.trace(String.format("JVM GC Time          : %,10.2f secs", ((finalGCTimes - initialGCTimes) / 1000.0)));
       if (compMxBean.isCompilationTimeMonitoringSupported()) {
-        log.trace(String.format("JVM Compile Time     : %,10.2f secs", ((finalCompileTimes - initialCompileTimes) / 1000.0)));
+        log.trace(String.format("JVM Compile Time     : %,10.2f secs", (finalCompileTimes - initialCompileTimes) / 1000.0));
       }
       log.trace(String.format("System load average : initial=%6.2f final=%6.2f", initialSystemLoad, finalSystemLoad));
     }
@@ -506,7 +506,7 @@ public class TabletServerBatchWriter {
     somethingFailed = true;
     this.serverSideErrors.add(server);
     this.notifyAll();
-    log.error("Server side error on " + server);
+    log.error("Server side error on " + server + ": " + e);
   }
   
   private synchronized void updateUnknownErrors(String msg, Throwable t) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/impl/Translator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/Translator.java b/core/src/main/java/org/apache/accumulo/core/client/impl/Translator.java
index 1f6aa19..cfdd080 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/Translator.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/Translator.java
@@ -51,14 +51,14 @@ public abstract class Translator<IT,OT> {
     }
   }
   
-  public static class TCVSTranslator extends Translator<TConstraintViolationSummary,org.apache.accumulo.core.data.ConstraintViolationSummary> {
+  public static class TCVSTranslator extends Translator<TConstraintViolationSummary,ConstraintViolationSummary> {
     @Override
     public ConstraintViolationSummary translate(TConstraintViolationSummary input) {
       return new ConstraintViolationSummary(input);
     }
   }
   
-  public static class CVSTranslator extends Translator<org.apache.accumulo.core.data.ConstraintViolationSummary,TConstraintViolationSummary> {
+  public static class CVSTranslator extends Translator<ConstraintViolationSummary,TConstraintViolationSummary> {
     @Override
     public TConstraintViolationSummary translate(ConstraintViolationSummary input) {
       return input.toThrift();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/mapred/AbstractInputFormat.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapred/AbstractInputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapred/AbstractInputFormat.java
index 4e04cf2..ef7bcab 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapred/AbstractInputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapred/AbstractInputFormat.java
@@ -25,6 +25,7 @@ import java.util.Iterator;
 import java.util.LinkedList;
 import java.util.List;
 import java.util.Map;
+import java.util.Random;
 
 import org.apache.accumulo.core.client.AccumuloException;
 import org.apache.accumulo.core.client.AccumuloSecurityException;
@@ -449,8 +450,9 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
         throw new IOException(e);
       }
 
+      
       // setup a scanner within the bounds of this split
-      for (Pair<Text,Text> c : tableConfig.getFetchedColumns()) {
+      for (Pair<Text,Text> c : columns) {
         if (c.getSecond() != null) {
           log.debug("Fetching column " + c.getFirst() + ":" + c.getSecond());
           scanner.fetchColumn(c.getFirst(), c.getSecond());
@@ -505,6 +507,7 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
     log.setLevel(logLevel);
     validateOptions(job);
 
+    Random random = new Random();
     LinkedList<InputSplit> splits = new LinkedList<InputSplit>();
     Map<String,InputTableConfig> tableConfigs = getInputTableConfigs(job);
     for (Map.Entry<String,InputTableConfig> tableConfigEntry : tableConfigs.entrySet()) {
@@ -546,7 +549,7 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
           binnedRanges = binOfflineTable(job, tableId, ranges);
           while (binnedRanges == null) {
             // Some tablets were still online, try again
-            UtilWaitThread.sleep(100 + (int) (Math.random() * 100)); // sleep randomly between 100 and 200 ms
+            UtilWaitThread.sleep(100 + random.nextInt(100)); // sleep randomly between 100 and 200 ms
             binnedRanges = binOfflineTable(job, tableId, ranges);
           }
         } else {
@@ -564,7 +567,7 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
             }
             binnedRanges.clear();
             log.warn("Unable to locate bins for specified ranges. Retrying.");
-            UtilWaitThread.sleep(100 + (int) (Math.random() * 100)); // sleep randomly between 100 and 200 ms
+            UtilWaitThread.sleep(100 + random.nextInt(100)); // sleep randomly between 100 and 200 ms
             tl.invalidateCache();
           }
         }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AbstractInputFormat.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AbstractInputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AbstractInputFormat.java
index 35587d4..971dff5 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AbstractInputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AbstractInputFormat.java
@@ -26,6 +26,7 @@ import java.util.Iterator;
 import java.util.LinkedList;
 import java.util.List;
 import java.util.Map;
+import java.util.Random;
 
 import org.apache.accumulo.core.client.AccumuloException;
 import org.apache.accumulo.core.client.AccumuloSecurityException;
@@ -525,7 +526,7 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
     Level logLevel = getLogLevel(context);
     log.setLevel(logLevel);
     validateOptions(context);
-
+    Random random = new Random();
     LinkedList<InputSplit> splits = new LinkedList<InputSplit>();
     Map<String,InputTableConfig> tableConfigs = getInputTableConfigs(context);
     for (Map.Entry<String,InputTableConfig> tableConfigEntry : tableConfigs.entrySet()) {
@@ -568,7 +569,7 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
           binnedRanges = binOfflineTable(context, tableId, ranges);
           while (binnedRanges == null) {
             // Some tablets were still online, try again
-            UtilWaitThread.sleep(100 + (int) (Math.random() * 100)); // sleep randomly between 100 and 200 ms
+            UtilWaitThread.sleep(100 + random.nextInt(100)); // sleep randomly between 100 and 200 ms
             binnedRanges = binOfflineTable(context, tableId, ranges);
 
           }
@@ -587,7 +588,7 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
             }
             binnedRanges.clear();
             log.warn("Unable to locate bins for specified ranges. Retrying.");
-            UtilWaitThread.sleep(100 + (int) (Math.random() * 100)); // sleep randomly between 100 and 200 ms
+            UtilWaitThread.sleep(100 + random.nextInt(100)); // sleep randomly between 100 and 200 ms
             tl.invalidateCache();
           }
         }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplit.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplit.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplit.java
index 98b1a32..b238903 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplit.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplit.java
@@ -21,6 +21,7 @@ import java.io.DataOutput;
 import java.io.IOException;
 import java.math.BigInteger;
 import java.util.ArrayList;
+import java.util.Arrays;
 import java.util.Collection;
 import java.util.HashSet;
 import java.util.List;
@@ -318,7 +319,7 @@ public class RangeInputSplit extends InputSplit implements Writable {
   public String toString() {
     StringBuilder sb = new StringBuilder(256);
     sb.append("Range: ").append(range);
-    sb.append(" Locations: ").append(locations);
+    sb.append(" Locations: ").append(Arrays.asList(locations));
     sb.append(" Table: ").append(tableName);
     sb.append(" TableID: ").append(tableId);
     sb.append(" InstanceName: ").append(instanceName);
@@ -417,7 +418,7 @@ public class RangeInputSplit extends InputSplit implements Writable {
   }
 
   public void setLocations(String[] locations) {
-    this.locations = locations;
+    this.locations = Arrays.copyOf(locations, locations.length);
   }
 
   public Boolean isMockInstance() {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/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 8e2af63..99cc721 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
@@ -126,7 +126,7 @@ public interface AuthenticationToken extends Writable, Destroyable, Cloneable {
     }
   }
   
-  public class Properties implements Destroyable, Map<String,char[]> {
+  class Properties implements Destroyable, Map<String,char[]> {
     
     private boolean destroyed = false;
     private HashMap<String,char[]> map = new HashMap<String,char[]>();
@@ -233,13 +233,13 @@ public interface AuthenticationToken extends Writable, Destroyable, Cloneable {
     }
     
     @Override
-    public Set<java.util.Map.Entry<String,char[]>> entrySet() {
+    public Set<Map.Entry<String,char[]>> entrySet() {
       checkDestroyed();
       return map.entrySet();
     }
   }
   
-  public static class TokenProperty implements Comparable<TokenProperty> {
+  static class TokenProperty implements Comparable<TokenProperty> {
     private String key, description;
     private boolean masked;
     

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/security/tokens/NullToken.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/NullToken.java b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/NullToken.java
index 8673963..474b4a1 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/NullToken.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/NullToken.java
@@ -31,17 +31,14 @@ public class NullToken implements AuthenticationToken {
   
   @Override
   public void readFields(DataInput arg0) throws IOException {
-    return;
   }
   
   @Override
   public void write(DataOutput arg0) throws IOException {
-    return;
   }
   
   @Override
   public void destroy() throws DestroyFailedException {
-    return;
   }
   
   @Override

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/security/tokens/PasswordToken.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/PasswordToken.java b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/PasswordToken.java
index 11bbf49..1474435 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/PasswordToken.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/PasswordToken.java
@@ -40,7 +40,7 @@ public class PasswordToken implements AuthenticationToken {
   private byte[] password = null;
   
   public byte[] getPassword() {
-    return password;
+    return Arrays.copyOf(password, password.length);
   }
   
   /**

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/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 8685d43..6d20cb0 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
@@ -32,7 +32,7 @@ import org.apache.log4j.Logger;
 
 public abstract class AccumuloConfiguration implements Iterable<Entry<String,String>> {
 
-  public static interface PropertyFilter {
+  public interface PropertyFilter {
     boolean accept(String key);
   }
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/conf/ConfigSanityCheck.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/ConfigSanityCheck.java b/core/src/main/java/org/apache/accumulo/core/conf/ConfigSanityCheck.java
index 6724670..f9781f4 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/ConfigSanityCheck.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/ConfigSanityCheck.java
@@ -43,7 +43,7 @@ public class ConfigSanityCheck {
     checkTimeDuration(acuconf, Property.INSTANCE_ZK_TIMEOUT, new CheckTimeDurationBetween(1000, 300000));
   }
   
-  private static interface CheckTimeDuration {
+  private interface CheckTimeDuration {
     boolean check(long propVal);
     
     String getDescription(Property prop);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/conf/PropertyType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/PropertyType.java b/core/src/main/java/org/apache/accumulo/core/conf/PropertyType.java
index 688b186..16f22e4 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/PropertyType.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/PropertyType.java
@@ -17,6 +17,7 @@
 package org.apache.accumulo.core.conf;
 
 import java.util.regex.Pattern;
+import java.util.Arrays;
 
 import org.apache.accumulo.core.Constants;
 import org.apache.hadoop.fs.Path;
@@ -49,9 +50,9 @@ public enum PropertyType {
       "A floating point number that represents either a fraction or, if suffixed with the '%' character, a percentage.<br />"
           + "Examples of valid fractions/percentages are '10', '1000%', '0.05', '5%', '0.2%', '0.0005'.<br />"
           + "Examples of invalid fractions/percentages are '', '10 percent', 'Hulk Hogan'"),
-  
+
   PATH("path", ".*",
-      "A string that represents a filesystem path, which can be either relative or absolute to some directory. The filesystem depends on the property.  The following environment variables will be substituted: " + Constants.PATH_PROPERTY_ENV_VARS),
+      "A string that represents a filesystem path, which can be either relative or absolute to some directory. The filesystem depends on the property.  The following environment variables will be substituted: " + Arrays.asList(Constants.PATH_PROPERTY_ENV_VARS)),
   ABSOLUTEPATH("absolute path", null,
       "An absolute filesystem path. The filesystem depends on the property. This is the same as path, but enforces that its root is explicitly specified.") {
     @Override

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/constraints/Constraint.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/constraints/Constraint.java b/core/src/main/java/org/apache/accumulo/core/constraints/Constraint.java
index 89b2dc8..1ddc892 100644
--- a/core/src/main/java/org/apache/accumulo/core/constraints/Constraint.java
+++ b/core/src/main/java/org/apache/accumulo/core/constraints/Constraint.java
@@ -42,7 +42,7 @@ import org.apache.accumulo.core.security.Authorizations;
 
 public interface Constraint {
   
-  public interface Environment {
+  interface Environment {
     KeyExtent getExtent();
     
     String getUser();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/data/ColumnUpdate.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/ColumnUpdate.java b/core/src/main/java/org/apache/accumulo/core/data/ColumnUpdate.java
index 641ca3a..38589af 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/ColumnUpdate.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/ColumnUpdate.java
@@ -77,8 +77,8 @@ public class ColumnUpdate {
   
   @Override
   public String toString() {
-    return new String(Arrays.toString(columnFamily)) + ":" + new String(Arrays.toString(columnQualifier)) + " ["
-        + new String(Arrays.toString(columnVisibility)) + "] " + (hasTimestamp ? timestamp : "NO_TIME_STAMP") + " " + Arrays.toString(val) + " " + deleted;
+    return Arrays.toString(columnFamily) + ":" + Arrays.toString(columnQualifier) + " ["
+        + Arrays.toString(columnVisibility) + "] " + (hasTimestamp ? timestamp : "NO_TIME_STAMP") + " " + Arrays.toString(val) + " " + deleted;
   }
   
   @Override
@@ -94,7 +94,7 @@ public class ColumnUpdate {
   @Override
   public int hashCode() {
     return Arrays.hashCode(columnFamily) + Arrays.hashCode(columnQualifier) + Arrays.hashCode(columnVisibility)
-        + (hasTimestamp ? (Boolean.TRUE.hashCode() + new Long(timestamp).hashCode()) : Boolean.FALSE.hashCode())
+        + (hasTimestamp ? (Boolean.TRUE.hashCode() + Long.valueOf(timestamp).hashCode()) : Boolean.FALSE.hashCode())
         + (deleted ? Boolean.TRUE.hashCode() : (Boolean.FALSE.hashCode() + Arrays.hashCode(val)));
   }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/data/Condition.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/Condition.java b/core/src/main/java/org/apache/accumulo/core/data/Condition.java
index fc8f2bf..c80dcd6 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/Condition.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/Condition.java
@@ -205,7 +205,7 @@ public class Condition {
     if (o == this) {
       return true;
     }
-    if (o == null || o.getClass() != Condition.class) {
+    if (o == null || !(o instanceof Condition)) {
       return false;
     }
     Condition c = (Condition) o;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/data/ConditionalMutation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/ConditionalMutation.java b/core/src/main/java/org/apache/accumulo/core/data/ConditionalMutation.java
index da72493..c1206e5 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/ConditionalMutation.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/ConditionalMutation.java
@@ -84,7 +84,7 @@ public class ConditionalMutation extends Mutation {
     if (o == this) {
       return true;
     }
-    if (o == null || o.getClass() != ConditionalMutation.class) {
+    if (o == null || !(o instanceof ConditionalMutation)) {
       return false;
     }
     ConditionalMutation cm = (ConditionalMutation) o;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/data/KeyExtent.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/KeyExtent.java b/core/src/main/java/org/apache/accumulo/core/data/KeyExtent.java
index 9dc8db5..dda78fb 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/KeyExtent.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/KeyExtent.java
@@ -357,7 +357,7 @@ public class KeyExtent implements WritableComparable<KeyExtent> {
             }
           } else {
             // no null prevend or endrows and no empty string start or end rows
-            if ((ckes.getPrevEndRow().compareTo(endRow) < 0 && ckes.getEndRow().compareTo(startRow) >= 0)) {
+            if (ckes.getPrevEndRow().compareTo(endRow) < 0 && ckes.getEndRow().compareTo(startRow) >= 0) {
               keys.add(ckes);
             }
           }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/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 65873c3..26faea8 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
@@ -408,7 +408,7 @@ public class Range implements WritableComparable<Range> {
       boolean startKeysEqual;
       if (range.infiniteStartKey) {
         // previous start key must be infinite because it is sorted
-        assert (currentRange.infiniteStartKey);
+        assert currentRange.infiniteStartKey;
         startKeysEqual = true;
       } else if (currentRange.infiniteStartKey) {
         startKeysEqual = false;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/FileSKVIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/FileSKVIterator.java b/core/src/main/java/org/apache/accumulo/core/file/FileSKVIterator.java
index b5674bf..2de5cfc 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/FileSKVIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/FileSKVIterator.java
@@ -23,13 +23,13 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.iterators.system.InterruptibleIterator;
 
 public interface FileSKVIterator extends InterruptibleIterator {
-  public Key getFirstKey() throws IOException;
+  Key getFirstKey() throws IOException;
   
-  public Key getLastKey() throws IOException;
+  Key getLastKey() throws IOException;
   
-  public DataInputStream getMetaStore(String name) throws IOException, NoSuchMetaStoreException;
+  DataInputStream getMetaStore(String name) throws IOException, NoSuchMetaStoreException;
   
-  public void closeDeepCopies() throws IOException;
+  void closeDeepCopies() throws IOException;
   
-  public void close() throws IOException;
+  void close() throws IOException;
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/FileUtil.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/FileUtil.java b/core/src/main/java/org/apache/accumulo/core/file/FileUtil.java
index 33e1835..b06a9bf 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/FileUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/FileUtil.java
@@ -26,6 +26,7 @@ import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
 import java.util.Map.Entry;
+import java.util.Random;
 import java.util.Set;
 import java.util.SortedMap;
 import java.util.TreeMap;
@@ -74,10 +75,10 @@ public class FileUtil {
   
   private static String createTmpDir(AccumuloConfiguration acuConf, FileSystem fs) throws IOException {
     String accumuloDir = acuConf.get(Property.INSTANCE_DFS_DIR);
-    
+    Random random = new Random();
     String tmpDir = null;
     while (tmpDir == null) {
-      tmpDir = accumuloDir + "/tmp/idxReduce_" + String.format("%09d", (int) (Math.random() * Integer.MAX_VALUE));
+      tmpDir = accumuloDir + "/tmp/idxReduce_" + String.format("%09d", random.nextInt(Integer.MAX_VALUE));
       
       try {
         fs.getFileStatus(new Path(tmpDir));
@@ -338,7 +339,7 @@ public class FileUtil {
       
       long t2 = System.currentTimeMillis();
       
-      log.debug(String.format("Found midPoint from indexes in %6.2f secs.%n", ((t2 - t1) / 1000.0)));
+      log.debug(String.format("Found midPoint from indexes in %6.2f secs.%n", (t2 - t1) / 1000.0));
       
       ret.put(.5, mmfi.getTopKey());
       

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockReader.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockReader.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockReader.java
index af95060..592d325 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockReader.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockReader.java
@@ -28,26 +28,26 @@ import java.io.IOException;
 
 public interface ABlockReader extends DataInput {
   
-  public long getRawSize();
+  long getRawSize();
   
-  public DataInputStream getStream() throws IOException;
+  DataInputStream getStream() throws IOException;
   
-  public void close() throws IOException;
+  void close() throws IOException;
   
   /**
    * An indexable block supports seeking, getting a position, and associating an arbitrary index with the block
    * 
    * @return true, if the block is indexable; otherwise false.
    */
-  public boolean isIndexable();
+  boolean isIndexable();
 
-  public void seek(int position);
+  void seek(int position);
 
   /** Get the file position.
 
    * @return the file position.
    */
-  public int getPosition();
+  int getPosition();
 
   <T> T getIndex(Class<T> clazz);
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockWriter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockWriter.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockWriter.java
index 1ab4668..19b6f0c 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockWriter.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockWriter.java
@@ -28,14 +28,14 @@ import java.io.IOException;
 
 public interface ABlockWriter extends DataOutput {
   
-  public long getCompressedSize() throws IOException;
+  long getCompressedSize() throws IOException;
   
-  public void close() throws IOException;
+  void close() throws IOException;
   
-  public long getRawSize() throws IOException;
+  long getRawSize() throws IOException;
   
-  public long getStartPos() throws IOException;
+  long getStartPos() throws IOException;
   
-  public DataOutputStream getStream() throws IOException;
+  DataOutputStream getStream() throws IOException;
   
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/blockfile/BlockFileReader.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/BlockFileReader.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/BlockFileReader.java
index c5a1d5e..2c918aa 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/BlockFileReader.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/BlockFileReader.java
@@ -28,14 +28,14 @@ import java.io.IOException;
 
 public interface BlockFileReader {
   
-  public ABlockReader getMetaBlock(String name) throws IOException;
+  ABlockReader getMetaBlock(String name) throws IOException;
   
-  public ABlockReader getDataBlock(int blockIndex) throws IOException;
+  ABlockReader getDataBlock(int blockIndex) throws IOException;
   
-  public void close() throws IOException;
+  void close() throws IOException;
   
-  public ABlockReader getMetaBlock(long offset, long compressedSize, long rawSize) throws IOException;
+  ABlockReader getMetaBlock(long offset, long compressedSize, long rawSize) throws IOException;
   
-  public ABlockReader getDataBlock(long offset, long compressedSize, long rawSize) throws IOException;
+  ABlockReader getDataBlock(long offset, long compressedSize, long rawSize) throws IOException;
   
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/blockfile/BlockFileWriter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/BlockFileWriter.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/BlockFileWriter.java
index 56c1797..cf86006 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/BlockFileWriter.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/BlockFileWriter.java
@@ -28,11 +28,11 @@ import java.io.IOException;
 
 public interface BlockFileWriter {
   
-  public ABlockWriter prepareMetaBlock(String name, String compressionName) throws IOException;
+  ABlockWriter prepareMetaBlock(String name, String compressionName) throws IOException;
   
-  public ABlockWriter prepareMetaBlock(String name) throws IOException;
+  ABlockWriter prepareMetaBlock(String name) throws IOException;
   
-  public ABlockWriter prepareDataBlock() throws IOException;
+  ABlockWriter prepareDataBlock() throws IOException;
   
-  public void close() throws IOException;
+  void close() throws IOException;
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/BlockCache.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/BlockCache.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/BlockCache.java
index adbc586..8673385 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/BlockCache.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/BlockCache.java
@@ -33,7 +33,7 @@ public interface BlockCache {
    * @param inMemory
    *          Whether block should be treated as in-memory
    */
-  public CacheEntry cacheBlock(String blockName, byte buf[], boolean inMemory);
+  CacheEntry cacheBlock(String blockName, byte buf[], boolean inMemory);
   
   /**
    * Add block to cache (defaults to not in-memory).
@@ -43,7 +43,7 @@ public interface BlockCache {
    * @param buf
    *          The block contents wrapped in a ByteBuffer.
    */
-  public CacheEntry cacheBlock(String blockName, byte buf[]);
+  CacheEntry cacheBlock(String blockName, byte buf[]);
   
   /**
    * Fetch block from cache.
@@ -52,17 +52,17 @@ public interface BlockCache {
    *          Block number to fetch.
    * @return Block or null if block is not in the cache.
    */
-  public CacheEntry getBlock(String blockName);
+  CacheEntry getBlock(String blockName);
   
   /**
    * Shutdown the cache.
    */
-  public void shutdown();
+  void shutdown();
   
   /**
    * Get the maximum size of this cache.
    *
    * @return max size in bytes
    */
-  public long getMaxSize();
+  long getMaxSize();
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CacheEntry.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CacheEntry.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CacheEntry.java
index 609e374..0e628d3 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CacheEntry.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CacheEntry.java
@@ -19,8 +19,8 @@ package org.apache.accumulo.core.file.blockfile.cache;
 public interface CacheEntry {
   byte[] getBuffer();
   
-  public Object getIndex();
+  Object getIndex();
   
-  public void setIndex(Object idx);
+  void setIndex(Object idx);
   
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/HeapSize.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/HeapSize.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/HeapSize.java
index 0aa7e06..ca2402e 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/HeapSize.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/HeapSize.java
@@ -40,6 +40,6 @@ public interface HeapSize {
   /**
    * @return Approximate 'exclusive deep size' of implementing object. Includes count of payload and hosting object sizings.
    */
-  public long heapSize();
+  long heapSize();
   
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/LruBlockCache.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/LruBlockCache.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/LruBlockCache.java
index 007e8a0..83f363e 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/LruBlockCache.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/LruBlockCache.java
@@ -436,11 +436,19 @@ public class LruBlockCache implements BlockCache, HeapSize {
       return totalSize;
     }
     
+    @Override
     public int compareTo(BlockBucket that) {
       if (this.overflow() == that.overflow())
         return 0;
       return this.overflow() > that.overflow() ? 1 : -1;
     }
+    
+    @Override
+    public boolean equals(Object that) {
+      if (that instanceof BlockBucket)
+        return compareTo((BlockBucket)that) == 0;
+      return false;
+    }
   }
   
   /**

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnFamilyFunctor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnFamilyFunctor.java b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnFamilyFunctor.java
index 244bd49..e200b44 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnFamilyFunctor.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnFamilyFunctor.java
@@ -26,7 +26,7 @@ public class ColumnFamilyFunctor implements KeyFunctor {
   public static final PartialKey kDepth = PartialKey.ROW_COLFAM;
   
   @Override
-  public org.apache.hadoop.util.bloom.Key transform(org.apache.accumulo.core.data.Key acuKey) {
+  public Key transform(org.apache.accumulo.core.data.Key acuKey) {
     
     byte keyData[];
     
@@ -36,7 +36,7 @@ public class ColumnFamilyFunctor implements KeyFunctor {
     System.arraycopy(row.getBackingArray(), row.offset(), keyData, 0, row.length());
     System.arraycopy(cf.getBackingArray(), cf.offset(), keyData, row.length(), cf.length());
     
-    return new org.apache.hadoop.util.bloom.Key(keyData, 1.0);
+    return new Key(keyData, 1.0);
   }
   
   @Override

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/KeyFunctor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/KeyFunctor.java b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/KeyFunctor.java
index c5a0e59..69902a4 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/KeyFunctor.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/KeyFunctor.java
@@ -24,7 +24,7 @@ public interface KeyFunctor {
    * Implementations should return null if a range can not be converted to a bloom key.
    * 
    */
-  public org.apache.hadoop.util.bloom.Key transform(Range range);
+  org.apache.hadoop.util.bloom.Key transform(Range range);
   
-  public org.apache.hadoop.util.bloom.Key transform(Key key);
+  org.apache.hadoop.util.bloom.Key transform(Key key);
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/RowFunctor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/RowFunctor.java b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/RowFunctor.java
index 06597a3..20eb26c 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/RowFunctor.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/RowFunctor.java
@@ -24,14 +24,14 @@ import org.apache.hadoop.util.bloom.Key;
 public class RowFunctor implements KeyFunctor {
   
   @Override
-  public org.apache.hadoop.util.bloom.Key transform(org.apache.accumulo.core.data.Key acuKey) {
+  public Key transform(org.apache.accumulo.core.data.Key acuKey) {
     byte keyData[];
     
     ByteSequence row = acuKey.getRowData();
     keyData = new byte[row.length()];
     System.arraycopy(row.getBackingArray(), 0, keyData, 0, row.length());
     
-    return new org.apache.hadoop.util.bloom.Key(keyData, 1.0);
+    return new Key(keyData, 1.0);
   }
   
   @Override

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/rfile/BlockIndex.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/BlockIndex.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/BlockIndex.java
index 2b3cdf5..e8829f9 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/BlockIndex.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/BlockIndex.java
@@ -86,6 +86,13 @@ public class BlockIndex {
     }
     
     @Override
+    public boolean equals(Object o) {
+      if (o instanceof BlockIndexEntry)
+        return compareTo((BlockIndexEntry) o) == 0;
+      return false;
+    }
+    
+    @Override
     public String toString() {
       return prevKey + " " + entriesLeft + " " + pos;
     }
@@ -93,6 +100,12 @@ public class BlockIndex {
     public Key getPrevKey() {
       return prevKey;
     }
+    
+    @Override
+    public int hashCode() {
+      assert false : "hashCode not designed";
+      return 42; // any arbitrary constant will do
+    }
   }
   
   public BlockIndexEntry seekBlock(Key startKey, ABlockReader cacheBlock) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/rfile/MultiLevelIndex.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/MultiLevelIndex.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/MultiLevelIndex.java
index 15918ec..632968e 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/MultiLevelIndex.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/MultiLevelIndex.java
@@ -114,6 +114,19 @@ public class MultiLevelIndex {
     public int compareTo(IndexEntry o) {
       return key.compareTo(o.key);
     }
+    
+    @Override
+    public boolean equals(Object o) {
+      if (o instanceof IndexEntry)
+        return compareTo((IndexEntry)o) == 0;
+      return false;
+    }
+    
+    @Override
+    public int hashCode() {
+      assert false : "hashCode not designed";
+      return 42; // any arbitrary constant will do
+    }
   }
   
   // a list that deserializes index entries on demand
@@ -585,7 +598,7 @@ public class MultiLevelIndex {
       }
     }
     
-    public class IndexIterator implements ListIterator<IndexEntry> {
+    static public class IndexIterator implements ListIterator<IndexEntry> {
       
       private Node node;
       private ListIterator<IndexEntry> liter;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/rfile/RFile.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/RFile.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/RFile.java
index d6a2532..da5a3ea 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/RFile.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/RFile.java
@@ -260,7 +260,7 @@ public class RFile {
       out.println("\tFirst key            : " + firstKey);
       
       Key lastKey = null;
-      if (indexReader != null && indexReader.size() > 0) {
+      if (indexReader.size() > 0) {
         lastKey = indexReader.getLastKey();
       }
       

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/BCFile.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/BCFile.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/BCFile.java
index f91ac59..6083a62 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/BCFile.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/BCFile.java
@@ -106,7 +106,7 @@ public final class BCFile {
     /**
      * Call-back interface to register a block after a block is closed.
      */
-    private static interface BlockRegister {
+    private interface BlockRegister {
       /**
        * Register a block that is fully closed.
        * 
@@ -117,7 +117,7 @@ public final class BCFile {
        * @param offsetEnd
        *          One byte after the end of the block. Compressed block size is offsetEnd - offsetStart.
        */
-      public void register(long raw, long offsetStart, long offsetEnd);
+      void register(long raw, long offsetStart, long offsetEnd);
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/CompareUtils.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/CompareUtils.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/CompareUtils.java
index 9dba4b1..4642fc1 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/CompareUtils.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/CompareUtils.java
@@ -52,7 +52,7 @@ class CompareUtils {
   /**
    * Interface for all objects that has a single integer magnitude.
    */
-  static interface Scalar {
+  interface Scalar {
     long magnitude();
   }
   

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/RawComparable.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/RawComparable.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/RawComparable.java
index e45a950..48c0bfe 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/RawComparable.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/RawComparable.java
@@ -35,19 +35,19 @@ public interface RawComparable {
    * 
    * @return The underlying byte array.
    */
-  abstract byte[] buffer();
+  byte[] buffer();
   
   /**
    * Get the offset of the first byte in the byte array.
    * 
    * @return The offset of the first byte in the byte array.
    */
-  abstract int offset();
+  int offset();
   
   /**
    * Get the size of the byte range in the byte array.
    * 
    * @return The size of the byte range in the byte array.
    */
-  abstract int size();
+  int size();
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/iterators/OptionDescriber.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/OptionDescriber.java b/core/src/main/java/org/apache/accumulo/core/iterators/OptionDescriber.java
index 209d3d9..6069a39 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/OptionDescriber.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/OptionDescriber.java
@@ -31,7 +31,7 @@ import java.util.Map;
  * 
  */
 public interface OptionDescriber {
-  public static class IteratorOptions {
+  public class IteratorOptions {
     public LinkedHashMap<String,String> namedOptions;
     public ArrayList<String> unnamedOptionDescriptions;
     public String name;
@@ -115,7 +115,7 @@ public interface OptionDescriber {
    * 
    * @return an iterator options object
    */
-  public IteratorOptions describeOptions();
+  IteratorOptions describeOptions();
   
   /**
    * Check to see if an options map contains all options required by an iterator and that the option values are in the expected formats.
@@ -126,5 +126,5 @@ public interface OptionDescriber {
    * @exception IllegalArgumentException
    *              if there are problems with the options
    */
-  public boolean validateOptions(Map<String,String> options);
+  boolean validateOptions(Map<String,String> options);
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/iterators/TypedValueCombiner.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/TypedValueCombiner.java b/core/src/main/java/org/apache/accumulo/core/iterators/TypedValueCombiner.java
index 54a1333..00fa89a 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/TypedValueCombiner.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/TypedValueCombiner.java
@@ -107,10 +107,10 @@ public abstract class TypedValueCombiner<V> extends Combiner {
   /**
    * An interface for translating from byte[] to V and back.
    */
-  public static interface Encoder<V> {
-    public byte[] encode(V v);
+  public interface Encoder<V> {
+    byte[] encode(V v);
     
-    public V decode(byte[] b) throws ValueFormatException;
+    V decode(byte[] b) throws ValueFormatException;
   }
   
   /**

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/iterators/system/InterruptibleIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/system/InterruptibleIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/system/InterruptibleIterator.java
index 08a86b2..a9a871d 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/system/InterruptibleIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/system/InterruptibleIterator.java
@@ -23,5 +23,5 @@ import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.iterators.SortedKeyValueIterator;
 
 public interface InterruptibleIterator extends SortedKeyValueIterator<Key,Value> {
-  public void setInterruptFlag(AtomicBoolean flag);
+  void setInterruptFlag(AtomicBoolean flag);
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/iterators/user/AgeOffFilter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/AgeOffFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/AgeOffFilter.java
index 54c9597..6e9a571 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/AgeOffFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/AgeOffFilter.java
@@ -51,8 +51,6 @@ public class AgeOffFilter extends Filter {
   
   @Override
   public void init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env) throws IOException {
-    super.init(source, options, env);
-    threshold = -1;
     if (options == null)
       throw new IllegalArgumentException(TTL + " must be set for AgeOffFilter");
     
@@ -60,6 +58,8 @@ public class AgeOffFilter extends Filter {
     if (ttl == null)
       throw new IllegalArgumentException(TTL + " must be set for AgeOffFilter");
     
+    super.init(source, options, env);
+    threshold = -1;
     threshold = Long.parseLong(ttl);
     
     String time = options.get(CURRENT_TIME);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/iterators/user/TimestampFilter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/TimestampFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/TimestampFilter.java
index 1134529..8747aa6 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/TimestampFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/TimestampFilter.java
@@ -69,11 +69,11 @@ public class TimestampFilter extends Filter {
   
   @Override
   public void init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env) throws IOException {
-    super.init(source, options, env);
-    
     if (options == null)
       throw new IllegalArgumentException("start and/or end must be set for " + TimestampFilter.class.getName());
     
+    super.init(source, options, env);
+    
     hasStart = false;
     hasEnd = false;
     startInclusive = true;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/iterators/user/TransformingIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/TransformingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/TransformingIterator.java
index f439437..f851eac 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/TransformingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/TransformingIterator.java
@@ -627,7 +627,7 @@ abstract public class TransformingIterator extends WrappingIterator implements O
    */
   abstract protected PartialKey getKeyPrefix();
   
-  public static interface KVBuffer {
+  public interface KVBuffer {
     void append(Key key, Value val);
   }
   

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/iterators/user/VisibilityFilter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/VisibilityFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/VisibilityFilter.java
index 4e8aa95..6a5db49 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/VisibilityFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/VisibilityFilter.java
@@ -97,12 +97,6 @@ public class VisibilityFilter extends org.apache.accumulo.core.iterators.system.
     return io;
   }
   
-  @Override
-  public boolean validateOptions(Map<String,String> options) {
-    // All local options are valid; only check super options
-    return super.validateOptions(options);
-  }
-  
   public static void setAuthorizations(IteratorSetting setting, Authorizations auths) {
     setting.addOption(AUTHS, auths.serialize());
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/security/AuthorizationContainer.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/AuthorizationContainer.java b/core/src/main/java/org/apache/accumulo/core/security/AuthorizationContainer.java
index 382e20b..029b622 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/AuthorizationContainer.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/AuthorizationContainer.java
@@ -28,5 +28,5 @@ public interface AuthorizationContainer {
    * @param auth authorization, as a string encoded in UTF-8
    * @return true if authorization is in this collection
    */
-  public boolean contains(ByteSequence auth);
+  boolean contains(ByteSequence auth);
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/security/Authorizations.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/Authorizations.java b/core/src/main/java/org/apache/accumulo/core/security/Authorizations.java
index 6047352..8350e2e 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/Authorizations.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/Authorizations.java
@@ -274,7 +274,7 @@ public class Authorizations implements Iterable<byte[]>, Serializable, Authoriza
    * @return true if authorization is in this collection
    */
   public boolean contains(String auth) {
-    return auths.contains(auth.getBytes(Constants.UTF8));
+    return auths.contains(new ArrayByteSequence(auth));
   }
 
   @Override

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModule.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModule.java b/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModule.java
index 01f7888..783709a 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModule.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModule.java
@@ -50,7 +50,7 @@ public interface CryptoModule {
    *         That stream may be exactly the same stream as {@link CryptoModuleParameters#getPlaintextInputStream()} if the params object specifies no cryptography.
    * @throws IOException
    */
-  public CryptoModuleParameters getEncryptingOutputStream(CryptoModuleParameters params) throws IOException;
+  CryptoModuleParameters getEncryptingOutputStream(CryptoModuleParameters params) throws IOException;
   
   
   
@@ -72,7 +72,7 @@ public interface CryptoModule {
    *         That stream may be exactly the same stream as {@link CryptoModuleParameters#getEncryptedInputStream()} if the params object specifies no cryptography.
    * @throws IOException
    */
-  public CryptoModuleParameters getDecryptingInputStream(CryptoModuleParameters params) throws IOException;
+  CryptoModuleParameters getDecryptingInputStream(CryptoModuleParameters params) throws IOException;
 
   
   /**
@@ -83,7 +83,7 @@ public interface CryptoModule {
    * @param params a {@link CryptoModuleParameters} object contained a correctly instantiated set of properties.
    * @return the same {@link CryptoModuleParameters} object with the plaintext key set
    */
-  public CryptoModuleParameters generateNewRandomSessionKey(CryptoModuleParameters params);
+  CryptoModuleParameters generateNewRandomSessionKey(CryptoModuleParameters params);
   
   /**
    * Generates a {@link Cipher} object based on the parameters in the given {@link CryptoModuleParameters} object and places it into the
@@ -93,6 +93,6 @@ public interface CryptoModule {
    * @param params a {@link CryptoModuleParameters} object contained a correctly instantiated set of properties.
    * @return the same {@link CryptoModuleParameters} object with the cipher set.
    */
-  public CryptoModuleParameters initializeCipher(CryptoModuleParameters params);
+  CryptoModuleParameters initializeCipher(CryptoModuleParameters params);
  
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/security/crypto/SecretKeyEncryptionStrategy.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/crypto/SecretKeyEncryptionStrategy.java b/core/src/main/java/org/apache/accumulo/core/security/crypto/SecretKeyEncryptionStrategy.java
index 637ed4b..0cd9bd0 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/crypto/SecretKeyEncryptionStrategy.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/crypto/SecretKeyEncryptionStrategy.java
@@ -21,8 +21,8 @@ package org.apache.accumulo.core.security.crypto;
  */
 public interface SecretKeyEncryptionStrategy {  
   
-  public CryptoModuleParameters encryptSecretKey(CryptoModuleParameters params);
-  public CryptoModuleParameters decryptSecretKey(CryptoModuleParameters params);
+  CryptoModuleParameters encryptSecretKey(CryptoModuleParameters params);
+  CryptoModuleParameters decryptSecretKey(CryptoModuleParameters params);
   
   
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/security/crypto/SecretKeyEncryptionStrategyContext.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/crypto/SecretKeyEncryptionStrategyContext.java b/core/src/main/java/org/apache/accumulo/core/security/crypto/SecretKeyEncryptionStrategyContext.java
index d46d459..dfe948d 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/crypto/SecretKeyEncryptionStrategyContext.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/crypto/SecretKeyEncryptionStrategyContext.java
@@ -20,12 +20,12 @@ package org.apache.accumulo.core.security.crypto;
 import java.util.Map;
 
 public interface SecretKeyEncryptionStrategyContext {
-  public String getOpaqueKeyEncryptionKeyID();
-  public void setOpaqueKeyEncryptionKeyID(String id);
-  public byte[] getPlaintextSecretKey();
-  public void setPlaintextSecretKey(byte[] key);
-  public byte[] getEncryptedSecretKey();
-  public void setEncryptedSecretKey(byte[] key);
-  public Map<String, String> getContext();
-  public void setContext(Map<String, String> context);
+  String getOpaqueKeyEncryptionKeyID();
+  void setOpaqueKeyEncryptionKeyID(String id);
+  byte[] getPlaintextSecretKey();
+  void setPlaintextSecretKey(byte[] key);
+  byte[] getEncryptedSecretKey();
+  void setEncryptedSecretKey(byte[] key);
+  Map<String, String> getContext();
+  void setContext(Map<String, String> context);
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/trace/SpanTree.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/trace/SpanTree.java b/core/src/main/java/org/apache/accumulo/core/trace/SpanTree.java
index 2a5d72e..772a133 100644
--- a/core/src/main/java/org/apache/accumulo/core/trace/SpanTree.java
+++ b/core/src/main/java/org/apache/accumulo/core/trace/SpanTree.java
@@ -42,7 +42,7 @@ public class SpanTree {
   
   public Set<Long> visit(SpanTreeVisitor visitor) {
     Set<Long> visited = new HashSet<Long>();
-    List<Long> root = parentChildren.get(new Long(Span.ROOT_SPAN_ID));
+    List<Long> root = parentChildren.get(Long.valueOf(Span.ROOT_SPAN_ID));
     if (root == null || root.isEmpty())
       return visited;
     RemoteSpan rootSpan = nodes.get(root.iterator().next());

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/util/CreateToken.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/CreateToken.java b/core/src/main/java/org/apache/accumulo/core/util/CreateToken.java
index 083720b..cc6762a 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/CreateToken.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/CreateToken.java
@@ -113,6 +113,5 @@ public class CreateToken {
     } catch (Exception e) {
       throw new RuntimeException(e);
     }
-    return;
   }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/util/format/Formatter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/format/Formatter.java b/core/src/main/java/org/apache/accumulo/core/util/format/Formatter.java
index 0c1fc5f..497cc74 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/format/Formatter.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/format/Formatter.java
@@ -23,5 +23,5 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Value;
 
 public interface Formatter extends Iterator<String> {
-  public void initialize(Iterable<Entry<Key,Value>> scanner, boolean printTimestamps);
+  void initialize(Iterable<Entry<Key,Value>> scanner, boolean printTimestamps);
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/util/interpret/ScanInterpreter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/interpret/ScanInterpreter.java b/core/src/main/java/org/apache/accumulo/core/util/interpret/ScanInterpreter.java
index ca43487..315767e 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/interpret/ScanInterpreter.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/interpret/ScanInterpreter.java
@@ -23,13 +23,13 @@ import org.apache.hadoop.io.Text;
  */
 public interface ScanInterpreter {
   
-  public Text interpretRow(Text row);
+  Text interpretRow(Text row);
 
-  public Text interpretBeginRow(Text row);
+  Text interpretBeginRow(Text row);
   
-  public Text interpretEndRow(Text row);
+  Text interpretEndRow(Text row);
   
-  public Text interpretColumnFamily(Text cf);
+  Text interpretColumnFamily(Text cf);
   
-  public Text interpretColumnQualifier(Text cq);
+  Text interpretColumnQualifier(Text cq);
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/util/shell/Shell.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/shell/Shell.java b/core/src/main/java/org/apache/accumulo/core/util/shell/Shell.java
index 837b4b8..0c4d731 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/shell/Shell.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/shell/Shell.java
@@ -877,9 +877,8 @@ public class Shell extends ShellOptions {
   }
 
   public interface PrintLine {
-    public void print(String s);
-
-    public void close();
+    void print(String s);
+    void close();
   }
 
   public static class PrintShell implements PrintLine {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/test/java/org/apache/accumulo/core/cli/TestClientOpts.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/cli/TestClientOpts.java b/core/src/test/java/org/apache/accumulo/core/cli/TestClientOpts.java
index 7f20286..c2b40c4 100644
--- a/core/src/test/java/org/apache/accumulo/core/cli/TestClientOpts.java
+++ b/core/src/test/java/org/apache/accumulo/core/cli/TestClientOpts.java
@@ -43,9 +43,9 @@ public class TestClientOpts {
     assertEquals(System.getProperty("user.name"), args.principal);
     assertNull(args.securePassword);
     assertNull(args.getToken());
-    assertEquals(new Long(cfg.getMaxLatency(TimeUnit.MILLISECONDS)), bwOpts.batchLatency);
-    assertEquals(new Long(cfg.getTimeout(TimeUnit.MILLISECONDS)), bwOpts.batchTimeout);
-    assertEquals(new Long(cfg.getMaxMemory()), bwOpts.batchMemory);
+    assertEquals(Long.valueOf(cfg.getMaxLatency(TimeUnit.MILLISECONDS)), bwOpts.batchLatency);
+    assertEquals(Long.valueOf(cfg.getTimeout(TimeUnit.MILLISECONDS)), bwOpts.batchTimeout);
+    assertEquals(Long.valueOf(cfg.getMaxMemory()), bwOpts.batchMemory);
     assertFalse(args.debug);
     assertFalse(args.trace);
     assertEquals(10, bsOpts.scanThreads.intValue());
@@ -63,9 +63,9 @@ public class TestClientOpts {
     assertEquals("bar", args.principal);
     assertNull(args.securePassword);
     assertEquals(new PasswordToken("foo"), args.getToken());
-    assertEquals(new Long(3000), bwOpts.batchLatency);
-    assertEquals(new Long(2000), bwOpts.batchTimeout);
-    assertEquals(new Long(1024 * 1024), bwOpts.batchMemory);
+    assertEquals(Long.valueOf(3000), bwOpts.batchLatency);
+    assertEquals(Long.valueOf(2000), bwOpts.batchTimeout);
+    assertEquals(Long.valueOf(1024 * 1024), bwOpts.batchMemory);
     assertTrue(args.debug);
     assertTrue(args.trace);
     assertEquals(7, bsOpts.scanThreads.intValue());

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/test/java/org/apache/accumulo/core/client/IteratorSettingTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/IteratorSettingTest.java b/core/src/test/java/org/apache/accumulo/core/client/IteratorSettingTest.java
index 39d7512..72342f9 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/IteratorSettingTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/IteratorSettingTest.java
@@ -36,7 +36,7 @@ public class IteratorSettingTest {
   IteratorSetting setting2 = new IteratorSetting(500, "combiner", Combiner.class.getName());
   IteratorSetting setting3 = new IteratorSetting(500, "combiner", Combiner.class.getName());
   IteratorSetting devnull = new IteratorSetting(500, "devNull", DevNull.class.getName());
-  IteratorSetting nullsetting = null;
+  final IteratorSetting nullsetting = null;
   IteratorSetting setting4 = new IteratorSetting(300, "combiner", Combiner.class.getName());
   IteratorSetting setting5 = new IteratorSetting(500, "foocombiner", Combiner.class.getName());
   IteratorSetting setting6 = new IteratorSetting(500, "combiner", "MySuperCombiner");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/test/java/org/apache/accumulo/core/file/blockfile/cache/TestLruBlockCache.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/file/blockfile/cache/TestLruBlockCache.java b/core/src/test/java/org/apache/accumulo/core/file/blockfile/cache/TestLruBlockCache.java
index bc515cb..8d6a61a 100644
--- a/core/src/test/java/org/apache/accumulo/core/file/blockfile/cache/TestLruBlockCache.java
+++ b/core/src/test/java/org/apache/accumulo/core/file/blockfile/cache/TestLruBlockCache.java
@@ -19,6 +19,7 @@
  */
 package org.apache.accumulo.core.file.blockfile.cache;
 
+import java.util.Arrays;
 import java.util.Random;
 
 import junit.framework.TestCase;
@@ -138,7 +139,7 @@ public class TestLruBlockCache extends TestCase {
     assertTrue(cache.getBlock(blocks[0].blockName) == null);
     assertTrue(cache.getBlock(blocks[1].blockName) == null);
     for (int i = 2; i < blocks.length; i++) {
-      assertEquals(cache.getBlock(blocks[i].blockName).getBuffer(), blocks[i].buf);
+      assertTrue(Arrays.equals(cache.getBlock(blocks[i].blockName).getBuffer(), blocks[i].buf));
     }
   }
   
@@ -163,7 +164,7 @@ public class TestLruBlockCache extends TestCase {
     for (Block block : multiBlocks) {
       cache.cacheBlock(block.blockName, block.buf);
       expectedCacheSize += block.heapSize();
-      assertEquals(cache.getBlock(block.blockName).getBuffer(), block.buf);
+      assertTrue(Arrays.equals(cache.getBlock(block.blockName).getBuffer(), block.buf));
     }
     
     // Add the single blocks (no get)
@@ -196,8 +197,8 @@ public class TestLruBlockCache extends TestCase {
     
     // And all others to be cached
     for (int i = 1; i < 4; i++) {
-      assertEquals(cache.getBlock(singleBlocks[i].blockName).getBuffer(), singleBlocks[i].buf);
-      assertEquals(cache.getBlock(multiBlocks[i].blockName).getBuffer(), multiBlocks[i].buf);
+      assertTrue(Arrays.equals(cache.getBlock(singleBlocks[i].blockName).getBuffer(), singleBlocks[i].buf));
+      assertTrue(Arrays.equals(cache.getBlock(multiBlocks[i].blockName).getBuffer(), multiBlocks[i].buf));
     }
   }
   
@@ -429,9 +430,9 @@ public class TestLruBlockCache extends TestCase {
     
     // And the newest 5 blocks should still be accessible
     for (int i = 5; i < 10; i++) {
-      assertEquals(singleBlocks[i].buf, cache.getBlock(singleBlocks[i].blockName).getBuffer());
-      assertEquals(multiBlocks[i].buf, cache.getBlock(multiBlocks[i].blockName).getBuffer());
-      assertEquals(memoryBlocks[i].buf, cache.getBlock(memoryBlocks[i].blockName).getBuffer());
+      assertTrue(Arrays.equals(singleBlocks[i].buf, cache.getBlock(singleBlocks[i].blockName).getBuffer()));
+      assertTrue(Arrays.equals(multiBlocks[i].buf, cache.getBlock(multiBlocks[i].blockName).getBuffer()));
+      assertTrue(Arrays.equals(memoryBlocks[i].buf, cache.getBlock(memoryBlocks[i].blockName).getBuffer()));
     }
   }
   

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileTest.java b/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileTest.java
index afc94c6..cffe2cb 100644
--- a/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileTest.java
@@ -20,13 +20,11 @@ import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertFalse;
 import static org.junit.Assert.assertTrue;
 
-import java.io.BufferedOutputStream;
 import java.io.ByteArrayInputStream;
 import java.io.ByteArrayOutputStream;
 import java.io.DataInputStream;
 import java.io.DataOutputStream;
 import java.io.File;
-import java.io.FileInputStream;
 import java.io.FileOutputStream;
 import java.io.IOException;
 import java.io.InputStream;
@@ -167,8 +165,6 @@ public class RFileTest {
 
   public static class TestRFile {
 
-    public File preGeneratedInputFile = null;
-    public File outputFile = null;
     private Configuration conf = CachedConfiguration.getInstance();
     public RFile.Writer writer;
     private ByteArrayOutputStream baos;
@@ -180,14 +176,8 @@ public class RFileTest {
 
     public void openWriter(boolean startDLG) throws IOException {
 
-      if (outputFile == null) {
-        baos = new ByteArrayOutputStream();
-
-        dos = new FSDataOutputStream(baos, new FileSystem.Statistics("a"));
-      } else {
-        BufferedOutputStream bufos = new BufferedOutputStream(new FileOutputStream(outputFile));
-        dos = new FSDataOutputStream(bufos, new FileSystem.Statistics("a"));
-      }
+      baos = new ByteArrayOutputStream();
+      dos = new FSDataOutputStream(baos, new FileSystem.Statistics("a"));
       CachableBlockFile.Writer _cbw = new CachableBlockFile.Writer(dos, "gz", conf);
       writer = new RFile.Writer(_cbw, 1000, 1000);
 
@@ -212,14 +202,7 @@ public class RFileTest {
 
       int fileLength = 0;
       byte[] data = null;
-      if (preGeneratedInputFile != null) {
-        data = new byte[(int) preGeneratedInputFile.length()];
-        DataInputStream in = new DataInputStream(new FileInputStream(preGeneratedInputFile));
-        in.readFully(data);
-        in.close();
-      } else {
-        data = baos.toByteArray();
-      }
+      data = baos.toByteArray();
 
       bais = new SeekableByteArrayInputStream(data);
       in = new FSDataInputStream(bais);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/test/java/org/apache/accumulo/core/iterators/user/BigDecimalCombinerTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/user/BigDecimalCombinerTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/user/BigDecimalCombinerTest.java
index 47d8212..4cf4d5d 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/user/BigDecimalCombinerTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/user/BigDecimalCombinerTest.java
@@ -50,9 +50,9 @@ public class BigDecimalCombinerTest {
     TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
     
     // keys that do not aggregate
-    CombinerTest.nkv(tm1, 1, 1, 1, 1, false, new BigDecimal(2), encoder);
-    CombinerTest.nkv(tm1, 1, 1, 1, 2, false, new BigDecimal(2.3), encoder);
-    CombinerTest.nkv(tm1, 1, 1, 1, 3, false, new BigDecimal(-1.4E1), encoder);
+    CombinerTest.nkv(tm1, 1, 1, 1, 1, false, BigDecimal.valueOf(2), encoder);
+    CombinerTest.nkv(tm1, 1, 1, 1, 2, false, BigDecimal.valueOf(2.3), encoder);
+    CombinerTest.nkv(tm1, 1, 1, 1, 3, false, BigDecimal.valueOf(-1.4E1), encoder);
     
     Combiner ai = new BigDecimalCombiner.BigDecimalSummingCombiner();
     IteratorSetting is = new IteratorSetting(1, BigDecimalCombiner.BigDecimalSummingCombiner.class);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchScanner.java
----------------------------------------------------------------------
diff --git a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchScanner.java b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchScanner.java
index 2ae82b4..06e9ef7 100644
--- a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchScanner.java
+++ b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchScanner.java
@@ -99,7 +99,7 @@ public class RandomBatchScanner {
   static void generateRandomQueries(int num, long min, long max, Random r, HashSet<Range> ranges, HashMap<Text,Boolean> expectedRows) {
     log.info(String.format("Generating %,d random queries...", num));
     while (ranges.size() < num) {
-      long rowid = (Math.abs(r.nextLong()) % (max - min)) + min;
+      long rowid = (abs(r.nextLong()) % (max - min)) + min;
       
       Text row1 = new Text(String.format("row_%010d", rowid));
       
@@ -111,6 +111,12 @@ public class RandomBatchScanner {
     log.info("finished");
   }
   
+  private static long abs(long l) {
+    if (l < 0)
+      return -l;
+    return l;
+  }
+
   /**
    * Prints a count of the number of rows mapped to false.
    * 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchWriter.java
----------------------------------------------------------------------
diff --git a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchWriter.java b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchWriter.java
index 689f07c..6748797 100644
--- a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchWriter.java
+++ b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchWriter.java
@@ -110,6 +110,12 @@ public class RandomBatchWriter {
     Long seed = null;
   }
 
+  private static long abs(long l) {
+    if (l < 0)
+      return -l;
+    return l;
+  }
+
   /**
    * Writes a specified number of entries to Accumulo using a {@link BatchWriter}.
    * 
@@ -121,7 +127,7 @@ public class RandomBatchWriter {
     Opts opts = new Opts();
     BatchWriterOpts bwOpts = new BatchWriterOpts();
     opts.parseArgs(RandomBatchWriter.class.getName(), args, bwOpts);
-    if ((opts.max - opts.min) < opts.num) {
+    if ((opts.max - opts.min) < (long)opts.num) {
       System.err
           .println(String
               .format(
@@ -144,7 +150,7 @@ public class RandomBatchWriter {
     // Generate num unique row ids in the given range
     HashSet<Long> rowids = new HashSet<Long>(opts.num);
     while (rowids.size() < opts.num) {
-      rowids.add((Math.abs(r.nextLong()) % (opts.max - opts.min)) + opts.min);
+      rowids.add((abs(r.nextLong()) % (opts.max - opts.min)) + opts.min);
     }
     for (long rowid : rowids) {
       Mutation m = createMutation(rowid, opts.size, cv);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RowOperations.java
----------------------------------------------------------------------
diff --git a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RowOperations.java b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RowOperations.java
index 56d4840..7f19bc4 100644
--- a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RowOperations.java
+++ b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RowOperations.java
@@ -106,9 +106,9 @@ public class RowOperations {
     bw.flush();
     
     // Now lets look at the rows
-    Scanner rowThree = getRow(opts, scanOpts, new Text("row3"));
-    Scanner rowTwo = getRow(opts, scanOpts, new Text("row2"));
-    Scanner rowOne = getRow(opts, scanOpts, new Text("row1"));
+    Scanner rowThree = getRow(scanOpts, new Text("row3"));
+    Scanner rowTwo = getRow(scanOpts, new Text("row2"));
+    Scanner rowOne = getRow(scanOpts, new Text("row1"));
     
     // And print them
     log.info("This is everything");
@@ -118,13 +118,13 @@ public class RowOperations {
     System.out.flush();
     
     // Now lets delete rowTwo with the iterator
-    rowTwo = getRow(opts, scanOpts, new Text("row2"));
+    rowTwo = getRow(scanOpts, new Text("row2"));
     deleteRow(rowTwo);
     
     // Now lets look at the rows again
-    rowThree = getRow(opts, scanOpts, new Text("row3"));
-    rowTwo = getRow(opts, scanOpts, new Text("row2"));
-    rowOne = getRow(opts, scanOpts, new Text("row1"));
+    rowThree = getRow(scanOpts, new Text("row3"));
+    rowTwo = getRow(scanOpts, new Text("row2"));
+    rowOne = getRow(scanOpts, new Text("row1"));
     
     // And print them
     log.info("This is row1 and row3");
@@ -136,12 +136,12 @@ public class RowOperations {
     // Should only see the two rows
     // Now lets delete rowOne without passing in the iterator
     
-    deleteRow(opts, scanOpts, row1);
+    deleteRow(scanOpts, row1);
     
     // Now lets look at the rows one last time
-    rowThree = getRow(opts, scanOpts, new Text("row3"));
-    rowTwo = getRow(opts, scanOpts, new Text("row2"));
-    rowOne = getRow(opts, scanOpts, new Text("row1"));
+    rowThree = getRow(scanOpts, new Text("row3"));
+    rowTwo = getRow(scanOpts, new Text("row2"));
+    rowOne = getRow(scanOpts, new Text("row1"));
     
     // And print them
     log.info("This is just row3");
@@ -173,8 +173,8 @@ public class RowOperations {
    * @throws AccumuloSecurityException
    * @throws AccumuloException
    */
-  private static void deleteRow(ClientOpts opts, ScannerOpts scanOpts, Text row) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
-    deleteRow(getRow(opts, scanOpts, row));
+  private static void deleteRow(ScannerOpts scanOpts, Text row) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+    deleteRow(getRow(scanOpts, row));
   }
   
   /**
@@ -210,7 +210,7 @@ public class RowOperations {
   /**
    * Gets a scanner over one row
    */
-  private static Scanner getRow(ClientOpts opts, ScannerOpts scanOpts, Text row) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+  private static Scanner getRow(ScannerOpts scanOpts, Text row) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     // Create a scanner
     Scanner scanner = connector.createScanner(table, Authorizations.EMPTY);
     scanner.setBatchSize(scanOpts.scanBatchSize);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/fate/src/main/java/org/apache/accumulo/fate/AgeOffStore.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/AgeOffStore.java b/fate/src/main/java/org/apache/accumulo/fate/AgeOffStore.java
index 3f52e70..4fe1184 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/AgeOffStore.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/AgeOffStore.java
@@ -34,7 +34,7 @@ import org.apache.log4j.Logger;
  */
 public class AgeOffStore<T> implements TStore<T> {
   
-  public static interface TimeSource {
+  public interface TimeSource {
     long currentTimeMillis();
   }
   

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/fate/src/main/java/org/apache/accumulo/fate/Fate.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/Fate.java b/fate/src/main/java/org/apache/accumulo/fate/Fate.java
index 5ddec9c..2d69647 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/Fate.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/Fate.java
@@ -138,6 +138,7 @@ public class Fate<T> {
     
   }
   
+  // TODO: move thread creation to another method ACCUMULO-2136
   public Fate(T environment, TStore<T> store, int numThreads) {
     this.store = store;
     this.environment = environment;
@@ -171,7 +172,7 @@ public class Fate<T> {
         }
         
         if (autoCleanUp)
-          store.setProperty(tid, AUTO_CLEAN_PROP, new Boolean(autoCleanUp));
+          store.setProperty(tid, AUTO_CLEAN_PROP, Boolean.valueOf(autoCleanUp));
         
         store.setProperty(tid, DEBUG_PROP, repo.getDescription());
         

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/fate/src/main/java/org/apache/accumulo/fate/TStore.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/TStore.java b/fate/src/main/java/org/apache/accumulo/fate/TStore.java
index 3554064..98e936c 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/TStore.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/TStore.java
@@ -49,7 +49,7 @@ public interface TStore<T> {
    * 
    * @return a transaction id
    */
-  public long create();
+  long create();
   
   /**
    * Reserve a transaction that is IN_PROGRESS or FAILED_IN_PROGRESS.
@@ -57,7 +57,7 @@ public interface TStore<T> {
    */
   long reserve();
   
-  public void reserve(long tid);
+  void reserve(long tid);
   
   /**
    * Return the given transaction to the store
@@ -84,7 +84,7 @@ public interface TStore<T> {
    * @param repo
    *          the operation
    */
-  public void push(long tid, Repo<T> repo) throws StackOverflowException;
+  void push(long tid, Repo<T> repo) throws StackOverflowException;
   
   /**
    * Remove the last pushed operation from the given transaction.
@@ -100,7 +100,7 @@ public interface TStore<T> {
    *          transaction id
    * @return execution status
    */
-  public TStatus getStatus(long tid);
+  TStatus getStatus(long tid);
   
   /**
    * Update the state of a given transaction
@@ -110,7 +110,7 @@ public interface TStore<T> {
    * @param status
    *          execution status
    */
-  public void setStatus(long tid, TStatus status);
+  void setStatus(long tid, TStatus status);
   
   /**
    * Wait for the satus of a transaction to change
@@ -118,11 +118,11 @@ public interface TStore<T> {
    * @param tid
    *          transaction id
    */
-  public TStatus waitForStatusChange(long tid, EnumSet<TStatus> expected);
+  TStatus waitForStatusChange(long tid, EnumSet<TStatus> expected);
   
-  public void setProperty(long tid, String prop, Serializable val);
+  void setProperty(long tid, String prop, Serializable val);
   
-  public Serializable getProperty(long tid, String prop);
+  Serializable getProperty(long tid, String prop);
   
   /**
    * Remove the transaction from the store.
@@ -130,13 +130,13 @@ public interface TStore<T> {
    * @param tid
    *          the transaction id
    */
-  public void delete(long tid);
+  void delete(long tid);
   
   /**
    * list all transaction ids in store
    * 
    */
   
-  public List<Long> list();
+  List<Long> list();
   
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/fate/src/main/java/org/apache/accumulo/fate/zookeeper/DistributedReadWriteLock.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/DistributedReadWriteLock.java b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/DistributedReadWriteLock.java
index a9e4f1e..cde84dc 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/DistributedReadWriteLock.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/DistributedReadWriteLock.java
@@ -101,7 +101,6 @@ public class DistributedReadWriteLock implements java.util.concurrent.locks.Read
     QueueLock qlock;
     byte[] userData;
     long entry = -1;
-    long lastRead = -1;
     
     ReadLock(QueueLock qlock, byte[] userData) {
       this.qlock = qlock;