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:20 UTC

[5/6] git commit: ACCUMULO-2160 fixed up a lot of findbugs/pmd complaints

ACCUMULO-2160 fixed up a lot of findbugs/pmd complaints


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

Branch: refs/heads/master
Commit: 5bd4e27cbc4dd800d88188c4b39f59447e02e44a
Parents: 1a9ae3c
Author: Eric Newton <er...@gmail.com>
Authored: Wed Jan 8 18:31:37 2014 -0500
Committer: Eric Newton <er...@gmail.com>
Committed: Wed Jan 8 18:31:37 2014 -0500

----------------------------------------------------------------------
 .../accumulo/core/client/BatchDeleter.java      |   2 +-
 .../accumulo/core/client/BatchWriter.java       |   8 +-
 .../accumulo/core/client/ConditionalWriter.java |   8 +-
 .../apache/accumulo/core/client/Instance.java   |  24 +--
 .../accumulo/core/client/IsolatedScanner.java   |   5 +-
 .../core/client/MultiTableBatchWriter.java      |   8 +-
 .../core/client/MutationsRejectedException.java |  15 +-
 .../apache/accumulo/core/client/Scanner.java    |  18 +-
 .../accumulo/core/client/ScannerBase.java       |  22 +--
 .../core/client/admin/InstanceOperations.java   |  18 +-
 .../core/client/admin/NamespaceOperations.java  |  38 ++--
 .../core/client/admin/SecurityOperations.java   |  42 ++---
 .../core/client/admin/TableOperations.java      |  94 +++++-----
 .../core/client/admin/TableOperationsImpl.java  |  22 ++-
 .../core/client/impl/ConditionalWriterImpl.java |   8 +-
 .../client/impl/MultiTableBatchWriterImpl.java  |  14 +-
 .../accumulo/core/client/impl/Tables.java       |   4 +-
 .../core/client/impl/TabletLocatorImpl.java     |   9 +-
 .../client/impl/TabletServerBatchWriter.java    |   8 +-
 .../accumulo/core/client/impl/Translator.java   |   4 +-
 .../core/client/mapred/AbstractInputFormat.java |   9 +-
 .../client/mapreduce/AbstractInputFormat.java   |   7 +-
 .../core/client/mapreduce/RangeInputSplit.java  |   5 +-
 .../security/tokens/AuthenticationToken.java    |   6 +-
 .../core/client/security/tokens/NullToken.java  |   3 -
 .../client/security/tokens/PasswordToken.java   |   2 +-
 .../core/conf/AccumuloConfiguration.java        |   2 +-
 .../accumulo/core/conf/ConfigSanityCheck.java   |   2 +-
 .../apache/accumulo/core/conf/PropertyType.java |   5 +-
 .../accumulo/core/constraints/Constraint.java   |   2 +-
 .../apache/accumulo/core/data/ColumnUpdate.java |   6 +-
 .../apache/accumulo/core/data/Condition.java    |   2 +-
 .../accumulo/core/data/ConditionalMutation.java |   2 +-
 .../apache/accumulo/core/data/KeyExtent.java    |   2 +-
 .../org/apache/accumulo/core/data/Range.java    |   2 +-
 .../accumulo/core/file/FileSKVIterator.java     |  10 +-
 .../org/apache/accumulo/core/file/FileUtil.java |   7 +-
 .../core/file/blockfile/ABlockReader.java       |  12 +-
 .../core/file/blockfile/ABlockWriter.java       |  10 +-
 .../core/file/blockfile/BlockFileReader.java    |  10 +-
 .../core/file/blockfile/BlockFileWriter.java    |   8 +-
 .../core/file/blockfile/cache/BlockCache.java   |  10 +-
 .../core/file/blockfile/cache/CacheEntry.java   |   4 +-
 .../core/file/blockfile/cache/HeapSize.java     |   2 +-
 .../file/blockfile/cache/LruBlockCache.java     |   8 +
 .../file/keyfunctor/ColumnFamilyFunctor.java    |   4 +-
 .../core/file/keyfunctor/KeyFunctor.java        |   4 +-
 .../core/file/keyfunctor/RowFunctor.java        |   4 +-
 .../accumulo/core/file/rfile/BlockIndex.java    |  13 ++
 .../core/file/rfile/MultiLevelIndex.java        |  15 +-
 .../apache/accumulo/core/file/rfile/RFile.java  |   2 +-
 .../accumulo/core/file/rfile/bcfile/BCFile.java |   4 +-
 .../core/file/rfile/bcfile/CompareUtils.java    |   2 +-
 .../core/file/rfile/bcfile/RawComparable.java   |   6 +-
 .../core/iterators/OptionDescriber.java         |   6 +-
 .../core/iterators/TypedValueCombiner.java      |   6 +-
 .../iterators/system/InterruptibleIterator.java |   2 +-
 .../core/iterators/user/AgeOffFilter.java       |   4 +-
 .../core/iterators/user/TimestampFilter.java    |   4 +-
 .../iterators/user/TransformingIterator.java    |   2 +-
 .../core/iterators/user/VisibilityFilter.java   |   6 -
 .../core/security/AuthorizationContainer.java   |   2 +-
 .../accumulo/core/security/Authorizations.java  |   2 +-
 .../core/security/crypto/CryptoModule.java      |   8 +-
 .../crypto/SecretKeyEncryptionStrategy.java     |   4 +-
 .../SecretKeyEncryptionStrategyContext.java     |  16 +-
 .../apache/accumulo/core/trace/SpanTree.java    |   2 +-
 .../apache/accumulo/core/util/CreateToken.java  |   1 -
 .../accumulo/core/util/format/Formatter.java    |   2 +-
 .../core/util/interpret/ScanInterpreter.java    |  10 +-
 .../apache/accumulo/core/util/shell/Shell.java  |   5 +-
 .../accumulo/core/cli/TestClientOpts.java       |  12 +-
 .../core/client/IteratorSettingTest.java        |   2 +-
 .../file/blockfile/cache/TestLruBlockCache.java |  15 +-
 .../accumulo/core/file/rfile/RFileTest.java     |  23 +--
 .../iterators/user/BigDecimalCombinerTest.java  |   6 +-
 .../simple/client/RandomBatchScanner.java       |   8 +-
 .../simple/client/RandomBatchWriter.java        |  10 +-
 .../examples/simple/client/RowOperations.java   |  28 +--
 .../org/apache/accumulo/fate/AgeOffStore.java   |   2 +-
 .../java/org/apache/accumulo/fate/Fate.java     |   3 +-
 .../java/org/apache/accumulo/fate/TStore.java   |  20 +-
 .../zookeeper/DistributedReadWriteLock.java     |   1 -
 .../accumulo/fate/zookeeper/IZooReader.java     |  16 +-
 .../fate/zookeeper/IZooReaderWriter.java        |  32 ++--
 .../fate/zookeeper/TransactionWatcher.java      |   8 +-
 .../accumulo/fate/zookeeper/ZooCache.java       |   2 +-
 .../apache/accumulo/fate/zookeeper/ZooLock.java |   2 -
 .../fate/zookeeper/ZooReaderWriter.java         |   3 +-
 .../accumulo/fate/zookeeper/ZooReservation.java |   6 +-
 .../accumulo/fate/zookeeper/ZooSession.java     |   6 +-
 .../minicluster/MiniAccumuloCluster.java        |   4 +-
 .../accumulo/minicluster/ProcessReference.java  |   5 +-
 .../minicluster/MiniAccumuloClusterGCTest.java  |   2 +-
 pom.xml                                         |   1 +
 .../java/org/apache/accumulo/proxy/Proxy.java   |   3 +-
 .../org/apache/accumulo/proxy/ProxyServer.java  |   9 +-
 .../org/apache/accumulo/server/Accumulo.java    |   2 +-
 .../server/conf/NamespaceConfiguration.java     |   7 +-
 .../server/conf/TableConfiguration.java         |   7 +-
 .../accumulo/server/fs/VolumeManagerImpl.java   |   2 +-
 .../server/master/recovery/LogCloser.java       |   2 +-
 .../server/master/state/Assignment.java         |   1 -
 .../server/master/state/DistributedStore.java   |   8 +-
 .../server/master/state/MetaDataStateStore.java |   3 -
 .../master/state/RootTabletStateStore.java      |   3 -
 .../server/master/state/TabletStateStore.java   |   2 -
 .../server/metrics/MetricsConfiguration.java    |  16 +-
 .../server/metrics/ThriftMetricsMBean.java      |  22 +--
 .../server/problems/ProblemReports.java         |   6 +-
 .../server/security/handler/Authenticator.java  |  22 +--
 .../server/security/handler/Authorizor.java     |  16 +-
 .../security/handler/InsecureAuthenticator.java |   5 -
 .../security/handler/InsecurePermHandler.java   |  12 --
 .../security/handler/PermissionHandler.java     |  40 ++--
 .../accumulo/server/util/DumpZookeeper.java     |   2 -
 .../apache/accumulo/server/util/FileUtil.java   |   1 -
 .../accumulo/server/util/time/ProvidesTime.java |   2 +-
 .../gc/GarbageCollectWriteAheadLogs.java        |   1 +
 .../master/recovery/RecoveryManager.java        |   2 +-
 .../accumulo/master/tableOps/BulkImport.java    |   3 -
 .../accumulo/master/tableOps/TableRangeOp.java  |   2 +-
 .../accumulo/monitor/EmbeddedWebServer.java     |   8 +-
 .../monitor/servlets/OperationServlet.java      |   4 +-
 .../accumulo/monitor/servlets/VisServlet.java   |   2 +-
 .../monitor/servlets/trace/ListType.java        |   2 +-
 .../org/apache/accumulo/tserver/Compactor.java  |   2 +-
 .../tserver/ConditionalMutationSet.java         |   2 +-
 .../apache/accumulo/tserver/InMemoryMap.java    |  14 +-
 .../apache/accumulo/tserver/TabletServer.java   |   2 +-
 .../tserver/metrics/TabletServerMBean.java      |  30 +--
 .../metrics/TabletServerMinCMetricsMBean.java   |  22 +--
 .../metrics/TabletServerScanMetricsMBean.java   |  22 +--
 .../metrics/TabletServerUpdateMetricsMBean.java |  52 +++---
 .../vfs/AccumuloReloadingVFSClassLoader.java    |   5 +-
 .../vfs/FinalCloseDefaultFileSystemManager.java |   2 +-
 .../start/classloader/vfs/MiniDFSUtil.java      |  22 ++-
 .../vfs/PostDelegatingVFSClassLoader.java       |  14 +-
 .../classloader/vfs/UniqueFileReplicator.java   |  13 +-
 .../vfs/providers/HdfsFileSystem.java           | 182 +++++++++----------
 .../apache/accumulo/test/IMMLGBenchmark.java    |   8 +-
 .../test/continuous/UndefinedAnalyzer.java      |   4 +-
 .../metadata/MetadataBatchScanTest.java         |   4 +-
 .../apache/accumulo/test/randomwalk/Module.java |   2 +-
 .../accumulo/test/randomwalk/bulk/Setup.java    |   2 +-
 .../test/randomwalk/concurrent/AddSplits.java   |   2 +-
 .../test/randomwalk/concurrent/BatchScan.java   |   2 +-
 .../test/randomwalk/concurrent/BatchWrite.java  |   4 +-
 .../randomwalk/concurrent/CheckBalance.java     |   2 +-
 .../test/randomwalk/concurrent/Setup.java       |   2 +-
 .../accumulo/test/randomwalk/image/Commit.java  |   2 +-
 .../test/randomwalk/image/ImageFixture.java     |   6 +-
 .../test/randomwalk/image/ScanMeta.java         |   2 +-
 .../accumulo/test/randomwalk/image/Write.java   |   2 +-
 .../test/randomwalk/multitable/Commit.java      |   2 +-
 .../multitable/MultiTableFixture.java           |   6 +-
 .../randomwalk/security/SecurityHelper.java     |   2 +-
 .../randomwalk/security/WalkingSecurity.java    |   2 +-
 .../test/randomwalk/sequential/BatchVerify.java |   2 +-
 .../test/randomwalk/sequential/Commit.java      |   2 +-
 .../randomwalk/sequential/MapRedVerifyTool.java |   2 +-
 .../sequential/SequentialFixture.java           |   4 +-
 .../test/randomwalk/sequential/Write.java       |   2 +-
 .../test/randomwalk/shard/BulkInsert.java       |   4 +-
 .../accumulo/test/randomwalk/shard/Insert.java  |   2 +-
 .../test/randomwalk/shard/ShardFixture.java     |   4 +-
 .../apache/accumulo/test/scalability/Run.java   |   1 -
 .../accumulo/test/scalability/ScaleTest.java    |   2 +-
 .../accumulo/test/ConditionalWriterIT.java      |  12 +-
 .../apache/accumulo/test/TableOperationsIT.java |   2 +-
 .../apache/accumulo/trace/instrument/Span.java  |   2 +-
 .../trace/instrument/receivers/LogSpans.java    |   4 +-
 172 files changed, 797 insertions(+), 767 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/BatchDeleter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/BatchDeleter.java b/core/src/main/java/org/apache/accumulo/core/client/BatchDeleter.java
