You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by ct...@apache.org on 2015/05/07 20:54:11 UTC

[07/11] accumulo git commit: ACCUMULO-3771 Configure automatic Java code style formatting

ACCUMULO-3771 Configure automatic Java code style formatting

* Built Accumulo which ran maven-java-formatter-plugin for first time


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

Branch: refs/heads/master
Commit: b932755e0caa808bbe5ff4df99ca1c22d9effa58
Parents: a08dd85
Author: Mike Walch <mw...@gmail.com>
Authored: Wed May 6 11:40:17 2015 -0400
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Thu May 7 14:43:00 2015 -0400

----------------------------------------------------------------------
 .../core/client/ClientConfiguration.java        |  4 +--
 .../core/client/ClientSideIteratorScanner.java  |  4 +--
 .../core/client/impl/ActiveCompactionImpl.java  |  1 -
 .../core/client/impl/OfflineIterator.java       |  2 +-
 .../core/client/impl/ThriftScanner.java         |  2 +-
 .../core/client/impl/ThriftTransportPool.java   |  3 +-
 .../core/client/lexicoder/PairLexicoder.java    |  3 +-
 .../lexicoder/impl/AbstractLexicoder.java       |  3 +-
 .../core/client/mapred/AbstractInputFormat.java | 11 +++----
 .../core/client/mapred/InputFormatBase.java     | 20 ++++++-------
 .../client/mapred/impl/BatchInputSplit.java     |  3 +-
 .../client/mapreduce/AbstractInputFormat.java   | 25 ++++++++--------
 .../client/mapreduce/AccumuloInputFormat.java   |  2 +-
 .../core/client/mapreduce/InputFormatBase.java  | 20 ++++++-------
 .../core/client/mapreduce/RangeInputSplit.java  |  2 +-
 .../client/mapreduce/impl/BatchInputSplit.java  | 19 +++++++------
 .../core/client/mapreduce/impl/SplitUtils.java  |  8 +++---
 .../core/client/mock/MockScannerBase.java       |  7 +++--
 .../client/security/tokens/DelegationToken.java |  3 +-
 .../accumulo/core/compaction/PatternType.java   |  2 +-
 .../accumulo/core/compaction/SizeType.java      |  2 +-
 .../accumulo/core/compaction/StringType.java    |  2 +-
 .../apache/accumulo/core/compaction/Type.java   |  2 +-
 .../accumulo/core/compaction/UIntType.java      |  2 +-
 .../org/apache/accumulo/core/conf/Property.java | 10 ++-----
 .../apache/accumulo/core/data/KeyExtent.java    | 15 +++++-----
 .../org/apache/accumulo/core/data/Mutation.java |  6 ++--
 .../org/apache/accumulo/core/data/TabletId.java |  2 ++
 .../accumulo/core/data/impl/TabletIdImpl.java   | 10 +++----
 .../core/file/DispatchingFileFactory.java       |  2 +-
 .../apache/accumulo/core/file/rfile/RFile.java  |  3 +-
 .../core/iterators/AggregatingIterator.java     |  1 -
 .../accumulo/core/iterators/IteratorUtil.java   |  3 +-
 .../accumulo/core/iterators/LongCombiner.java   |  4 +--
 .../core/iterators/SortedKeyValueIterator.java  | 10 +++----
 .../core/iterators/system/MapFileIterator.java  |  1 -
 .../core/iterators/system/VisibilityFilter.java |  1 -
 .../core/iterators/user/BigDecimalCombiner.java |  3 +-
 .../core/iterators/user/RegExFilter.java        |  1 -
 .../iterators/user/RowEncodingIterator.java     |  2 +-
 .../iterators/user/TransformingIterator.java    |  1 -
 .../core/metadata/schema/MetadataSchema.java    |  2 +-
 .../accumulo/core/rpc/SaslConnectionParams.java |  7 ++---
 .../core/rpc/UGIAssumingTransportFactory.java   |  2 +-
 .../CachingHDFSSecretKeyEncryptionStrategy.java | 12 ++++----
 .../security/crypto/CryptoModuleFactory.java    |  8 +++---
 .../NonCachingSecretKeyEncryptionStrategy.java  | 14 ++++-----
 .../org/apache/accumulo/core/util/Help.java     |  2 +-
 .../java/org/apache/accumulo/core/util/Jar.java |  2 +-
 .../accumulo/core/util/UtilWaitThread.java      |  1 -
 .../core/util/format/FormatterFactory.java      |  1 -
 .../apache/accumulo/core/volume/VolumeImpl.java |  1 -
 .../apache/accumulo/core/zookeeper/ZooUtil.java |  1 -
 .../core/client/ClientConfigurationTest.java    |  4 +--
 .../client/lexicoder/BytesLexicoderTest.java    |  2 +-
 .../client/lexicoder/DateLexicoderTest.java     |  2 +-
 .../client/lexicoder/StringLexicoderTest.java   |  2 +-
 .../client/lexicoder/TextLexicoderTest.java     |  2 +-
 .../client/lexicoder/impl/ByteUtilsTest.java    |  4 +--
 .../apache/accumulo/core/data/MutationTest.java | 16 +++++------
 .../iterators/FirstEntryInRowIteratorTest.java  |  3 +-
 .../iterators/aggregation/NumSummationTest.java |  3 +-
 .../iterators/user/RowDeletingIteratorTest.java |  2 +-
 .../client/CountingVerifyingReceiver.java       |  2 +-
 .../examples/simple/client/RowOperations.java   |  1 -
 .../simple/mapreduce/TokenFileWordCount.java    |  1 -
 .../examples/simple/reservations/ARS.java       |  1 -
 .../examples/simple/dirlist/CountTest.java      |  1 -
 .../org/apache/accumulo/fate/AdminUtil.java     |  2 +-
 .../org/apache/accumulo/fate/AgeOffStore.java   |  1 -
 .../java/org/apache/accumulo/fate/Fate.java     |  1 -
 .../apache/accumulo/fate/util/AddressUtil.java  |  1 -
 .../accumulo/fate/util/UtilWaitThread.java      |  1 -
 .../zookeeper/DistributedReadWriteLock.java     |  1 -
 .../apache/accumulo/fate/zookeeper/Retry.java   |  1 -
 .../fate/zookeeper/TransactionWatcher.java      |  1 -
 .../accumulo/fate/util/AddressUtilTest.java     |  1 -
 .../org/apache/accumulo/proxy/ProxyServer.java  |  3 +-
 .../org/apache/accumulo/server/TabletLevel.java |  4 +--
 .../server/client/ClientServiceHandler.java     |  4 +--
 .../server/master/state/MetaDataStateStore.java |  2 +-
 .../server/master/state/TabletStateStore.java   |  7 +++--
 .../master/state/ZooTabletStateStore.java       |  5 ++--
 .../AuthenticationTokenKeyManager.java          |  3 +-
 .../ZooAuthenticationKeyDistributor.java        |  1 -
 .../server/util/MasterMetadataUtil.java         |  2 --
 .../accumulo/server/util/MetadataTableUtil.java |  4 +--
 .../iterators/MetadataBulkLoadFilterTest.java   |  2 +-
 .../security/handler/ZKAuthenticatorTest.java   |  2 +-
 .../org/apache/accumulo/gc/GCExecutable.java    |  2 +-
 .../accumulo/master/TabletGroupWatcher.java     | 13 +++------
 .../accumulo/master/tableOps/ChooseDir.java     |  2 +-
 .../master/tableOps/CleanUpBulkImport.java      |  2 +-
 .../accumulo/master/tableOps/CloneInfo.java     |  2 +-
 .../accumulo/master/tableOps/CloneMetadata.java |  2 +-
 .../master/tableOps/CloneZookeeper.java         |  2 +-
 .../master/tableOps/CompactionDriver.java       |  2 +-
 .../master/tableOps/CompleteBulkImport.java     |  2 +-
 .../accumulo/master/tableOps/CreateDir.java     |  2 +-
 .../master/tableOps/CreateImportDir.java        |  2 +-
 .../accumulo/master/tableOps/ExportInfo.java    |  2 +-
 .../master/tableOps/FinishCancelCompaction.java |  2 +-
 .../master/tableOps/FinishCloneTable.java       |  2 +-
 .../master/tableOps/FinishCreateNamespace.java  |  2 +-
 .../master/tableOps/FinishCreateTable.java      |  2 +-
 .../master/tableOps/FinishImportTable.java      |  2 +-
 .../tableOps/ImportPopulateZookeeper.java       |  2 +-
 .../master/tableOps/ImportSetupPermissions.java |  2 +-
 .../master/tableOps/ImportedTableInfo.java      |  2 +-
 .../accumulo/master/tableOps/NamespaceInfo.java |  2 +-
 .../master/tableOps/PopulateMetadata.java       |  2 +-
 .../master/tableOps/PopulateZookeeper.java      |  2 +-
 .../PopulateZookeeperWithNamespace.java         |  2 +-
 .../accumulo/master/tableOps/TableInfo.java     |  2 +-
 .../master/tableOps/WriteExportFiles.java       |  2 +-
 .../monitor/servlets/trace/NullScanner.java     |  3 +-
 .../accumulo/monitor/ShowTraceLinkTypeTest.java |  3 +-
 .../accumulo/tracer/AsyncSpanReceiver.java      |  4 +--
 .../apache/accumulo/tracer/TraceTableStats.java | 30 ++++++++------------
 .../server/GarbageCollectionLogger.java         |  3 +-
 .../accumulo/tserver/MemKeyComparator.java      |  2 +-
 .../tserver/MemKeyConversionIterator.java       |  2 +-
 .../PartialMutationSkippingIterator.java        |  2 +-
 .../tserver/TabletIteratorEnvironment.java      |  2 +-
 .../apache/accumulo/tserver/TabletServer.java   |  7 ++---
 .../EverythingCompactionStrategy.java           |  2 +-
 .../apache/accumulo/tserver/log/DfsLogger.java  |  8 +++---
 .../tserver/log/TabletServerLogger.java         |  4 +--
 .../accumulo/tserver/tablet/MinorCompactor.java |  2 +-
 .../org/apache/accumulo/shell/ShellOptions.java |  1 -
 .../accumulo/test/EstimateInMemMapOverhead.java |  1 -
 .../test/InMemoryMapMemoryUsageTest.java        |  2 +-
 .../accumulo/test/IntObjectMemoryUsageTest.java |  2 +-
 .../apache/accumulo/test/MemoryUsageTest.java   |  2 +-
 .../accumulo/test/MutationMemoryUsageTest.java  |  2 +-
 .../accumulo/test/TextMemoryUsageTest.java      |  2 +-
 .../accumulo/test/continuous/HistData.java      |  2 +-
 .../test/continuous/PrintScanTimeHistogram.java |  2 +-
 .../accumulo/test/functional/AuthsIterator.java |  2 +-
 .../accumulo/test/randomwalk/Environment.java   |  2 +-
 .../test/randomwalk/concurrent/Replication.java | 14 ++++-----
 .../accumulo/harness/AccumuloClusterIT.java     |  3 +-
 .../apache/accumulo/proxy/SimpleProxyBase.java  |  2 +-
 .../test/BalanceWithOfflineTableIT.java         |  8 +++---
 .../accumulo/test/GarbageCollectWALIT.java      |  2 +-
 .../apache/accumulo/test/TableOperationsIT.java |  4 +--
 .../java/org/apache/accumulo/test/VolumeIT.java |  2 +-
 .../test/functional/AccumuloInputFormatIT.java  | 14 ++++-----
 .../accumulo/test/functional/KerberosIT.java    |  6 ++--
 .../test/functional/KerberosProxyIT.java        |  8 +++---
 .../accumulo/test/functional/WALSunnyDayIT.java | 16 +++++------
 .../test/performance/RollWALPerformanceIT.java  | 14 +++------
 .../test/replication/ReplicationIT.java         |  4 +--
 153 files changed, 286 insertions(+), 343 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/ClientConfiguration.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/ClientConfiguration.java b/core/src/main/java/org/apache/accumulo/core/client/ClientConfiguration.java