index 15405a0..2bfc347 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/BatchDeleter.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/BatchDeleter.java
@@ -34,7 +34,7 @@ public interface BatchDeleter extends ScannerBase {
    * @throws TableNotFoundException
    *           when the table does not exist
    */
-  public void delete() throws MutationsRejectedException, TableNotFoundException;
+  void delete() throws MutationsRejectedException, TableNotFoundException;
   
   /**
    * Allows deleting multiple ranges efficiently.

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/BatchWriter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/BatchWriter.java b/core/src/main/java/org/apache/accumulo/core/client/BatchWriter.java
index be88be0..b321411 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/BatchWriter.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/BatchWriter.java
@@ -40,7 +40,7 @@ public interface BatchWriter {
    *           this could be thrown because current or previous mutations failed
    */
   
-  public void addMutation(Mutation m) throws MutationsRejectedException;
+  void addMutation(Mutation m) throws MutationsRejectedException;
   
   /**
    * Queues several mutations to write.
@@ -50,7 +50,7 @@ public interface BatchWriter {
    * @throws MutationsRejectedException
    *           this could be thrown because current or previous mutations failed
    */
-  public void addMutations(Iterable<Mutation> iterable) throws MutationsRejectedException;
+  void addMutations(Iterable<Mutation> iterable) throws MutationsRejectedException;
   
   /**
    * Send any buffered mutations to Accumulo immediately.
@@ -58,7 +58,7 @@ public interface BatchWriter {
    * @throws MutationsRejectedException
    *           this could be thrown because current or previous mutations failed
    */
-  public void flush() throws MutationsRejectedException;
+  void flush() throws MutationsRejectedException;
   
   /**
    * Flush and release any resources.
@@ -66,6 +66,6 @@ public interface BatchWriter {
    * @throws MutationsRejectedException
    *           this could be thrown because current or previous mutations failed
    */
-  public void close() throws MutationsRejectedException;
+  void close() throws MutationsRejectedException;
   
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriter.java b/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriter.java
index 2c24a2e..5fdccf0 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriter.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriter.java
@@ -29,7 +29,7 @@ import org.apache.accumulo.core.data.ConditionalMutation;
  * @since 1.6.0
  */
 public interface ConditionalWriter {
-  public static class Result {
+  class Result {
     
     private Status status;
     private ConditionalMutation mutation;
@@ -122,7 +122,7 @@ public interface ConditionalWriter {
    * @return Result for each mutation submitted. The mutations may still be processing in the background when this method returns, if so the iterator will
    *         block.
    */
-  public abstract Iterator<Result> write(Iterator<ConditionalMutation> mutations);
+  Iterator<Result> write(Iterator<ConditionalMutation> mutations);
   
   /**
    * This method has the same thread safety guarantees as @link {@link #write(Iterator)}
@@ -132,10 +132,10 @@ public interface ConditionalWriter {
    * @return Result for the submitted mutation
    */
 
-  public abstract Result write(ConditionalMutation mutation);
+  Result write(ConditionalMutation mutation);
 
   /**
    * release any resources (like threads pools) used by conditional writer
    */
-  public void close();
+  void close();
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/Instance.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/Instance.java b/core/src/main/java/org/apache/accumulo/core/client/Instance.java
index 8912b51..9bf2a08 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/Instance.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/Instance.java
@@ -33,42 +33,42 @@ public interface Instance {
    * 
    * @return location in "hostname:port" form
    */
-  public abstract String getRootTabletLocation();
+  String getRootTabletLocation();
 
   /**
    * Returns the location(s) of the accumulo master and any redundant servers.
    * 
    * @return a list of locations in "hostname:port" form
    */
-  public abstract List<String> getMasterLocations();
+  List<String> getMasterLocations();
 
   /**
    * Returns a unique string that identifies this instance of accumulo.
    * 
    * @return a UUID
    */
-  public abstract String getInstanceID();
+  String getInstanceID();
 
   /**
    * Returns the instance name given at system initialization time.
    * 
    * @return current instance name
    */
-  public abstract String getInstanceName();
+  String getInstanceName();
 
   /**
    * Returns a comma-separated list of zookeeper servers the instance is using.
    * 
    * @return the zookeeper servers this instance is using in "hostname:port" form
    */
-  public abstract String getZooKeepers();
+  String getZooKeepers();
 
   /**
    * Returns the zookeeper connection timeout.
    * 
    * @return the configured timeout to connect to zookeeper
    */
-  public abstract int getZooKeepersSessionTimeOut();
+  int getZooKeepersSessionTimeOut();
 
   /**
    * Returns a connection to accumulo.
@@ -85,7 +85,7 @@ public interface Instance {
    * @deprecated since 1.5, use {@link #getConnector(String, AuthenticationToken)} with {@link PasswordToken}
    */
   @Deprecated
-  public abstract Connector getConnector(String user, byte[] pass) throws AccumuloException, AccumuloSecurityException;
+  Connector getConnector(String user, byte[] pass) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Returns a connection to accumulo.
@@ -102,7 +102,7 @@ public interface Instance {
    * @deprecated since 1.5, use {@link #getConnector(String, AuthenticationToken)} with {@link PasswordToken}
    */
   @Deprecated
-  public abstract Connector getConnector(String user, ByteBuffer pass) throws AccumuloException, AccumuloSecurityException;
+  Connector getConnector(String user, ByteBuffer pass) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Returns a connection to this instance of accumulo.
@@ -119,7 +119,7 @@ public interface Instance {
    * @deprecated since 1.5, use {@link #getConnector(String, AuthenticationToken)} with {@link PasswordToken}
    */
   @Deprecated
-  public abstract Connector getConnector(String user, CharSequence pass) throws AccumuloException, AccumuloSecurityException;
+  Connector getConnector(String user, CharSequence pass) throws AccumuloException, AccumuloSecurityException;
   
   /**
    * Returns the AccumuloConfiguration to use when interacting with this instance.
@@ -128,7 +128,7 @@ public interface Instance {
    * @deprecated since 1.6.0
    */
   @Deprecated
-  public abstract AccumuloConfiguration getConfiguration();
+  AccumuloConfiguration getConfiguration();
 
   /**
    * Set the AccumuloConfiguration to use when interacting with this instance.
@@ -138,7 +138,7 @@ public interface Instance {
    * @deprecated since 1.6.0
    */
   @Deprecated
-  public abstract void setConfiguration(AccumuloConfiguration conf);
+  void setConfiguration(AccumuloConfiguration conf);
 
   /**
    * Returns a connection to this instance of accumulo.
@@ -150,5 +150,5 @@ public interface Instance {
    *          {@link PasswordToken}
    * @since 1.5.0
    */
-  public abstract Connector getConnector(String principal, AuthenticationToken token) throws AccumuloException, AccumuloSecurityException;
+  Connector getConnector(String principal, AuthenticationToken token) throws AccumuloException, AccumuloSecurityException;
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/IsolatedScanner.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/IsolatedScanner.java b/core/src/main/java/org/apache/accumulo/core/client/IsolatedScanner.java
index 2e99abf..443596a 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/IsolatedScanner.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/IsolatedScanner.java
@@ -169,11 +169,11 @@ public class IsolatedScanner extends ScannerOptions implements Scanner {
     
   }
   
-  public static interface RowBufferFactory {
+  interface RowBufferFactory {
     RowBuffer newBuffer();
   }
   
-  public static interface RowBuffer extends Iterable<Entry<Key,Value>> {
+  interface RowBuffer extends Iterable<Entry<Key,Value>> {
     void add(Entry<Key,Value> entry);
     
     @Override
@@ -256,7 +256,6 @@ public class IsolatedScanner extends ScannerOptions implements Scanner {
   @Override
   public void setRange(Range range) {
     this.range = range;
-    ;
   }
   
   @Override

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/MultiTableBatchWriter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/MultiTableBatchWriter.java b/core/src/main/java/org/apache/accumulo/core/client/MultiTableBatchWriter.java
index eda5fa7..39287e8 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/MultiTableBatchWriter.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/MultiTableBatchWriter.java
@@ -36,7 +36,7 @@ public interface MultiTableBatchWriter {
    * @throws TableNotFoundException
    *           when the table does not exist
    */
-  public BatchWriter getBatchWriter(String table) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
+   BatchWriter getBatchWriter(String table) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
   
   /**
    * Send mutations for all tables to accumulo.
@@ -44,7 +44,7 @@ public interface MultiTableBatchWriter {
    * @throws MutationsRejectedException
    *           when queued mutations are unable to be inserted
    */
-  public void flush() throws MutationsRejectedException;
+  void flush() throws MutationsRejectedException;
   
   /**
    * Flush and release all resources.
@@ -53,12 +53,12 @@ public interface MultiTableBatchWriter {
    *           when queued mutations are unable to be inserted
    * 
    */
-  public void close() throws MutationsRejectedException;
+  void close() throws MutationsRejectedException;
   
   /**
    * Returns true if this batch writer has been closed.
    * 
    * @return true if this batch writer has been closed
    */
-  public boolean isClosed();
+  boolean isClosed();
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/MutationsRejectedException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/MutationsRejectedException.java b/core/src/main/java/org/apache/accumulo/core/client/MutationsRejectedException.java
index bfa62d3..fba2893 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/MutationsRejectedException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/MutationsRejectedException.java
@@ -22,6 +22,7 @@ import java.util.HashMap;
 import java.util.HashSet;
 import java.util.List;
 import java.util.Map;
+import java.util.Map.Entry;
 import java.util.Set;
 
 import org.apache.accumulo.core.client.impl.Tables;
@@ -62,19 +63,19 @@ public class MutationsRejectedException extends AccumuloException {
   }
   
   private static String format(HashMap<KeyExtent,Set<SecurityErrorCode>> hashMap, Instance instance) {
-    Map<String,Set<SecurityErrorCode>> errorMap = new HashMap<String,Set<SecurityErrorCode>>();
+    Map<String,Set<SecurityErrorCode>> result = new HashMap<String,Set<SecurityErrorCode>>();
     
-    for (KeyExtent ke : hashMap.keySet()) {
-      String tableInfo = Tables.getPrintableTableInfoFromId(instance, ke.getTableId().toString());
+    for (Entry<KeyExtent,Set<SecurityErrorCode>> entry : hashMap.entrySet()) {
+      String tableInfo = Tables.getPrintableTableInfoFromId(instance, entry.getKey().getTableId().toString());
       
-      if (!errorMap.containsKey(tableInfo)) {
-        errorMap.put(tableInfo, new HashSet<SecurityErrorCode>());
+      if (!result.containsKey(tableInfo)) {
+        result.put(tableInfo, new HashSet<SecurityErrorCode>());
       }
       
-      errorMap.get(tableInfo).addAll(hashMap.get(ke));
+      result.get(tableInfo).addAll(hashMap.get(entry.getKey()));
     }
     
-    return errorMap.toString();
+    return result.toString();
   }
   
   /**

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/Scanner.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/Scanner.java b/core/src/main/java/org/apache/accumulo/core/client/Scanner.java
index 245aa18..112179e 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/Scanner.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/Scanner.java
@@ -35,7 +35,7 @@ public interface Scanner extends ScannerBase {
    * @deprecated Since 1.5. See {@link ScannerBase#setTimeout(long, java.util.concurrent.TimeUnit)}
    */
   @Deprecated
-  public void setTimeOut(int timeOut);
+  void setTimeOut(int timeOut);
   
   /**
    * Returns the setting for how long a scanner will automatically retry when a failure occurs.
@@ -44,7 +44,7 @@ public interface Scanner extends ScannerBase {
    * @deprecated Since 1.5. See {@link ScannerBase#getTimeout(java.util.concurrent.TimeUnit)}
    */
   @Deprecated
-  public int getTimeOut();
+  int getTimeOut();
   
   /**
    * Sets the range of keys to scan over.
@@ -52,14 +52,14 @@ public interface Scanner extends ScannerBase {
    * @param range
    *          key range to begin and end scan
    */
-  public void setRange(Range range);
+  void setRange(Range range);
   
   /**
    * Returns the range of keys to scan over.
    * 
    * @return the range configured for this scanner
    */
-  public Range getRange();
+  Range getRange();
   
   /**
    * Sets the number of Key/Value pairs that will be fetched at a time from a tablet server.
@@ -67,19 +67,19 @@ public interface Scanner extends ScannerBase {
    * @param size
    *          the number of Key/Value pairs to fetch per call to Accumulo
    */
-  public void setBatchSize(int size);
+  void setBatchSize(int size);
   
   /**
    * Returns the batch size (number of Key/Value pairs) that will be fetched at a time from a tablet server.
    * 
    * @return the batch size configured for this scanner
    */
-  public int getBatchSize();
+  int getBatchSize();
   
   /**
    * Enables row isolation. Writes that occur to a row after a scan of that row has begun will not be seen if this option is enabled.
    */
-  public void enableIsolation();
+  void enableIsolation();
   
   /**
    * Disables row isolation. Writes that occur to a row after a scan of that row has begun may be seen if this option is enabled.
@@ -91,12 +91,12 @@ public interface Scanner extends ScannerBase {
    * @return Number of batches before read-ahead begins
    * @since 1.6.0
    */
-  public long getReadaheadThreshold();
+  long getReadaheadThreshold();
   
   /**
    * Sets the number of batches of Key/Value pairs returned before the {@link Scanner} will begin to prefetch the next batch
    * @param batches Non-negative number of batches
    * @since 1.6.0
    */
-  public void setReadaheadThreshold(long batches); 
+  void setReadaheadThreshold(long batches); 
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/ScannerBase.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/ScannerBase.java b/core/src/main/java/org/apache/accumulo/core/client/ScannerBase.java
index 873a3ad..26056b8 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/ScannerBase.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/ScannerBase.java
@@ -39,7 +39,7 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>> {
    * @throws IllegalArgumentException
    *           if the setting conflicts with existing iterators
    */
-  public void addScanIterator(IteratorSetting cfg);
+  void addScanIterator(IteratorSetting cfg);
   
   /**
    * Remove an iterator from the list of iterators.
@@ -47,7 +47,7 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>> {
    * @param iteratorName
    *          nickname used for the iterator
    */
-  public void removeScanIterator(String iteratorName);
+  void removeScanIterator(String iteratorName);
   
   /**
    * Update the options for an iterator. Note that this does <b>not</b> change the iterator options during a scan, it just replaces the given option on a
@@ -60,7 +60,7 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>> {
    * @param value
    *          the new value for the named option
    */
-  public void updateScanIteratorOption(String iteratorName, String key, String value);
+  void updateScanIteratorOption(String iteratorName, String key, String value);
   
   /**
    * Adds a column family to the list of columns that will be fetched by this scanner. By default when no columns have been added the scanner fetches all
@@ -69,7 +69,7 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>> {
    * @param col
    *          the column family to be fetched
    */
-  public void fetchColumnFamily(Text col);
+  void fetchColumnFamily(Text col);
   
   /**
    * Adds a column to the list of columns that will be fetched by this scanner. The column is identified by family and qualifier. By default when no columns
@@ -80,17 +80,17 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>> {
    * @param colQual
    *          the column qualifier of the column to be fetched
    */
-  public void fetchColumn(Text colFam, Text colQual);
+  void fetchColumn(Text colFam, Text colQual);
   
   /**
    * Clears the columns to be fetched (useful for resetting the scanner for reuse). Once cleared, the scanner will fetch all columns.
    */
-  public void clearColumns();
+  void clearColumns();
   
   /**
    * Clears scan iterators prior to returning a scanner to the pool.
    */
-  public void clearScanIterators();
+  void clearScanIterators();
   
   /**
    * Returns an iterator over an accumulo table. This iterator uses the options that are currently set for its lifetime, so setting options will have no effect
@@ -100,7 +100,7 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>> {
    * 
    * @return an iterator over Key,Value pairs which meet the restrictions set on the scanner
    */
-  public Iterator<Entry<Key,Value>> iterator();
+  Iterator<Entry<Key,Value>> iterator();
   
   /**
    * This setting determines how long a scanner will automatically retry when a failure occurs. By default a scanner will retry forever.
@@ -112,7 +112,7 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>> {
    *          determines how timeout is interpreted
    * @since 1.5.0
    */
-  public void setTimeout(long timeOut, TimeUnit timeUnit);
+  void setTimeout(long timeOut, TimeUnit timeUnit);
   
   /**
    * Returns the setting for how long a scanner will automatically retry when a failure occurs.
@@ -120,11 +120,11 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>> {
    * @return the timeout configured for this scanner
    * @since 1.5.0
    */
-  public long getTimeout(TimeUnit timeUnit);
+  long getTimeout(TimeUnit timeUnit);
 
   /**
    * Closes any underlying connections on the scanner
    * @since 1.5.0
    */
-  public void close();
+  void close();
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/admin/InstanceOperations.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/InstanceOperations.java b/core/src/main/java/org/apache/accumulo/core/client/admin/InstanceOperations.java
index fce0716..afa539a 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/InstanceOperations.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/InstanceOperations.java
@@ -40,7 +40,7 @@ public interface InstanceOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission
    */
-  public void setProperty(final String property, final String value) throws AccumuloException, AccumuloSecurityException;
+  void setProperty(final String property, final String value) throws AccumuloException, AccumuloSecurityException;
   
   /**
    * Removes a system property from zookeeper. Changes can be seen using {@link #getSystemConfiguration()}
@@ -52,7 +52,7 @@ public interface InstanceOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission
    */
-  public void removeProperty(final String property) throws AccumuloException, AccumuloSecurityException;
+  void removeProperty(final String property) throws AccumuloException, AccumuloSecurityException;
   
   /**
    * 
@@ -62,7 +62,7 @@ public interface InstanceOperations {
    * @throws AccumuloSecurityException
    */
 
-  public Map<String,String> getSystemConfiguration() throws AccumuloException, AccumuloSecurityException;
+  Map<String,String> getSystemConfiguration() throws AccumuloException, AccumuloSecurityException;
   
   /**
    * 
@@ -72,7 +72,7 @@ public interface InstanceOperations {
    * @throws AccumuloSecurityException
    */
 
-  public Map<String,String> getSiteConfiguration() throws AccumuloException, AccumuloSecurityException;
+  Map<String,String> getSiteConfiguration() throws AccumuloException, AccumuloSecurityException;
   
   /**
    * List the currently active tablet servers participating in the accumulo instance
@@ -80,7 +80,7 @@ public interface InstanceOperations {
    * @return A list of currently active tablet servers.
    */
   
-  public List<String> getTabletServers();
+  List<String> getTabletServers();
   
   /**
    * List the active scans on tablet server.
@@ -92,7 +92,7 @@ public interface InstanceOperations {
    * @throws AccumuloSecurityException
    */
   
-  public List<ActiveScan> getActiveScans(String tserver) throws AccumuloException, AccumuloSecurityException;
+  List<ActiveScan> getActiveScans(String tserver) throws AccumuloException, AccumuloSecurityException;
   
   /**
    * List the active compaction running on a tablet server
@@ -105,7 +105,7 @@ public interface InstanceOperations {
    * @since 1.5.0
    */
   
-  public List<ActiveCompaction> getActiveCompactions(String tserver) throws AccumuloException, AccumuloSecurityException;
+  List<ActiveCompaction> getActiveCompactions(String tserver) throws AccumuloException, AccumuloSecurityException;
   
   /**
    * Throws an exception if a tablet server can not be contacted.
@@ -115,7 +115,7 @@ public interface InstanceOperations {
    * @throws AccumuloException
    * @since 1.5.0
    */
-  public void ping(String tserver) throws AccumuloException;
+  void ping(String tserver) throws AccumuloException;
   
   /**
    * Test to see if the instance can load the given class as the given type. This check does not consider per table classpaths, see
@@ -126,6 +126,6 @@ public interface InstanceOperations {
    * @return true if the instance can load the given class as the given type, false otherwise
    * @throws AccumuloException
    */
-  public boolean testClassLoad(final String className, final String asTypeName) throws AccumuloException, AccumuloSecurityException;
+  boolean testClassLoad(final String className, final String asTypeName) throws AccumuloException, AccumuloSecurityException;
   
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/admin/NamespaceOperations.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/NamespaceOperations.java b/core/src/main/java/org/apache/accumulo/core/client/admin/NamespaceOperations.java
index b81310e..269e563 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/NamespaceOperations.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/NamespaceOperations.java
@@ -49,7 +49,7 @@ public interface NamespaceOperations {
    *           if the user does not have permission
    * @since 1.6.0
    */
-  public SortedSet<String> list() throws AccumuloException, AccumuloSecurityException;
+  SortedSet<String> list() throws AccumuloException, AccumuloSecurityException;
 
   /**
    * A method to check if a namespace exists in Accumulo.
@@ -63,7 +63,7 @@ public interface NamespaceOperations {
    *           if the user does not have permission
    * @since 1.6.0
    */
-  public boolean exists(String namespace) throws AccumuloException, AccumuloSecurityException;
+  boolean exists(String namespace) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Create an empty namespace with no initial configuration. Valid names for a namespace contain letters, numbers, and the underscore character.
@@ -78,7 +78,7 @@ public interface NamespaceOperations {
    *           if the specified namespace already exists
    * @since 1.6.0
    */
-  public void create(String namespace) throws AccumuloException, AccumuloSecurityException, NamespaceExistsException;
+  void create(String namespace) throws AccumuloException, AccumuloSecurityException, NamespaceExistsException;
 
   /**
    * Delete an empty namespace
@@ -95,7 +95,7 @@ public interface NamespaceOperations {
    *           if the namespaces still contains tables
    * @since 1.6.0
    */
-  public void delete(String namespace) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException, NamespaceNotEmptyException;
+  void delete(String namespace) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException, NamespaceNotEmptyException;
 
   /**
    * Rename a namespace
@@ -114,7 +114,7 @@ public interface NamespaceOperations {
    *           if the new namespace already exists
    * @since 1.6.0
    */
-  public void rename(String oldNamespaceName, String newNamespaceName) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException,
+  void rename(String oldNamespaceName, String newNamespaceName) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException,
       NamespaceExistsException;
 
   /**
@@ -134,7 +134,7 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  public void setProperty(String namespace, String property, String value) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
+  void setProperty(String namespace, String property, String value) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
 
   /**
    * Removes a property from a namespace. Note that it may take a few seconds to propagate the change everywhere.
@@ -151,7 +151,7 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  public void removeProperty(String namespace, String property) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
+  void removeProperty(String namespace, String property) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
 
   /**
    * Gets properties of a namespace, which are inherited by tables in this namespace. Note that recently changed properties may not be available immediately.
@@ -167,7 +167,7 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  public Iterable<Entry<String,String>> getProperties(String namespace) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
+  Iterable<Entry<String,String>> getProperties(String namespace) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
 
   /**
    * Get a mapping of namespace name to internal namespace id.
@@ -179,7 +179,7 @@ public interface NamespaceOperations {
    *           if the user does not have permission
    * @since 1.6.0
    */
-  public Map<String,String> namespaceIdMap() throws AccumuloException, AccumuloSecurityException;
+  Map<String,String> namespaceIdMap() throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Add an iterator to a namespace on all scopes.
@@ -196,7 +196,7 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  public void attachIterator(String namespace, IteratorSetting setting) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
+  void attachIterator(String namespace, IteratorSetting setting) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
 
   /**
    * Add an iterator to a namespace on the given scopes.
@@ -215,7 +215,7 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  public void attachIterator(String namespace, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloException, AccumuloSecurityException,
+  void attachIterator(String namespace, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloException, AccumuloSecurityException,
       NamespaceNotFoundException;
 
   /**
@@ -235,7 +235,7 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  public void removeIterator(String namespace, String name, EnumSet<IteratorScope> scopes) throws AccumuloException, AccumuloSecurityException,
+  void removeIterator(String namespace, String name, EnumSet<IteratorScope> scopes) throws AccumuloException, AccumuloSecurityException,
       NamespaceNotFoundException;
 
   /**
@@ -256,7 +256,7 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  public IteratorSetting getIteratorSetting(String namespace, String name, IteratorScope scope) throws AccumuloException, AccumuloSecurityException,
+  IteratorSetting getIteratorSetting(String namespace, String name, IteratorScope scope) throws AccumuloException, AccumuloSecurityException,
       NamespaceNotFoundException;
 
   /**
@@ -273,7 +273,7 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  public Map<String,EnumSet<IteratorScope>> listIterators(String namespace) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
+  Map<String,EnumSet<IteratorScope>> listIterators(String namespace) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
 
   /**
    * Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for
@@ -293,7 +293,7 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  public void checkIteratorConflicts(String namespace, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloException,
+  void checkIteratorConflicts(String namespace, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloException,
       AccumuloSecurityException, NamespaceNotFoundException;
 
   /**
@@ -312,7 +312,7 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  public int addConstraint(String namespace, String constraintClassName) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
+  int addConstraint(String namespace, String constraintClassName) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
 
   /**
    * Remove a constraint from a namespace.
@@ -329,7 +329,7 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  public void removeConstraint(String namespace, int id) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
+  void removeConstraint(String namespace, int id) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
 
   /**
    * List constraints on a namespace with their assigned numbers.
@@ -345,7 +345,7 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  public Map<String,Integer> listConstraints(String namespace) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
+  Map<String,Integer> listConstraints(String namespace) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
 
   /**
    * Test to see if the instance can load the given class as the given type. This check uses the table classpath property if it is set.
@@ -365,6 +365,6 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  public boolean testClassLoad(String namespace, String className, String asTypeName) throws AccumuloException, AccumuloSecurityException,
+  boolean testClassLoad(String namespace, String className, String asTypeName) throws AccumuloException, AccumuloSecurityException,
       NamespaceNotFoundException;
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/admin/SecurityOperations.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/SecurityOperations.java b/core/src/main/java/org/apache/accumulo/core/client/admin/SecurityOperations.java
index b3178fd..ea1fde1 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/SecurityOperations.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/SecurityOperations.java
@@ -48,7 +48,7 @@ public interface SecurityOperations {
    * @deprecated since 1.5.0; use {@link #createLocalUser(String, PasswordToken)} or the user management functions of your configured authenticator instead.
    */
   @Deprecated
-  public void createUser(String user, byte[] password, Authorizations authorizations) throws AccumuloException, AccumuloSecurityException;
+  void createUser(String user, byte[] password, Authorizations authorizations) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Create a user
@@ -63,7 +63,7 @@ public interface SecurityOperations {
    *           if the user does not have permission to create a user
    * @since 1.5.0
    */
-  public void createLocalUser(String principal, PasswordToken password) throws AccumuloException, AccumuloSecurityException;
+  void createLocalUser(String principal, PasswordToken password) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Delete a user
@@ -77,7 +77,7 @@ public interface SecurityOperations {
    * @deprecated since 1.5.0; use {@link #dropUser(String)} or the user management functions of your configured authenticator instead.
    */
   @Deprecated
-  public void dropUser(String user) throws AccumuloException, AccumuloSecurityException;
+  void dropUser(String user) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Delete a user
@@ -90,7 +90,7 @@ public interface SecurityOperations {
    *           if the user does not have permission to delete a user
    * @since 1.5.0
    */
-  public void dropLocalUser(String principal) throws AccumuloException, AccumuloSecurityException;
+  void dropLocalUser(String principal) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Verify a username/password combination is valid
@@ -107,7 +107,7 @@ public interface SecurityOperations {
    * @deprecated since 1.5.0; use {@link #authenticateUser(String, AuthenticationToken)} instead.
    */
   @Deprecated
-  public boolean authenticateUser(String user, byte[] password) throws AccumuloException, AccumuloSecurityException;
+  boolean authenticateUser(String user, byte[] password) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Verify a username/password combination is valid
@@ -123,7 +123,7 @@ public interface SecurityOperations {
    *           if the user does not have permission to ask
    * @since 1.5.0
    */
-  public boolean authenticateUser(String principal, AuthenticationToken token) throws AccumuloException, AccumuloSecurityException;
+  boolean authenticateUser(String principal, AuthenticationToken token) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Set the user's password
@@ -140,7 +140,7 @@ public interface SecurityOperations {
    *             instead.
    */
   @Deprecated
-  public void changeUserPassword(String user, byte[] password) throws AccumuloException, AccumuloSecurityException;
+  void changeUserPassword(String user, byte[] password) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Set the user's password
@@ -155,7 +155,7 @@ public interface SecurityOperations {
    *           if the user does not have permission to modify a user
    * @since 1.5.0
    */
-  public void changeLocalUserPassword(String principal, PasswordToken token) throws AccumuloException, AccumuloSecurityException;
+  void changeLocalUserPassword(String principal, PasswordToken token) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Set the user's record-level authorizations
@@ -169,7 +169,7 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to modify a user
    */
-  public void changeUserAuthorizations(String principal, Authorizations authorizations) throws AccumuloException, AccumuloSecurityException;
+  void changeUserAuthorizations(String principal, Authorizations authorizations) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Retrieves the user's authorizations for scanning
@@ -182,7 +182,7 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to query a user
    */
-  public Authorizations getUserAuthorizations(String principal) throws AccumuloException, AccumuloSecurityException;
+  Authorizations getUserAuthorizations(String principal) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Verify the user has a particular system permission
@@ -197,7 +197,7 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to query a user
    */
-  public boolean hasSystemPermission(String principal, SystemPermission perm) throws AccumuloException, AccumuloSecurityException;
+  boolean hasSystemPermission(String principal, SystemPermission perm) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Verify the user has a particular table permission
@@ -214,7 +214,7 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to query a user
    */
-  public boolean hasTablePermission(String principal, String table, TablePermission perm) throws AccumuloException, AccumuloSecurityException;
+  boolean hasTablePermission(String principal, String table, TablePermission perm) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Verify the user has a particular namespace permission
@@ -231,7 +231,7 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to query a user
    */
-  public boolean hasNamespacePermission(String principal, String namespace, NamespacePermission perm) throws AccumuloException, AccumuloSecurityException;
+  boolean hasNamespacePermission(String principal, String namespace, NamespacePermission perm) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Grant a user a system permission
@@ -245,7 +245,7 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to grant a user permissions
    */
-  public void grantSystemPermission(String principal, SystemPermission permission) throws AccumuloException, AccumuloSecurityException;
+  void grantSystemPermission(String principal, SystemPermission permission) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Grant a user a specific permission for a specific table
@@ -261,7 +261,7 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to grant a user permissions
    */
-  public void grantTablePermission(String principal, String table, TablePermission permission) throws AccumuloException, AccumuloSecurityException;
+  void grantTablePermission(String principal, String table, TablePermission permission) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Grant a user a specific permission for a specific namespace
@@ -277,7 +277,7 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to grant a user permissions
    */
-  public void grantNamespacePermission(String principal, String namespace, NamespacePermission permission) throws AccumuloException, AccumuloSecurityException;
+  void grantNamespacePermission(String principal, String namespace, NamespacePermission permission) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Revoke a system permission from a user
@@ -291,7 +291,7 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to revoke a user's permissions
    */
-  public void revokeSystemPermission(String principal, SystemPermission permission) throws AccumuloException, AccumuloSecurityException;
+  void revokeSystemPermission(String principal, SystemPermission permission) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Revoke a table permission for a specific user on a specific table
@@ -307,7 +307,7 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to revoke a user's permissions
    */
-  public void revokeTablePermission(String principal, String table, TablePermission permission) throws AccumuloException, AccumuloSecurityException;
+  void revokeTablePermission(String principal, String table, TablePermission permission) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Revoke a namespace permission for a specific user on a specific namespace
@@ -323,7 +323,7 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to revoke a user's permissions
    */
-  public void revokeNamespacePermission(String principal, String namespace, NamespacePermission permission) throws AccumuloException, AccumuloSecurityException;
+  void revokeNamespacePermission(String principal, String namespace, NamespacePermission permission) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Return a list of users in accumulo
@@ -336,7 +336,7 @@ public interface SecurityOperations {
    * @deprecated since 1.5.0; use {@link #listLocalUsers()} or the user management functions of your configured authenticator instead.
    */
   @Deprecated
-  public Set<String> listUsers() throws AccumuloException, AccumuloSecurityException;
+  Set<String> listUsers() throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Return a list of users in accumulo
@@ -348,6 +348,6 @@ public interface SecurityOperations {
    *           if the user does not have permission to query users
    * @since 1.5.0
    */
-  public Set<String> listLocalUsers() throws AccumuloException, AccumuloSecurityException;
+  Set<String> listLocalUsers() throws AccumuloException, AccumuloSecurityException;
 
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperations.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperations.java b/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperations.java
index 4f6c315..253aa52 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperations.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperations.java
@@ -47,7 +47,7 @@ public interface TableOperations {
    * 
    * @return List of tables in accumulo
    */
-  public SortedSet<String> list();
+  SortedSet<String> list();
 
   /**
    * A method to check if a table exists in Accumulo.
@@ -56,7 +56,7 @@ public interface TableOperations {
    *          the name of the table
    * @return true if the table exists
    */
-  public boolean exists(String tableName);
+  boolean exists(String tableName);
 
   /**
    * Create a table with no special configuration
@@ -70,7 +70,7 @@ public interface TableOperations {
    * @throws TableExistsException
    *           if the table already exists
    */
-  public void create(String tableName) throws AccumuloException, AccumuloSecurityException, TableExistsException;
+  void create(String tableName) throws AccumuloException, AccumuloSecurityException, TableExistsException;
 
   /**
    * @param tableName
@@ -84,7 +84,7 @@ public interface TableOperations {
    * @throws TableExistsException
    *           if the table already exists
    */
-  public void create(String tableName, boolean limitVersion) throws AccumuloException, AccumuloSecurityException, TableExistsException;
+  void create(String tableName, boolean limitVersion) throws AccumuloException, AccumuloSecurityException, TableExistsException;
 
   /**
    * @param tableName
@@ -100,7 +100,7 @@ public interface TableOperations {
    * @throws TableExistsException
    *           if the table already exists
    */
-  public void create(String tableName, boolean versioningIter, TimeType timeType) throws AccumuloException, AccumuloSecurityException, TableExistsException;
+  void create(String tableName, boolean versioningIter, TimeType timeType) throws AccumuloException, AccumuloSecurityException, TableExistsException;
 
   /**
    * Imports a table exported via exportTable and copied via hadoop distcp.
@@ -114,7 +114,7 @@ public interface TableOperations {
    * @throws AccumuloSecurityException
    * @since 1.5.0
    */
-  public void importTable(String tableName, String importDir) throws TableExistsException, AccumuloException, AccumuloSecurityException;
+  void importTable(String tableName, String importDir) throws TableExistsException, AccumuloException, AccumuloSecurityException;
 
   /**
    * Exports a table. The tables data is not exported, just table metadata and a list of files to distcp. The table being exported must be offline and stay
@@ -132,7 +132,7 @@ public interface TableOperations {
    * @throws AccumuloSecurityException
    * @since 1.5.0
    */
-  public void exportTable(String tableName, String exportDir) throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
+  void exportTable(String tableName, String exportDir) throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
 
   /**
    * @param tableName
@@ -146,7 +146,7 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           if the table does not exist
    */
-  public void addSplits(String tableName, SortedSet<Text> partitionKeys) throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
+  void addSplits(String tableName, SortedSet<Text> partitionKeys) throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
 
   /**
    * @param tableName
@@ -157,7 +157,7 @@ public interface TableOperations {
    * @deprecated since 1.5.0; use {@link #listSplits(String)} instead.
    */
   @Deprecated
-  public Collection<Text> getSplits(String tableName) throws TableNotFoundException;
+  Collection<Text> getSplits(String tableName) throws TableNotFoundException;
 
   /**
    * @param tableName
@@ -171,7 +171,7 @@ public interface TableOperations {
    *           if the user does not have permission
    * @since 1.5.0
    */
-  public Collection<Text> listSplits(String tableName) throws TableNotFoundException, AccumuloSecurityException, AccumuloException;
+  Collection<Text> listSplits(String tableName) throws TableNotFoundException, AccumuloSecurityException, AccumuloException;
 
   /**
    * @param tableName
@@ -183,7 +183,7 @@ public interface TableOperations {
    * @deprecated since 1.5.0; use {@link #listSplits(String, int)} instead.
    */
   @Deprecated
-  public Collection<Text> getSplits(String tableName, int maxSplits) throws TableNotFoundException;
+  Collection<Text> getSplits(String tableName, int maxSplits) throws TableNotFoundException;
 
   /**
    * @param tableName
@@ -198,7 +198,7 @@ public interface TableOperations {
    * @throws TableNotFoundException
    * @since 1.5.0
    */
-  public Collection<Text> listSplits(String tableName, int maxSplits) throws TableNotFoundException, AccumuloSecurityException, AccumuloException;
+  Collection<Text> listSplits(String tableName, int maxSplits) throws TableNotFoundException, AccumuloSecurityException, AccumuloException;
 
   /**
    * Finds the max row within a given range. To find the max row in a table, pass null for start and end row.
@@ -221,7 +221,7 @@ public interface TableOperations {
    * @throws AccumuloException
    * @throws TableNotFoundException
    */
-  public Text getMaxRow(String tableName, Authorizations auths, Text startRow, boolean startInclusive, Text endRow, boolean endInclusive)
+  Text getMaxRow(String tableName, Authorizations auths, Text startRow, boolean startInclusive, Text endRow, boolean endInclusive)
       throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
 
   /**
@@ -234,7 +234,7 @@ public interface TableOperations {
    * @param end
    *          last tablet to be merged contains this row, null means the last tablet
    */
-  public void merge(String tableName, Text start, Text end) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
+  void merge(String tableName, Text start, Text end) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 
   /**
    * Delete rows between (start, end]
@@ -246,7 +246,7 @@ public interface TableOperations {
    * @param end
    *          last row to be deleted, inclusive, null means the last row of the table
    */
-  public void deleteRows(String tableName, Text start, Text end) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
+  void deleteRows(String tableName, Text start, Text end) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 
   /**
    * Starts a full major compaction of the tablets in the range (start, end]. The compaction is preformed even for tablets that have only one file.
@@ -262,7 +262,7 @@ public interface TableOperations {
    * @param wait
    *          when true, the call will not return until compactions are finished
    */
-  public void compact(String tableName, Text start, Text end, boolean flush, boolean wait) throws AccumuloSecurityException, TableNotFoundException,
+  void compact(String tableName, Text start, Text end, boolean flush, boolean wait) throws AccumuloSecurityException, TableNotFoundException,
       AccumuloException;
 
   /**
@@ -282,7 +282,7 @@ public interface TableOperations {
    *          when true, the call will not return until compactions are finished
    * @since 1.5.0
    */
-  public void compact(String tableName, Text start, Text end, List<IteratorSetting> iterators, boolean flush, boolean wait) throws AccumuloSecurityException,
+  void compact(String tableName, Text start, Text end, List<IteratorSetting> iterators, boolean flush, boolean wait) throws AccumuloSecurityException,
       TableNotFoundException, AccumuloException;
 
   /**
@@ -300,7 +300,7 @@ public interface TableOperations {
    *           if the user does not have permission
    * @since 1.5.0
    */
-  public void cancelCompaction(String tableName) throws AccumuloSecurityException, TableNotFoundException, AccumuloException;
+  void cancelCompaction(String tableName) throws AccumuloSecurityException, TableNotFoundException, AccumuloException;
 
   /**
    * Delete a table
@@ -314,7 +314,7 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           if the table does not exist
    */
-  public void delete(String tableName) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
+  void delete(String tableName) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 
   /**
    * Clone a table from an existing table. The cloned table will have the same data as the source table it was created from. After cloning, the two tables can
@@ -335,7 +335,7 @@ public interface TableOperations {
    *          do not copy these properties from the source table, just revert to system defaults
    */
 
-  public void clone(String srcTableName, String newTableName, boolean flush, Map<String,String> propertiesToSet, Set<String> propertiesToExclude)
+  void clone(String srcTableName, String newTableName, boolean flush, Map<String,String> propertiesToSet, Set<String> propertiesToExclude)
       throws AccumuloException, AccumuloSecurityException, TableNotFoundException, TableExistsException;
 
   /**
@@ -354,7 +354,7 @@ public interface TableOperations {
    * @throws TableExistsException
    *           if the new table name already exists
    */
-  public void rename(String oldTableName, String newTableName) throws AccumuloSecurityException, TableNotFoundException, AccumuloException,
+  void rename(String oldTableName, String newTableName) throws AccumuloSecurityException, TableNotFoundException, AccumuloException,
       TableExistsException;
 
   /**
@@ -370,7 +370,7 @@ public interface TableOperations {
    * @deprecated As of release 1.4, replaced by {@link #flush(String, Text, Text, boolean)}
    */
   @Deprecated
-  public void flush(String tableName) throws AccumuloException, AccumuloSecurityException;
+  void flush(String tableName) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Flush a table's data that is currently in memory.
@@ -386,7 +386,7 @@ public interface TableOperations {
    *           if the user does not have permission
    * @throws TableNotFoundException
    */
-  public void flush(String tableName, Text start, Text end, boolean wait) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
+  void flush(String tableName, Text start, Text end, boolean wait) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 
   /**
    * Sets a property on a table. Note that it may take a short period of time (a second) to propagate the change everywhere.
@@ -402,7 +402,7 @@ public interface TableOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission
    */
-  public void setProperty(String tableName, String property, String value) throws AccumuloException, AccumuloSecurityException;
+  void setProperty(String tableName, String property, String value) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Removes a property from a table. Note that it may take a short period of time (a second) to propagate the change everywhere.
@@ -416,7 +416,7 @@ public interface TableOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission
    */
-  public void removeProperty(String tableName, String property) throws AccumuloException, AccumuloSecurityException;
+  void removeProperty(String tableName, String property) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Gets properties of a table. Note that recently changed properties may not be available immediately.
@@ -427,7 +427,7 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           if the table does not exist
    */
-  public Iterable<Entry<String,String>> getProperties(String tableName) throws AccumuloException, TableNotFoundException;
+  Iterable<Entry<String,String>> getProperties(String tableName) throws AccumuloException, TableNotFoundException;
 
   /**
    * Sets a table's locality groups. A table's locality groups can be changed at any time.
@@ -443,7 +443,7 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           if the table does not exist
    */
-  public void setLocalityGroups(String tableName, Map<String,Set<Text>> groups) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
+  void setLocalityGroups(String tableName, Map<String,Set<Text>> groups) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 
   /**
    * 
@@ -457,7 +457,7 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           if the table does not exist
    */
-  public Map<String,Set<Text>> getLocalityGroups(String tableName) throws AccumuloException, TableNotFoundException;
+  Map<String,Set<Text>> getLocalityGroups(String tableName) throws AccumuloException, TableNotFoundException;
 
   /**
    * @param tableName
@@ -474,7 +474,7 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           if the table does not exist
    */
-  public Set<Range> splitRangeByTablets(String tableName, Range range, int maxSplits) throws AccumuloException, AccumuloSecurityException,
+  Set<Range> splitRangeByTablets(String tableName, Range range, int maxSplits) throws AccumuloException, AccumuloSecurityException,
       TableNotFoundException;
 
   /**
@@ -498,7 +498,7 @@ public interface TableOperations {
    *           when the table no longer exists
    * 
    */
-  public void importDirectory(String tableName, String dir, String failureDir, boolean setTime) throws TableNotFoundException, IOException, AccumuloException,
+  void importDirectory(String tableName, String dir, String failureDir, boolean setTime) throws TableNotFoundException, IOException, AccumuloException,
       AccumuloSecurityException;
 
   /**
@@ -512,7 +512,7 @@ public interface TableOperations {
    *           when the user does not have the proper permissions
    * @throws TableNotFoundException
    */
-  public void offline(String tableName) throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
+  void offline(String tableName) throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
 
   /**
    * 
@@ -527,7 +527,7 @@ public interface TableOperations {
    * @throws TableNotFoundException
    * @since 1.6.0
    */
-  public void offline(String tableName, boolean wait) throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
+  void offline(String tableName, boolean wait) throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
 
   /**
    * Initiates bringing a table online, but does not wait for action to complete
@@ -540,7 +540,7 @@ public interface TableOperations {
    *           when the user does not have the proper permissions
    * @throws TableNotFoundException
    */
-  public void online(String tableName) throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
+  void online(String tableName) throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
 
   /**
    * 
@@ -555,7 +555,7 @@ public interface TableOperations {
    * @throws TableNotFoundException
    * @since 1.6.0
    */
-  public void online(String tableName, boolean wait) throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
+  void online(String tableName, boolean wait) throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
 
   /**
    * Clears the tablet locator cache for a specified table
@@ -565,14 +565,14 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           if table does not exist
    */
-  public void clearLocatorCache(String tableName) throws TableNotFoundException;
+  void clearLocatorCache(String tableName) throws TableNotFoundException;
 
   /**
    * Get a mapping of table name to internal table id.
    * 
    * @return the map from table name to internal table id
    */
-  public Map<String,String> tableIdMap();
+  Map<String,String> tableIdMap();
 
   /**
    * Add an iterator to a table on all scopes.
@@ -589,7 +589,7 @@ public interface TableOperations {
    * @throws IllegalArgumentException
    *           if the setting conflicts with any existing iterators
    */
-  public void attachIterator(String tableName, IteratorSetting setting) throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
+  void attachIterator(String tableName, IteratorSetting setting) throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
 
   /**
    * Add an iterator to a table on the given scopes.
@@ -606,7 +606,7 @@ public interface TableOperations {
    * @throws IllegalArgumentException
    *           if the setting conflicts with any existing iterators
    */
-  public void attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloSecurityException, AccumuloException,
+  void attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloSecurityException, AccumuloException,
       TableNotFoundException;
 
   /**
@@ -624,7 +624,7 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           throw if the table no longer exists
    */
-  public void removeIterator(String tableName, String name, EnumSet<IteratorScope> scopes) throws AccumuloSecurityException, AccumuloException,
+  void removeIterator(String tableName, String name, EnumSet<IteratorScope> scopes) throws AccumuloSecurityException, AccumuloException,
       TableNotFoundException;
 
   /**
@@ -643,7 +643,7 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           throw if the table no longer exists
    */
-  public IteratorSetting getIteratorSetting(String tableName, String name, IteratorScope scope) throws AccumuloSecurityException, AccumuloException,
+  IteratorSetting getIteratorSetting(String tableName, String name, IteratorScope scope) throws AccumuloSecurityException, AccumuloException,
       TableNotFoundException;
 
   /**
@@ -656,7 +656,7 @@ public interface TableOperations {
    * @throws AccumuloException
    * @throws TableNotFoundException
    */
-  public Map<String,EnumSet<IteratorScope>> listIterators(String tableName) throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
+  Map<String,EnumSet<IteratorScope>> listIterators(String tableName) throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
 
   /**
    * Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for
@@ -669,7 +669,7 @@ public interface TableOperations {
    * @throws AccumuloException
    * @throws TableNotFoundException
    */
-  public void checkIteratorConflicts(String tableName, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloException, TableNotFoundException;
+  void checkIteratorConflicts(String tableName, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloException, TableNotFoundException;
 
   /**
    * Add a new constraint to a table.
@@ -686,7 +686,7 @@ public interface TableOperations {
    * @throws TableNotFoundException
    * @since 1.5.0
    */
-  public int addConstraint(String tableName, String constraintClassName) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
+  int addConstraint(String tableName, String constraintClassName) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 
   /**
    * Remove a constraint from a table.
@@ -700,7 +700,7 @@ public interface TableOperations {
    *           thrown if the user doesn't have permission to remove the constraint
    * @since 1.5.0
    */
-  public void removeConstraint(String tableName, int number) throws AccumuloException, AccumuloSecurityException;
+  void removeConstraint(String tableName, int number) throws AccumuloException, AccumuloSecurityException;
 
   /**
    * List constraints on a table with their assigned numbers.
@@ -713,7 +713,7 @@ public interface TableOperations {
    * @throws TableNotFoundException
    * @since 1.5.0
    */
-  public Map<String,Integer> listConstraints(String tableName) throws AccumuloException, TableNotFoundException;
+  Map<String,Integer> listConstraints(String tableName) throws AccumuloException, TableNotFoundException;
 
   /**
    * Gets the number of bytes being used in the files for a set of tables
@@ -724,7 +724,7 @@ public interface TableOperations {
    * @throws AccumuloException
    * @throws AccumuloSecurityException
    */
-  public List<DiskUsage> getDiskUsage(Set<String> tables) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
+  List<DiskUsage> getDiskUsage(Set<String> tables) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 
   /**
    * Test to see if the instance can load the given class as the given type. This check uses the table classpath if it is set.
@@ -737,6 +737,6 @@ public interface TableOperations {
    * 
    * @since 1.5.0
    */
-  public boolean testClassLoad(String tableName, final String className, final String asTypeName) throws AccumuloException, AccumuloSecurityException,
+  boolean testClassLoad(String tableName, final String className, final String asTypeName) throws AccumuloException, AccumuloSecurityException,
       TableNotFoundException;
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperationsImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperationsImpl.java b/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperationsImpl.java
index 9956538..4003e6f 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperationsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperationsImpl.java
@@ -32,6 +32,7 @@ import java.util.LinkedList;
 import java.util.List;
 import java.util.Map;
 import java.util.Map.Entry;
+import java.util.Random;
 import java.util.Set;
 import java.util.SortedSet;
 import java.util.TreeMap;
@@ -1081,6 +1082,7 @@ public class TableOperationsImpl extends TableOperationsHelper {
     if (maxSplits == 1)
       return Collections.singleton(range);
 
+    Random random = new Random();
     Map<String,Map<KeyExtent,List<Range>>> binnedRanges = new HashMap<String,Map<KeyExtent,List<Range>>>();
     String tableId = Tables.getTableId(instance, tableName);
     TabletLocator tl = TabletLocator.getLocator(instance, new Text(tableId));
@@ -1094,7 +1096,7 @@ public class TableOperationsImpl extends TableOperationsHelper {
 
       log.warn("Unable to locate bins for specified range. Retrying.");
       // sleep randomly between 100 and 200ms
-      UtilWaitThread.sleep(100 + (int) (Math.random() * 100));
+      UtilWaitThread.sleep(100 + random.nextInt(100));
       binnedRanges.clear();
       tl.invalidateCache();
     }
@@ -1454,10 +1456,14 @@ public class TableOperationsImpl extends TableOperationsHelper {
       while ((zipEntry = zis.getNextEntry()) != null) {
         if (zipEntry.getName().equals(Constants.EXPORT_TABLE_CONFIG_FILE)) {
           BufferedReader in = new BufferedReader(new InputStreamReader(zis));
-          String line;
-          while ((line = in.readLine()) != null) {
-            String sa[] = line.split("=", 2);
-            props.put(sa[0], sa[1]);
+          try {
+            String line;
+            while ((line = in.readLine()) != null) {
+              String sa[] = line.split("=", 2);
+              props.put(sa[0], sa[1]);
+            }
+          } finally {
+            in.close();
           }
 
           break;
@@ -1483,10 +1489,10 @@ public class TableOperationsImpl extends TableOperationsHelper {
       FileSystem fs = new Path(importDir).getFileSystem(CachedConfiguration.getInstance());
       Map<String,String> props = getExportedProps(fs, new Path(importDir, Constants.EXPORT_FILE));
 
-      for (String propKey : props.keySet()) {
-        if (Property.isClassProperty(propKey) && !props.get(propKey).contains(Constants.CORE_PACKAGE_NAME)) {
+      for (Entry<String,String> entry : props.entrySet()) {
+        if (Property.isClassProperty(entry.getKey()) && !entry.getValue().contains(Constants.CORE_PACKAGE_NAME)) {
           Logger.getLogger(this.getClass()).info(
-              "Imported table sets '" + propKey + "' to '" + props.get(propKey) + "'.  Ensure this class is on Accumulo classpath.");
+              "Imported table sets '" + entry.getKey() + "' to '" + entry.getValue() + "'.  Ensure this class is on Accumulo classpath.");
         }
       }
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/impl/ConditionalWriterImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ConditionalWriterImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ConditionalWriterImpl.java
index cd89adb..1ec6dee 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ConditionalWriterImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ConditionalWriterImpl.java
@@ -181,6 +181,13 @@ class ConditionalWriterImpl implements ConditionalWriter {
     }
     
     @Override
+    public boolean equals(Object o) {
+      if (o instanceof QCMutation)
+        return compareTo((QCMutation) o) == 0;
+      return false;
+    }
+
+    @Override
     public long getDelay(TimeUnit unit) {
       return unit.convert(delay - (System.currentTimeMillis() - resetTime), TimeUnit.MILLISECONDS);
     }
@@ -368,7 +375,6 @@ class ConditionalWriterImpl implements ConditionalWriter {
     this.auths = config.getAuthorizations();
     this.ve = new VisibilityEvaluator(config.getAuthorizations());
     this.threadPool = new ScheduledThreadPoolExecutor(config.getMaxWriteThreads());
-    this.threadPool.setMaximumPoolSize(config.getMaxWriteThreads());
     this.locator = TabletLocator.getLocator(instance, new Text(tableId));
     this.serverQueues = new HashMap<String,ServerQueue>();
     this.tableId = tableId;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/impl/MultiTableBatchWriterImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/MultiTableBatchWriterImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/MultiTableBatchWriterImpl.java
index 7eea455..f2478d9 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/MultiTableBatchWriterImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/MultiTableBatchWriterImpl.java
@@ -91,7 +91,7 @@ public class MultiTableBatchWriterImpl implements MultiTableBatchWriter {
       String tableId = Tables.getNameToIdMap(instance).get(tableName);
 
       if (tableId == null)
-        throw new TableNotFoundException(tableId, tableName, null);
+        throw new TableNotFoundException(null, tableName, null);
 
       if (Tables.getTableState(instance, tableId) == TableState.OFFLINE)
         throw new TableOfflineException(instance, tableId);
@@ -215,12 +215,14 @@ public class MultiTableBatchWriterImpl implements MultiTableBatchWriter {
 
     String tableId = getId(tableName);
 
-    BatchWriter tbw = tableWriters.get(tableId);
-    if (tbw == null) {
-      tbw = new TableBatchWriter(tableId);
-      tableWriters.put(tableId, tbw);
+    synchronized (tableWriters) {
+      BatchWriter tbw = tableWriters.get(tableId);
+      if (tbw == null) {
+        tbw = new TableBatchWriter(tableId);
+        tableWriters.put(tableId, tbw);
+      }
+      return tbw;
     }
-    return tbw;
   }
 
   @Override

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/impl/Tables.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/Tables.java b/core/src/main/java/org/apache/accumulo/core/client/impl/Tables.java
index f3b5a8d..215f381 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/Tables.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/Tables.java
@@ -134,7 +134,7 @@ public class Tables {
       // create fully qualified table name
       if (nId == null) {
         namespaceName = null;
-      } else if (nId != null) {
+      } else {
         String namespaceId = new String(nId, Constants.UTF8);
         if (!namespaceId.equals(Namespaces.DEFAULT_NAMESPACE_ID)) {
           try {
@@ -189,7 +189,7 @@ public class Tables {
   public static String getTableName(Instance instance, String tableId) throws TableNotFoundException {
     String tableName = getIdToNameMap(instance).get(tableId);
     if (tableName == null)
-      throw new TableNotFoundException(tableId, tableName, null);
+      throw new TableNotFoundException(tableId, null, null);
     return tableName;
   }
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5bd4e27c/core/src/main/java/org/apache/accumulo/core/client/impl/TabletLocatorImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletLocatorImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletLocatorImpl.java
index 6f4e598..c550f15 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletLocatorImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletLocatorImpl.java
@@ -16,6 +16,7 @@
  */
 package org.apache.accumulo.core.client.impl;
 
+import java.io.Serializable;
 import java.util.ArrayList;
 import java.util.Collection;
 import java.util.Collections;
@@ -59,8 +60,10 @@ public class TabletLocatorImpl extends TabletLocator {
   // putting null, put MAX_TEXT
   static final Text MAX_TEXT = new Text();
   
-  private static class EndRowComparator implements Comparator<Text> {
+  private static class EndRowComparator implements Comparator<Text>, Serializable {
     
+    private static final long serialVersionUID = 1L;
+
     @Override
     public int compare(Text o1, Text o2) {
       
@@ -96,7 +99,7 @@ public class TabletLocatorImpl extends TabletLocator {
   private final Lock wLock = rwLock.writeLock();
 
   
-  public static interface TabletLocationObtainer {
+  public interface TabletLocationObtainer {
     /**
      * @return null when unable to read information successfully
      */
@@ -634,7 +637,7 @@ public class TabletLocatorImpl extends TabletLocator {
     if (badExtents.size() == 0)
       return;
     
-    boolean writeLockHeld = rwLock.isWriteLockedByCurrentThread();
+    final boolean writeLockHeld = rwLock.isWriteLockedByCurrentThread();
     try {
       if (!writeLockHeld) {
         rLock.unlock();