index b531f26..f008ab7 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/ClientConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/ClientConfiguration.java
@@ -179,8 +179,8 @@ public class ClientConfiguration extends CompositeConfiguration {
       if (c instanceof AbstractConfiguration) {
         AbstractConfiguration abstractConfiguration = (AbstractConfiguration) c;
         if (!abstractConfiguration.isDelimiterParsingDisabled() && abstractConfiguration.getListDelimiter() != '\0') {
-          log.warn("Client configuration constructed with a Configuration that did not have list delimiter disabled or overridden, multi-valued config " +
-              "properties may be unavailable");
+          log.warn("Client configuration constructed with a Configuration that did not have list delimiter disabled or overridden, multi-valued config "
+              + "properties may be unavailable");
           abstractConfiguration.setListDelimiter('\0');
         }
       }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/ClientSideIteratorScanner.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/ClientSideIteratorScanner.java b/core/src/main/java/org/apache/accumulo/core/client/ClientSideIteratorScanner.java
index c75f54a..f077573 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/ClientSideIteratorScanner.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/ClientSideIteratorScanner.java
@@ -62,7 +62,7 @@ public class ClientSideIteratorScanner extends ScannerOptions implements Scanner
   private long readaheadThreshold = Constants.SCANNER_DEFAULT_READAHEAD_THRESHOLD;
 
   /**
-   * @deprecated since 1.7.0 was never intended for public use.  However this could have been used by anything extending this class.
+   * @deprecated since 1.7.0 was never intended for public use. However this could have been used by anything extending this class.
    */
   @Deprecated
   public class ScannerTranslator extends ScannerTranslatorImpl {
@@ -209,7 +209,7 @@ public class ClientSideIteratorScanner extends ScannerOptions implements Scanner
 
         @Override
         public Authorizations getAuthorizations() {
-            return smi.scanner.getAuthorizations();
+          return smi.scanner.getAuthorizations();
         }
       }, false, null);
     } catch (IOException e) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveCompactionImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveCompactionImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveCompactionImpl.java
index bb7366b..1e429c8 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveCompactionImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveCompactionImpl.java
@@ -48,7 +48,6 @@ public class ActiveCompactionImpl extends ActiveCompaction {
     return Tables.getTableName(instance, new KeyExtent(tac.getExtent()).getTableId().toString());
   }
 
-
   @Override
   @Deprecated
   public org.apache.accumulo.core.data.KeyExtent getExtent() {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/impl/OfflineIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/OfflineIterator.java b/core/src/main/java/org/apache/accumulo/core/client/impl/OfflineIterator.java
index b035e3e..69ad41e 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/OfflineIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/OfflineIterator.java
@@ -337,4 +337,4 @@ class OfflineIterator implements Iterator<Entry<Key,Value>> {
     throw new UnsupportedOperationException();
   }
 
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/impl/ThriftScanner.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ThriftScanner.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ThriftScanner.java
index 4bfbfa0..39d3b32 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ThriftScanner.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ThriftScanner.java
@@ -199,7 +199,7 @@ public class ThriftScanner {
   private static long pause(long millis) throws InterruptedException {
     Thread.sleep(millis);
     // wait 2 * last time, with +-10% random jitter
-    return (long)(Math.max(millis * 2, 3000) * (.9 + Math.random() / 5));
+    return (long) (Math.max(millis * 2, 3000) * (.9 + Math.random() / 5));
   }
 
   public static List<KeyValue> scan(ClientContext context, ScanState scanState, int timeOut) throws ScanTimedOutException, AccumuloException,

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/impl/ThriftTransportPool.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ThriftTransportPool.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ThriftTransportPool.java
index 2afbb83..ba62cec 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ThriftTransportPool.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ThriftTransportPool.java
@@ -475,7 +475,8 @@ public class ThriftTransportPool {
   }
 
   private TTransport createNewTransport(ThriftTransportKey cacheKey) throws TTransportException {
-    TTransport transport = ThriftUtil.createClientTransport(cacheKey.getServer(), (int) cacheKey.getTimeout(), cacheKey.getSslParams(), cacheKey.getSaslParams());
+    TTransport transport = ThriftUtil.createClientTransport(cacheKey.getServer(), (int) cacheKey.getTimeout(), cacheKey.getSslParams(),
+        cacheKey.getSaslParams());
 
     log.trace("Creating new connection to connection to {}", cacheKey.getServer());
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/lexicoder/PairLexicoder.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/PairLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/PairLexicoder.java
index dff946f..f28912c 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/PairLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/PairLexicoder.java
@@ -49,7 +49,8 @@ import static org.apache.accumulo.core.client.lexicoder.impl.ByteUtils.unescape;
  * @since 1.6.0
  */
 
-public class PairLexicoder<A extends Comparable<A>,B extends Comparable<B>> extends AbstractLexicoder<ComparablePair<A,B>> implements Lexicoder<ComparablePair<A,B>> {
+public class PairLexicoder<A extends Comparable<A>,B extends Comparable<B>> extends AbstractLexicoder<ComparablePair<A,B>> implements
+    Lexicoder<ComparablePair<A,B>> {
 
   private Lexicoder<A> firstLexicoder;
   private Lexicoder<B> secondLexicoder;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/lexicoder/impl/AbstractLexicoder.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/impl/AbstractLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/impl/AbstractLexicoder.java
index e568f25..5652747 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/impl/AbstractLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/impl/AbstractLexicoder.java
@@ -19,5 +19,4 @@ package org.apache.accumulo.core.client.lexicoder.impl;
 import org.apache.accumulo.core.client.lexicoder.AbstractEncoder;
 import org.apache.accumulo.core.client.lexicoder.Lexicoder;
 
-public abstract class AbstractLexicoder<T> extends AbstractEncoder<T> implements Lexicoder<T> {
-}
+public abstract class AbstractLexicoder<T> extends AbstractEncoder<T> implements Lexicoder<T> {}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/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 cb3ef11..86a7adf 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
@@ -398,7 +398,6 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
     private org.apache.accumulo.core.client.mapreduce.RangeInputSplit baseSplit;
     protected ScannerBase scannerBase;
 
-
     /**
      * Extracts Iterators settings from the context to be used by RecordReader.
      *
@@ -496,7 +495,7 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
         BatchScanner scanner;
         BatchInputSplit multiRangeSplit = (BatchInputSplit) baseSplit;
 
-        try{
+        try {
           // Note: BatchScanner will use at most one thread per tablet, currently BatchInputSplit will not span tablets
           int scanThreads = 1;
           scanner = instance.getConnector(principal, token).createBatchScanner(baseSplit.getTableName(), authorizations, scanThreads);
@@ -608,7 +607,6 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
     return InputConfigurator.binOffline(tableId, ranges, instance, conn);
   }
 
-
   /**
    * Gets the splits of the tables that have been set on the job by reading the metadata table for the specified ranges.
    *
@@ -646,9 +644,8 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
       String principal = getPrincipal(job);
       AuthenticationToken token = getAuthenticationToken(job);
 
-      boolean batchScan =  InputConfigurator.isBatchScan(CLASS, job);
-      boolean supportBatchScan =
-        !(tableConfig.isOfflineScan() || tableConfig.shouldUseIsolatedScanners() || tableConfig.shouldUseLocalIterators());
+      boolean batchScan = InputConfigurator.isBatchScan(CLASS, job);
+      boolean supportBatchScan = !(tableConfig.isOfflineScan() || tableConfig.shouldUseIsolatedScanners() || tableConfig.shouldUseLocalIterators());
       if (batchScan && !supportBatchScan)
         throw new IllegalArgumentException("BatchScanner optimization not available for offline scan, isolated, or local iterators");
 
@@ -716,7 +713,7 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
           if (batchScan) {
             // group ranges by tablet to be read by a BatchScanner
             ArrayList<Range> clippedRanges = new ArrayList<Range>();
-            for(Range r: extentRanges.getValue())
+            for (Range r : extentRanges.getValue())
               clippedRanges.add(ke.clip(r));
 
             BatchInputSplit split = new BatchInputSplit(tableName, tableId, clippedRanges, new String[] {location});

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/mapred/InputFormatBase.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapred/InputFormatBase.java b/core/src/main/java/org/apache/accumulo/core/client/mapred/InputFormatBase.java
index 517cd19..ffb02a9 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapred/InputFormatBase.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapred/InputFormatBase.java
@@ -177,8 +177,7 @@ public abstract class InputFormatBase<K,V> extends AbstractInputFormat<K,V> {
   }
 
   /**
-   * Determines whether a configuration has auto-adjust ranges enabled.
-   * Must be enabled when {@link #setBatchScan(JobConf, boolean)} is true.
+   * Determines whether a configuration has auto-adjust ranges enabled. Must be enabled when {@link #setBatchScan(JobConf, boolean)} is true.
    *
    * @param job
    *          the Hadoop context for the configured job
@@ -298,21 +297,20 @@ public abstract class InputFormatBase<K,V> extends AbstractInputFormat<K,V> {
   }
 
   /**
-   * Controls the use of the {@link org.apache.accumulo.core.client.BatchScanner} in this job.
-   * Using this feature will group Ranges by their source tablet, producing an InputSplit per tablet
-   * rather than per Range. This batching helps to reduce overhead when querying a large number of small ranges.
-   * (ex: when doing quad-tree decomposition for spatial queries)
+   * Controls the use of the {@link org.apache.accumulo.core.client.BatchScanner} in this job. Using this feature will group Ranges by their source tablet,
+   * producing an InputSplit per tablet rather than per Range. This batching helps to reduce overhead when querying a large number of small ranges. (ex: when
+   * doing quad-tree decomposition for spatial queries)
    * <p>
-   * In order to achieve good locality of InputSplits this option always clips the input Ranges to tablet boundaries.
-   * This may result in one input Range contributing to several InputSplits.
+   * In order to achieve good locality of InputSplits this option always clips the input Ranges to tablet boundaries. This may result in one input Range
+   * contributing to several InputSplits.
    * <p>
    * Note: that the value of {@link #setAutoAdjustRanges(JobConf, boolean)} is ignored and is assumed to be true when BatchScan option is enabled.
    * <p>
    * This configuration is incompatible with:
    * <ul>
-   *   <li>{@link #setOfflineTableScan(JobConf, boolean)}</li>
-   *   <li>{@link #setLocalIterators(JobConf, boolean)}</li>
-   *   <li>{@link #setScanIsolation(JobConf, boolean)}</li>
+   * <li>{@link #setOfflineTableScan(JobConf, boolean)}</li>
+   * <li>{@link #setLocalIterators(JobConf, boolean)}</li>
+   * <li>{@link #setScanIsolation(JobConf, boolean)}</li>
    * </ul>
    * <p>
    * By default, this feature is <b>disabled</b>.

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/mapred/impl/BatchInputSplit.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapred/impl/BatchInputSplit.java b/core/src/main/java/org/apache/accumulo/core/client/mapred/impl/BatchInputSplit.java
index 619f9cd..a046ee3 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapred/impl/BatchInputSplit.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapred/impl/BatchInputSplit.java
@@ -23,8 +23,7 @@ import org.apache.accumulo.core.data.Range;
 import org.apache.hadoop.mapred.InputSplit;
 
 /**
- * The Class BatchInputSplit. Encapsulates Accumulo ranges for use in Map Reduce jobs.
- * Can contain several Ranges per InputSplit.
+ * The Class BatchInputSplit. Encapsulates Accumulo ranges for use in Map Reduce jobs. Can contain several Ranges per InputSplit.
  */
 public class BatchInputSplit extends org.apache.accumulo.core.client.mapreduce.impl.BatchInputSplit implements InputSplit {
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/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 b2f1035..2575fe5 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
@@ -364,7 +364,7 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
    *           if the table name set on the configuration doesn't exist
    * @since 1.6.0
    * @deprecated since 1.7.0 This method returns a type that is not part of the public API and is not guaranteed to be stable. The method was deprecated to
-   *              discourage its use.
+   *             discourage its use.
    */
   @Deprecated
   protected static TabletLocator getTabletLocator(JobContext context, String table) throws TableNotFoundException {
@@ -430,18 +430,18 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
     /**
      * Extracts Iterators settings from the context to be used by RecordReader.
      *
-     * @param  context
-     *           the Hadoop context for the configured job
-     * @param  tableName
-     *           the table name for which the scanner is configured
+     * @param context
+     *          the Hadoop context for the configured job
+     * @param tableName
+     *          the table name for which the scanner is configured
      * @return List of iterator settings for given table
      * @since 1.7.0
      */
     protected abstract List<IteratorSetting> contextIterators(TaskAttemptContext context, String tableName);
 
     /**
-     * Configures the iterators on a scanner for the given table name.
-     * Will attempt to use configuration from the InputSplit, on failure will try to extract them from TaskAttemptContext.
+     * Configures the iterators on a scanner for the given table name. Will attempt to use configuration from the InputSplit, on failure will try to extract
+     * them from TaskAttemptContext.
      *
      * @param context
      *          the Hadoop context for the configured job
@@ -526,7 +526,7 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
         BatchInputSplit batchSplit = (BatchInputSplit) split;
 
         BatchScanner scanner;
-        try{
+        try {
           // Note: BatchScanner will use at most one thread per tablet, currently BatchInputSplit will not span tablets
           int scanThreads = 1;
           scanner = instance.getConnector(principal, token).createBatchScanner(split.getTableName(), authorizations, scanThreads);
@@ -691,9 +691,8 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
       String principal = getPrincipal(context);
       AuthenticationToken token = getAuthenticationToken(context);
 
-      boolean batchScan =  InputConfigurator.isBatchScan(CLASS, context.getConfiguration());
-      boolean supportBatchScan =
-        !(tableConfig.isOfflineScan() || tableConfig.shouldUseIsolatedScanners() || tableConfig.shouldUseLocalIterators());
+      boolean batchScan = InputConfigurator.isBatchScan(CLASS, context.getConfiguration());
+      boolean supportBatchScan = !(tableConfig.isOfflineScan() || tableConfig.shouldUseIsolatedScanners() || tableConfig.shouldUseLocalIterators());
       if (batchScan && !supportBatchScan)
         throw new IllegalArgumentException("BatchScanner optimization not available for offline scan, isolated, or local iterators");
 
@@ -743,7 +742,7 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
         throw new IOException(e);
       }
 
-      // all of this code will add either range per  each locations or split ranges and add range-location split
+      // all of this code will add either range per each locations or split ranges and add range-location split
       // Map from Range to Array of Locations, we only use this if we're don't split
       HashMap<Range,ArrayList<String>> splitsToAdd = null;
 
@@ -764,7 +763,7 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
           if (batchScan) {
             // group ranges by tablet to be read by a BatchScanner
             ArrayList<Range> clippedRanges = new ArrayList<Range>();
-            for(Range r: extentRanges.getValue())
+            for (Range r : extentRanges.getValue())
               clippedRanges.add(ke.clip(r));
             BatchInputSplit split = new BatchInputSplit(tableName, tableId, clippedRanges, new String[] {location});
             SplitUtils.updateSplit(split, instance, tableConfig, principal, token, auths, logLevel);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormat.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormat.java
index 45315db..33eccc1 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormat.java
@@ -60,7 +60,7 @@ public class AccumuloInputFormat extends InputFormatBase<Key,Value> {
         log.setLevel(level);
       }
     } else {
-        throw new IllegalArgumentException("No RecordReader for " + split.getClass().toString());
+      throw new IllegalArgumentException("No RecordReader for " + split.getClass().toString());
     }
 
     return new RecordReaderBase<Key,Value>() {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputFormatBase.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputFormatBase.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputFormatBase.java
index 16bc96e..6ab8a19 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputFormatBase.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputFormatBase.java
@@ -176,8 +176,7 @@ public abstract class InputFormatBase<K,V> extends AbstractInputFormat<K,V> {
   }
 
   /**
-   * Determines whether a configuration has auto-adjust ranges enabled.
-   * Must be enabled when {@link #setBatchScan(Job, boolean)} is true.
+   * Determines whether a configuration has auto-adjust ranges enabled. Must be enabled when {@link #setBatchScan(Job, boolean)} is true.
    *
    * @param context
    *          the Hadoop context for the configured job
@@ -297,21 +296,20 @@ public abstract class InputFormatBase<K,V> extends AbstractInputFormat<K,V> {
   }
 
   /**
-   * Controls the use of the {@link org.apache.accumulo.core.client.BatchScanner} in this job.
-   * Using this feature will group Ranges by their source tablet, producing an InputSplit per tablet
-   * rather than per Range. This batching helps to reduce overhead when querying a large number of small ranges.
-   * (ex: when doing quad-tree decomposition for spatial queries)
+   * Controls the use of the {@link org.apache.accumulo.core.client.BatchScanner} in this job. Using this feature will group Ranges by their source tablet,
+   * producing an InputSplit per tablet rather than per Range. This batching helps to reduce overhead when querying a large number of small ranges. (ex: when
+   * doing quad-tree decomposition for spatial queries)
    * <p>
-   * In order to achieve good locality of InputSplits this option always clips the input Ranges to tablet boundaries.
-   * This may result in one input Range contributing to several InputSplits.
+   * In order to achieve good locality of InputSplits this option always clips the input Ranges to tablet boundaries. This may result in one input Range
+   * contributing to several InputSplits.
    * <p>
    * Note: that the value of {@link #setAutoAdjustRanges(Job, boolean)} is ignored and is assumed to be true when BatchScan option is enabled.
    * <p>
    * This configuration is incompatible with:
    * <ul>
-   *   <li>{@link #setOfflineTableScan(org.apache.hadoop.mapreduce.Job, boolean)}</li>
-   *   <li>{@link #setLocalIterators(org.apache.hadoop.mapreduce.Job, boolean)}</li>
-   *   <li>{@link #setScanIsolation(org.apache.hadoop.mapreduce.Job, boolean)}</li>
+   * <li>{@link #setOfflineTableScan(org.apache.hadoop.mapreduce.Job, boolean)}</li>
+   * <li>{@link #setLocalIterators(org.apache.hadoop.mapreduce.Job, boolean)}</li>
+   * <li>{@link #setScanIsolation(org.apache.hadoop.mapreduce.Job, boolean)}</li>
    * </ul>
    * <p>
    * By default, this feature is <b>disabled</b>.

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/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 b55e2cf..25886d6 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
@@ -98,7 +98,7 @@ public class RangeInputSplit extends InputSplit implements Writable {
   public float getProgress(Key currentKey) {
     if (currentKey == null)
       return 0f;
-    if(range.contains(currentKey)){
+    if (range.contains(currentKey)) {
       if (range.getStartKey() != null && range.getEndKey() != null) {
         if (range.getStartKey().compareTo(range.getEndKey(), PartialKey.ROW) != 0) {
           // just look at the row progress

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/mapreduce/impl/BatchInputSplit.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/impl/BatchInputSplit.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/impl/BatchInputSplit.java
index f674485..04875ac 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/impl/BatchInputSplit.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/impl/BatchInputSplit.java
@@ -30,8 +30,7 @@ import org.apache.accumulo.core.data.PartialKey;
 import org.apache.accumulo.core.data.Range;
 
 /**
- * The Class BatchInputSplit. Encapsulates a set of Accumulo ranges on a single tablet for use in Map Reduce jobs.
- * Can contain several Ranges per split.
+ * The Class BatchInputSplit. Encapsulates a set of Accumulo ranges on a single tablet for use in Map Reduce jobs. Can contain several Ranges per split.
  */
 public class BatchInputSplit extends RangeInputSplit {
   private Collection<Range> ranges;
@@ -75,10 +74,12 @@ public class BatchInputSplit extends RangeInputSplit {
               rangeProgress[i] = SplitUtils.getProgress(range.getStartKey().getRowData(), range.getEndKey().getRowData(), currentKey.getRowData());
             } else if (range.getStartKey().compareTo(range.getEndKey(), PartialKey.ROW_COLFAM) != 0) {
               // just look at the column family progress
-              rangeProgress[i] = SplitUtils.getProgress(range.getStartKey().getColumnFamilyData(), range.getEndKey().getColumnFamilyData(), currentKey.getColumnFamilyData());
+              rangeProgress[i] = SplitUtils.getProgress(range.getStartKey().getColumnFamilyData(), range.getEndKey().getColumnFamilyData(),
+                  currentKey.getColumnFamilyData());
             } else if (range.getStartKey().compareTo(range.getEndKey(), PartialKey.ROW_COLFAM_COLQUAL) != 0) {
               // just look at the column qualifier progress
-              rangeProgress[i] = SplitUtils.getProgress(range.getStartKey().getColumnQualifierData(), range.getEndKey().getColumnQualifierData(), currentKey.getColumnQualifierData());
+              rangeProgress[i] = SplitUtils.getProgress(range.getStartKey().getColumnQualifierData(), range.getEndKey().getColumnQualifierData(),
+                  currentKey.getColumnQualifierData());
             }
           }
           total += rangeProgress[i];
@@ -107,7 +108,7 @@ public class BatchInputSplit extends RangeInputSplit {
 
     int numRanges = in.readInt();
     ranges = new ArrayList<Range>(numRanges);
-    for (int i = 0; i < numRanges; ++i){
+    for (int i = 0; i < numRanges; ++i) {
       Range r = new Range();
       r.readFields(in);
       ranges.add(r);
@@ -119,7 +120,7 @@ public class BatchInputSplit extends RangeInputSplit {
     super.write(out);
 
     out.writeInt(ranges.size());
-    for (Range r: ranges)
+    for (Range r : ranges)
       r.write(out);
   }
 
@@ -141,12 +142,12 @@ public class BatchInputSplit extends RangeInputSplit {
   }
 
   @Override
-  public Range getRange(){
+  public Range getRange() {
     throw new UnsupportedOperationException();
   }
 
   @Override
-  public void setRange(Range range){
+  public void setRange(Range range) {
     throw new UnsupportedOperationException();
   }
 
@@ -179,4 +180,4 @@ public class BatchInputSplit extends RangeInputSplit {
   public void setUsesLocalIterators(Boolean localIterators) {
     throw new UnsupportedOperationException();
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/mapreduce/impl/SplitUtils.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/impl/SplitUtils.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/impl/SplitUtils.java
index 742660d..d19b499 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/impl/SplitUtils.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/impl/SplitUtils.java
@@ -34,11 +34,11 @@ import org.apache.log4j.Level;
 public class SplitUtils {
 
   /**
-   * Central place to set common split configuration not handled by split constructors.
-   * The intention is to make it harder to miss optional setters in future refactor.
+   * Central place to set common split configuration not handled by split constructors. The intention is to make it harder to miss optional setters in future
+   * refactor.
    */
-  public static void updateSplit(RangeInputSplit split,  Instance instance, InputTableConfig tableConfig,
-                                  String principal, AuthenticationToken token, Authorizations auths, Level logLevel) {
+  public static void updateSplit(RangeInputSplit split, Instance instance, InputTableConfig tableConfig, String principal, AuthenticationToken token,
+      Authorizations auths, Level logLevel) {
     split.setInstanceName(instance.getInstanceName());
     split.setZooKeepers(instance.getZooKeepers());
     split.setMockInstance(instance instanceof MockInstance);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/mock/MockScannerBase.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mock/MockScannerBase.java b/core/src/main/java/org/apache/accumulo/core/client/mock/MockScannerBase.java
index 60f2a2a..3c746e1 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mock/MockScannerBase.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mock/MockScannerBase.java
@@ -66,7 +66,7 @@ public class MockScannerBase extends ScannerOptions implements ScannerBase {
     private final Authorizations auths;
 
     MockIteratorEnvironment(Authorizations auths) {
-        this.auths = auths;
+      this.auths = auths;
     }
 
     @Override
@@ -98,7 +98,7 @@ public class MockScannerBase extends ScannerOptions implements ScannerBase {
 
     @Override
     public Authorizations getAuthorizations() {
-        return auths;
+      return auths;
     }
 
     SortedKeyValueIterator<Key,Value> getTopLevelIterator(SortedKeyValueIterator<Key,Value> iter) {
@@ -127,7 +127,8 @@ public class MockScannerBase extends ScannerOptions implements ScannerBase {
     throw new UnsupportedOperationException();
   }
 
-  @Override public Authorizations getAuthorizations() {
+  @Override
+  public Authorizations getAuthorizations() {
     return auths;
   }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/client/security/tokens/DelegationToken.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/DelegationToken.java b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/DelegationToken.java
index 8256d66..43a16d3 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/DelegationToken.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/DelegationToken.java
@@ -25,7 +25,8 @@ import org.apache.accumulo.core.client.admin.SecurityOperations;
  * itself. The delegation token serves as a mechanism to obtain a transient shared secret with Accumulo using a {@link KerberosToken} and then run some task
  * authenticating with that shared secret.
  *
- * <p>Obtain a delegation token by calling {@link SecurityOperations#getDelegationToken(org.apache.accumulo.core.client.admin.DelegationTokenConfig)}
+ * <p>
+ * Obtain a delegation token by calling {@link SecurityOperations#getDelegationToken(org.apache.accumulo.core.client.admin.DelegationTokenConfig)}
  *
  * @since 1.7.0
  */

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/compaction/PatternType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/compaction/PatternType.java b/core/src/main/java/org/apache/accumulo/core/compaction/PatternType.java
index c52dcb4..0603e0e 100644
--- a/core/src/main/java/org/apache/accumulo/core/compaction/PatternType.java
+++ b/core/src/main/java/org/apache/accumulo/core/compaction/PatternType.java
@@ -25,4 +25,4 @@ class PatternType implements Type {
     Pattern.compile(str);
     return str;
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/compaction/SizeType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/compaction/SizeType.java b/core/src/main/java/org/apache/accumulo/core/compaction/SizeType.java
index c2af401..ea86605 100644
--- a/core/src/main/java/org/apache/accumulo/core/compaction/SizeType.java
+++ b/core/src/main/java/org/apache/accumulo/core/compaction/SizeType.java
@@ -27,4 +27,4 @@ class SizeType implements Type {
     Preconditions.checkArgument(size > 0);
     return Long.toString(size);
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/compaction/StringType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/compaction/StringType.java b/core/src/main/java/org/apache/accumulo/core/compaction/StringType.java
index 7098a5c..595d388 100644
--- a/core/src/main/java/org/apache/accumulo/core/compaction/StringType.java
+++ b/core/src/main/java/org/apache/accumulo/core/compaction/StringType.java
@@ -21,4 +21,4 @@ class StringType implements Type {
   public String convert(String str) {
     return str;
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/compaction/Type.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/compaction/Type.java b/core/src/main/java/org/apache/accumulo/core/compaction/Type.java
index d8f81a6..ef2f540 100644
--- a/core/src/main/java/org/apache/accumulo/core/compaction/Type.java
+++ b/core/src/main/java/org/apache/accumulo/core/compaction/Type.java
@@ -18,4 +18,4 @@ package org.apache.accumulo.core.compaction;
 
 interface Type {
   String convert(String str);
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/compaction/UIntType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/compaction/UIntType.java b/core/src/main/java/org/apache/accumulo/core/compaction/UIntType.java
index c8880fc..09923c3 100644
--- a/core/src/main/java/org/apache/accumulo/core/compaction/UIntType.java
+++ b/core/src/main/java/org/apache/accumulo/core/compaction/UIntType.java
@@ -24,4 +24,4 @@ class UIntType implements Type {
     Preconditions.checkArgument(Integer.parseInt(str) > 0);
     return str;
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/conf/Property.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/Property.java b/core/src/main/java/org/apache/accumulo/core/conf/Property.java
index a5bef0a..09d462d 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/Property.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/Property.java
@@ -39,7 +39,6 @@ import org.apache.commons.configuration.PropertiesConfiguration;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-
 public enum Property {
   // Crypto-related properties
   @Experimental
@@ -274,10 +273,8 @@ public enum Property {
       "The maximum number of concurrent major compactions for a tablet server"),
   TSERV_MINC_MAXCONCURRENT("tserver.compaction.minor.concurrent.max", "4", PropertyType.COUNT,
       "The maximum number of concurrent minor compactions for a tablet server"),
-  TSERV_MAJC_TRACE_PERCENT("tserver.compaction.major.trace.percent", "0.1", PropertyType.FRACTION,
-      "The percent of major compactions to trace"),
-  TSERV_MINC_TRACE_PERCENT("tserver.compaction.minor.trace.percent", "0.1", PropertyType.FRACTION,
-      "The percent of minor compactions to trace"),
+  TSERV_MAJC_TRACE_PERCENT("tserver.compaction.major.trace.percent", "0.1", PropertyType.FRACTION, "The percent of major compactions to trace"),
+  TSERV_MINC_TRACE_PERCENT("tserver.compaction.minor.trace.percent", "0.1", PropertyType.FRACTION, "The percent of minor compactions to trace"),
   TSERV_COMPACTION_WARN_TIME("tserver.compaction.warn.time", "10m", PropertyType.TIMEDURATION,
       "When a compaction has not made progress for this time period, a warning will be logged"),
   TSERV_BLOOM_LOAD_MAXCONCURRENT("tserver.bloom.load.concurrent.max", "4", PropertyType.COUNT,
@@ -560,8 +557,7 @@ public enum Property {
       "Amount of time to wait before first checking for replication work, not useful outside of tests"),
   REPLICATION_WORK_PROCESSOR_PERIOD("replication.work.processor.period", "0s", PropertyType.TIMEDURATION,
       "Amount of time to wait before re-checking for replication work, not useful outside of tests"),
-  REPLICATION_TRACE_PERCENT("replication.trace.percent", "0.1", PropertyType.FRACTION,
-      "The sampling percentage to use for replication traces"),
+  REPLICATION_TRACE_PERCENT("replication.trace.percent", "0.1", PropertyType.FRACTION, "The sampling percentage to use for replication traces"),
 
   ;
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/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 e9f3b65..7bbb0c2 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
@@ -127,8 +127,8 @@ public class KeyExtent implements WritableComparable<KeyExtent> {
 
   @Override
   public boolean equals(Object o) {
-    if(o instanceof KeyExtent){
-      return wrapped.equals(((KeyExtent)o).wrapped);
+    if (o instanceof KeyExtent) {
+      return wrapped.equals(((KeyExtent) o).wrapped);
     }
 
     return false;
@@ -179,7 +179,7 @@ public class KeyExtent implements WritableComparable<KeyExtent> {
     return wrapped.isRootTablet();
   }
 
-  private static SortedSet<org.apache.accumulo.core.data.impl.KeyExtent> unwrap(Set<KeyExtent> tablets){
+  private static SortedSet<org.apache.accumulo.core.data.impl.KeyExtent> unwrap(Set<KeyExtent> tablets) {
     SortedSet<org.apache.accumulo.core.data.impl.KeyExtent> trans = new TreeSet<>();
     for (KeyExtent wrapper : tablets) {
       trans.add(wrapper.wrapped);
@@ -188,11 +188,11 @@ public class KeyExtent implements WritableComparable<KeyExtent> {
     return trans;
   }
 
-  private static KeyExtent wrap(org.apache.accumulo.core.data.impl.KeyExtent ke){
+  private static KeyExtent wrap(org.apache.accumulo.core.data.impl.KeyExtent ke) {
     return new KeyExtent(ke.getTableId(), ke.getEndRow(), ke.getPrevEndRow());
   }
 
-  private static SortedSet<KeyExtent> wrap(Collection<org.apache.accumulo.core.data.impl.KeyExtent> unwrapped){
+  private static SortedSet<KeyExtent> wrap(Collection<org.apache.accumulo.core.data.impl.KeyExtent> unwrapped) {
     SortedSet<KeyExtent> wrapped = new TreeSet<>();
     for (org.apache.accumulo.core.data.impl.KeyExtent wrappee : unwrapped) {
       wrapped.add(wrap(wrappee));
@@ -225,7 +225,7 @@ public class KeyExtent implements WritableComparable<KeyExtent> {
   }
 
   public static Mutation getPrevRowUpdateMutation(KeyExtent ke) {
-   return org.apache.accumulo.core.data.impl.KeyExtent.getPrevRowUpdateMutation(ke.wrapped);
+    return org.apache.accumulo.core.data.impl.KeyExtent.getPrevRowUpdateMutation(ke.wrapped);
   }
 
   public static byte[] tableOfMetadataRow(Text row) {
@@ -246,12 +246,13 @@ public class KeyExtent implements WritableComparable<KeyExtent> {
 
   public static Set<KeyExtent> findOverlapping(KeyExtent nke, SortedMap<KeyExtent,?> extents) {
     SortedMap<org.apache.accumulo.core.data.impl.KeyExtent,Object> trans = new TreeMap<>();
-    for(Entry<KeyExtent, ?> entry : extents.entrySet()){
+    for (Entry<KeyExtent,?> entry : extents.entrySet()) {
       trans.put(entry.getKey().wrapped, entry.getValue());
     }
 
     return wrap(org.apache.accumulo.core.data.impl.KeyExtent.findOverlapping(nke.wrapped, trans));
   }
+
   public static Text getMetadataEntry(KeyExtent extent) {
     return org.apache.accumulo.core.data.impl.KeyExtent.getMetadataEntry(extent.wrapped);
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/data/Mutation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/Mutation.java b/core/src/main/java/org/apache/accumulo/core/data/Mutation.java
index 31c02eb..59a1402 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/Mutation.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/Mutation.java
@@ -1141,11 +1141,9 @@ public class Mutation implements Writable {
   }
 
   /**
-   * Creates a {@link org.apache.accumulo.core.data.thrift.TMutation} object
-   * containing this Mutation's data.
+   * Creates a {@link org.apache.accumulo.core.data.thrift.TMutation} object containing this Mutation's data.
    *
-   * Note that this method will move the Mutation into a "serialized" state
-   * that will prevent users from adding more data via Mutation#put().
+   * Note that this method will move the Mutation into a "serialized" state that will prevent users from adding more data via Mutation#put().
    *
    * @return a thrift form of this Mutation
    */

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/data/TabletId.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/TabletId.java b/core/src/main/java/org/apache/accumulo/core/data/TabletId.java
index 2dfba47..113183d 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/TabletId.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/TabletId.java
@@ -26,6 +26,8 @@ import org.apache.hadoop.io.Text;
  */
 public interface TabletId extends Comparable<TabletId> {
   public Text getTableId();
+
   public Text getEndRow();
+
   public Text getPrevEndRow();
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/data/impl/TabletIdImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/impl/TabletIdImpl.java b/core/src/main/java/org/apache/accumulo/core/data/impl/TabletIdImpl.java
index 395dd22..61e882a 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/impl/TabletIdImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/impl/TabletIdImpl.java
@@ -30,20 +30,20 @@ public class TabletIdImpl implements TabletId {
   public static final Function<org.apache.accumulo.core.data.KeyExtent,TabletId> KE_2_TID_OLD = new Function<org.apache.accumulo.core.data.KeyExtent,TabletId>() {
     @Override
     public TabletId apply(org.apache.accumulo.core.data.KeyExtent input) {
-      //the following if null check is to appease findbugs... grumble grumble spent a good part of my morning looking into this
+      // the following if null check is to appease findbugs... grumble grumble spent a good part of my morning looking into this
       // http://sourceforge.net/p/findbugs/bugs/1139/
       // https://code.google.com/p/guava-libraries/issues/detail?id=920
-      if(input == null)
+      if (input == null)
         return null;
       return new TabletIdImpl(input);
     }
   };
 
   @SuppressWarnings("deprecation")
-  public static final Function<TabletId, org.apache.accumulo.core.data.KeyExtent> TID_2_KE_OLD = new Function<TabletId, org.apache.accumulo.core.data.KeyExtent>() {
+  public static final Function<TabletId,org.apache.accumulo.core.data.KeyExtent> TID_2_KE_OLD = new Function<TabletId,org.apache.accumulo.core.data.KeyExtent>() {
     @Override
     public org.apache.accumulo.core.data.KeyExtent apply(TabletId input) {
-      if(input == null)
+      if (input == null)
         return null;
       return new org.apache.accumulo.core.data.KeyExtent(input.getTableId(), input.getEndRow(), input.getPrevEndRow());
     }
@@ -94,7 +94,7 @@ public class TabletIdImpl implements TabletId {
   }
 
   @Override
-  public String toString(){
+  public String toString() {
     return ke.toString();
   }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/file/DispatchingFileFactory.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/DispatchingFileFactory.java b/core/src/main/java/org/apache/accumulo/core/file/DispatchingFileFactory.java
index 128a931..1e7ecc9 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/DispatchingFileFactory.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/DispatchingFileFactory.java
@@ -133,4 +133,4 @@ class DispatchingFileFactory extends FileOperations {
     return findFileFactory(file).openIndex(file, fs, conf, acuconf, dCache, iCache);
   }
 
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/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 c6de9cc..060d956 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
@@ -68,7 +68,6 @@ import org.apache.hadoop.io.Writable;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-
 public class RFile {
 
   public static final String EXTENSION = "rf";
@@ -565,7 +564,7 @@ public class RFile {
           currBlock = getDataBlock(indexEntry);
 
           checkRange = range.afterEndKey(indexEntry.getKey());
-    if (!checkRange)
+          if (!checkRange)
             hasTop = true;
 
         } else {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
index 6b5a8fc..3292cc2 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
@@ -33,7 +33,6 @@ import org.apache.accumulo.start.classloader.vfs.AccumuloVFSClassLoader;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-
 /**
  * This iterator wraps another iterator. It automatically aggregates.
  *

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/iterators/IteratorUtil.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/IteratorUtil.java b/core/src/main/java/org/apache/accumulo/core/iterators/IteratorUtil.java
index 5efa2c2..031d13f 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/IteratorUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/IteratorUtil.java
@@ -66,7 +66,8 @@ public class IteratorUtil {
     /**
      * Fetch the correct configuration key prefix for the given scope. Throws an IllegalArgumentException if no property exists for the given scope.
      *
-     * @deprecated since 1.7.0 This method returns a type that is not part of the public API and is not guaranteed to be stable.  The method was deprecated to discourage its use.
+     * @deprecated since 1.7.0 This method returns a type that is not part of the public API and is not guaranteed to be stable. The method was deprecated to
+     *             discourage its use.
      */
     @Deprecated
     public static Property getProperty(IteratorScope scope) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/iterators/LongCombiner.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/LongCombiner.java b/core/src/main/java/org/apache/accumulo/core/iterators/LongCombiner.java
index 2a225fd..cbc76ab 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/LongCombiner.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/LongCombiner.java
@@ -167,7 +167,7 @@ public abstract class LongCombiner extends TypedValueCombiner<Long> {
       return decodeStatic(b, offset, len);
     }
 
-    // refactor?  it's public, so cannot remove
+    // refactor? it's public, so cannot remove
     public static long decode(byte[] b, int offset) {
       if (b.length < offset + 8)
         throw new ValueFormatException("trying to convert to long, but byte array isn't long enough, wanted " + (offset + 8) + " found " + b.length);
@@ -179,7 +179,7 @@ public abstract class LongCombiner extends TypedValueCombiner<Long> {
       if (b.length < offset + 8 || len < 8)
         throw new ValueFormatException("trying to convert to long, but byte array isn't long enough, wanted " + (offset + 8) + " found " + len);
       return (((long) b[offset + 0] << 56) + ((long) (b[offset + 1] & 255) << 48) + ((long) (b[offset + 2] & 255) << 40) + ((long) (b[offset + 3] & 255) << 32)
-              + ((long) (b[offset + 4] & 255) << 24) + ((b[offset + 5] & 255) << 16) + ((b[offset + 6] & 255) << 8) + ((b[offset + 7] & 255) << 0));
+          + ((long) (b[offset + 4] & 255) << 24) + ((b[offset + 5] & 255) << 16) + ((b[offset + 6] & 255) << 8) + ((b[offset + 7] & 255) << 0));
     }
   }
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/iterators/SortedKeyValueIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/SortedKeyValueIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/SortedKeyValueIterator.java
index f6d3170..ce5ef24 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/SortedKeyValueIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/SortedKeyValueIterator.java
@@ -107,9 +107,9 @@ public interface SortedKeyValueIterator<K extends WritableComparable<?>,V extend
    * compaction scopes the iterator may see deletion entries. These entries should be preserved by all iterators except ones that are strictly scan-time
    * iterators that will never be configured for the minc or majc scopes. Deletion entries are only removed during full major compactions.
    * <p>
-   * For performance reasons, iterators reserve the right to reuse objects returned by <tt>getTopKey</tt> when {@link #next()} is called, changing the data
-   * that the object references. Iterators that need to save an object returned by <tt>getTopKey</tt> ought to copy the object's data into a new object
-   * in order to avoid aliasing bugs.
+   * For performance reasons, iterators reserve the right to reuse objects returned by <tt>getTopKey</tt> when {@link #next()} is called, changing the data that
+   * the object references. Iterators that need to save an object returned by <tt>getTopKey</tt> ought to copy the object's data into a new object in order to
+   * avoid aliasing bugs.
    *
    * @return <tt>K</tt>
    * @exception IllegalStateException
@@ -123,8 +123,8 @@ public interface SortedKeyValueIterator<K extends WritableComparable<?>,V extend
    * Returns top value. Can be called 0 or more times without affecting behavior of next() or hasTop().
    * <p>
    * For performance reasons, iterators reserve the right to reuse objects returned by <tt>getTopValue</tt> when {@link #next()} is called, changing the
-   * underlying data that the object references. Iterators that need to save an object returned by <tt>getTopValue</tt> ought to copy the object's data
-   * into a new object in order to avoid aliasing bugs.
+   * underlying data that the object references. Iterators that need to save an object returned by <tt>getTopValue</tt> ought to copy the object's data into a
+   * new object in order to avoid aliasing bugs.
    *
    * @return <tt>V</tt>
    * @exception IllegalStateException

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/iterators/system/MapFileIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/system/MapFileIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/system/MapFileIterator.java
index da5f37c..9d59570 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/system/MapFileIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/system/MapFileIterator.java
@@ -40,7 +40,6 @@ import org.apache.hadoop.io.MapFile.Reader;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-
 public class MapFileIterator implements FileSKVIterator {
   private static final Logger log = LoggerFactory.getLogger(MapFileIterator.class);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/iterators/system/VisibilityFilter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/system/VisibilityFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/system/VisibilityFilter.java
index 069d999..a204ad1 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/system/VisibilityFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/system/VisibilityFilter.java
@@ -32,7 +32,6 @@ import org.apache.hadoop.io.Text;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-
 public class VisibilityFilter extends Filter {
   protected VisibilityEvaluator ve;
   protected Text defaultVisibility;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/iterators/user/BigDecimalCombiner.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/BigDecimalCombiner.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/BigDecimalCombiner.java
index 3a6dbcb..e90e87e 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/BigDecimalCombiner.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/BigDecimalCombiner.java
@@ -101,7 +101,8 @@ public abstract class BigDecimalCombiner extends TypedValueCombiner<BigDecimal>
    * Provides the ability to encode scientific notation.
    *
    */
-  public static class BigDecimalEncoder extends AbstractLexicoder<BigDecimal> implements org.apache.accumulo.core.iterators.TypedValueCombiner.Encoder<BigDecimal> {
+  public static class BigDecimalEncoder extends AbstractLexicoder<BigDecimal> implements
+      org.apache.accumulo.core.iterators.TypedValueCombiner.Encoder<BigDecimal> {
     @Override
     public byte[] encode(BigDecimal v) {
       return v.toString().getBytes(UTF_8);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/iterators/user/RegExFilter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/RegExFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/RegExFilter.java
index c61a160..9fccaa7 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/RegExFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/RegExFilter.java
@@ -34,7 +34,6 @@ import org.apache.accumulo.core.iterators.SortedKeyValueIterator;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-
 /**
  * A Filter that matches entries based on Java regular expressions.
  */

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/iterators/user/RowEncodingIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/RowEncodingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/RowEncodingIterator.java
index 8a36bef..320301d 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/RowEncodingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/RowEncodingIterator.java
@@ -169,7 +169,7 @@ public abstract class RowEncodingIterator implements SortedKeyValueIterator<Key,
   }
 
   @Override
-  public boolean validateOptions(Map<String, String> options) {
+  public boolean validateOptions(Map<String,String> options) {
     String maxBufferSizeStr = options.get(MAX_BUFFER_SIZE_OPT);
     try {
       AccumuloConfiguration.getMemoryInBytes(maxBufferSizeStr);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/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 52fa70e..66de3d6 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
@@ -53,7 +53,6 @@ import org.apache.hadoop.io.Text;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-
 /**
  * The TransformingIterator allows portions of a key (except for the row) to be transformed. This iterator handles the details that come with modifying keys
  * (i.e., that the sort order could change). In order to do so, however, the iterator must put all keys sharing the same prefix in memory. Prefix is defined as

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataSchema.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataSchema.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataSchema.java
index c787d6d..fe75f9e 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataSchema.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataSchema.java
@@ -289,7 +289,7 @@ public class MetadataSchema {
    */
   public static class CurrentLogsSection {
     private static final Section section = new Section(RESERVED_PREFIX + "wal+", true, RESERVED_PREFIX + "wal,", false);
-    private static byte LEFT_BRACKET = (byte)'[';
+    private static byte LEFT_BRACKET = (byte) '[';
     public static final Text COLF = new Text("log");
     public static final Value UNUSED = new Value("unused".getBytes(UTF_8));
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/rpc/SaslConnectionParams.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/SaslConnectionParams.java b/core/src/main/java/org/apache/accumulo/core/rpc/SaslConnectionParams.java
index 0e88967..956fee2 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/SaslConnectionParams.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/SaslConnectionParams.java
@@ -53,9 +53,7 @@ public class SaslConnectionParams {
    * Enumeration around {@link Sasl#QOP}
    */
   public enum QualityOfProtection {
-    AUTH("auth"),
-    AUTH_INT("auth-int"),
-    AUTH_CONF("auth-conf");
+    AUTH("auth"), AUTH_INT("auth-int"), AUTH_CONF("auth-conf");
 
     private final String quality;
 
@@ -226,6 +224,7 @@ public class SaslConnectionParams {
   public Map<String,String> getSaslProperties() {
     return Collections.unmodifiableMap(saslProperties);
   }
+
   /**
    * The quality of protection used with SASL. See {@link Sasl#QOP} for more information.
    */
@@ -263,7 +262,7 @@ public class SaslConnectionParams {
 
   @Override
   public int hashCode() {
-    HashCodeBuilder hcb = new HashCodeBuilder(23,29);
+    HashCodeBuilder hcb = new HashCodeBuilder(23, 29);
     hcb.append(kerberosServerPrimary).append(saslProperties).append(qop.hashCode()).append(principal).append(mechanism).append(callbackHandler);
     return hcb.toHashCode();
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/rpc/UGIAssumingTransportFactory.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/UGIAssumingTransportFactory.java b/core/src/main/java/org/apache/accumulo/core/rpc/UGIAssumingTransportFactory.java
index 77a3ce3..b1772fa 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/UGIAssumingTransportFactory.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/UGIAssumingTransportFactory.java
@@ -52,4 +52,4 @@ public class UGIAssumingTransportFactory extends TTransportFactory {
       }
     });
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/security/crypto/CachingHDFSSecretKeyEncryptionStrategy.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/crypto/CachingHDFSSecretKeyEncryptionStrategy.java b/core/src/main/java/org/apache/accumulo/core/security/crypto/CachingHDFSSecretKeyEncryptionStrategy.java
index c685a2d..4ee27ef 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/crypto/CachingHDFSSecretKeyEncryptionStrategy.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/crypto/CachingHDFSSecretKeyEncryptionStrategy.java
@@ -50,7 +50,7 @@ public class CachingHDFSSecretKeyEncryptionStrategy implements SecretKeyEncrypti
       secretKeyCache.ensureSecretKeyCacheInitialized(context);
       doKeyEncryptionOperation(Cipher.WRAP_MODE, context);
     } catch (IOException e) {
-      log.error("{}", e.getMessage(),e);
+      log.error("{}", e.getMessage(), e);
       throw new RuntimeException(e);
     }
     return context;
@@ -62,7 +62,7 @@ public class CachingHDFSSecretKeyEncryptionStrategy implements SecretKeyEncrypti
       secretKeyCache.ensureSecretKeyCacheInitialized(context);
       doKeyEncryptionOperation(Cipher.UNWRAP_MODE, context);
     } catch (IOException e) {
-      log.error("{}", e.getMessage(),e);
+      log.error("{}", e.getMessage(), e);
       throw new RuntimeException(e);
     }
     return context;
@@ -74,7 +74,7 @@ public class CachingHDFSSecretKeyEncryptionStrategy implements SecretKeyEncrypti
     try {
       cipher.init(encryptionMode, new SecretKeySpec(secretKeyCache.getKeyEncryptionKey(), params.getAlgorithmName()));
     } catch (InvalidKeyException e) {
-      log.error("{}", e.getMessage(),e);
+      log.error("{}", e.getMessage(), e);
       throw new RuntimeException(e);
     }
 
@@ -83,10 +83,10 @@ public class CachingHDFSSecretKeyEncryptionStrategy implements SecretKeyEncrypti
         Key plaintextKey = cipher.unwrap(params.getEncryptedKey(), params.getAlgorithmName(), Cipher.SECRET_KEY);
         params.setPlaintextKey(plaintextKey.getEncoded());
       } catch (InvalidKeyException e) {
-        log.error("{}", e.getMessage(),e);
+        log.error("{}", e.getMessage(), e);
         throw new RuntimeException(e);
       } catch (NoSuchAlgorithmException e) {
-        log.error("{}", e.getMessage(),e);
+        log.error("{}", e.getMessage(), e);
         throw new RuntimeException(e);
       }
     } else {
@@ -96,7 +96,7 @@ public class CachingHDFSSecretKeyEncryptionStrategy implements SecretKeyEncrypti
         params.setEncryptedKey(encryptedSecretKey);
         params.setOpaqueKeyEncryptionKeyID(secretKeyCache.getPathToKeyName());
       } catch (InvalidKeyException e) {
-        log.error("{}", e.getMessage(),e);
+        log.error("{}", e.getMessage(), e);
         throw new RuntimeException(e);
       } catch (IllegalBlockSizeException e) {
         log.error("{}", e.getMessage(), e);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModuleFactory.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModuleFactory.java b/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModuleFactory.java
index e2058bd..e8e2326 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModuleFactory.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModuleFactory.java
@@ -107,12 +107,12 @@ public class CryptoModuleFactory {
       } catch (InstantiationException e) {
         log.warn(String.format("Got instantiation exception %s when instantiating crypto module \"%s\".  No encryption will be used.", e.getCause().getClass()
             .getName(), cryptoModuleClassname));
-        log.warn("InstantiationException",e.getCause());
+        log.warn("InstantiationException", e.getCause());
         return new NullCryptoModule();
       } catch (IllegalAccessException e) {
         log.warn(String.format("Got illegal access exception when trying to instantiate crypto module \"%s\".  No encryption will be used.",
             cryptoModuleClassname));
-        log.warn("IllegalAccessException",e);
+        log.warn("IllegalAccessException", e);
         return new NullCryptoModule();
       }
     }
@@ -184,12 +184,12 @@ public class CryptoModuleFactory {
       } catch (InstantiationException e) {
         log.warn(String.format("Got instantiation exception %s when instantiating secret key encryption strategy \"%s\".  No encryption will be used.", e
             .getCause().getClass().getName(), className));
-        log.warn("InstantiationException",e.getCause());
+        log.warn("InstantiationException", e.getCause());
         return new NullSecretKeyEncryptionStrategy();
       } catch (IllegalAccessException e) {
         log.warn(String.format("Got illegal access exception when trying to instantiate secret key encryption strategy \"%s\".  No encryption will be used.",
             className));
-        log.warn("IllegalAccessException",e);
+        log.warn("IllegalAccessException", e);
         return new NullSecretKeyEncryptionStrategy();
       }
     }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/security/crypto/NonCachingSecretKeyEncryptionStrategy.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/crypto/NonCachingSecretKeyEncryptionStrategy.java b/core/src/main/java/org/apache/accumulo/core/security/crypto/NonCachingSecretKeyEncryptionStrategy.java
index ce9da77..1dd8d60 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/crypto/NonCachingSecretKeyEncryptionStrategy.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/crypto/NonCachingSecretKeyEncryptionStrategy.java
@@ -83,7 +83,7 @@ public class NonCachingSecretKeyEncryptionStrategy implements SecretKeyEncryptio
       try {
         cipher.init(encryptionMode, new SecretKeySpec(keyEncryptionKey, params.getAlgorithmName()));
       } catch (InvalidKeyException e) {
-        log.error("{}", e.getMessage(),e);
+        log.error("{}", e.getMessage(), e);
         throw new RuntimeException(e);
       }
 
@@ -92,10 +92,10 @@ public class NonCachingSecretKeyEncryptionStrategy implements SecretKeyEncryptio
           Key plaintextKey = cipher.unwrap(params.getEncryptedKey(), params.getAlgorithmName(), Cipher.SECRET_KEY);
           params.setPlaintextKey(plaintextKey.getEncoded());
         } catch (InvalidKeyException e) {
-          log.error("{}", e.getMessage(),e);
+          log.error("{}", e.getMessage(), e);
           throw new RuntimeException(e);
         } catch (NoSuchAlgorithmException e) {
-          log.error("{}", e.getMessage(),e);
+          log.error("{}", e.getMessage(), e);
           throw new RuntimeException(e);
         }
       } else {
@@ -105,10 +105,10 @@ public class NonCachingSecretKeyEncryptionStrategy implements SecretKeyEncryptio
           params.setEncryptedKey(encryptedSecretKey);
           params.setOpaqueKeyEncryptionKeyID(pathToKeyName);
         } catch (InvalidKeyException e) {
-          log.error("{}", e.getMessage(),e);
+          log.error("{}", e.getMessage(), e);
           throw new RuntimeException(e);
         } catch (IllegalBlockSizeException e) {
-          log.error("{}", e.getMessage(),e);
+          log.error("{}", e.getMessage(), e);
           throw new RuntimeException(e);
         }
 
@@ -159,7 +159,7 @@ public class NonCachingSecretKeyEncryptionStrategy implements SecretKeyEncryptio
       doKeyEncryptionOperation(Cipher.WRAP_MODE, params, fullPath, pathToKey, fs);
 
     } catch (IOException e) {
-      log.error("{}", e.getMessage(),e);
+      log.error("{}", e.getMessage(), e);
       throw new RuntimeException(e);
     }
 
@@ -183,7 +183,7 @@ public class NonCachingSecretKeyEncryptionStrategy implements SecretKeyEncryptio
       doKeyEncryptionOperation(Cipher.UNWRAP_MODE, params, pathToKeyName, pathToKey, fs);
 
     } catch (IOException e) {
-      log.error("{}", e.getMessage(),e);
+      log.error("{}", e.getMessage(), e);
       throw new RuntimeException(e);
     }
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/util/Help.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/Help.java b/core/src/main/java/org/apache/accumulo/core/util/Help.java
index fda72fe..f090b18 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/Help.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/Help.java
@@ -32,4 +32,4 @@ public class Help implements KeywordExecutable {
   public void execute(final String[] args) throws Exception {
     Main.printUsage();
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/util/Jar.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/Jar.java b/core/src/main/java/org/apache/accumulo/core/util/Jar.java
index 2fc6d17..e5c2d1c 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/Jar.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/Jar.java
@@ -56,4 +56,4 @@ public class Jar implements KeywordExecutable {
     String[] newArgs = Main.stripArgs(args, mainClass.getName().equals(candidateMainClass) ? 2 : 1);
     Main.execMainClass(mainClass, newArgs);
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/util/UtilWaitThread.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/UtilWaitThread.java b/core/src/main/java/org/apache/accumulo/core/util/UtilWaitThread.java
index d7005a4..01f5fa8 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/UtilWaitThread.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/UtilWaitThread.java
@@ -19,7 +19,6 @@ package org.apache.accumulo.core.util;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-
 public class UtilWaitThread {
   private static final Logger log = LoggerFactory.getLogger(UtilWaitThread.class);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/util/format/FormatterFactory.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/format/FormatterFactory.java b/core/src/main/java/org/apache/accumulo/core/util/format/FormatterFactory.java
index 65b34f2..7eb542f 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/format/FormatterFactory.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/format/FormatterFactory.java
@@ -23,7 +23,6 @@ import org.apache.accumulo.core.data.Value;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-
 public class FormatterFactory {
   private static final Logger log = LoggerFactory.getLogger(FormatterFactory.class);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/volume/VolumeImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/volume/VolumeImpl.java b/core/src/main/java/org/apache/accumulo/core/volume/VolumeImpl.java
index c91c36e..9285cb6 100644
--- a/core/src/main/java/org/apache/accumulo/core/volume/VolumeImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/volume/VolumeImpl.java
@@ -28,7 +28,6 @@ import org.apache.hadoop.fs.Path;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-
 /**
  * Basic Volume implementation that contains a FileSystem and a base path that should be used within that filesystem.
  */

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooUtil.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooUtil.java b/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooUtil.java
index be05730..07a38dc 100644
--- a/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooUtil.java
@@ -32,7 +32,6 @@ import org.apache.hadoop.fs.Path;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-
 public class ZooUtil extends org.apache.accumulo.fate.zookeeper.ZooUtil {
 
   private static final Logger log = LoggerFactory.getLogger(ZooUtil.class);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b932755e/core/src/test/java/org/apache/accumulo/core/client/ClientConfigurationTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/ClientConfigurationTest.java b/core/src/test/java/org/apache/accumulo/core/client/ClientConfigurationTest.java
index 6f91b0b..b1f1968 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/ClientConfigurationTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/ClientConfigurationTest.java
@@ -114,7 +114,7 @@ public class ClientConfigurationTest {
     assertEquals(1, conf.getList(ClientProperty.TRACE_SPAN_RECEIVERS.getKey()).size());
 
     // only used internally
-    Map<String, String> map = new HashMap<>();
+    Map<String,String> map = new HashMap<>();
     map.put(ClientProperty.INSTANCE_ZK_HOST.getKey(), val);
     map.put(ClientProperty.TRACE_SPAN_RECEIVERS.getKey(), val);
     conf = new ClientConfiguration(new MapConfiguration(map));
@@ -131,7 +131,7 @@ public class ClientConfigurationTest {
     conf.addProperty(ClientProperty.TRACE_SPAN_RECEIVER_PREFIX.getKey() + "second", "2nd");
     conf.addProperty("other", "value");
 
-    Map<String, String> props = conf.getAllPropertiesWithPrefix(ClientProperty.TRACE_SPAN_RECEIVER_PREFIX);
+    Map<String,String> props = conf.getAllPropertiesWithPrefix(ClientProperty.TRACE_SPAN_RECEIVER_PREFIX);
     assertEquals(2, props.size());
     assertEquals("1st", props.get(ClientProperty.TRACE_SPAN_RECEIVER_PREFIX.getKey() + "first"));
     assertEquals("2nd", props.get(ClientProperty.TRACE_SPAN_RECEIVER_PREFIX.getKey() + "second"));