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 2018/04/06 09:53:00 UTC

[accumulo] branch 1.8 updated (4aef962 -> b8c19f8)

This is an automated email from the ASF dual-hosted git repository.

ctubbsii pushed a change to branch 1.8
in repository https://gitbox.apache.org/repos/asf/accumulo.git.


    from 4aef962  ACCUMULO-4833 Disable broken randomwalk task
     new fc20be3  POM updates for formatting (#416)
     new f4f43fe  Apply initial formatting changes to 100-char lines
     new 2387957  Fix findbugs error due to line-wrapping
     new 2ecae2d  Fix line wrap and other checkstyle errors
     new b8c19f8  Remove unused variables

The 5 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 contrib/Eclipse-Accumulo-Codestyle.xml             |    4 +-
 .../java/org/apache/accumulo/core/Constants.java   |    3 +-
 .../accumulo/core/bloomfilter/BloomFilter.java     |   36 +-
 .../core/bloomfilter/DynamicBloomFilter.java       |   49 +-
 .../apache/accumulo/core/bloomfilter/Filter.java   |    5 +-
 .../apache/accumulo/core/cli/BatchScannerOpts.java |    3 +-
 .../apache/accumulo/core/cli/BatchWriterOpts.java  |   12 +-
 .../org/apache/accumulo/core/cli/ClientOpts.java   |   49 +-
 .../core/cli/MapReduceClientOnRequiredTable.java   |    3 +-
 .../accumulo/core/cli/MapReduceClientOpts.java     |   13 +-
 .../org/apache/accumulo/core/cli/ScannerOpts.java  |    3 +-
 .../core/client/AccumuloSecurityException.java     |   15 +-
 .../apache/accumulo/core/client/BatchScanner.java  |   26 +-
 .../apache/accumulo/core/client/BatchWriter.java   |   15 +-
 .../accumulo/core/client/BatchWriterConfig.java    |   49 +-
 .../accumulo/core/client/ClientConfiguration.java  |  360 ++++--
 .../core/client/ClientSideIteratorScanner.java     |   59 +-
 .../accumulo/core/client/ConditionalWriter.java    |   30 +-
 .../core/client/ConditionalWriterConfig.java       |   25 +-
 .../org/apache/accumulo/core/client/Connector.java |   92 +-
 .../apache/accumulo/core/client/Durability.java    |    6 +-
 .../org/apache/accumulo/core/client/Instance.java  |   40 +-
 .../accumulo/core/client/IsolatedScanner.java      |   16 +-
 .../accumulo/core/client/IteratorSetting.java      |   54 +-
 .../core/client/MultiTableBatchWriter.java         |    8 +-
 .../core/client/MutationsRejectedException.java    |   41 +-
 .../core/client/NamespaceExistsException.java      |   11 +-
 .../core/client/NamespaceNotEmptyException.java    |   11 +-
 .../core/client/NamespaceNotFoundException.java    |   11 +-
 .../apache/accumulo/core/client/RowIterator.java   |   11 +-
 .../core/client/SampleNotPresentException.java     |    3 +-
 .../org/apache/accumulo/core/client/Scanner.java   |   25 +-
 .../apache/accumulo/core/client/ScannerBase.java   |   93 +-
 .../core/client/TableDeletedException.java         |    3 +-
 .../accumulo/core/client/TableExistsException.java |    8 +-
 .../core/client/TableNotFoundException.java        |   14 +-
 .../accumulo/core/client/TimedOutException.java    |    3 +-
 .../accumulo/core/client/ZooKeeperInstance.java    |   89 +-
 .../core/client/admin/ActiveCompaction.java        |    3 +-
 .../core/client/admin/CompactionConfig.java        |   30 +-
 .../client/admin/CompactionStrategyConfig.java     |   14 +-
 .../core/client/admin/DelegationTokenConfig.java   |   10 +-
 .../apache/accumulo/core/client/admin/FindMax.java |   15 +-
 .../core/client/admin/InstanceOperations.java      |   35 +-
 .../accumulo/core/client/admin/Locations.java      |   12 +-
 .../core/client/admin/NamespaceOperations.java     |   82 +-
 .../core/client/admin/NewTableConfiguration.java   |   16 +-
 .../core/client/admin/ReplicationOperations.java   |   34 +-
 .../core/client/admin/SecurityOperations.java      |   76 +-
 .../core/client/admin/TableOperations.java         |  280 +++--
 .../accumulo/core/client/admin/TimeType.java       |    7 +-
 .../AcceptableThriftTableOperationException.java   |    6 +-
 .../core/client/impl/ActiveCompactionImpl.java     |    9 +-
 .../accumulo/core/client/impl/ActiveScanImpl.java  |    7 +-
 .../client/impl/AuthenticationTokenIdentifier.java |    3 +-
 .../core/client/impl/BaseIteratorEnvironment.java  |    8 +-
 .../accumulo/core/client/impl/ClientContext.java   |   65 +-
 .../core/client/impl/ConditionalWriterImpl.java    |   70 +-
 .../accumulo/core/client/impl/ConnectorImpl.java   |   62 +-
 .../accumulo/core/client/impl/Credentials.java     |   65 +-
 .../core/client/impl/DelegationTokenImpl.java      |   21 +-
 .../core/client/impl/InstanceOperationsImpl.java   |   61 +-
 .../accumulo/core/client/impl/MasterClient.java    |   29 +-
 .../client/impl/MultiTableBatchWriterImpl.java     |   18 +-
 .../client/impl/NamespaceOperationsHelper.java     |   80 +-
 .../core/client/impl/NamespaceOperationsImpl.java  |   80 +-
 .../accumulo/core/client/impl/Namespaces.java      |   27 +-
 .../accumulo/core/client/impl/OfflineIterator.java |   63 +-
 .../accumulo/core/client/impl/OfflineScanner.java  |    3 +-
 .../core/client/impl/ReplicationClient.java        |   44 +-
 .../client/impl/ReplicationOperationsImpl.java     |   32 +-
 .../core/client/impl/RootTabletLocator.java        |   27 +-
 .../accumulo/core/client/impl/ScannerImpl.java     |   13 +-
 .../accumulo/core/client/impl/ScannerIterator.java |   16 +-
 .../accumulo/core/client/impl/ScannerOptions.java  |    3 +-
 .../core/client/impl/SecurityOperationsImpl.java   |  126 ++-
 .../accumulo/core/client/impl/ServerClient.java    |   37 +-
 .../core/client/impl/SyncingTabletLocator.java     |   17 +-
 .../apache/accumulo/core/client/impl/TableMap.java |    3 +-
 .../core/client/impl/TableOperationsHelper.java    |   77 +-
 .../core/client/impl/TableOperationsImpl.java      |  411 ++++---
 .../apache/accumulo/core/client/impl/Tables.java   |   58 +-
 .../accumulo/core/client/impl/TabletLocator.java   |   28 +-
 .../core/client/impl/TabletLocatorImpl.java        |  141 ++-
 .../core/client/impl/TabletServerBatchDeleter.java |    9 +-
 .../core/client/impl/TabletServerBatchReader.java  |   15 +-
 .../impl/TabletServerBatchReaderIterator.java      |  142 ++-
 .../core/client/impl/TabletServerBatchWriter.java  |  136 ++-
 .../accumulo/core/client/impl/TabletType.java      |    3 +-
 .../accumulo/core/client/impl/ThriftScanner.java   |  126 ++-
 .../core/client/impl/ThriftTransportKey.java       |    6 +-
 .../core/client/impl/ThriftTransportPool.java      |   48 +-
 .../core/client/impl/TimeoutTabletLocator.java     |   15 +-
 .../accumulo/core/client/impl/Translator.java      |   15 +-
 .../apache/accumulo/core/client/impl/Writer.java   |   12 +-
 .../core/client/lexicoder/AbstractEncoder.java     |   14 +-
 .../core/client/lexicoder/BigIntegerLexicoder.java |    6 +-
 .../core/client/lexicoder/BytesLexicoder.java      |   10 +-
 .../core/client/lexicoder/DateLexicoder.java       |    3 +-
 .../core/client/lexicoder/DoubleLexicoder.java     |    3 +-
 .../accumulo/core/client/lexicoder/Encoder.java    |    3 +-
 .../core/client/lexicoder/FloatLexicoder.java      |    3 +-
 .../core/client/lexicoder/IntegerLexicoder.java    |    7 +-
 .../accumulo/core/client/lexicoder/Lexicoder.java  |    4 +-
 .../core/client/lexicoder/ListLexicoder.java       |    6 +-
 .../core/client/lexicoder/LongLexicoder.java       |    4 +-
 .../core/client/lexicoder/PairLexicoder.java       |   44 +-
 .../core/client/lexicoder/ReverseLexicoder.java    |    7 +-
 .../core/client/lexicoder/StringLexicoder.java     |    7 +-
 .../core/client/lexicoder/TextLexicoder.java       |    7 +-
 .../core/client/lexicoder/UIntegerLexicoder.java   |    8 +-
 .../core/client/lexicoder/ULongLexicoder.java      |    8 +-
 .../core/client/lexicoder/UUIDLexicoder.java       |    7 +-
 .../lexicoder/impl/FixedByteArrayOutputStream.java |    3 +-
 .../core/client/mapred/AbstractInputFormat.java    |  140 ++-
 .../client/mapred/AccumuloFileOutputFormat.java    |   58 +-
 .../core/client/mapred/AccumuloInputFormat.java    |   15 +-
 .../mapred/AccumuloMultiTableInputFormat.java      |   11 +-
 .../core/client/mapred/AccumuloOutputFormat.java   |   82 +-
 .../core/client/mapred/AccumuloRowInputFormat.java |   66 +-
 .../core/client/mapred/InputFormatBase.java        |  100 +-
 .../core/client/mapred/RangeInputSplit.java        |    3 +-
 .../core/client/mapred/impl/BatchInputSplit.java   |    9 +-
 .../core/client/mapreduce/AbstractInputFormat.java |  151 ++-
 .../client/mapreduce/AccumuloFileOutputFormat.java |   52 +-
 .../core/client/mapreduce/AccumuloInputFormat.java |   15 +-
 .../mapreduce/AccumuloMultiTableInputFormat.java   |   11 +-
 .../client/mapreduce/AccumuloOutputFormat.java     |   85 +-
 .../client/mapreduce/AccumuloRowInputFormat.java   |   13 +-
 .../core/client/mapreduce/InputFormatBase.java     |  106 +-
 .../core/client/mapreduce/InputTableConfig.java    |   58 +-
 .../core/client/mapreduce/RangeInputSplit.java     |   18 +-
 .../client/mapreduce/impl/BatchInputSplit.java     |   30 +-
 .../client/mapreduce/impl/DelegationTokenStub.java |    3 +-
 .../core/client/mapreduce/impl/SplitUtils.java     |   16 +-
 .../mapreduce/lib/impl/ConfiguratorBase.java       |  134 ++-
 .../mapreduce/lib/impl/FileOutputConfigurator.java |   83 +-
 .../mapreduce/lib/impl/InputConfigurator.java      |  240 ++--
 .../mapreduce/lib/impl/OutputConfigurator.java     |   36 +-
 .../client/mapreduce/lib/impl/package-info.java    |   27 +-
 .../lib/partition/KeyRangePartitioner.java         |    3 +-
 .../mapreduce/lib/partition/RangePartitioner.java  |    9 +-
 .../mapreduce/lib/util/ConfiguratorBase.java       |   72 +-
 .../mapreduce/lib/util/FileOutputConfigurator.java |   67 +-
 .../mapreduce/lib/util/InputConfigurator.java      |  167 ++-
 .../mapreduce/lib/util/OutputConfigurator.java     |   54 +-
 .../client/mapreduce/lib/util/package-info.java    |    1 -
 .../accumulo/core/client/mock/MockAccumulo.java    |   15 +-
 .../core/client/mock/MockBatchDeleter.java         |    9 +-
 .../core/client/mock/MockConfiguration.java        |    3 +-
 .../accumulo/core/client/mock/MockConnector.java   |   46 +-
 .../accumulo/core/client/mock/MockInstance.java    |   25 +-
 .../core/client/mock/MockInstanceOperations.java   |   18 +-
 .../client/mock/MockMultiTableBatchWriter.java     |    3 +-
 .../core/client/mock/MockNamespaceOperations.java  |   25 +-
 .../accumulo/core/client/mock/MockScannerBase.java |   14 +-
 .../core/client/mock/MockSecurityOperations.java   |   54 +-
 .../accumulo/core/client/mock/MockTable.java       |   14 +-
 .../core/client/mock/MockTableOperations.java      |  149 ++-
 .../core/client/mock/impl/MockTabletLocator.java   |   12 +-
 .../accumulo/core/client/mock/package-info.java    |    1 -
 .../client/replication/PeerExistsException.java    |    3 +-
 .../apache/accumulo/core/client/rfile/RFile.java   |   93 +-
 .../accumulo/core/client/rfile/RFileScanner.java   |   33 +-
 .../core/client/rfile/RFileScannerBuilder.java     |    6 +-
 .../accumulo/core/client/rfile/RFileSource.java    |    4 +-
 .../accumulo/core/client/rfile/RFileWriter.java    |   56 +-
 .../core/client/rfile/RFileWriterBuilder.java      |    8 +-
 .../core/client/sample/AbstractHashSampler.java    |   13 +-
 .../core/client/sample/RowColumnSampler.java       |   23 +-
 .../accumulo/core/client/sample/RowSampler.java    |   18 +-
 .../accumulo/core/client/sample/Sampler.java       |   30 +-
 .../security/tokens/AuthenticationToken.java       |   26 +-
 .../security/tokens/CredentialProviderToken.java   |   24 +-
 .../client/security/tokens/DelegationToken.java    |   13 +-
 .../core/client/security/tokens/KerberosToken.java |   28 +-
 .../core/client/security/tokens/PasswordToken.java |   21 +-
 .../accumulo/core/conf/AccumuloConfiguration.java  |   67 +-
 .../accumulo/core/conf/ConfigSanityCheck.java      |   17 +-
 .../accumulo/core/conf/ConfigurationCopy.java      |    3 +-
 .../accumulo/core/conf/ConfigurationDocGen.java    |   38 +-
 .../core/conf/CredentialProviderFactoryShim.java   |  153 ++-
 .../accumulo/core/conf/DefaultConfiguration.java   |    3 +-
 .../apache/accumulo/core/conf/Interpolated.java    |    9 +-
 .../core/conf/ObservableConfiguration.java         |    6 +-
 .../org/apache/accumulo/core/conf/Property.java    | 1179 +++++++++++++-------
 .../apache/accumulo/core/conf/PropertyType.java    |  113 +-
 .../org/apache/accumulo/core/conf/Sensitive.java   |    3 +-
 .../accumulo/core/conf/SiteConfiguration.java      |   43 +-
 .../accumulo/core/constraints/Constraint.java      |   14 +-
 .../core/constraints/VisibilityConstraint.java     |    3 +-
 .../accumulo/core/data/ArrayByteSequence.java      |   24 +-
 .../apache/accumulo/core/data/ByteSequence.java    |   17 +-
 .../java/org/apache/accumulo/core/data/Column.java |   10 +-
 .../apache/accumulo/core/data/ColumnUpdate.java    |   20 +-
 .../apache/accumulo/core/data/ComparableBytes.java |   11 +-
 .../org/apache/accumulo/core/data/Condition.java   |   55 +-
 .../accumulo/core/data/ConditionalMutation.java    |    6 +-
 .../core/data/ConstraintViolationSummary.java      |   13 +-
 .../java/org/apache/accumulo/core/data/Key.java    |  312 ++++--
 .../org/apache/accumulo/core/data/KeyExtent.java   |   36 +-
 .../org/apache/accumulo/core/data/Mutation.java    |  229 ++--
 .../org/apache/accumulo/core/data/PartialKey.java  |    6 +-
 .../java/org/apache/accumulo/core/data/Range.java  |  180 +--
 .../org/apache/accumulo/core/data/TabletId.java    |    3 +-
 .../java/org/apache/accumulo/core/data/Value.java  |   32 +-
 .../accumulo/core/data/impl/ComparableBytes.java   |    3 +-
 .../apache/accumulo/core/data/impl/KeyExtent.java  |   76 +-
 .../accumulo/core/data/impl/TabletIdImpl.java      |   17 +-
 .../accumulo/core/file/BloomFilterLayer.java       |   71 +-
 .../accumulo/core/file/DispatchingFileFactory.java |    8 +-
 .../apache/accumulo/core/file/FileOperations.java  |  131 ++-
 .../accumulo/core/file/blockfile/ABlockReader.java |    3 +-
 .../core/file/blockfile/BlockFileReader.java       |    3 +-
 .../core/file/blockfile/BlockFileWriter.java       |    3 +-
 .../core/file/blockfile/cache/CachedBlock.java     |   16 +-
 .../file/blockfile/cache/CachedBlockQueue.java     |   15 +-
 .../core/file/blockfile/cache/ClassSize.java       |   18 +-
 .../core/file/blockfile/cache/HeapSize.java        |    9 +-
 .../core/file/blockfile/cache/LruBlockCache.java   |  112 +-
 .../file/blockfile/impl/CachableBlockFile.java     |   97 +-
 .../impl/SeekableByteArrayInputStream.java         |    9 +-
 .../file/keyfunctor/ColumnQualifierFunctor.java    |    3 +-
 .../accumulo/core/file/keyfunctor/RowFunctor.java  |    3 +-
 .../accumulo/core/file/map/MapFileOperations.java  |   19 +-
 .../apache/accumulo/core/file/map/MapFileUtil.java |    6 +-
 .../accumulo/core/file/rfile/BlockIndex.java       |   15 +-
 .../accumulo/core/file/rfile/CreateEmpty.java      |   23 +-
 .../accumulo/core/file/rfile/IndexIterator.java    |    6 +-
 .../accumulo/core/file/rfile/KeyShortener.java     |   27 +-
 .../accumulo/core/file/rfile/MetricsGatherer.java  |   10 +-
 .../core/file/rfile/MultiIndexIterator.java        |    6 +-
 .../accumulo/core/file/rfile/MultiLevelIndex.java  |   58 +-
 .../apache/accumulo/core/file/rfile/PrintInfo.java |   28 +-
 .../org/apache/accumulo/core/file/rfile/RFile.java |  229 ++--
 .../accumulo/core/file/rfile/RFileOperations.java  |   15 +-
 .../accumulo/core/file/rfile/RelativeKey.java      |   33 +-
 .../accumulo/core/file/rfile/RollingStats.java     |   15 +-
 .../accumulo/core/file/rfile/SplitLarge.java       |   15 +-
 .../core/file/rfile/VisMetricsGatherer.java        |   19 +-
 .../accumulo/core/file/rfile/VisibilityMetric.java |   10 +-
 .../accumulo/core/file/rfile/bcfile/BCFile.java    |  209 ++--
 .../core/file/rfile/bcfile/Compression.java        |  134 ++-
 .../accumulo/core/file/rfile/bcfile/PrintInfo.java |   15 +-
 .../core/file/rfile/bcfile/RawComparable.java      |   10 +-
 .../rfile/bcfile/SimpleBufferedOutputStream.java   |    3 +-
 .../accumulo/core/file/rfile/bcfile/Utils.java     |   67 +-
 .../file/streams/BoundedRangeFileInputStream.java  |   11 +-
 .../file/streams/PositionedDataOutputStream.java   |    6 +-
 .../core/file/streams/PositionedOutput.java        |    3 +-
 .../core/file/streams/PositionedOutputs.java       |    8 +-
 .../core/file/streams/RateLimitedInputStream.java  |    3 +-
 .../core/file/streams/SeekableDataInputStream.java |    3 +-
 .../core/iterators/AggregatingIterator.java        |   35 +-
 .../core/iterators/ColumnFamilyCounter.java        |    9 +-
 .../apache/accumulo/core/iterators/Combiner.java   |  134 ++-
 .../accumulo/core/iterators/DebugIterator.java     |   10 +-
 .../apache/accumulo/core/iterators/DevNull.java    |   10 +-
 .../core/iterators/FamilyIntersectingIterator.java |    3 +-
 .../org/apache/accumulo/core/iterators/Filter.java |   25 +-
 .../core/iterators/FirstEntryInRowIterator.java    |   16 +-
 .../core/iterators/IntersectingIterator.java       |    6 +-
 .../accumulo/core/iterators/IteratorAdapter.java   |    3 +-
 .../core/iterators/IteratorEnvironment.java        |   17 +-
 .../accumulo/core/iterators/IteratorUtil.java      |  149 ++-
 .../accumulo/core/iterators/LongCombiner.java      |   61 +-
 .../accumulo/core/iterators/OptionDescriber.java   |   39 +-
 .../apache/accumulo/core/iterators/OrIterator.java |   52 +-
 .../core/iterators/RowDeletingIterator.java        |    6 +-
 .../accumulo/core/iterators/SkippingIterator.java  |   10 +-
 .../accumulo/core/iterators/SortedKeyIterator.java |    4 +-
 .../core/iterators/SortedKeyValueIterator.java     |   86 +-
 .../accumulo/core/iterators/SortedMapIterator.java |   13 +-
 .../core/iterators/TypedValueCombiner.java         |   38 +-
 .../core/iterators/VersioningIterator.java         |    3 +-
 .../accumulo/core/iterators/WholeRowIterator.java  |    3 +-
 .../accumulo/core/iterators/WrappingIterator.java  |   22 +-
 .../accumulo/core/iterators/YieldCallback.java     |    5 +-
 .../core/iterators/YieldingKeyValueIterator.java   |   18 +-
 .../core/iterators/aggregation/LongSummation.java  |   15 +-
 .../iterators/aggregation/NumArraySummation.java   |    3 +-
 .../core/iterators/aggregation/NumSummation.java   |    3 +-
 .../core/iterators/aggregation/StringMax.java      |    4 +-
 .../core/iterators/aggregation/StringMin.java      |    4 +-
 .../iterators/aggregation/StringSummation.java     |    3 +-
 .../aggregation/conf/AggregatorConfiguration.java  |    3 +-
 .../iterators/aggregation/conf/AggregatorSet.java  |    6 +-
 .../accumulo/core/iterators/conf/ColumnSet.java    |    6 +-
 .../core/iterators/conf/ColumnToClassMapping.java  |   12 +-
 .../accumulo/core/iterators/conf/ColumnUtil.java   |    9 +-
 .../iterators/conf/PerColumnIteratorConfig.java    |    6 +-
 .../system/ColumnFamilySkippingIterator.java       |   12 +-
 .../iterators/system/ColumnQualifierFilter.java    |    9 +-
 .../core/iterators/system/CountingIterator.java    |    3 +-
 .../core/iterators/system/DeletingIterator.java    |   15 +-
 .../core/iterators/system/EmptyIterator.java       |    6 +-
 .../core/iterators/system/HeapIterator.java        |    4 +-
 .../iterators/system/LocalityGroupIterator.java    |   43 +-
 .../core/iterators/system/MapFileIterator.java     |    9 +-
 .../core/iterators/system/MultiIterator.java       |    9 +-
 .../iterators/system/SequenceFileIterator.java     |    6 +-
 .../iterators/system/SourceSwitchingIterator.java  |   53 +-
 .../core/iterators/system/StatsIterator.java       |    6 +-
 .../iterators/system/SynchronizedIterator.java     |   14 +-
 .../core/iterators/system/TimeSettingIterator.java |    6 +-
 .../core/iterators/system/VisibilityFilter.java    |    9 +-
 .../accumulo/core/iterators/user/AgeOffFilter.java |   18 +-
 .../core/iterators/user/BigDecimalCombiner.java    |   12 +-
 .../core/iterators/user/CfCqSliceFilter.java       |   13 +-
 .../core/iterators/user/CfCqSliceOpts.java         |   50 +-
 .../iterators/user/CfCqSliceSeekingFilter.java     |   27 +-
 .../core/iterators/user/ColumnAgeOffFilter.java    |   17 +-
 .../core/iterators/user/ColumnSliceFilter.java     |   22 +-
 .../accumulo/core/iterators/user/GrepIterator.java |    9 +-
 .../core/iterators/user/IndexedDocIterator.java    |   38 +-
 .../core/iterators/user/IntersectingIterator.java  |   97 +-
 .../core/iterators/user/LargeRowFilter.java        |   49 +-
 .../accumulo/core/iterators/user/MaxCombiner.java  |    4 +-
 .../accumulo/core/iterators/user/MinCombiner.java  |    4 +-
 .../accumulo/core/iterators/user/RegExFilter.java  |   26 +-
 .../core/iterators/user/RowDeletingIterator.java   |   45 +-
 .../core/iterators/user/RowEncodingIterator.java   |   61 +-
 .../accumulo/core/iterators/user/RowFilter.java    |   44 +-
 .../core/iterators/user/SeekingFilter.java         |   47 +-
 .../core/iterators/user/SummingArrayCombiner.java  |   26 +-
 .../core/iterators/user/SummingCombiner.java       |    4 +-
 .../core/iterators/user/TimestampFilter.java       |   15 +-
 .../core/iterators/user/TransformingIterator.java  |  231 ++--
 .../core/iterators/user/VersioningIterator.java    |   19 +-
 .../core/iterators/user/VisibilityFilter.java      |   16 +-
 .../iterators/user/WholeColumnFamilyIterator.java  |   52 +-
 .../core/iterators/user/WholeRowIterator.java      |   27 +-
 .../core/metadata/MetadataLocationObtainer.java    |   54 +-
 .../accumulo/core/metadata/MetadataServicer.java   |    9 +-
 .../apache/accumulo/core/metadata/RootTable.java   |    3 +-
 .../core/metadata/ServicerForRootTable.java        |    3 +-
 .../core/metadata/TableMetadataServicer.java       |   26 +-
 .../core/metadata/schema/MetadataSchema.java       |   50 +-
 .../replication/AccumuloReplicationReplayer.java   |    7 +-
 .../core/replication/ReplicationSchema.java        |   53 +-
 .../core/replication/ReplicationTable.java         |    9 +-
 .../core/replication/ReplicationTarget.java        |   10 +-
 .../apache/accumulo/core/rpc/FilterTransport.java  |    5 +-
 .../rpc/ProtocolOverridingSSLSocketFactory.java    |   24 +-
 .../core/rpc/SaslClientDigestCallbackHandler.java  |    5 +-
 .../accumulo/core/rpc/SaslConnectionParams.java    |   15 +-
 .../core/rpc/SaslDigestCallbackHandler.java        |    6 +-
 .../accumulo/core/rpc/SslConnectionParams.java     |   19 +-
 .../apache/accumulo/core/rpc/TBufferedSocket.java  |    3 +-
 .../accumulo/core/rpc/TTimeoutTransport.java       |    6 +-
 .../org/apache/accumulo/core/rpc/ThriftUtil.java   |  144 ++-
 .../accumulo/core/rpc/TraceProtocolFactory.java    |    3 +-
 .../accumulo/core/rpc/UGIAssumingTransport.java    |    8 +-
 .../core/sample/impl/SamplerConfigurationImpl.java |   18 +-
 .../accumulo/core/sample/impl/SamplerFactory.java  |    6 +-
 .../accumulo/core/security/Authorizations.java     |   24 +-
 .../accumulo/core/security/ColumnVisibility.java   |   91 +-
 .../core/security/NamespacePermission.java         |    3 +-
 .../accumulo/core/security/SystemPermission.java   |    3 +-
 .../accumulo/core/security/TablePermission.java    |    3 +-
 .../core/security/VisibilityConstraint.java        |    8 +-
 .../core/security/VisibilityEvaluator.java         |   29 +-
 .../core/security/VisibilityParseException.java    |    3 +-
 .../core/security/crypto/BlockedInputStream.java   |   10 +-
 .../core/security/crypto/BlockedOutputStream.java  |   19 +-
 .../CachingHDFSSecretKeyEncryptionStrategy.java    |   27 +-
 .../core/security/crypto/CryptoModule.java         |   87 +-
 .../core/security/crypto/CryptoModuleFactory.java  |   84 +-
 .../security/crypto/CryptoModuleParameters.java    |  263 +++--
 .../core/security/crypto/DefaultCryptoModule.java  |  186 +--
 .../security/crypto/DefaultCryptoModuleUtils.java  |   14 +-
 .../NonCachingSecretKeyEncryptionStrategy.java     |   35 +-
 .../apache/accumulo/core/trace/CountSampler.java   |    3 +-
 .../accumulo/core/trace/DistributedTrace.java      |   43 +-
 .../accumulo/core/trace/ProbabilitySampler.java    |    3 +-
 .../java/org/apache/accumulo/core/trace/Span.java  |    3 +-
 .../java/org/apache/accumulo/core/trace/Trace.java |    3 +-
 .../accumulo/core/trace/wrappers/TraceWrap.java    |   11 +-
 .../org/apache/accumulo/core/util/AddressUtil.java |    6 +-
 .../accumulo/core/util/AsyncSocketAppender.java    |    8 +-
 .../java/org/apache/accumulo/core/util/Base64.java |   13 +-
 .../apache/accumulo/core/util/ByteBufferUtil.java  |   12 +-
 .../org/apache/accumulo/core/util/CleanUp.java     |   11 +-
 .../apache/accumulo/core/util/ComparablePair.java  |    3 +-
 .../org/apache/accumulo/core/util/CreateToken.java |   24 +-
 .../apache/accumulo/core/util/DeprecationUtil.java |   13 +-
 .../org/apache/accumulo/core/util/FastFormat.java  |    6 +-
 .../org/apache/accumulo/core/util/HostAndPort.java |   46 +-
 .../java/org/apache/accumulo/core/util/Jar.java    |    8 +-
 .../accumulo/core/util/LocalityGroupUtil.java      |   38 +-
 .../java/org/apache/accumulo/core/util/Merge.java  |   34 +-
 .../org/apache/accumulo/core/util/OpTimer.java     |   14 +-
 .../apache/accumulo/core/util/PeekingIterator.java |    3 +-
 .../accumulo/core/util/PreAllocatedArray.java      |    5 +-
 .../apache/accumulo/core/util/ServerServices.java  |    3 +-
 .../accumulo/core/util/SimpleThreadPool.java       |    3 +-
 .../accumulo/core/util/ThriftMessageUtil.java      |   13 +-
 .../accumulo/core/util/UnsynchronizedBuffer.java   |   26 +-
 .../org/apache/accumulo/core/util/Validator.java   |   15 +-
 .../accumulo/core/util/format/BinaryFormatter.java |   12 +-
 .../core/util/format/DateFormatSupplier.java       |   19 +-
 .../core/util/format/DateStringFormatter.java      |   17 +-
 .../core/util/format/DefaultFormatter.java         |    9 +-
 .../accumulo/core/util/format/FormatterConfig.java |    5 +-
 .../core/util/format/FormatterFactory.java         |    6 +-
 .../accumulo/core/util/format/HexFormatter.java    |    3 +-
 .../format/ShardedTableDistributionFormatter.java  |    7 +-
 .../util/format/StatisticsDisplayFormatter.java    |    5 +-
 .../core/util/interpret/HexScanInterpreter.java    |    5 +-
 .../core/util/interpret/ScanInterpreter.java       |    3 +-
 .../core/util/ratelimit/GuavaRateLimiter.java      |    9 +-
 .../util/ratelimit/SharedRateLimiterFactory.java   |   22 +-
 .../accumulo/core/volume/NonConfiguredVolume.java  |   21 +-
 .../org/apache/accumulo/core/volume/Volume.java    |    6 +-
 .../accumulo/core/volume/VolumeConfiguration.java  |   21 +-
 .../apache/accumulo/core/volume/VolumeImpl.java    |   12 +-
 .../apache/accumulo/core/zookeeper/ZooUtil.java    |   16 +-
 .../apache/accumulo/core/cli/TestClientOpts.java   |   34 +-
 .../core/client/BatchWriterConfigTest.java         |    6 +-
 .../core/client/ClientConfigurationTest.java       |    6 +-
 .../accumulo/core/client/IteratorSettingTest.java  |    6 +-
 .../accumulo/core/client/TestThrift1474.java       |    3 +-
 .../core/client/ZooKeeperInstanceTest.java         |   21 +-
 .../client/admin/DelegationTokenConfigTest.java    |    6 +-
 .../core/client/impl/ClientContextTest.java        |   15 +-
 .../core/client/impl/ScannerOptionsTest.java       |    3 +-
 .../client/impl/TableOperationsHelperTest.java     |  143 ++-
 .../core/client/impl/TableOperationsImplTest.java  |    3 +-
 .../core/client/impl/TabletLocatorImplTest.java    |  258 +++--
 .../core/client/impl/ThriftScannerTest.java        |    6 +-
 .../core/client/impl/ThriftTransportKeyTest.java   |   89 +-
 .../client/lexicoder/BigIntegerLexicoderTest.java  |   19 +-
 .../core/client/lexicoder/DoubleLexicoderTest.java |   10 +-
 .../core/client/lexicoder/FloatLexicoderTest.java  |    9 +-
 .../client/lexicoder/IntegerLexicoderTest.java     |    4 +-
 .../core/client/lexicoder/LexicoderTest.java       |    3 +-
 .../core/client/lexicoder/LongLexicoderTest.java   |    8 +-
 .../core/client/lexicoder/PairLexicoderTest.java   |   21 +-
 .../client/lexicoder/ReverseLexicoderTest.java     |   11 +-
 .../core/client/lexicoder/ULongLexicoderTest.java  |   31 +-
 .../core/client/lexicoder/UUIDLexicoderTest.java   |    4 +-
 .../lexicoder/impl/AbstractLexicoderTest.java      |    5 +-
 .../mapred/AccumuloFileOutputFormatTest.java       |    9 +-
 .../client/mapred/AccumuloInputFormatTest.java     |   38 +-
 .../mapred/AccumuloMultiTableInputFormatTest.java  |    9 +-
 .../client/mapred/AccumuloOutputFormatTest.java    |    6 +-
 .../core/client/mapred/RangeInputSplitTest.java    |    9 +-
 .../mapreduce/AccumuloFileOutputFormatTest.java    |   12 +-
 .../client/mapreduce/AccumuloInputFormatTest.java  |   38 +-
 .../AccumuloMultiTableInputFormatTest.java         |    3 +-
 .../client/mapreduce/AccumuloOutputFormatTest.java |    6 +-
 .../core/client/mapreduce/RangeInputSplitTest.java |    9 +-
 .../client/mapreduce/impl/BatchInputSplitTest.java |    9 +-
 .../mapreduce/lib/impl/ConfiguratorBaseTest.java   |   43 +-
 .../lib/partition/RangePartitionerTest.java        |    9 +-
 .../core/client/mock/MockConnectorTest.java        |   26 +-
 .../core/client/mock/MockNamespacesTest.java       |   25 +-
 .../accumulo/core/client/mock/MockScannerTest.java |    6 +-
 .../core/client/mock/MockTableOperationsTest.java  |   34 +-
 .../core/client/mock/TestBatchScanner821.java      |    3 +-
 .../accumulo/core/client/rfile/RFileTest.java      |   58 +-
 .../client/security/SecurityErrorCodeTest.java     |    6 +-
 .../security/tokens/DelegationTokenImplTest.java   |   21 +-
 .../client/security/tokens/KerberosTokenTest.java  |    3 +-
 .../core/conf/AccumuloConfigurationTest.java       |    6 +-
 .../accumulo/core/conf/ConfigSanityCheckTest.java  |    3 +-
 .../conf/CredentialProviderFactoryShimTest.java    |   38 +-
 .../core/conf/DefaultConfigurationTest.java        |    3 +-
 .../apache/accumulo/core/conf/PropertyTest.java    |   23 +-
 .../accumulo/core/conf/PropertyTypeTest.java       |   52 +-
 .../accumulo/core/conf/SiteConfigurationTest.java  |   15 +-
 .../constraints/DefaultKeySizeConstraintTest.java  |   16 +-
 .../accumulo/core/data/ArrayByteSequenceTest.java  |    3 +-
 .../apache/accumulo/core/data/ConditionTest.java   |   12 +-
 .../core/data/ConstraintViolationSummaryTest.java  |   13 +-
 .../org/apache/accumulo/core/data/KeyTest.java     |   12 +-
 .../apache/accumulo/core/data/MutationTest.java    |   41 +-
 .../org/apache/accumulo/core/data/OldMutation.java |   84 +-
 .../org/apache/accumulo/core/data/RangeTest.java   |  103 +-
 .../core/file/BloomFilterLayerLookupTest.java      |   15 +-
 .../accumulo/core/file/FileOperationsTest.java     |    3 +-
 .../file/blockfile/cache/TestCachedBlockQueue.java |   10 +-
 .../file/blockfile/cache/TestLruBlockCache.java    |   43 +-
 .../accumulo/core/file/rfile/BlockIndexTest.java   |   15 +-
 .../core/file/rfile/CreateCompatTestFile.java      |   22 +-
 .../accumulo/core/file/rfile/KeyShortenerTest.java |   78 +-
 .../core/file/rfile/MultiLevelIndexTest.java       |    6 +-
 .../core/file/rfile/MultiThreadedRFileTest.java    |   56 +-
 .../accumulo/core/file/rfile/RFileMetricsTest.java |    9 +-
 .../apache/accumulo/core/file/rfile/RFileTest.java |  299 +++--
 .../accumulo/core/file/rfile/RelativeKeyTest.java  |   24 +-
 .../core/file/rfile/RolllingStatsTest.java         |    4 +-
 .../core/file/rfile/bcfile/CompressionTest.java    |   21 +-
 .../file/streams/RateLimitedInputStreamTest.java   |   12 +-
 .../file/streams/RateLimitedOutputStreamTest.java  |    3 +-
 .../core/iterators/AggregatingIteratorTest.java    |    9 +-
 .../core/iterators/DefaultIteratorEnvironment.java |    3 +-
 .../iterators/FirstEntryInRowIteratorTest.java     |    9 +-
 .../core/iterators/FirstEntryInRowTest.java        |    9 +-
 .../accumulo/core/iterators/IteratorUtilTest.java  |   74 +-
 .../conf/AggregatorConfigurationTest.java          |   21 +-
 .../system/ColumnFamilySkippingIteratorTest.java   |   16 +-
 .../core/iterators/system/ColumnFilterTest.java    |    6 +-
 .../iterators/system/DeletingIteratorTest.java     |    3 +-
 .../core/iterators/system/MultiIteratorTest.java   |   20 +-
 .../system/SourceSwitchingIteratorTest.java        |   31 +-
 .../iterators/system/TimeSettingIteratorTest.java  |   21 +-
 .../iterators/system/VisibilityFilterTest.java     |    6 +-
 .../core/iterators/user/ColumnSliceFilterTest.java |    3 +-
 .../accumulo/core/iterators/user/CombinerTest.java |   53 +-
 .../accumulo/core/iterators/user/FilterTest.java   |   27 +-
 .../core/iterators/user/GrepIteratorTest.java      |    3 +-
 .../iterators/user/IndexedDocIteratorTest.java     |   39 +-
 .../iterators/user/IntersectingIteratorTest.java   |   39 +-
 .../core/iterators/user/LargeRowFilterTest.java    |   27 +-
 .../iterators/user/RowDeletingIteratorTest.java    |   12 +-
 .../iterators/user/RowEncodingIteratorTest.java    |    9 +-
 .../core/iterators/user/RowFilterTest.java         |   12 +-
 .../core/iterators/user/TestCfCqSlice.java         |   81 +-
 .../iterators/user/TransformingIteratorTest.java   |  102 +-
 .../iterators/user/VersioningIteratorTest.java     |    3 +-
 .../core/iterators/user/VisibilityFilterTest.java  |   15 +-
 .../user/WholeColumnFamilyIteratorTest.java        |   53 +-
 .../core/iterators/user/WholeRowIteratorTest.java  |   44 +-
 .../core/metadata/MetadataServicerTest.java        |    3 +-
 .../ReplicationConfigurationUtilTest.java          |   20 +-
 .../rpc/SaslClientDigestCallbackHandlerTest.java   |    5 +-
 .../core/rpc/SaslConnectionParamsTest.java         |  121 +-
 .../AuthenticationTokenIdentifierTest.java         |    6 +-
 .../core/security/AuthenticationTokenTest.java     |    6 +-
 .../accumulo/core/security/AuthorizationsTest.java |    3 +-
 .../core/security/ColumnVisibilityTest.java        |    6 +-
 .../accumulo/core/security/CredentialsTest.java    |   19 +-
 .../core/security/NamespacePermissionsTest.java    |    3 +-
 .../core/security/VisibilityConstraintTest.java    |    3 +-
 .../core/security/VisibilityEvaluatorTest.java     |   33 +-
 .../core/security/crypto/BlockedIOStreamTest.java  |    3 +-
 .../accumulo/core/security/crypto/CryptoTest.java  |   63 +-
 .../core/util/AsyncSocketAppenderTest.java         |    6 +-
 .../accumulo/core/util/ByteBufferUtilTest.java     |    6 +-
 .../accumulo/core/util/LocalityGroupUtilTest.java  |    3 +-
 .../org/apache/accumulo/core/util/MergeTest.java   |   12 +-
 .../org/apache/accumulo/core/util/OpTimerTest.java |   15 +-
 .../org/apache/accumulo/core/util/PairTest.java    |    3 +-
 .../apache/accumulo/core/util/PartitionerTest.java |    3 +-
 .../accumulo/core/util/PreAllocatedArrayTest.java  |    3 +-
 .../core/util/format/DateFormatSupplierTest.java   |    6 +-
 .../core/util/format/DefaultFormatterTest.java     |    9 +-
 .../core/util/format/FormatterFactoryTest.java     |    3 +-
 .../simple/client/CountingVerifyingReceiver.java   |    3 +-
 .../examples/simple/client/RandomBatchScanner.java |   26 +-
 .../examples/simple/client/RandomBatchWriter.java  |   30 +-
 .../examples/simple/client/ReadWriteExample.java   |   10 +-
 .../examples/simple/client/RowOperations.java      |   50 +-
 .../simple/client/SequentialBatchWriter.java       |   14 +-
 .../examples/simple/client/TraceDumpExample.java   |   12 +-
 .../examples/simple/client/TracingExample.java     |   21 +-
 .../examples/simple/combiner/StatsCombiner.java    |   17 +-
 .../simple/constraints/NumericValueConstraint.java |    6 +-
 .../examples/simple/dirlist/FileCount.java         |   25 +-
 .../accumulo/examples/simple/dirlist/Ingest.java   |   24 +-
 .../examples/simple/dirlist/QueryUtil.java         |   38 +-
 .../accumulo/examples/simple/dirlist/Viewer.java   |    9 +-
 .../simple/filedata/CharacterHistogram.java        |   11 +-
 .../examples/simple/filedata/ChunkCombiner.java    |   21 +-
 .../examples/simple/filedata/ChunkInputFormat.java |    8 +-
 .../examples/simple/filedata/ChunkInputStream.java |   21 +-
 .../examples/simple/filedata/FileDataIngest.java   |   27 +-
 .../examples/simple/filedata/FileDataQuery.java    |   10 +-
 .../simple/filedata/VisibilityCombiner.java        |    3 +-
 .../simple/helloworld/InsertWithBatchWriter.java   |   10 +-
 .../examples/simple/helloworld/ReadData.java       |    6 +-
 .../simple/isolation/InterferenceTest.java         |   14 +-
 .../examples/simple/mapreduce/NGramIngest.java     |    9 +-
 .../examples/simple/mapreduce/RegexExample.java    |    3 +-
 .../examples/simple/mapreduce/RowHash.java         |    3 +-
 .../examples/simple/mapreduce/TableToFile.java     |   14 +-
 .../examples/simple/mapreduce/TeraSortIngest.java  |   39 +-
 .../simple/mapreduce/TokenFileWordCount.java       |    9 +-
 .../examples/simple/mapreduce/UniqueColumns.java   |   18 +-
 .../examples/simple/mapreduce/WordCount.java       |    3 +-
 .../simple/mapreduce/bulk/BulkIngestExample.java   |   18 +-
 .../simple/mapreduce/bulk/GenerateTestData.java    |    3 +-
 .../simple/mapreduce/bulk/VerifyIngest.java        |    9 +-
 .../accumulo/examples/simple/reservations/ARS.java |   72 +-
 .../examples/simple/sample/SampleExample.java      |   32 +-
 .../examples/simple/shard/ContinuousQuery.java     |   11 +-
 .../simple/shard/CutoffIntersectingIterator.java   |   24 +-
 .../accumulo/examples/simple/shard/Index.java      |   15 +-
 .../accumulo/examples/simple/shard/Query.java      |   16 +-
 .../accumulo/examples/simple/shard/Reverse.java    |    5 +-
 .../constraints/AlphaNumKeyConstraintTest.java     |   13 +-
 .../constraints/NumericValueConstraintTest.java    |    6 +-
 .../simple/filedata/ChunkCombinerTest.java         |   21 +-
 .../simple/filedata/ChunkInputStreamTest.java      |   12 +-
 .../apache/accumulo/fate/AcceptableException.java  |   12 +-
 .../java/org/apache/accumulo/fate/AdminUtil.java   |   56 +-
 .../java/org/apache/accumulo/fate/AgeOffStore.java |    6 +-
 .../main/java/org/apache/accumulo/fate/Fate.java   |   21 +-
 .../org/apache/accumulo/fate/ReadOnlyRepo.java     |    4 +-
 .../org/apache/accumulo/fate/ReadOnlyStore.java    |    6 +-
 .../org/apache/accumulo/fate/ReadOnlyTStore.java   |   19 +-
 .../main/java/org/apache/accumulo/fate/TStore.java |    7 +-
 .../java/org/apache/accumulo/fate/ZooStore.java    |   27 +-
 .../org/apache/accumulo/fate/util/AddressUtil.java |   23 +-
 .../apache/accumulo/fate/util/LoggingRunnable.java |    9 +-
 .../java/org/apache/accumulo/fate/util/Retry.java  |   47 +-
 .../apache/accumulo/fate/util/UtilWaitThread.java  |    8 +-
 .../fate/zookeeper/DistributedReadWriteLock.java   |   20 +-
 .../apache/accumulo/fate/zookeeper/IZooReader.java |    9 +-
 .../accumulo/fate/zookeeper/IZooReaderWriter.java  |   24 +-
 .../apache/accumulo/fate/zookeeper/ZooCache.java   |   63 +-
 .../accumulo/fate/zookeeper/ZooCacheFactory.java   |    7 +-
 .../apache/accumulo/fate/zookeeper/ZooLock.java    |   52 +-
 .../accumulo/fate/zookeeper/ZooQueueLock.java      |    3 +-
 .../apache/accumulo/fate/zookeeper/ZooReader.java  |   42 +-
 .../accumulo/fate/zookeeper/ZooReaderWriter.java   |   46 +-
 .../accumulo/fate/zookeeper/ZooReservation.java    |   12 +-
 .../apache/accumulo/fate/zookeeper/ZooSession.java |   18 +-
 .../apache/accumulo/fate/zookeeper/ZooUtil.java    |   72 +-
 .../org/apache/accumulo/fate/AgeOffStoreTest.java  |   12 +-
 .../apache/accumulo/fate/ReadOnlyStoreTest.java    |    6 +-
 .../java/org/apache/accumulo/fate/SimpleStore.java |    6 +-
 .../apache/accumulo/fate/util/AddressUtilTest.java |   15 +-
 .../org/apache/accumulo/fate/util/RetryTest.java   |   29 +-
 .../accumulo/fate/zookeeper/ZooCacheTest.java      |   24 +-
 .../zookeeper/ZooKeeperConnectionInfoTest.java     |    7 +-
 .../fate/zookeeper/ZooReaderWriterTest.java        |   17 +-
 .../iteratortest/IteratorTestCaseFinder.java       |    9 +-
 .../accumulo/iteratortest/IteratorTestInput.java   |   29 +-
 .../accumulo/iteratortest/IteratorTestOutput.java  |   17 +-
 .../accumulo/iteratortest/IteratorTestReport.java  |    6 +-
 .../accumulo/iteratortest/IteratorTestRunner.java  |   14 +-
 .../accumulo/iteratortest/IteratorTestUtil.java    |    3 +-
 .../iteratortest/SimpleKVReusingIterator.java      |    9 +-
 .../environments/SimpleIteratorEnvironment.java    |    3 +-
 .../junit4/BaseJUnit4IteratorTest.java             |   12 +-
 .../testcases/InstantiationTestCase.java           |    3 +-
 .../testcases/IsolatedDeepCopiesTestCase.java      |   24 +-
 .../iteratortest/testcases/IteratorTestCase.java   |    7 +-
 .../testcases/MultipleHasTopCalls.java             |   13 +-
 .../testcases/OutputVerifyingTestCase.java         |    3 +-
 .../iteratortest/testcases/ReSeekTestCase.java     |   20 +-
 .../iteratortest/testcases/YieldingTestCase.java   |   24 +-
 .../iteratortest/framework/JUnitFrameworkTest.java |    9 +-
 .../maven/plugin/AbstractAccumuloMojo.java         |    6 +-
 .../apache/accumulo/maven/plugin/StartMojo.java    |   24 +-
 .../org/apache/accumulo/maven/plugin/StopMojo.java |    6 +-
 .../apache/accumulo/cluster/AccumuloCluster.java   |    6 +-
 .../apache/accumulo/cluster/ClusterControl.java    |    9 +-
 .../org/apache/accumulo/cluster/ClusterUser.java   |    6 +-
 .../org/apache/accumulo/cluster/ClusterUsers.java  |    3 +-
 .../org/apache/accumulo/cluster/RemoteShell.java   |   12 +-
 .../accumulo/cluster/RemoteShellOptions.java       |    5 +-
 .../standalone/StandaloneAccumuloCluster.java      |   29 +-
 .../standalone/StandaloneClusterControl.java       |   60 +-
 .../apache/accumulo/minicluster/MemoryUnit.java    |    5 +-
 .../accumulo/minicluster/MiniAccumuloCluster.java  |   18 +-
 .../accumulo/minicluster/MiniAccumuloConfig.java   |   18 +-
 .../accumulo/minicluster/MiniAccumuloInstance.java |   10 +-
 .../accumulo/minicluster/MiniAccumuloRunner.java   |   64 +-
 .../apache/accumulo/minicluster/ServerType.java    |    7 +-
 .../impl/MiniAccumuloClusterControl.java           |   16 +-
 .../minicluster/impl/MiniAccumuloClusterImpl.java  |  123 +-
 .../minicluster/impl/MiniAccumuloConfigImpl.java   |   76 +-
 .../minicluster/impl/ProcessReference.java         |    3 +-
 .../minicluster/impl/ZooKeeperBindException.java   |    3 +-
 .../standalone/StandaloneAccumuloClusterTest.java  |    6 +-
 .../standalone/StandaloneClusterControlTest.java   |   14 +-
 .../MiniAccumuloClusterExistingZooKeepersTest.java |   13 +-
 .../MiniAccumuloClusterStartStopTest.java          |    3 +-
 .../minicluster/MiniAccumuloClusterTest.java       |   20 +-
 .../minicluster/impl/CleanShutdownMacTest.java     |    6 +-
 .../impl/MiniAccumuloClusterImplTest.java          |   18 +-
 .../impl/MiniAccumuloConfigImplTest.java           |   15 +-
 pom.xml                                            |  157 ++-
 .../main/java/org/apache/accumulo/proxy/Proxy.java |   56 +-
 .../org/apache/accumulo/proxy/ProxyServer.java     |  806 ++++++++-----
 .../main/java/org/apache/accumulo/proxy/Util.java  |   15 +-
 .../org/apache/accumulo/proxy/ProxyServerTest.java |    6 +-
 .../java/org/apache/accumulo/server/Accumulo.java  |   87 +-
 .../accumulo/server/AccumuloServerContext.java     |   30 +-
 .../accumulo/server/GarbageCollectionLogger.java   |    9 +-
 .../apache/accumulo/server/ServerConstants.java    |   44 +-
 .../accumulo/server/client/BulkImporter.java       |  172 ++-
 .../server/client/ClientServiceHandler.java        |  178 +--
 .../accumulo/server/client/HdfsZooInstance.java    |   27 +-
 .../accumulo/server/conf/NamespaceConfWatcher.java |   13 +-
 .../server/conf/NamespaceConfiguration.java        |    9 +-
 .../server/conf/ServerConfigurationFactory.java    |   21 +-
 .../accumulo/server/conf/TableConfWatcher.java     |   10 +-
 .../accumulo/server/conf/TableConfiguration.java   |   15 +-
 .../server/conf/ZooCachePropertyAccessor.java      |   15 +-
 .../accumulo/server/conf/ZooConfiguration.java     |    6 +-
 .../server/conf/ZooConfigurationFactory.java       |   15 +-
 .../server/constraints/MetadataConstraints.java    |   60 +-
 .../accumulo/server/data/ServerColumnUpdate.java   |    3 +-
 .../accumulo/server/data/ServerMutation.java       |    6 +-
 .../org/apache/accumulo/server/fs/FileRef.java     |    8 +-
 .../accumulo/server/fs/PerTableVolumeChooser.java  |   20 +-
 .../accumulo/server/fs/PreferredVolumeChooser.java |   26 +-
 .../org/apache/accumulo/server/fs/ViewFSUtils.java |    6 +-
 .../apache/accumulo/server/fs/VolumeChooser.java   |    4 +-
 .../apache/accumulo/server/fs/VolumeManager.java   |   18 +-
 .../accumulo/server/fs/VolumeManagerImpl.java      |   64 +-
 .../org/apache/accumulo/server/fs/VolumeUtil.java  |   57 +-
 .../apache/accumulo/server/init/Initialize.java    |  330 ++++--
 .../server/iterators/MetadataBulkLoadFilter.java   |    3 +-
 .../apache/accumulo/server/log/SortedLogState.java |    5 +-
 .../accumulo/server/log/WalStateManager.java       |   44 +-
 .../accumulo/server/master/LiveTServerSet.java     |   81 +-
 .../master/balancer/ChaoticLoadBalancer.java       |   22 +-
 .../master/balancer/DefaultLoadBalancer.java       |   33 +-
 .../server/master/balancer/GroupBalancer.java      |   94 +-
 .../balancer/HostRegexTableLoadBalancer.java       |  126 ++-
 .../server/master/balancer/RegexGroupBalancer.java |   35 +-
 .../server/master/balancer/TableLoadBalancer.java  |   16 +-
 .../server/master/balancer/TabletBalancer.java     |   75 +-
 .../server/master/recovery/HadoopLogCloser.java    |    3 +-
 .../accumulo/server/master/state/CurrentState.java |    3 +-
 .../accumulo/server/master/state/MergeInfo.java    |    3 +-
 .../accumulo/server/master/state/MergeState.java   |    6 +-
 .../server/master/state/MetaDataStateStore.java    |   21 +-
 .../server/master/state/MetaDataTableScanner.java  |   20 +-
 .../server/master/state/RootTabletStateStore.java  |    3 +-
 .../server/master/state/TServerInstance.java       |    6 +-
 .../server/master/state/TabletLocationState.java   |   26 +-
 .../master/state/TabletStateChangeIterator.java    |    9 +-
 .../server/master/state/TabletStateStore.java      |   46 +-
 .../server/master/state/ZooTabletStateStore.java   |   21 +-
 .../master/tableOps/UserCompactionConfig.java      |    3 +-
 .../server/metrics/AbstractMetricsImpl.java        |   16 +-
 .../server/metrics/MetricsConfiguration.java       |   14 +-
 .../server/metrics/MetricsSystemHelper.java        |    3 +-
 .../accumulo/server/metrics/ThriftMetrics.java     |    3 +-
 .../accumulo/server/monitor/DedupedLogEvent.java   |    6 +-
 .../apache/accumulo/server/monitor/LogService.java |    6 +-
 .../accumulo/server/problems/ProblemReport.java    |   27 +-
 .../server/problems/ProblemReportingIterator.java  |   19 +-
 .../accumulo/server/problems/ProblemReports.java   |   34 +-
 .../DistributedWorkQueueWorkAssignerHelper.java    |   21 +-
 .../replication/PrintReplicationRecords.java       |    6 +-
 .../accumulo/server/replication/ReplicaSystem.java |    6 +-
 .../server/replication/ReplicaSystemFactory.java   |   15 +-
 .../server/replication/ReplicaSystemHelper.java    |   10 +-
 .../server/replication/ReplicationUtil.java        |   33 +-
 .../server/replication/StatusCombiner.java         |   20 +-
 .../server/replication/StatusFormatter.java        |   10 +-
 .../accumulo/server/replication/StatusUtil.java    |   15 +-
 .../replication/ZooKeeperInitialization.java       |    6 +-
 .../server/rpc/ClientInfoProcessorFactory.java     |    3 +-
 .../server/rpc/CustomNonBlockingServer.java        |   25 +-
 .../org/apache/accumulo/server/rpc/RpcWrapper.java |   36 +-
 .../server/rpc/SaslServerConnectionParams.java     |    9 +-
 .../rpc/SaslServerDigestCallbackHandler.java       |   12 +-
 .../rpc/TCredentialsUpdatingInvocationHandler.java |   66 +-
 .../server/rpc/TCredentialsUpdatingWrapper.java    |   13 +-
 .../apache/accumulo/server/rpc/TServerUtils.java   |  281 +++--
 .../accumulo/server/rpc/ThriftServerType.java      |   10 +-
 .../apache/accumulo/server/rpc/TimedProcessor.java |    6 +-
 .../accumulo/server/rpc/UGIAssumingProcessor.java  |    6 +-
 .../server/security/AuditedSecurityOperation.java  |  269 +++--
 .../server/security/SecurityOperation.java         |  386 ++++---
 .../accumulo/server/security/SecurityUtil.java     |   36 +-
 .../server/security/SystemCredentials.java         |   18 +-
 .../server/security/UserImpersonation.java         |   37 +-
 .../security/delegation/AuthenticationKey.java     |   12 +-
 .../delegation/AuthenticationTokenKeyManager.java  |   21 +-
 .../AuthenticationTokenSecretManager.java          |   36 +-
 .../ZooAuthenticationKeyDistributor.java           |   36 +-
 .../delegation/ZooAuthenticationKeyWatcher.java    |   24 +-
 .../server/security/handler/Authenticator.java     |   11 +-
 .../server/security/handler/Authorizor.java        |   14 +-
 .../security/handler/InsecureAuthenticator.java    |   14 +-
 .../security/handler/InsecurePermHandler.java      |   54 +-
 .../security/handler/KerberosAuthenticator.java    |   31 +-
 .../security/handler/KerberosAuthorizor.java       |   24 +-
 .../handler/KerberosPermissionHandler.java         |   91 +-
 .../server/security/handler/PermissionHandler.java |   59 +-
 .../server/security/handler/ZKAuthenticator.java   |   28 +-
 .../server/security/handler/ZKAuthorizor.java      |   19 +-
 .../server/security/handler/ZKPermHandler.java     |  132 ++-
 .../server/security/handler/ZKSecurityTool.java    |   16 +-
 .../accumulo/server/tables/TableManager.java       |  165 +--
 .../server/tablets/UniqueNameAllocator.java        |   26 +-
 .../tabletserver/LargestFirstMemoryManager.java    |   37 +-
 .../server/tabletserver/MemoryManager.java         |   14 +-
 .../accumulo/server/util/AccumuloStatus.java       |    3 +-
 .../org/apache/accumulo/server/util/Admin.java     |   96 +-
 .../apache/accumulo/server/util/ChangeSecret.java  |   28 +-
 .../server/util/CheckForMetadataProblems.java      |   18 +-
 .../accumulo/server/util/CleanZookeeper.java       |   10 +-
 .../apache/accumulo/server/util/DefaultMap.java    |    3 +-
 .../apache/accumulo/server/util/DumpZookeeper.java |   12 +-
 .../accumulo/server/util/FileSystemMonitor.java    |    6 +-
 .../org/apache/accumulo/server/util/FileUtil.java  |  150 ++-
 .../accumulo/server/util/FindOfflineTablets.java   |   18 +-
 .../apache/accumulo/server/util/ListInstances.java |   23 +-
 .../accumulo/server/util/ListVolumesUsed.java      |   18 +-
 .../apache/accumulo/server/util/LocalityCheck.java |    9 +-
 .../accumulo/server/util/LoginProperties.java      |   12 +-
 .../accumulo/server/util/MasterMetadataUtil.java   |   94 +-
 .../accumulo/server/util/MetadataTableUtil.java    |  282 +++--
 .../accumulo/server/util/NamespacePropUtil.java    |   21 +-
 .../apache/accumulo/server/util/RandomWriter.java  |    6 +-
 .../accumulo/server/util/RandomizeVolumes.java     |   17 +-
 .../server/util/RemoveEntriesForMissingFiles.java  |   17 +-
 .../accumulo/server/util/ReplicationTableUtil.java |   27 +-
 .../accumulo/server/util/RestoreZookeeper.java     |    6 +-
 .../accumulo/server/util/SendLogToChainsaw.java    |   33 +-
 .../accumulo/server/util/SystemPropUtil.java       |   27 +-
 .../accumulo/server/util/TableDiskUsage.java       |   18 +-
 .../apache/accumulo/server/util/TableInfoUtil.java |    3 +-
 .../apache/accumulo/server/util/TablePropUtil.java |   18 +-
 .../accumulo/server/util/TabletIterator.java       |   32 +-
 .../accumulo/server/util/TabletServerLocks.java    |    3 +-
 .../server/util/VerifyTabletAssignments.java       |   22 +-
 .../apache/accumulo/server/util/ZooKeeperMain.java |   12 +-
 .../org/apache/accumulo/server/util/ZooZap.java    |    6 +-
 .../server/util/time/BaseRelativeTime.java         |    3 +-
 .../accumulo/server/util/time/SimpleTimer.java     |   21 +-
 .../server/watcher/Log4jConfiguration.java         |    9 +-
 .../server/watcher/MonitorLog4jWatcher.java        |    3 +-
 .../server/zookeeper/DistributedWorkQueue.java     |   21 +-
 .../server/zookeeper/TransactionWatcher.java       |   21 +-
 .../apache/accumulo/server/zookeeper/ZooLock.java  |    3 +-
 .../accumulo/server/zookeeper/ZooQueueLock.java    |    3 +-
 .../accumulo/server/zookeeper/ZooReaderWriter.java |    3 +-
 .../server/zookeeper/ZooReaderWriterFactory.java   |    6 +-
 .../accumulo/server/AccumuloServerContextTest.java |   42 +-
 .../org/apache/accumulo/server/AccumuloTest.java   |   15 +-
 .../accumulo/server/ServerConstantsTest.java       |   51 +-
 .../accumulo/server/client/BulkImporterTest.java   |   52 +-
 .../server/conf/NamespaceConfigurationTest.java    |   29 +-
 .../conf/ServerConfigurationFactoryTest.java       |    3 +-
 .../server/conf/TableConfigurationTest.java        |   24 +-
 .../constraints/MetadataConstraintsTest.java       |   72 +-
 .../org/apache/accumulo/server/fs/FileRefTest.java |   72 +-
 .../apache/accumulo/server/fs/FileTypeTest.java    |   75 +-
 .../apache/accumulo/server/fs/ViewFSUtilsTest.java |   41 +-
 .../accumulo/server/fs/VolumeManagerImplTest.java  |    9 +-
 .../apache/accumulo/server/fs/VolumeUtilTest.java  |  153 +--
 .../accumulo/server/init/InitializeTest.java       |   12 +-
 .../iterators/MetadataBulkLoadFilterTest.java      |   31 +-
 .../accumulo/server/master/LiveTServerSetTest.java |    6 +-
 .../BaseHostRegexTableLoadBalancerTest.java        |   90 +-
 .../master/balancer/ChaoticLoadBalancerTest.java   |   18 +-
 .../master/balancer/DefaultLoadBalancerTest.java   |   29 +-
 .../server/master/balancer/GroupBalancerTest.java  |   56 +-
 ...tRegexTableLoadBalancerReconfigurationTest.java |   24 +-
 .../balancer/HostRegexTableLoadBalancerTest.java   |   74 +-
 .../master/balancer/TableLoadBalancerTest.java     |   26 +-
 .../server/master/state/MergeInfoTest.java         |    3 +-
 .../server/problems/ProblemReportTest.java         |   36 +-
 .../server/replication/ReplicationUtilTest.java    |    6 +-
 .../server/replication/StatusCombinerTest.java     |  114 +-
 .../server/replication/StatusUtilTest.java         |   15 +-
 .../replication/ZooKeeperInitializationTest.java   |   12 +-
 .../apache/accumulo/server/rpc/RpcWrapperTest.java |   21 +-
 .../server/rpc/SaslDigestCallbackHandlerTest.java  |   15 +-
 .../server/rpc/SaslServerConnectionParamsTest.java |    3 +-
 .../TCredentialsUpdatingInvocationHandlerTest.java |   63 +-
 .../accumulo/server/rpc/ThriftServerTypeTest.java  |    3 +-
 .../server/security/SystemCredentialsTest.java     |   27 +-
 .../server/security/UserImpersonationTest.java     |   18 +-
 .../security/delegation/AuthenticationKeyTest.java |    9 +-
 .../AuthenticationTokenKeyManagerTest.java         |   32 +-
 .../AuthenticationTokenSecretManagerTest.java      |   99 +-
 .../ZooAuthenticationKeyDistributorTest.java       |   74 +-
 .../ZooAuthenticationKeyWatcherTest.java           |   68 +-
 .../security/handler/ZKAuthenticatorTest.java      |    6 +-
 .../IllegalTableTransitionExceptionTest.java       |    6 +-
 .../org/apache/accumulo/server/util/AdminTest.java |   23 +-
 .../accumulo/server/util/DefaultMapTest.java       |    3 +-
 .../server/util/FileSystemMonitorTest.java         |   39 +-
 .../apache/accumulo/server/util/FileUtilTest.java  |   15 +-
 .../server/util/ReplicationTableUtilTest.java      |   21 +-
 .../accumulo/server/util/TServerUtilsTest.java     |   41 +-
 .../server/util/time/BaseRelativeTimeTest.java     |    3 +-
 .../accumulo/gc/GarbageCollectWriteAheadLogs.java  |   43 +-
 .../accumulo/gc/GarbageCollectionAlgorithm.java    |   60 +-
 .../accumulo/gc/GarbageCollectionEnvironment.java  |   37 +-
 .../apache/accumulo/gc/SimpleGarbageCollector.java |  154 ++-
 .../replication/CloseWriteAheadLogReferences.java  |   30 +-
 .../gc/GarbageCollectWriteAheadLogsTest.java       |   60 +-
 .../apache/accumulo/gc/GarbageCollectionTest.java  |   47 +-
 .../accumulo/gc/SimpleGarbageCollectorTest.java    |   30 +-
 .../apache/accumulo/master/FateServiceHandler.java |  248 ++--
 .../java/org/apache/accumulo/master/Master.java    |  346 ++++--
 .../master/MasterClientServiceHandler.java         |  152 ++-
 .../org/apache/accumulo/master/MasterTime.java     |   21 +-
 .../apache/accumulo/master/TabletGroupWatcher.java |  150 ++-
 .../master/metrics/Metrics2ReplicationMetrics.java |   23 +-
 .../master/metrics/ReplicationMetrics.java         |    4 +-
 .../master/metrics/ReplicationMetricsMBean.java    |   14 +-
 .../accumulo/master/recovery/RecoveryManager.java  |   34 +-
 .../DistributedWorkQueueWorkAssigner.java          |   30 +-
 .../master/replication/FinishedWorkUpdater.java    |   30 +-
 .../replication/MasterReplicationCoordinator.java  |   23 +-
 .../RemoveCompleteReplicationRecords.java          |   29 +-
 .../master/replication/ReplicationDriver.java      |    6 +-
 .../master/replication/SequentialWorkAssigner.java |   30 +-
 .../accumulo/master/replication/StatusMaker.java   |   34 +-
 .../master/replication/UnorderedWorkAssigner.java  |   26 +-
 .../accumulo/master/replication/WorkMaker.java     |    9 +-
 .../apache/accumulo/master/state/MergeStats.java   |   55 +-
 .../apache/accumulo/master/state/SetGoalState.java |    8 +-
 .../accumulo/master/tableOps/BulkImport.java       |   31 +-
 .../master/tableOps/CancelCompactions.java         |   13 +-
 .../accumulo/master/tableOps/ChangeTableState.java |    9 +-
 .../apache/accumulo/master/tableOps/ChooseDir.java |    6 +-
 .../apache/accumulo/master/tableOps/CleanUp.java   |   27 +-
 .../master/tableOps/CleanUpBulkImport.java         |    3 +-
 .../accumulo/master/tableOps/CloneMetadata.java    |   14 +-
 .../accumulo/master/tableOps/ClonePermissions.java |    9 +-
 .../accumulo/master/tableOps/CloneTable.java       |    6 +-
 .../accumulo/master/tableOps/CloneZookeeper.java   |    9 +-
 .../accumulo/master/tableOps/CompactRange.java     |   39 +-
 .../accumulo/master/tableOps/CompactionDriver.java |   28 +-
 .../accumulo/master/tableOps/CopyFailed.java       |   16 +-
 .../accumulo/master/tableOps/CreateImportDir.java  |    3 +-
 .../accumulo/master/tableOps/CreateNamespace.java  |    3 +-
 .../accumulo/master/tableOps/CreateTable.java      |    3 +-
 .../accumulo/master/tableOps/DeleteTable.java      |    3 +-
 .../accumulo/master/tableOps/ExportTable.java      |    3 +-
 .../master/tableOps/FinishCancelCompaction.java    |    3 +-
 .../accumulo/master/tableOps/FinishCloneTable.java |    9 +-
 .../master/tableOps/FinishCreateNamespace.java     |    3 +-
 .../master/tableOps/FinishCreateTable.java         |    3 +-
 .../master/tableOps/FinishImportTable.java         |    3 +-
 .../master/tableOps/ImportPopulateZookeeper.java   |   12 +-
 .../master/tableOps/ImportSetupPermissions.java    |    6 +-
 .../accumulo/master/tableOps/ImportTable.java      |    9 +-
 .../apache/accumulo/master/tableOps/LoadFiles.java |   18 +-
 .../master/tableOps/MapImportFileNames.java        |    3 +-
 .../master/tableOps/MoveExportedFiles.java         |    6 +-
 .../accumulo/master/tableOps/PopulateMetadata.java |    6 +-
 .../master/tableOps/PopulateMetadataTable.java     |   46 +-
 .../master/tableOps/PopulateZookeeper.java         |    6 +-
 .../tableOps/PopulateZookeeperWithNamespace.java   |   12 +-
 .../accumulo/master/tableOps/RenameNamespace.java  |   10 +-
 .../accumulo/master/tableOps/RenameTable.java      |   21 +-
 .../master/tableOps/SetupNamespacePermissions.java |    3 +-
 .../accumulo/master/tableOps/SetupPermissions.java |    6 +-
 .../accumulo/master/tableOps/TableRangeOp.java     |   10 +-
 .../accumulo/master/tableOps/TableRangeOpWait.java |   22 +-
 .../org/apache/accumulo/master/tableOps/Utils.java |   75 +-
 .../accumulo/master/tableOps/WriteExportFiles.java |   59 +-
 .../master/tserverOps/ShutdownTServer.java         |    6 +-
 .../org/apache/accumulo/master/util/FateAdmin.java |    5 +-
 .../accumulo/master/util/TableValidators.java      |   10 +-
 .../metrics/Metrics2ReplicationMetricsTest.java    |    3 +-
 ...DistributedWorkQueueWorkAssignerHelperTest.java |    3 +-
 .../replication/SequentialWorkAssignerTest.java    |   24 +-
 .../replication/UnorderedWorkAssignerTest.java     |   20 +-
 .../accumulo/master/replication/WorkMakerTest.java |    6 +-
 .../master/state/RootTabletStateStoreTest.java     |    3 +-
 .../accumulo/master/tableOps/ImportTableTest.java  |    9 +-
 .../apache/accumulo/monitor/EmbeddedWebServer.java |    9 +-
 .../java/org/apache/accumulo/monitor/Monitor.java  |   85 +-
 .../apache/accumulo/monitor/ZooKeeperStatus.java   |    6 +-
 .../accumulo/monitor/servlets/BasicServlet.java    |   76 +-
 .../monitor/servlets/BulkImportServlet.java        |   12 +-
 .../accumulo/monitor/servlets/DefaultServlet.java  |   47 +-
 .../accumulo/monitor/servlets/GcStatusServlet.java |   23 +-
 .../accumulo/monitor/servlets/JSONServlet.java     |   12 +-
 .../accumulo/monitor/servlets/LogServlet.java      |   13 +-
 .../accumulo/monitor/servlets/MasterServlet.java   |   80 +-
 .../monitor/servlets/OperationServlet.java         |   18 +-
 .../accumulo/monitor/servlets/ProblemServlet.java  |   35 +-
 .../monitor/servlets/ReplicationServlet.java       |   28 +-
 .../accumulo/monitor/servlets/ScanServlet.java     |    9 +-
 .../accumulo/monitor/servlets/ShellServlet.java    |   34 +-
 .../accumulo/monitor/servlets/TServersServlet.java |  157 ++-
 .../accumulo/monitor/servlets/TablesServlet.java   |   74 +-
 .../accumulo/monitor/servlets/VisServlet.java      |   51 +-
 .../accumulo/monitor/servlets/XMLServlet.java      |   32 +-
 .../accumulo/monitor/servlets/trace/Basic.java     |   21 +-
 .../accumulo/monitor/servlets/trace/ListType.java  |    6 +-
 .../accumulo/monitor/servlets/trace/ShowTrace.java |   25 +-
 .../monitor/servlets/trace/ShowTraceLinkType.java  |    3 +-
 .../accumulo/monitor/servlets/trace/Summary.java   |   15 +-
 .../org/apache/accumulo/monitor/util/Table.java    |   41 +-
 .../monitor/util/celltypes/CompactionsType.java    |    3 +-
 .../monitor/util/celltypes/DateTimeType.java       |    3 +-
 .../monitor/util/celltypes/NumberType.java         |   12 +-
 .../monitor/util/celltypes/TableLinkType.java      |    3 +-
 .../accumulo/monitor/ShowTraceLinkTypeTest.java    |    3 +-
 .../accumulo/monitor/ZooKeeperStatusTest.java      |    3 +-
 .../apache/accumulo/tracer/AsyncSpanReceiver.java  |    9 +-
 .../apache/accumulo/tracer/SendSpansViaThrift.java |    3 +-
 .../java/org/apache/accumulo/tracer/SpanTree.java  |    3 +-
 .../java/org/apache/accumulo/tracer/TraceDump.java |   19 +-
 .../org/apache/accumulo/tracer/TraceFormatter.java |    6 +-
 .../org/apache/accumulo/tracer/TraceServer.java    |   84 +-
 .../apache/accumulo/tracer/TraceTableStats.java    |   17 +-
 .../org/apache/accumulo/tracer/ZooTraceClient.java |    6 +-
 .../accumulo/tracer/AsyncSpanReceiverTest.java     |    9 +-
 .../org/apache/accumulo/tracer/TracerTest.java     |   16 +-
 .../apache/accumulo/tracer/ZooTraceClientTest.java |   12 +-
 .../accumulo/tserver/ActiveAssignmentRunnable.java |    9 +-
 .../apache/accumulo/tserver/CompactionQueue.java   |    6 +-
 .../accumulo/tserver/ConditionCheckerContext.java  |   30 +-
 .../accumulo/tserver/ConditionalMutationSet.java   |   15 +-
 .../org/apache/accumulo/tserver/FileManager.java   |   59 +-
 .../org/apache/accumulo/tserver/InMemoryMap.java   |   81 +-
 .../java/org/apache/accumulo/tserver/MemKey.java   |    3 +-
 .../accumulo/tserver/MemKeyConversionIterator.java |    3 +-
 .../java/org/apache/accumulo/tserver/MemValue.java |    3 +-
 .../org/apache/accumulo/tserver/NativeMap.java     |   93 +-
 .../java/org/apache/accumulo/tserver/RowLocks.java |    6 +-
 .../tserver/TConstraintViolationException.java     |    3 +-
 .../tserver/TabletIteratorEnvironment.java         |   32 +-
 .../org/apache/accumulo/tserver/TabletServer.java  |  751 ++++++++-----
 .../tserver/TabletServerResourceManager.java       |  110 +-
 .../accumulo/tserver/TservConstraintEnv.java       |    3 +-
 .../org/apache/accumulo/tserver/WriteTracker.java  |    7 +-
 .../tserver/compaction/CompactionPlan.java         |    7 +-
 .../tserver/compaction/CompactionStrategy.java     |   49 +-
 .../compaction/DefaultCompactionStrategy.java      |    3 +-
 .../compaction/EverythingCompactionStrategy.java   |    3 +-
 .../tserver/compaction/MajorCompactionReason.java  |    5 +-
 .../tserver/compaction/MajorCompactionRequest.java |    6 +-
 .../strategies/ConfigurableCompactionStrategy.java |   24 +-
 .../tserver/constraints/ConstraintChecker.java     |   15 +-
 .../tserver/data/ServerConditionalMutation.java    |    3 +-
 .../org/apache/accumulo/tserver/log/DfsLogger.java |  100 +-
 .../org/apache/accumulo/tserver/log/LogSorter.java |   22 +-
 .../apache/accumulo/tserver/log/MultiReader.java   |    8 +-
 .../accumulo/tserver/log/SortedLogRecovery.java    |   41 +-
 .../accumulo/tserver/log/TabletServerLogger.java   |   69 +-
 .../apache/accumulo/tserver/logger/LogEvents.java  |    7 +-
 .../apache/accumulo/tserver/logger/LogFileKey.java |    6 +-
 .../accumulo/tserver/logger/LogFileValue.java      |    8 +-
 .../apache/accumulo/tserver/logger/LogReader.java  |    6 +-
 .../tserver/mastermessage/MasterMessage.java       |    3 +-
 .../tserver/mastermessage/SplitReportMessage.java  |    6 +-
 .../tserver/mastermessage/TabletStatusMessage.java |    3 +-
 .../metrics/Metrics2TabletServerMetrics.java       |   46 +-
 .../metrics/Metrics2TabletServerMinCMetrics.java   |    6 +-
 .../metrics/Metrics2TabletServerScanMetrics.java   |    6 +-
 .../metrics/Metrics2TabletServerUpdateMetrics.java |   30 +-
 .../tserver/metrics/TabletServerMBeanImpl.java     |    4 +-
 .../metrics/TabletServerMetricsFactory.java        |    3 +-
 .../tserver/metrics/TabletServerMinCMetrics.java   |   10 +-
 .../tserver/metrics/TabletServerScanMetrics.java   |   10 +-
 .../tserver/metrics/TabletServerUpdateMetrics.java |   10 +-
 .../tserver/replication/AccumuloReplicaSystem.java |  209 ++--
 .../BatchWriterReplicationReplayer.java            |   41 +-
 .../tserver/replication/ReplicationProcessor.java  |   21 +-
 .../replication/ReplicationServicerHandler.java    |   23 +-
 .../tserver/replication/ReplicationWorker.java     |    9 +-
 .../apache/accumulo/tserver/scan/LookupTask.java   |   24 +-
 .../accumulo/tserver/scan/NextBatchTask.java       |   17 +-
 .../org/apache/accumulo/tserver/scan/ScanTask.java |    9 +-
 .../tserver/session/ConditionalSession.java        |    3 +-
 .../accumulo/tserver/session/MultiScanSession.java |    6 +-
 .../accumulo/tserver/session/ScanSession.java      |    5 +-
 .../accumulo/tserver/session/SessionManager.java   |   31 +-
 .../tserver/tablet/BulkImportCacheCleaner.java     |    3 +-
 .../accumulo/tserver/tablet/CompactionInfo.java    |    9 +-
 .../accumulo/tserver/tablet/CompactionRunner.java  |    3 +-
 .../accumulo/tserver/tablet/CompactionWatcher.java |   14 +-
 .../apache/accumulo/tserver/tablet/Compactor.java  |   51 +-
 .../accumulo/tserver/tablet/CountingIterator.java  |    3 +-
 .../accumulo/tserver/tablet/DatafileManager.java   |  116 +-
 .../tserver/tablet/MinorCompactionTask.java        |   23 +-
 .../accumulo/tserver/tablet/MinorCompactor.java    |   68 +-
 .../apache/accumulo/tserver/tablet/RootFiles.java  |   30 +-
 .../accumulo/tserver/tablet/ScanDataSource.java    |   53 +-
 .../accumulo/tserver/tablet/ScanOptions.java       |    6 +-
 .../apache/accumulo/tserver/tablet/Scanner.java    |   22 +-
 .../org/apache/accumulo/tserver/tablet/Tablet.java |  550 +++++----
 .../accumulo/tserver/tablet/TabletCommitter.java   |    5 +-
 .../apache/accumulo/tserver/tablet/TabletData.java |   13 +-
 .../accumulo/tserver/tablet/TabletMemory.java      |    3 +-
 .../accumulo/tserver/CheckTabletMetadataTest.java  |   24 +-
 .../apache/accumulo/tserver/InMemoryMapTest.java   |   55 +-
 .../tserver/LargestFirstMemoryManagerTest.java     |   84 +-
 .../tserver/TabletServerSyncCheckTest.java         |   12 +-
 .../accumulo/tserver/TservConstraintEnvTest.java   |    9 +-
 .../compaction/DefaultCompactionStrategyTest.java  |   24 +-
 .../SizeLimitCompactionStrategyTest.java           |   12 +-
 .../ConfigurableCompactionStrategyTest.java        |   15 +-
 .../apache/accumulo/tserver/log/DfsLoggerTest.java |   21 +-
 .../accumulo/tserver/log/MultiReaderTest.java      |    8 +-
 .../tserver/log/SortedLogRecoveryTest.java         |  215 ++--
 .../tserver/log/TestUpgradePathForWALogs.java      |   16 +-
 .../accumulo/tserver/logger/LogFileTest.java       |   11 +-
 .../replication/AccumuloReplicaSystemTest.java     |   66 +-
 .../BatchWriterReplicationReplayerTest.java        |    6 +-
 .../replication/ReplicationProcessorTest.java      |    6 +-
 .../tserver/tablet/DatafileManagerTest.java        |   27 +-
 .../accumulo/tserver/tablet/RootFilesTest.java     |   12 +-
 .../apache/accumulo/tserver/tablet/TabletTest.java |   12 +-
 .../main/java/org/apache/accumulo/shell/Shell.java |  251 +++--
 .../org/apache/accumulo/shell/ShellCompletor.java  |    3 +-
 .../org/apache/accumulo/shell/ShellOptionsJC.java  |   70 +-
 .../java/org/apache/accumulo/shell/ShellUtil.java  |    6 +-
 .../accumulo/shell/commands/AboutCommand.java      |    3 +-
 .../shell/commands/ActiveCompactionIterator.java   |   15 +-
 .../shell/commands/ActiveScanIterator.java         |   16 +-
 .../accumulo/shell/commands/AddAuthsCommand.java   |   12 +-
 .../accumulo/shell/commands/AddSplitsCommand.java  |    9 +-
 .../shell/commands/AuthenticateCommand.java        |    9 +-
 .../shell/commands/BulkImportListIterator.java     |    3 +-
 .../accumulo/shell/commands/ClearCommand.java      |    3 +-
 .../accumulo/shell/commands/CloneTableCommand.java |   20 +-
 .../accumulo/shell/commands/CompactCommand.java    |   83 +-
 .../accumulo/shell/commands/ConfigCommand.java     |   76 +-
 .../accumulo/shell/commands/ConstraintCommand.java |   40 +-
 .../shell/commands/CreateNamespaceCommand.java     |   12 +-
 .../shell/commands/CreateTableCommand.java         |   51 +-
 .../accumulo/shell/commands/CreateUserCommand.java |   11 +-
 .../apache/accumulo/shell/commands/DUCommand.java  |   24 +-
 .../accumulo/shell/commands/DebugCommand.java      |   12 +-
 .../shell/commands/DeleteAuthsCommand.java         |    9 +-
 .../accumulo/shell/commands/DeleteCommand.java     |   11 +-
 .../accumulo/shell/commands/DeleteIterCommand.java |   27 +-
 .../accumulo/shell/commands/DeleteManyCommand.java |   14 +-
 .../shell/commands/DeleteNamespaceCommand.java     |   12 +-
 .../accumulo/shell/commands/DeleteRowsCommand.java |   12 +-
 .../shell/commands/DeleteScanIterCommand.java      |   18 +-
 .../shell/commands/DeleteShellIterCommand.java     |    6 +-
 .../shell/commands/DeleteTableCommand.java         |    3 +-
 .../accumulo/shell/commands/DropUserCommand.java   |   12 +-
 .../accumulo/shell/commands/EGrepCommand.java      |   15 +-
 .../accumulo/shell/commands/ExecfileCommand.java   |    6 +-
 .../shell/commands/ExportTableCommand.java         |    8 +-
 .../accumulo/shell/commands/FateCommand.java       |   31 +-
 .../accumulo/shell/commands/FlushCommand.java      |    6 +-
 .../accumulo/shell/commands/FormatterCommand.java  |   19 +-
 .../accumulo/shell/commands/GetAuthsCommand.java   |    6 +-
 .../accumulo/shell/commands/GetGroupsCommand.java  |    9 +-
 .../accumulo/shell/commands/GetSplitsCommand.java  |   33 +-
 .../accumulo/shell/commands/GrantCommand.java      |   37 +-
 .../accumulo/shell/commands/GrepCommand.java       |   15 +-
 .../accumulo/shell/commands/HelpCommand.java       |   21 +-
 .../accumulo/shell/commands/HiddenCommand.java     |   15 +-
 .../accumulo/shell/commands/HistoryCommand.java    |    3 +-
 .../shell/commands/ImportDirectoryCommand.java     |   10 +-
 .../shell/commands/ImportTableCommand.java         |    5 +-
 .../accumulo/shell/commands/InsertCommand.java     |   20 +-
 .../shell/commands/InterpreterCommand.java         |    6 +-
 .../accumulo/shell/commands/ListBulkCommand.java   |    6 +-
 .../shell/commands/ListCompactionsCommand.java     |    7 +-
 .../accumulo/shell/commands/ListIterCommand.java   |   39 +-
 .../accumulo/shell/commands/ListScansCommand.java  |    6 +-
 .../shell/commands/ListShellIterCommand.java       |   12 +-
 .../accumulo/shell/commands/MaxRowCommand.java     |    7 +-
 .../accumulo/shell/commands/MergeCommand.java      |   16 +-
 .../commands/NamespacePermissionsCommand.java      |    3 +-
 .../accumulo/shell/commands/NamespacesCommand.java |   36 +-
 .../accumulo/shell/commands/NoTableCommand.java    |    3 +-
 .../accumulo/shell/commands/OfflineCommand.java    |    6 +-
 .../accumulo/shell/commands/OnlineCommand.java     |    6 +-
 .../apache/accumulo/shell/commands/OptUtil.java    |   16 +-
 .../accumulo/shell/commands/PasswdCommand.java     |   15 +-
 .../accumulo/shell/commands/PingCommand.java       |    3 +-
 .../shell/commands/QuotedStringTokenizer.java      |   12 +-
 .../shell/commands/RenameNamespaceCommand.java     |    8 +-
 .../shell/commands/RenameTableCommand.java         |    8 +-
 .../accumulo/shell/commands/RevokeCommand.java     |   37 +-
 .../accumulo/shell/commands/ScanCommand.java       |  133 ++-
 .../accumulo/shell/commands/ScriptCommand.java     |    6 +-
 .../accumulo/shell/commands/SetAuthsCommand.java   |   12 +-
 .../accumulo/shell/commands/SetGroupsCommand.java  |    3 +-
 .../accumulo/shell/commands/SetIterCommand.java    |  106 +-
 .../shell/commands/SetScanIterCommand.java         |   18 +-
 .../shell/commands/SetShellIterCommand.java        |   15 +-
 .../commands/ShellPluginConfigurationCommand.java  |   40 +-
 .../accumulo/shell/commands/SleepCommand.java      |    3 +-
 .../shell/commands/SystemPermissionsCommand.java   |    3 +-
 .../accumulo/shell/commands/TableCommand.java      |    7 +-
 .../accumulo/shell/commands/TableOperation.java    |   21 +-
 .../shell/commands/TablePermissionsCommand.java    |    3 +-
 .../accumulo/shell/commands/TablesCommand.java     |   38 +-
 .../accumulo/shell/commands/TraceCommand.java      |   15 +-
 .../accumulo/shell/commands/UserCommand.java       |    6 +-
 .../shell/commands/UserPermissionsCommand.java     |   12 +-
 .../accumulo/shell/commands/UsersCommand.java      |    3 +-
 .../accumulo/shell/commands/WhoAmICommand.java     |    3 +-
 .../accumulo/shell/format/DeleterFormatter.java    |    9 +-
 .../org/apache/accumulo/shell/mock/MockShell.java  |    8 +-
 .../org/apache/accumulo/shell/ShellConfigTest.java |   14 +-
 .../accumulo/shell/ShellSetInstanceTest.java       |   40 +-
 .../java/org/apache/accumulo/shell/ShellTest.java  |   44 +-
 .../org/apache/accumulo/shell/ShellUtilTest.java   |    6 +-
 .../shell/commands/CompactCommandTest.java         |    3 +-
 .../shell/commands/DeleteAuthsCommandTest.java     |    9 +-
 .../shell/commands/DeleteManyCommandTest.java      |    3 +-
 .../shell/commands/DeleteRowsCommandTest.java      |    3 +-
 .../shell/commands/DeleteTableCommandTest.java     |    3 +-
 .../accumulo/shell/commands/FlushCommandTest.java  |    3 +-
 .../shell/commands/HistoryCommandTest.java         |    6 +-
 .../accumulo/shell/commands/MergeCommandTest.java  |    3 +-
 .../accumulo/shell/commands/ScanCommandTest.java   |    3 +-
 .../shell/commands/SetIterCommandTest.java         |   25 +-
 .../shell/format/DeleterFormatterTest.java         |   18 +-
 .../main/java/org/apache/accumulo/start/Main.java  |   51 +-
 .../java/org/apache/accumulo/start/TestMain.java   |    5 +-
 .../start/classloader/AccumuloClassLoader.java     |   34 +-
 .../vfs/AccumuloReloadingVFSClassLoader.java       |   17 +-
 .../classloader/vfs/AccumuloVFSClassLoader.java    |   65 +-
 .../start/classloader/vfs/ContextManager.java      |    9 +-
 .../vfs/PostDelegatingVFSClassLoader.java          |    6 +-
 .../classloader/vfs/UniqueFileReplicator.java      |    3 +-
 .../accumulo/start/spi/KeywordExecutable.java      |   18 +-
 .../vfs/AccumuloReloadingVFSClassLoaderTest.java   |   76 +-
 .../vfs/AccumuloVFSClassLoaderTest.java            |   45 +-
 .../start/classloader/vfs/ContextManagerTest.java  |   12 +-
 .../accumulo/start/test/AccumuloDFSBase.java       |   10 +-
 .../accumulo/harness/AccumuloClusterHarness.java   |   79 +-
 .../apache/accumulo/harness/AccumuloITBase.java    |   28 +-
 .../harness/MiniClusterConfigurationCallback.java  |    3 +-
 .../accumulo/harness/MiniClusterHarness.java       |  113 +-
 .../accumulo/harness/SharedMiniClusterBase.java    |   55 +-
 .../org/apache/accumulo/harness/TestingKdc.java    |    9 +-
 .../conf/AccumuloClusterPropertyConfiguration.java |   18 +-
 .../conf/AccumuloMiniClusterConfiguration.java     |    6 +-
 .../StandaloneAccumuloClusterConfiguration.java    |   51 +-
 .../accumulo/test/ArbitraryTablePropertiesIT.java  |   12 +-
 .../org/apache/accumulo/test/AuditMessageIT.java   |  256 +++--
 .../accumulo/test/BadDeleteMarkersCreatedIT.java   |    6 +-
 .../accumulo/test/BatchWriterInTabletServerIT.java |   16 +-
 .../apache/accumulo/test/BatchWriterIterator.java  |   50 +-
 .../apache/accumulo/test/BulkImportDirectory.java  |   15 +-
 .../accumulo/test/BulkImportMonitoringIT.java      |    6 +-
 .../accumulo/test/BulkImportSequentialRowsIT.java  |   12 +-
 .../java/org/apache/accumulo/test/CleanWalIT.java  |    6 +-
 .../apache/accumulo/test/ClientSideIteratorIT.java |    6 +-
 .../java/org/apache/accumulo/test/CloneIT.java     |   30 +-
 .../accumulo/test/CompactionRateLimitingIT.java    |   10 +-
 .../apache/accumulo/test/ConditionalWriterIT.java  |  302 +++--
 .../test/ConfigurableMajorCompactionIT.java        |    3 +-
 .../org/apache/accumulo/test/CreateRFiles.java     |   11 +-
 .../apache/accumulo/test/CreateRandomRFile.java    |    3 +-
 .../test/CreateTableWithNewTableConfigIT.java      |   25 +-
 .../accumulo/test/DetectDeadTabletServersIT.java   |    3 +-
 .../org/apache/accumulo/test/DumpConfigIT.java     |   10 +-
 .../accumulo/test/EstimateInMemMapOverhead.java    |    6 +-
 .../org/apache/accumulo/test/ExistingMacIT.java    |   19 +-
 .../accumulo/test/FaultyConditionalWriter.java     |    6 +-
 .../org/apache/accumulo/test/FileArchiveIT.java    |   33 +-
 .../java/org/apache/accumulo/test/FindMaxIT.java   |   30 +-
 .../apache/accumulo/test/GarbageCollectWALIT.java  |    3 +-
 .../accumulo/test/GenerateSequentialRFile.java     |    6 +-
 .../apache/accumulo/test/GetFileInfoBulkIT.java    |    3 +-
 .../org/apache/accumulo/test/GetMasterStats.java   |    3 +-
 .../org/apache/accumulo/test/HardListIterator.java |   30 +-
 .../org/apache/accumulo/test/IMMLGBenchmark.java   |   19 +-
 .../org/apache/accumulo/test/ImportExportIT.java   |   27 +-
 .../org/apache/accumulo/test/InMemoryMapIT.java    |   83 +-
 .../accumulo/test/InMemoryMapMemoryUsageTest.java  |    3 +-
 .../accumulo/test/InterruptibleScannersIT.java     |    6 +-
 .../accumulo/test/IsolationAndDeepCopyIT.java      |    9 +-
 .../apache/accumulo/test/KeyValueEqualityIT.java   |   10 +-
 .../org/apache/accumulo/test/LargeSplitRowIT.java  |   48 +-
 .../java/org/apache/accumulo/test/LocatorIT.java   |   16 +-
 .../java/org/apache/accumulo/test/ManySplitIT.java |    3 +-
 .../test/MasterRepairsDualAssignmentIT.java        |    9 +-
 .../org/apache/accumulo/test/MemoryUsageTest.java  |    8 +-
 .../accumulo/test/MetaConstraintRetryIT.java       |    6 +-
 .../apache/accumulo/test/MetaGetsReadersIT.java    |    3 +-
 .../java/org/apache/accumulo/test/MetaSplitIT.java |    9 +-
 .../test/MissingWalHeaderCompletesRecoveryIT.java  |   33 +-
 .../accumulo/test/MultiTableBatchWriterIT.java     |   15 +-
 .../apache/accumulo/test/MultiTableRecoveryIT.java |    3 +-
 .../org/apache/accumulo/test/NamespacesIT.java     |  169 ++-
 .../accumulo/test/NativeMapConcurrencyTest.java    |    9 +-
 .../accumulo/test/NativeMapPerformanceTest.java    |   19 +-
 .../apache/accumulo/test/NativeMapStressTest.java  |   29 +-
 .../org/apache/accumulo/test/NullBatchWriter.java  |    3 +-
 .../org/apache/accumulo/test/OrIteratorIT.java     |   21 +-
 .../apache/accumulo/test/QueryMetadataTable.java   |    6 +-
 .../accumulo/test/RewriteTabletDirectoriesIT.java  |   24 +-
 .../java/org/apache/accumulo/test/SampleIT.java    |   53 +-
 .../org/apache/accumulo/test/ShellConfigIT.java    |   23 +-
 .../org/apache/accumulo/test/ShellServerIT.java    |  224 ++--
 .../org/apache/accumulo/test/SplitRecoveryIT.java  |    9 +-
 .../accumulo/test/TableConfigurationUpdateIT.java  |   10 +-
 .../apache/accumulo/test/TableOperationsIT.java    |   50 +-
 .../org/apache/accumulo/test/TestBinaryRows.java   |   38 +-
 .../java/org/apache/accumulo/test/TestIngest.java  |   50 +-
 .../apache/accumulo/test/TestMultiTableIngest.java |    9 +-
 .../apache/accumulo/test/TestRandomDeletes.java    |   19 +-
 .../apache/accumulo/test/TextMemoryUsageTest.java  |    4 +-
 .../org/apache/accumulo/test/TotalQueuedIT.java    |   17 +-
 .../test/TracerRecoversAfterOfflineTableIT.java    |    3 +-
 .../apache/accumulo/test/TransportCachingIT.java   |   12 +-
 .../java/org/apache/accumulo/test/UnusedWALIT.java |    6 +-
 .../accumulo/test/UserCompactionStrategyIT.java    |   57 +-
 .../java/org/apache/accumulo/test/UsersIT.java     |    9 +-
 .../org/apache/accumulo/test/VerifyIngest.java     |   40 +-
 .../accumulo/test/VerifySerialRecoveryIT.java      |    3 +-
 .../org/apache/accumulo/test/VolumeChooserIT.java  |   54 +-
 .../java/org/apache/accumulo/test/VolumeIT.java    |   77 +-
 .../org/apache/accumulo/test/WaitForBalanceIT.java |    9 +-
 .../org/apache/accumulo/test/WrongTabletTest.java  |    3 +-
 .../org/apache/accumulo/test/YieldScannersIT.java  |   30 +-
 .../test/categories/MiniClusterOnlyTests.java      |    3 +-
 .../accumulo/test/categories/PerformanceTests.java |    8 +-
 .../categories/StandaloneCapableClusterTests.java  |    4 +-
 .../accumulo/test/categories/SunnyDayTests.java    |    4 +-
 .../accumulo/test/categories/package-info.java     |    1 -
 .../test/continuous/ContinuousBatchWalker.java     |   12 +-
 .../accumulo/test/continuous/ContinuousIngest.java |   41 +-
 .../accumulo/test/continuous/ContinuousMoru.java   |   29 +-
 .../accumulo/test/continuous/ContinuousOpts.java   |   15 +-
 .../accumulo/test/continuous/ContinuousQuery.java  |    6 +-
 .../test/continuous/ContinuousScanner.java         |    9 +-
 .../test/continuous/ContinuousStatsCollector.java  |   37 +-
 .../accumulo/test/continuous/ContinuousUtil.java   |    6 +-
 .../accumulo/test/continuous/ContinuousVerify.java |   33 +-
 .../accumulo/test/continuous/ContinuousWalk.java   |    3 +-
 .../apache/accumulo/test/continuous/HistData.java  |    3 +-
 .../apache/accumulo/test/continuous/Histogram.java |    3 +-
 .../test/continuous/PrintScanTimeHistogram.java    |    3 +-
 .../accumulo/test/continuous/TimeBinner.java       |   26 +-
 .../test/continuous/UndefinedAnalyzer.java         |   39 +-
 .../test/examples/simple/dirlist/CountIT.java      |    6 +-
 .../simple/filedata/ChunkInputFormatIT.java        |   42 +-
 .../simple/filedata/ChunkInputStreamIT.java        |   18 +-
 .../accumulo/test/functional/AddSplitIT.java       |    3 +-
 .../accumulo/test/functional/AuthsIterator.java    |    3 +-
 .../accumulo/test/functional/BackupMasterIT.java   |    3 +-
 .../test/functional/BadIteratorMincIT.java         |    3 +-
 .../functional/BalanceAfterCommsFailureIT.java     |   16 +-
 .../BalanceInPresenceOfOfflineTableIT.java         |   21 +-
 .../accumulo/test/functional/BatchScanSplitIT.java |    6 +-
 .../test/functional/BatchWriterFlushIT.java        |   13 +-
 .../accumulo/test/functional/BigRootTabletIT.java  |    9 +-
 .../accumulo/test/functional/BloomFilterIT.java    |   30 +-
 .../accumulo/test/functional/BulkFileIT.java       |   18 +-
 .../apache/accumulo/test/functional/BulkIT.java    |   11 +-
 .../test/functional/BulkSplitOptimizationIT.java   |    9 +-
 .../accumulo/test/functional/ClassLoaderIT.java    |    9 +-
 .../apache/accumulo/test/functional/CleanUpIT.java |   14 +-
 .../accumulo/test/functional/CloneTestIT.java      |   25 +-
 .../accumulo/test/functional/CombinerIT.java       |    3 +-
 .../accumulo/test/functional/CompactionIT.java     |    3 +-
 .../accumulo/test/functional/ConcurrencyIT.java    |    8 +-
 .../test/functional/ConcurrentDeleteTableIT.java   |    3 +-
 .../test/functional/ConfigurableCompactionIT.java  |   21 +-
 .../test/functional/ConfigurableMacBase.java       |   32 +-
 .../accumulo/test/functional/ConstraintIT.java     |   66 +-
 .../accumulo/test/functional/CreateAndUseIT.java   |    3 +-
 .../accumulo/test/functional/CredentialsIT.java    |    6 +-
 .../test/functional/DeleteEverythingIT.java        |    6 +-
 .../apache/accumulo/test/functional/DeleteIT.java  |   15 +-
 .../accumulo/test/functional/DeleteRowsIT.java     |   10 +-
 .../accumulo/test/functional/DropModIter.java      |    6 +-
 .../accumulo/test/functional/DurabilityIT.java     |    3 +-
 .../test/functional/DynamicThreadPoolsIT.java      |    6 +-
 .../accumulo/test/functional/ExamplesIT.java       |  213 ++--
 .../test/functional/FunctionalTestUtils.java       |   33 +-
 .../test/functional/GarbageCollectorIT.java        |   20 +-
 .../test/functional/HalfDeadTServerIT.java         |   16 +-
 .../accumulo/test/functional/KerberosIT.java       |  222 ++--
 .../accumulo/test/functional/KerberosProxyIT.java  |  187 ++--
 .../test/functional/KerberosRenewalIT.java         |   44 +-
 .../accumulo/test/functional/LargeRowIT.java       |   18 +-
 .../test/functional/LateLastContactIT.java         |    3 +-
 .../accumulo/test/functional/LogicalTimeIT.java    |   62 +-
 .../accumulo/test/functional/MapReduceIT.java      |   13 +-
 .../test/functional/MasterAssignmentIT.java        |    9 +-
 .../apache/accumulo/test/functional/MaxOpenIT.java |    9 +-
 .../apache/accumulo/test/functional/MergeIT.java   |   64 +-
 .../test/functional/MetadataMaxFilesIT.java        |    3 +-
 .../accumulo/test/functional/MetadataSplitIT.java  |    3 +-
 .../accumulo/test/functional/MonitorLoggingIT.java |   15 +-
 .../accumulo/test/functional/MonitorSslIT.java     |   30 +-
 .../accumulo/test/functional/NativeMapIT.java      |   47 +-
 .../accumulo/test/functional/PermissionsIT.java    |  203 ++--
 .../accumulo/test/functional/ReadWriteIT.java      |  136 ++-
 .../test/functional/RecoveryWithEmptyRFileIT.java  |   14 +-
 .../test/functional/RegexGroupBalanceIT.java       |   19 +-
 .../apache/accumulo/test/functional/RestartIT.java |   37 +-
 .../accumulo/test/functional/RestartStressIT.java  |    8 +-
 .../apache/accumulo/test/functional/ScanIdIT.java  |   59 +-
 .../accumulo/test/functional/ScanIteratorIT.java   |   28 +-
 .../accumulo/test/functional/ScanRangeIT.java      |   18 +-
 .../test/functional/ScanSessionTimeOutIT.java      |    3 +-
 .../accumulo/test/functional/ScannerContextIT.java |   24 +-
 .../apache/accumulo/test/functional/ScannerIT.java |    6 +-
 .../test/functional/SessionBlockVerifyIT.java      |   19 +-
 .../test/functional/SessionDurabilityIT.java       |    6 +-
 .../accumulo/test/functional/ShutdownIT.java       |   28 +-
 .../test/functional/SimpleBalancerFairnessIT.java  |   10 +-
 .../accumulo/test/functional/SlowIterator.java     |    6 +-
 .../test/functional/SparseColumnFamilyIT.java      |    3 +-
 .../apache/accumulo/test/functional/SplitIT.java   |   16 +-
 .../accumulo/test/functional/SplitRecoveryIT.java  |   75 +-
 .../org/apache/accumulo/test/functional/SslIT.java |   13 +-
 .../test/functional/TableChangeStateIT.java        |   93 +-
 .../apache/accumulo/test/functional/TabletIT.java  |    6 +-
 .../functional/TabletStateChangeIteratorIT.java    |   64 +-
 .../apache/accumulo/test/functional/TimeoutIT.java |    3 +-
 .../accumulo/test/functional/VisibilityIT.java     |   27 +-
 .../accumulo/test/functional/WALSunnyDayIT.java    |   21 +-
 .../test/functional/WatchTheWatchCountIT.java      |    6 +-
 .../accumulo/test/functional/WriteLotsIT.java      |    3 +-
 .../accumulo/test/functional/YieldingIterator.java |   30 +-
 .../accumulo/test/functional/ZombieTServer.java    |   26 +-
 .../accumulo/test/functional/ZooCacheIT.java       |    6 +-
 .../CloseWriteAheadLogReferencesIT.java            |   45 +-
 .../test/mapred/AccumuloFileOutputFormatIT.java    |   21 +-
 .../test/mapred/AccumuloInputFormatIT.java         |   19 +-
 .../mapred/AccumuloMultiTableInputFormatIT.java    |    9 +-
 .../test/mapred/AccumuloOutputFormatIT.java        |   18 +-
 .../test/mapred/AccumuloRowInputFormatIT.java      |   18 +-
 .../apache/accumulo/test/mapred/TokenFileIT.java   |   12 +-
 .../test/mapreduce/AccumuloFileOutputFormatIT.java |   33 +-
 .../test/mapreduce/AccumuloInputFormatIT.java      |   88 +-
 .../mapreduce/AccumuloMultiTableInputFormatIT.java |   12 +-
 .../test/mapreduce/AccumuloOutputFormatIT.java     |    9 +-
 .../test/mapreduce/AccumuloRowInputFormatIT.java   |   21 +-
 .../accumulo/test/mapreduce/TokenFileIT.java       |   12 +-
 .../apache/accumulo/test/master/MergeStateIT.java  |   32 +-
 .../accumulo/test/master/SuspendedTabletsIT.java   |   47 +-
 .../test/mrit/IntegrationTestMapReduce.java        |   19 +-
 .../accumulo/test/performance/NullTserver.java     |  101 +-
 .../test/performance/RollWALPerformanceIT.java     |    5 +-
 .../performance/metadata/FastBulkImportIT.java     |    3 +-
 .../metadata/MetadataBatchScanTest.java            |   19 +-
 .../test/performance/scan/CollectTabletStats.java  |   84 +-
 .../accumulo/test/proxy/ProxyDurabilityIT.java     |    9 +-
 .../accumulo/test/proxy/SimpleProxyBase.java       |  531 +++++----
 .../accumulo/test/proxy/TestProxyClient.java       |   17 +-
 .../test/proxy/TestProxyInstanceOperations.java    |   10 +-
 .../test/proxy/TestProxyNamespaceOperations.java   |   40 +-
 .../accumulo/test/proxy/TestProxyReadWrite.java    |   60 +-
 .../test/proxy/TestProxySecurityOperations.java    |   26 +-
 .../test/proxy/TestProxyTableOperations.java       |   24 +-
 .../accumulo/test/randomwalk/Environment.java      |   24 +-
 .../apache/accumulo/test/randomwalk/Framework.java |    9 +-
 .../apache/accumulo/test/randomwalk/Module.java    |   27 +-
 .../org/apache/accumulo/test/randomwalk/Node.java  |    4 +-
 .../org/apache/accumulo/test/randomwalk/State.java |    3 +-
 .../test/randomwalk/bulk/BulkImportTest.java       |   20 +-
 .../accumulo/test/randomwalk/bulk/BulkPlusOne.java |   16 +-
 .../accumulo/test/randomwalk/bulk/Compact.java     |    3 +-
 .../test/randomwalk/bulk/ConsistencyCheck.java     |    6 +-
 .../accumulo/test/randomwalk/bulk/Merge.java       |    6 +-
 .../test/randomwalk/bulk/SelectiveBulkTest.java    |    6 +-
 .../test/randomwalk/bulk/SelectiveQueueing.java    |    3 +-
 .../accumulo/test/randomwalk/bulk/Split.java       |    3 +-
 .../accumulo/test/randomwalk/bulk/Verify.java      |    6 +-
 .../test/randomwalk/concurrent/Apocalypse.java     |    3 +-
 .../test/randomwalk/concurrent/BulkImport.java     |   15 +-
 .../concurrent/ChangeAuthorizations.java           |    3 +-
 .../randomwalk/concurrent/ChangePermissions.java   |    9 +-
 .../randomwalk/concurrent/CheckPermission.java     |    9 +-
 .../test/randomwalk/concurrent/CloneTable.java     |    6 +-
 .../test/randomwalk/concurrent/Compact.java        |    9 +-
 .../randomwalk/concurrent/ConcurrentFixture.java   |    6 +-
 .../test/randomwalk/concurrent/Config.java         |   39 +-
 .../test/randomwalk/concurrent/IsolatedScan.java   |    3 +-
 .../accumulo/test/randomwalk/concurrent/Merge.java |    6 +-
 .../test/randomwalk/concurrent/Replication.java    |    6 +-
 .../test/randomwalk/concurrent/Shutdown.java       |    3 +-
 .../test/randomwalk/concurrent/StartAll.java       |    9 +-
 .../randomwalk/concurrent/StopTabletServer.java    |    6 +-
 .../test/randomwalk/conditional/Setup.java         |    6 +-
 .../test/randomwalk/conditional/Transfer.java      |    6 +-
 .../test/randomwalk/conditional/Verify.java        |    6 +-
 .../accumulo/test/randomwalk/image/Commit.java     |    3 +-
 .../test/randomwalk/image/ImageFixture.java        |    6 +-
 .../accumulo/test/randomwalk/image/ScanMeta.java   |    6 +-
 .../accumulo/test/randomwalk/image/Verify.java     |    3 +-
 .../accumulo/test/randomwalk/image/Write.java      |    6 +-
 .../test/randomwalk/multitable/CopyTool.java       |   21 +-
 .../randomwalk/multitable/MultiTableFixture.java   |    3 +-
 .../test/randomwalk/security/AlterTable.java       |   19 +-
 .../test/randomwalk/security/AlterTablePerm.java   |   26 +-
 .../test/randomwalk/security/Authenticate.java     |   20 +-
 .../test/randomwalk/security/ChangePass.java       |   10 +-
 .../test/randomwalk/security/CreateTable.java      |   13 +-
 .../test/randomwalk/security/CreateUser.java       |   13 +-
 .../test/randomwalk/security/DropTable.java        |   10 +-
 .../test/randomwalk/security/DropUser.java         |   10 +-
 .../test/randomwalk/security/SecurityFixture.java  |    6 +-
 .../test/randomwalk/security/SecurityHelper.java   |    9 +-
 .../test/randomwalk/security/SetAuths.java         |   10 +-
 .../accumulo/test/randomwalk/security/TableOp.java |   73 +-
 .../test/randomwalk/security/Validate.java         |   41 +-
 .../test/randomwalk/security/WalkingSecurity.java  |   88 +-
 .../test/randomwalk/sequential/BatchVerify.java    |   12 +-
 .../test/randomwalk/sequential/Commit.java         |    3 +-
 .../randomwalk/sequential/MapRedVerifyTool.java    |   27 +-
 .../randomwalk/sequential/SequentialFixture.java   |    6 +-
 .../accumulo/test/randomwalk/shard/BulkInsert.java |   28 +-
 .../accumulo/test/randomwalk/shard/CloneIndex.java |    6 +-
 .../test/randomwalk/shard/CompactFilter.java       |   12 +-
 .../accumulo/test/randomwalk/shard/Delete.java     |    3 +-
 .../test/randomwalk/shard/DeleteSomeDocs.java      |    6 +-
 .../accumulo/test/randomwalk/shard/DeleteWord.java |    6 +-
 .../test/randomwalk/shard/ExportIndex.java         |   31 +-
 .../accumulo/test/randomwalk/shard/Grep.java       |   14 +-
 .../accumulo/test/randomwalk/shard/Insert.java     |   17 +-
 .../accumulo/test/randomwalk/shard/Merge.java      |    3 +-
 .../accumulo/test/randomwalk/shard/Reindex.java    |    3 +-
 .../accumulo/test/randomwalk/shard/Search.java     |    9 +-
 .../test/randomwalk/shard/ShardFixture.java        |   12 +-
 .../accumulo/test/randomwalk/shard/Split.java      |    3 +-
 .../test/randomwalk/shard/VerifyIndex.java         |    9 +-
 .../test/replication/CyclicReplicationIT.java      |   88 +-
 .../test/replication/FinishedWorkUpdaterIT.java    |   55 +-
 ...GarbageCollectorCommunicatesWithTServersIT.java |   85 +-
 .../test/replication/KerberosReplicationIT.java    |   32 +-
 .../test/replication/MockReplicaSystem.java        |   19 +-
 .../replication/MultiInstanceReplicationIT.java    |  191 ++--
 .../replication/MultiTserverReplicationIT.java     |    9 +-
 .../RemoveCompleteReplicationRecordsIT.java        |   45 +-
 .../accumulo/test/replication/ReplicationIT.java   |  255 +++--
 .../replication/ReplicationOperationsImplIT.java   |   48 +-
 .../test/replication/SequentialWorkAssignerIT.java |   75 +-
 .../test/replication/StatusCombinerMacIT.java      |   12 +-
 .../accumulo/test/replication/StatusMakerIT.java   |   47 +-
 .../test/replication/UnorderedWorkAssignerIT.java  |   36 +-
 .../UnorderedWorkAssignerReplicationIT.java        |  191 ++--
 .../UnusedWalDoesntCloseReplicationStatusIT.java   |   27 +-
 .../accumulo/test/replication/WorkMakerIT.java     |   36 +-
 .../test/replication/merkle/MerkleTree.java        |    7 +-
 .../test/replication/merkle/MerkleTreeNode.java    |   15 +-
 .../test/replication/merkle/cli/CompareTables.java |   36 +-
 .../replication/merkle/cli/ComputeRootHash.java    |   17 +-
 .../replication/merkle/cli/GenerateHashes.java     |   49 +-
 .../replication/merkle/cli/ManualComparison.java   |    7 +-
 .../replication/merkle/ingest/RandomWorkload.java  |   19 +-
 .../test/replication/merkle/package-info.java      |   33 +-
 .../replication/merkle/skvi/DigestIterator.java    |   15 +-
 .../apache/accumulo/test/scalability/Ingest.java   |    7 +-
 .../org/apache/accumulo/test/scalability/Run.java  |   10 +-
 .../accumulo/test/scalability/ScaleTest.java       |    8 +-
 .../test/server/security/SystemCredentialsIT.java  |   39 +-
 .../apache/accumulo/test/start/KeywordStartIT.java |   18 +-
 .../test/stress/random/RandomMutations.java        |    8 +-
 .../apache/accumulo/test/stress/random/Scan.java   |   15 +-
 .../accumulo/test/stress/random/ScanOpts.java      |    6 +-
 .../apache/accumulo/test/stress/random/Stream.java |    3 +-
 .../apache/accumulo/test/stress/random/Write.java  |   30 +-
 .../accumulo/test/stress/random/WriteOptions.java  |   42 +-
 .../accumulo/test/stress/random/package-info.java  |   30 +-
 .../org/apache/accumulo/test/util/CertUtils.java   |  103 +-
 .../accumulo/test/util/SerializationUtil.java      |   17 +-
 .../test/TraceRepoDeserializationTest.java         |   21 +-
 .../accumulo/test/fate/zookeeper/ZooLockTest.java  |   36 +-
 .../test/functional/ValueReversingIterator.java    |    6 +-
 .../accumulo/test/iterator/AgeOffFilterTest.java   |   21 +-
 .../test/iterator/CfCqSliceFilterTest.java         |   23 +-
 .../apache/accumulo/test/iterator/RegExTest.java   |    9 +-
 .../test/iterator/SummingCombinerTest.java         |    6 +-
 .../test/iterator/WholeRowIteratorTest.java        |    6 +-
 .../accumulo/test/randomwalk/FrameworkTest.java    |    9 +-
 .../apache/accumulo/test/util/CertUtilsTest.java   |   24 +-
 .../accumulo/trace/instrument/CloudtraceSpan.java  |   10 +-
 .../accumulo/trace/instrument/CountSampler.java    |    3 +-
 .../apache/accumulo/trace/instrument/Tracer.java   |    8 +-
 1559 files changed, 31152 insertions(+), 17158 deletions(-)

-- 
To stop receiving notification emails like this one, please contact
ctubbsii@apache.org.

[accumulo] 01/05: POM updates for formatting (#416)

Posted by ct...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

ctubbsii pushed a commit to branch 1.8
in repository https://gitbox.apache.org/repos/asf/accumulo.git

commit fc20be34d6984114e7240c4eba276a3fe87a347b
Author: Christopher Tubbs <ct...@apache.org>
AuthorDate: Fri Apr 6 00:00:39 2018 -0400

    POM updates for formatting (#416)
    
    * Update to formatter-maven-plugin 2.7.2
    * Update sortpom version
    * Simplify formatting plugin profiles which require jdk8
    * Use 100 character line limit
    * Update ciManagement and issueManagement sections for next release
    * Include rule to ignore @link/@see tags in javadocs
    * Ignore long 'new *Map<>' lines, because they tend to be long with
      generics
---
 contrib/Eclipse-Accumulo-Codestyle.xml |   4 +-
 pom.xml                                | 157 +++++++++++++++------------------
 2 files changed, 73 insertions(+), 88 deletions(-)

diff --git a/contrib/Eclipse-Accumulo-Codestyle.xml b/contrib/Eclipse-Accumulo-Codestyle.xml
index 42e03bf..3b04c4d 100644
--- a/contrib/Eclipse-Accumulo-Codestyle.xml
+++ b/contrib/Eclipse-Accumulo-Codestyle.xml
@@ -90,7 +90,7 @@
 <setting id="org.eclipse.jdt.core.formatter.insert_space_before_opening_angle_bracket_in_type_parameters" value="do not insert"/>
 <setting id="org.eclipse.jdt.core.formatter.comment.clear_blank_lines_in_block_comment" value="false"/>
 <setting id="org.eclipse.jdt.core.formatter.insert_new_line_in_empty_type_declaration" value="do not insert"/>
-<setting id="org.eclipse.jdt.core.formatter.lineSplit" value="160"/>
+<setting id="org.eclipse.jdt.core.formatter.lineSplit" value="100"/>
 <setting id="org.eclipse.jdt.core.formatter.insert_space_before_opening_paren_in_if" value="insert"/>
 <setting id="org.eclipse.jdt.core.formatter.insert_space_between_brackets_in_array_type_reference" value="do not insert"/>
 <setting id="org.eclipse.jdt.core.formatter.insert_space_after_opening_paren_in_parenthesized_expression" value="do not insert"/>
@@ -221,7 +221,7 @@
 <setting id="org.eclipse.jdt.core.formatter.insert_new_line_before_while_in_do_statement" value="do not insert"/>
 <setting id="org.eclipse.jdt.core.formatter.alignment_for_arguments_in_enum_constant" value="16"/>
 <setting id="org.eclipse.jdt.core.formatter.comment.format_javadoc_comments" value="true"/>
-<setting id="org.eclipse.jdt.core.formatter.comment.line_length" value="160"/>
+<setting id="org.eclipse.jdt.core.formatter.comment.line_length" value="100"/>
 <setting id="org.eclipse.jdt.core.formatter.insert_new_line_after_annotation_on_package" value="insert"/>
 <setting id="org.eclipse.jdt.core.formatter.blank_lines_between_import_groups" value="1"/>
 <setting id="org.eclipse.jdt.core.formatter.insert_space_before_comma_in_enum_constant_arguments" value="do not insert"/>
diff --git a/pom.xml b/pom.xml
index 44273de..f4b46bb 100644
--- a/pom.xml
+++ b/pom.xml
@@ -105,12 +105,12 @@
     <url>https://gitbox.apache.org/repos/asf?p=accumulo.git</url>
   </scm>
   <issueManagement>
-    <system>JIRA</system>
-    <url>https://issues.apache.org/jira/browse/ACCUMULO</url>
+    <system>GitHub Issues</system>
+    <url>https://github.com/apache/accumulo/issues</url>
   </issueManagement>
   <ciManagement>
-    <system>Apache Jenkins</system>
-    <url>https://builds.apache.org/view/A/view/Accumulo/</url>
+    <system>Travis CI</system>
+    <url>https://travis-ci.org/apache/accumulo</url>
   </ciManagement>
   <properties>
     <!-- used for filtering the java source with the current version -->
@@ -610,8 +610,7 @@
         <plugin>
           <groupId>com.github.ekryd.sortpom</groupId>
           <artifactId>sortpom-maven-plugin</artifactId>
-          <!-- version 2.4.0 is the last version which supports Java 7 -->
-          <version>2.4.0</version>
+          <version>2.8.0</version>
           <configuration>
             <predefinedSortOrder>recommended_2008_06</predefinedSortOrder>
             <createBackupFile>false</createBackupFile>
@@ -705,7 +704,7 @@
           <groupId>org.apache.maven.plugins</groupId>
           <artifactId>maven-release-plugin</artifactId>
           <configuration>
-            <arguments>-P !autoformat,!autoformat-with-jdk8,thrift,sunny -Dtimeout.factor=2 ${extraReleaseArgs}</arguments>
+            <arguments>-P !autoformat,thrift,sunny -Dtimeout.factor=2 ${extraReleaseArgs}</arguments>
             <autoVersionSubmodules>true</autoVersionSubmodules>
             <goals>clean deploy</goals>
             <preparationGoals>clean verify</preparationGoals>
@@ -812,10 +811,24 @@
           <version>1.2.0</version>
         </plugin>
         <plugin>
-          <groupId>com.googlecode.maven-java-formatter-plugin</groupId>
-          <artifactId>maven-java-formatter-plugin</artifactId>
-          <version>0.4</version>
+          <groupId>org.apache.rat</groupId>
+          <artifactId>apache-rat-plugin</artifactId>
           <configuration>
+            <excludes combine.children="append">
+              <exclude>src/main/resources/META-INF/services/*</exclude>
+              <exclude>nbproject/**</exclude>
+              <exclude>nb-configuration.xml</exclude>
+              <exclude>nbactions.xml</exclude>
+            </excludes>
+          </configuration>
+        </plugin>
+        <plugin>
+          <!-- this plugin requires java 1.8 and should only be used in a jdk8 profile -->
+          <groupId>net.revelc.code.formatter</groupId>
+          <artifactId>formatter-maven-plugin</artifactId>
+          <version>2.7.2</version>
+          <configuration>
+            <configFile>${eclipseFormatterStyle}</configFile>
             <compilerCompliance>${maven.compiler.source}</compilerCompliance>
             <compilerSource>${maven.compiler.source}</compilerSource>
             <compilerTargetPlatform>${maven.compiler.target}</compilerTargetPlatform>
@@ -825,33 +838,11 @@
             </excludes>
             <lineEnding>LF</lineEnding>
             <overrideConfigCompilerVersion>true</overrideConfigCompilerVersion>
-          </configuration>
-          <dependencies>
-            <dependency>
-              <groupId>org.eclipse.tycho</groupId>
-              <artifactId>org.eclipse.jdt.core</artifactId>
-              <version>3.10.0.v20140604-1726</version>
-            </dependency>
-          </dependencies>
-          <executions>
-            <execution>
-              <id>format-java-source</id>
-              <goals>
-                <goal>format</goal>
-              </goals>
-            </execution>
-          </executions>
-        </plugin>
-        <plugin>
-          <groupId>org.apache.rat</groupId>
-          <artifactId>apache-rat-plugin</artifactId>
-          <configuration>
-            <excludes combine.children="append">
-              <exclude>src/main/resources/META-INF/services/*</exclude>
-              <exclude>nbproject/**</exclude>
-              <exclude>nb-configuration.xml</exclude>
-              <exclude>nbactions.xml</exclude>
-            </excludes>
+            <skipJsFormatting>true</skipJsFormatting>
+            <skipHtmlFormatting>true</skipHtmlFormatting>
+            <skipXmlFormatting>true</skipXmlFormatting>
+            <skipJsonFormatting>true</skipJsonFormatting>
+            <skipCssFormatting>true</skipCssFormatting>
           </configuration>
         </plugin>
         <plugin>
@@ -866,6 +857,12 @@
             </excludes>
           </configuration>
         </plugin>
+        <plugin>
+          <!-- this plugin requires java 1.8 and should only be used in a jdk8 profile -->
+          <groupId>net.revelc.code</groupId>
+          <artifactId>warbucks-maven-plugin</artifactId>
+          <version>1.0.0</version>
+        </plugin>
       </plugins>
     </pluginManagement>
     <plugins>
@@ -882,20 +879,6 @@
         </executions>
       </plugin>
       <plugin>
-        <!-- verify before compile; should be sorted already -->
-        <groupId>com.github.ekryd.sortpom</groupId>
-        <artifactId>sortpom-maven-plugin</artifactId>
-        <executions>
-          <execution>
-            <id>verify-sorted-pom</id>
-            <goals>
-              <goal>verify</goal>
-            </goals>
-            <phase>process-resources</phase>
-          </execution>
-        </executions>
-      </plugin>
-      <plugin>
         <groupId>org.apache.maven.plugins</groupId>
         <artifactId>maven-enforcer-plugin</artifactId>
         <executions>
@@ -991,9 +974,8 @@
                 </module>
                 <module name="OuterTypeFilename" />
                 <module name="LineLength">
-                  <!-- needs extra, because Eclipse formatter ignores the ending left brace -->
-                  <property name="max" value="200" />
-                  <property name="ignorePattern" value="^package.*|^import.*|a href|href|http://|https://|ftp://" />
+                  <property name="max" value="100" />
+                  <property name="ignorePattern" value="^[ ]*[*].*@(link|see) |Map.* = new .*Map|a href=|http://|https://|ftp://" />
                 </module>
                 <module name="AvoidStarImport" />
                 <module name="UnusedImports">
@@ -1165,8 +1147,8 @@
                     </pluginExecution>
                     <pluginExecution>
                       <pluginExecutionFilter>
-                        <groupId>com.googlecode.maven-java-formatter-plugin</groupId>
-                        <artifactId>maven-java-formatter-plugin</artifactId>
+                        <groupId>net.revelc.code.formatter</groupId>
+                        <artifactId>formatter-maven-plugin</artifactId>
                         <versionRange>[0,)</versionRange>
                         <goals>
                           <goal>format</goal>
@@ -1389,9 +1371,11 @@
       </build>
     </profile>
     <profile>
+      <!-- this profile requires jdk8 -->
       <!-- on by default, but disable with '-P !autoformat' or '-DskipFormat' -->
       <id>autoformat</id>
       <activation>
+        <jdk>[1.8,1.9)</jdk>
         <property>
           <name>!skipFormat</name>
         </property>
@@ -1412,32 +1396,17 @@
             </executions>
           </plugin>
           <plugin>
-            <groupId>com.googlecode.maven-java-formatter-plugin</groupId>
-            <artifactId>maven-java-formatter-plugin</artifactId>
-            <configuration>
-              <configFile>${eclipseFormatterStyle}</configFile>
-            </configuration>
+            <groupId>net.revelc.code.formatter</groupId>
+            <artifactId>formatter-maven-plugin</artifactId>
+            <executions>
+              <execution>
+                <id>format-java-source</id>
+                <goals>
+                  <goal>format</goal>
+                </goals>
+              </execution>
+            </executions>
           </plugin>
-        </plugins>
-      </build>
-    </profile>
-    <profile>
-      <!-- Minimal testing profile. (a.k.a. SunnyDay) -->
-      <id>sunny</id>
-      <properties>
-        <failsafe.groups>org.apache.accumulo.test.categories.SunnyDayTests</failsafe.groups>
-      </properties>
-    </profile>
-    <profile>
-      <id>autoformat-with-jdk8</id>
-      <activation>
-        <jdk>[1.8,1.9)</jdk>
-        <property>
-          <name>!skipFormat</name>
-        </property>
-      </activation>
-      <build>
-        <plugins>
           <plugin>
             <groupId>net.revelc.code</groupId>
             <artifactId>impsort-maven-plugin</artifactId>
@@ -1454,6 +1423,13 @@
       </build>
     </profile>
     <profile>
+      <!-- Minimal testing profile. (a.k.a. SunnyDay) -->
+      <id>sunny</id>
+      <properties>
+        <failsafe.groups>org.apache.accumulo.test.categories.SunnyDayTests</failsafe.groups>
+      </properties>
+    </profile>
+    <profile>
       <id>jdk8</id>
       <activation>
         <jdk>[1.8,1.9)</jdk>
@@ -1471,15 +1447,24 @@
                 <additionalparam>-Xdoclint:all,-Xdoclint:-missing</additionalparam>
               </configuration>
             </plugin>
-            <plugin>
-              <groupId>net.revelc.code</groupId>
-              <artifactId>warbucks-maven-plugin</artifactId>
-              <version>1.0.0</version>
-            </plugin>
           </plugins>
         </pluginManagement>
         <plugins>
           <plugin>
+            <!-- verify before compile; should be sorted already -->
+            <groupId>com.github.ekryd.sortpom</groupId>
+            <artifactId>sortpom-maven-plugin</artifactId>
+            <executions>
+              <execution>
+                <id>verify-sorted-pom</id>
+                <goals>
+                  <goal>verify</goal>
+                </goals>
+                <phase>process-resources</phase>
+              </execution>
+            </executions>
+          </plugin>
+          <plugin>
             <groupId>net.revelc.code</groupId>
             <artifactId>warbucks-maven-plugin</artifactId>
             <executions>

-- 
To stop receiving notification emails like this one, please contact
ctubbsii@apache.org.

[accumulo] 05/05: Remove unused variables

Posted by ct...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

ctubbsii pushed a commit to branch 1.8
in repository https://gitbox.apache.org/repos/asf/accumulo.git

commit b8c19f8335d18ea02dbdddb9155066859894259e
Author: Christopher Tubbs <ct...@apache.org>
AuthorDate: Fri Apr 6 00:28:04 2018 -0400

    Remove unused variables
---
 .../main/java/org/apache/accumulo/shell/commands/SetIterCommand.java  | 4 ----
 .../java/org/apache/accumulo/shell/commands/SetShellIterCommand.java  | 4 ----
 2 files changed, 8 deletions(-)

diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/SetIterCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/SetIterCommand.java
index 42a8418..a3bc5a2 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/SetIterCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/SetIterCommand.java
@@ -47,15 +47,11 @@ import org.apache.commons.cli.Option;
 import org.apache.commons.cli.OptionGroup;
 import org.apache.commons.cli.Options;
 import org.apache.commons.lang.StringUtils;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
 
 import jline.console.ConsoleReader;
 
 public class SetIterCommand extends Command {
 
-  private static final Logger log = LoggerFactory.getLogger(SetIterCommand.class);
-
   private Option allScopeOpt, mincScopeOpt, majcScopeOpt, scanScopeOpt;
   Option profileOpt, priorityOpt, nameOpt;
   Option aggTypeOpt, ageoffTypeOpt, regexTypeOpt, versionTypeOpt, reqvisTypeOpt, classnameTypeOpt;
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/SetShellIterCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/SetShellIterCommand.java
index 40d046d..2156ea8 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/SetShellIterCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/SetShellIterCommand.java
@@ -32,13 +32,9 @@ import org.apache.accumulo.shell.ShellCommandException;
 import org.apache.commons.cli.CommandLine;
 import org.apache.commons.cli.Option;
 import org.apache.commons.cli.Options;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
 
 public class SetShellIterCommand extends SetIterCommand {
 
-  private static final Logger log = LoggerFactory.getLogger(SetShellIterCommand.class);
-
   @Override
   public int execute(final String fullCommand, final CommandLine cl, final Shell shellState)
       throws AccumuloException, AccumuloSecurityException, TableNotFoundException, IOException,

-- 
To stop receiving notification emails like this one, please contact
ctubbsii@apache.org.

[accumulo] 03/05: Fix findbugs error due to line-wrapping

Posted by ct...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

ctubbsii pushed a commit to branch 1.8
in repository https://gitbox.apache.org/repos/asf/accumulo.git

commit 2387957f92cc7cd3ca6120b331b0a759f7afd8c1
Author: Christopher Tubbs <ct...@apache.org>
AuthorDate: Fri Apr 6 00:01:12 2018 -0400

    Fix findbugs error due to line-wrapping
    
    Fix findbugs error due to known false-positive issue from line-wrapping:
    https://github.com/spotbugs/spotbugs/issues/462
---
 .../org/apache/accumulo/server/master/balancer/GroupBalancer.java    | 5 +++--
 1 file changed, 3 insertions(+), 2 deletions(-)

diff --git a/server/base/src/main/java/org/apache/accumulo/server/master/balancer/GroupBalancer.java b/server/base/src/main/java/org/apache/accumulo/server/master/balancer/GroupBalancer.java
index 3d8a33f..f57e46a 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/master/balancer/GroupBalancer.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/master/balancer/GroupBalancer.java
@@ -374,8 +374,9 @@ public abstract class GroupBalancer extends TabletBalancer {
 
       Integer extraCount = extraCounts.get(group);
 
-      checkArgument(extraCount != null && extraCount >= num, "group=%s num=%s extraCount=%s", group,
-          num, extraCount);
+      // don't wrap precondition check due to https://github.com/spotbugs/spotbugs/issues/462
+      String formatString = "group=%s num=%s extraCount=%s";
+      checkArgument(extraCount != null && extraCount >= num, formatString, group, num, extraCount);
 
       MutableInt initialCount = initialCounts.get(group);
 

-- 
To stop receiving notification emails like this one, please contact
ctubbsii@apache.org.

[accumulo] 04/05: Fix line wrap and other checkstyle errors

Posted by ct...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

ctubbsii pushed a commit to branch 1.8
in repository https://gitbox.apache.org/repos/asf/accumulo.git

commit 2ecae2dc26cc657ee6f0fa3fd738d488ee7d8d26
Author: Christopher Tubbs <ct...@apache.org>
AuthorDate: Fri Apr 6 00:01:59 2018 -0400

    Fix line wrap and other checkstyle errors
---
 .../accumulo/core/bloomfilter/BloomFilter.java     |   3 +-
 .../core/bloomfilter/DynamicBloomFilter.java       |   3 +-
 .../org/apache/accumulo/core/cli/ClientOpts.java   |   8 +-
 .../core/cli/MapReduceClientOnRequiredTable.java   |   2 +-
 .../accumulo/core/cli/MapReduceClientOpts.java     |   6 +-
 .../core/client/AccumuloSecurityException.java     |   3 +-
 .../accumulo/core/client/ClientConfiguration.java  |   9 +-
 .../core/client/ClientSideIteratorScanner.java     |  18 +-
 .../core/client/MutationsRejectedException.java    |   5 +-
 .../apache/accumulo/core/client/ScannerBase.java   |   3 +-
 .../accumulo/core/client/ZooKeeperInstance.java    |   5 +-
 .../core/client/admin/CompactionConfig.java        |   4 +-
 .../accumulo/core/client/impl/ClientContext.java   |  21 +-
 .../accumulo/core/client/impl/ConnectorImpl.java   |   3 +-
 .../core/client/impl/SecurityOperationsImpl.java   |  10 +-
 .../core/client/impl/TableOperationsImpl.java      |   5 +-
 .../impl/TabletServerBatchReaderIterator.java      |   8 +-
 .../core/client/impl/TabletServerBatchWriter.java  |  15 +-
 .../core/client/lexicoder/PairLexicoder.java       |  21 +-
 .../core/client/mapred/AbstractInputFormat.java    |   9 +-
 .../core/client/mapred/AccumuloInputFormat.java    |   5 +-
 .../mapred/AccumuloMultiTableInputFormat.java      |   3 +-
 .../core/client/mapred/AccumuloOutputFormat.java   |   5 +-
 .../core/client/mapred/AccumuloRowInputFormat.java |  54 ++-
 .../core/client/mapreduce/AbstractInputFormat.java |   9 +-
 .../core/client/mapreduce/AccumuloInputFormat.java |   5 +-
 .../client/mapreduce/AccumuloOutputFormat.java     |   5 +-
 .../mapreduce/lib/impl/InputConfigurator.java      |   4 +-
 .../accumulo/core/client/rfile/RFileWriter.java    |  16 +-
 .../core/client/sample/RowColumnSampler.java       |   8 +-
 .../accumulo/core/client/sample/RowSampler.java    |   8 +-
 .../security/tokens/AuthenticationToken.java       |   6 +-
 .../core/client/security/tokens/KerberosToken.java |   4 +-
 .../accumulo/core/conf/AccumuloConfiguration.java  |   4 +-
 .../core/conf/CredentialProviderFactoryShim.java   |  22 +-
 .../org/apache/accumulo/core/conf/Property.java    | 537 +++++++++++++--------
 .../apache/accumulo/core/conf/PropertyType.java    |  53 +-
 .../accumulo/core/conf/SiteConfiguration.java      |   5 +-
 .../core/data/ConstraintViolationSummary.java      |   3 +-
 .../accumulo/core/data/impl/TabletIdImpl.java      |  11 +-
 .../apache/accumulo/core/file/FileOperations.java  |  10 +-
 .../core/file/blockfile/cache/LruBlockCache.java   |   9 +-
 .../accumulo/core/file/rfile/CreateEmpty.java      |   8 +-
 .../accumulo/core/file/rfile/KeyShortener.java     |   5 +-
 .../org/apache/accumulo/core/file/rfile/RFile.java |   5 +-
 .../accumulo/core/file/rfile/bcfile/BCFile.java    |   9 +-
 .../core/iterators/AggregatingIterator.java        |   5 +-
 .../apache/accumulo/core/iterators/Combiner.java   |  11 +-
 .../org/apache/accumulo/core/iterators/Filter.java |   4 +-
 .../core/iterators/IteratorEnvironment.java        |   3 +-
 .../accumulo/core/iterators/IteratorUtil.java      |  89 ++--
 .../accumulo/core/iterators/LongCombiner.java      |   4 +-
 .../accumulo/core/iterators/OptionDescriber.java   |   5 +-
 .../core/iterators/TypedValueCombiner.java         |   4 +-
 .../accumulo/core/iterators/user/AgeOffFilter.java |   4 +-
 .../core/iterators/user/CfCqSliceOpts.java         |  40 +-
 .../core/iterators/user/ColumnAgeOffFilter.java    |   4 +-
 .../core/iterators/user/ColumnSliceFilter.java     |   4 +-
 .../core/iterators/user/LargeRowFilter.java        |   3 +-
 .../accumulo/core/iterators/user/MaxCombiner.java  |   5 +-
 .../accumulo/core/iterators/user/MinCombiner.java  |   5 +-
 .../accumulo/core/iterators/user/RegExFilter.java  |   4 +-
 .../core/iterators/user/RowEncodingIterator.java   |   6 +-
 .../core/iterators/user/SummingArrayCombiner.java  |   6 +-
 .../core/iterators/user/SummingCombiner.java       |   5 +-
 .../core/iterators/user/TransformingIterator.java  |  12 +-
 .../core/iterators/user/VisibilityFilter.java      |  10 +-
 .../core/metadata/schema/MetadataSchema.java       |   8 +-
 .../core/replication/ReplicationSchema.java        |  27 +-
 .../apache/accumulo/core/rpc/FilterTransport.java  |   2 +-
 .../org/apache/accumulo/core/rpc/ThriftUtil.java   |  16 +-
 .../accumulo/core/rpc/UGIAssumingTransport.java    |   2 +-
 .../accumulo/core/security/ColumnVisibility.java   |   5 +-
 .../core/security/crypto/BlockedOutputStream.java  |   7 +-
 .../core/security/crypto/CryptoModuleFactory.java  |  30 +-
 .../core/security/crypto/DefaultCryptoModule.java  |  33 +-
 .../security/crypto/DefaultCryptoModuleUtils.java  |  18 +-
 .../NonCachingSecretKeyEncryptionStrategy.java     |   6 +-
 .../org/apache/accumulo/core/util/CreateToken.java |   5 +-
 .../java/org/apache/accumulo/core/util/Merge.java  |   3 +-
 .../accumulo/core/volume/NonConfiguredVolume.java  |   4 +-
 .../client/security/SecurityErrorCodeTest.java     |   5 +-
 .../accumulo/core/conf/PropertyTypeTest.java       |   3 +-
 .../core/data/ConstraintViolationSummaryTest.java  |   9 +-
 .../apache/accumulo/core/data/MutationTest.java    |  14 +-
 .../conf/AggregatorConfigurationTest.java          |  19 +-
 .../core/iterators/user/VisibilityFilterTest.java  |   3 +-
 .../accumulo/core/security/crypto/CryptoTest.java  |   5 +-
 .../examples/simple/client/RandomBatchWriter.java  |   8 +-
 .../examples/simple/mapreduce/TableToFile.java     |  11 +-
 .../examples/simple/sample/SampleExample.java      |  12 +-
 .../accumulo/examples/simple/shard/Query.java      |   6 +-
 .../org/apache/accumulo/fate/util/AddressUtil.java |  19 +-
 .../apache/accumulo/fate/util/AddressUtilTest.java |  16 +-
 .../testcases/MultipleHasTopCalls.java             |   6 +-
 .../accumulo/minicluster/MiniAccumuloRunner.java   |   4 +-
 .../minicluster/impl/MiniAccumuloConfigImpl.java   |   4 +-
 .../main/java/org/apache/accumulo/proxy/Proxy.java |   4 +-
 .../org/apache/accumulo/proxy/ProxyServer.java     |  38 +-
 .../java/org/apache/accumulo/server/Accumulo.java  |  12 +-
 .../accumulo/server/GarbageCollectionLogger.java   |   4 +-
 .../accumulo/server/fs/PreferredVolumeChooser.java |   4 +-
 .../accumulo/server/fs/VolumeManagerImpl.java      |  10 +-
 .../apache/accumulo/server/init/Initialize.java    |  25 +-
 .../accumulo/server/log/WalStateManager.java       |  38 +-
 .../balancer/HostRegexTableLoadBalancer.java       |  46 +-
 .../server/metrics/MetricsConfiguration.java       |   7 +-
 .../rpc/TCredentialsUpdatingInvocationHandler.java |  13 +-
 .../apache/accumulo/server/rpc/TServerUtils.java   |  10 +-
 .../server/security/AuditedSecurityOperation.java  |  95 ++--
 .../server/security/SecurityOperation.java         |   3 +-
 .../server/security/UserImpersonation.java         |  14 +-
 .../server/security/handler/ZKAuthenticator.java   |   5 +-
 .../org/apache/accumulo/server/util/FileUtil.java  |  18 +-
 .../accumulo/server/util/SendLogToChainsaw.java    |   6 +-
 .../server/util/FileSystemMonitorTest.java         |   6 +-
 .../apache/accumulo/gc/SimpleGarbageCollector.java |   4 +-
 .../java/org/apache/accumulo/master/Master.java    |  45 +-
 .../DistributedWorkQueueWorkAssigner.java          |   5 +-
 .../master/replication/FinishedWorkUpdater.java    |  10 +-
 .../RemoveCompleteReplicationRecords.java          |   9 +-
 .../org/apache/accumulo/master/util/FateAdmin.java |   5 +-
 .../accumulo/monitor/servlets/BasicServlet.java    |  17 +-
 .../accumulo/monitor/servlets/MasterServlet.java   |   3 +-
 .../accumulo/monitor/servlets/ProblemServlet.java  |   3 +-
 .../accumulo/monitor/servlets/ShellServlet.java    |  20 +-
 .../accumulo/monitor/servlets/TServersServlet.java |  17 +-
 .../accumulo/monitor/servlets/TablesServlet.java   |  19 +-
 .../accumulo/monitor/servlets/VisServlet.java      |  20 +-
 .../accumulo/monitor/servlets/trace/Basic.java     |   4 +-
 .../accumulo/monitor/servlets/trace/ShowTrace.java |   8 +-
 .../accumulo/monitor/servlets/trace/Summary.java   |   4 +-
 .../apache/accumulo/tracer/AsyncSpanReceiver.java  |   3 +-
 .../org/apache/accumulo/tracer/TraceServer.java    |  25 +-
 .../org/apache/accumulo/tserver/InMemoryMap.java   |   6 +-
 .../org/apache/accumulo/tserver/TabletServer.java  |  42 +-
 .../tserver/TabletServerResourceManager.java       |   7 +-
 .../org/apache/accumulo/tserver/log/DfsLogger.java |  18 +-
 .../accumulo/tserver/log/SortedLogRecovery.java    |   8 +-
 .../tserver/metrics/TabletServerUpdateMetrics.java |   5 +-
 .../tserver/replication/AccumuloReplicaSystem.java |  22 +-
 .../apache/accumulo/tserver/tablet/Compactor.java  |   3 +-
 .../accumulo/tserver/tablet/DatafileManager.java   |   5 +-
 .../org/apache/accumulo/tserver/tablet/Tablet.java |   6 +-
 .../accumulo/tserver/tablet/TabletCommitter.java   |   5 +-
 .../tserver/LargestFirstMemoryManagerTest.java     |   6 +-
 .../main/java/org/apache/accumulo/shell/Shell.java |  12 +-
 .../org/apache/accumulo/shell/ShellOptionsJC.java  |  22 +-
 .../shell/commands/ActiveScanIterator.java         |   3 +-
 .../accumulo/shell/commands/CloneTableCommand.java |   4 +-
 .../accumulo/shell/commands/CompactCommand.java    |  42 +-
 .../shell/commands/CreateTableCommand.java         |   3 +-
 .../apache/accumulo/shell/commands/DUCommand.java  |   5 +-
 .../accumulo/shell/commands/DeleteCommand.java     |   3 +-
 .../accumulo/shell/commands/DeleteRowsCommand.java |   3 +-
 .../shell/commands/DeleteScanIterCommand.java      |   3 +-
 .../accumulo/shell/commands/EGrepCommand.java      |   8 +-
 .../accumulo/shell/commands/FateCommand.java       |   3 +-
 .../accumulo/shell/commands/GrepCommand.java       |   3 +-
 .../accumulo/shell/commands/HiddenCommand.java     |  14 +-
 .../shell/commands/ImportDirectoryCommand.java     |   3 +-
 .../accumulo/shell/commands/InsertCommand.java     |   3 +-
 .../shell/commands/ListCompactionsCommand.java     |   4 +-
 .../accumulo/shell/commands/ListScansCommand.java  |   3 +-
 .../accumulo/shell/commands/MergeCommand.java      |   3 +-
 .../shell/commands/QuotedStringTokenizer.java      |   5 +-
 .../accumulo/shell/commands/ScanCommand.java       |   3 +-
 .../accumulo/shell/commands/SetIterCommand.java    |  16 +-
 .../java/org/apache/accumulo/shell/ShellTest.java  |   3 +-
 .../shell/commands/SetIterCommandTest.java         |   3 +-
 .../classloader/vfs/AccumuloVFSClassLoader.java    |  19 +-
 .../accumulo/harness/AccumuloClusterHarness.java   |   5 +-
 .../accumulo/harness/MiniClusterHarness.java       |   9 +-
 .../apache/accumulo/test/ConditionalWriterIT.java  |  15 +-
 .../org/apache/accumulo/test/InMemoryMapIT.java    |   6 +-
 .../java/org/apache/accumulo/test/MetaSplitIT.java |   4 +-
 .../org/apache/accumulo/test/NamespacesIT.java     |   5 +-
 .../accumulo/test/NativeMapPerformanceTest.java    |   3 +-
 .../org/apache/accumulo/test/ShellConfigIT.java    |   5 +-
 .../org/apache/accumulo/test/ShellServerIT.java    |  41 +-
 .../org/apache/accumulo/test/TestBinaryRows.java   |   3 +-
 .../java/org/apache/accumulo/test/TestIngest.java  |   7 +-
 .../org/apache/accumulo/test/VerifyIngest.java     |   3 +-
 .../test/continuous/ContinuousStatsCollector.java  |  10 +-
 .../test/functional/GarbageCollectorIT.java        |   4 +-
 .../accumulo/test/functional/PermissionsIT.java    |   6 +-
 .../test/functional/RecoveryWithEmptyRFileIT.java  |   4 +-
 .../test/functional/SessionBlockVerifyIT.java      |   5 +-
 .../test/functional/WatchTheWatchCountIT.java      |   5 +-
 .../test/mapreduce/AccumuloInputFormatIT.java      |  10 +-
 .../accumulo/test/proxy/SimpleProxyBase.java       |   4 +-
 .../accumulo/test/proxy/TestProxyReadWrite.java    |  18 +-
 .../org/apache/accumulo/test/randomwalk/Node.java  |   5 +-
 .../test/randomwalk/multitable/CopyTool.java       |  10 +-
 .../test/randomwalk/security/Validate.java         |   6 +-
 .../randomwalk/sequential/MapRedVerifyTool.java    |  10 +-
 .../test/replication/FinishedWorkUpdaterIT.java    |  34 +-
 ...GarbageCollectorCommunicatesWithTServersIT.java |   4 +-
 .../accumulo/test/stress/random/WriteOptions.java  |   5 +-
 .../org/apache/accumulo/test/util/CertUtils.java   |  12 +-
 .../test/TraceRepoDeserializationTest.java         |   3 +-
 201 files changed, 1581 insertions(+), 1102 deletions(-)

diff --git a/core/src/main/java/org/apache/accumulo/core/bloomfilter/BloomFilter.java b/core/src/main/java/org/apache/accumulo/core/bloomfilter/BloomFilter.java
index 37e84d9..4d704f3 100644
--- a/core/src/main/java/org/apache/accumulo/core/bloomfilter/BloomFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/bloomfilter/BloomFilter.java
@@ -1,6 +1,7 @@
 /*
  *
- * Copyright (c) 2005, European Commission project OneLab under contract 034819 (http://www.one-lab.org)
+ * Copyright (c) 2005, European Commission project OneLab under contract 034819
+ * (http://www.one-lab.org)
  * All rights reserved.
  * Redistribution and use in source and binary forms, with or
  * without modification, are permitted provided that the following
diff --git a/core/src/main/java/org/apache/accumulo/core/bloomfilter/DynamicBloomFilter.java b/core/src/main/java/org/apache/accumulo/core/bloomfilter/DynamicBloomFilter.java
index 5f70105..85399bf 100644
--- a/core/src/main/java/org/apache/accumulo/core/bloomfilter/DynamicBloomFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/bloomfilter/DynamicBloomFilter.java
@@ -1,6 +1,7 @@
 /*
  *
- * Copyright (c) 2005, European Commission project OneLab under contract 034819 (http://www.one-lab.org)
+ * Copyright (c) 2005, European Commission project OneLab under contract 034819
+ * (http://www.one-lab.org)
  * All rights reserved.
  * Redistribution and use in source and binary forms, with or
  * without modification, are permitted provided that the following
diff --git a/core/src/main/java/org/apache/accumulo/core/cli/ClientOpts.java b/core/src/main/java/org/apache/accumulo/core/cli/ClientOpts.java
index b1d3150..e88c6d8 100644
--- a/core/src/main/java/org/apache/accumulo/core/cli/ClientOpts.java
+++ b/core/src/main/java/org/apache/accumulo/core/cli/ClientOpts.java
@@ -137,8 +137,8 @@ public class ClientOpts extends Help {
   @Parameter(names = {"-tc", "--tokenClass"}, description = "Token class")
   private String tokenClassName = null;
 
-  @DynamicParameter(names = "-l",
-      description = "login properties in the format key=value. Reuse -l for each property (prompt for properties if this option is missing")
+  @DynamicParameter(names = "-l", description = "login properties in the format key=value. "
+      + "Reuse -l for each property (prompt for properties if this option is missing")
   public Map<String,String> loginProps = new LinkedHashMap<>();
 
   public AuthenticationToken getToken() {
@@ -205,8 +205,8 @@ public class ClientOpts extends Help {
   public boolean saslEnabled = false;
 
   @Parameter(names = "--config-file", description = "Read the given client config file. "
-      + "If omitted, the path searched can be specified with $ACCUMULO_CLIENT_CONF_PATH, "
-      + "which defaults to ~/.accumulo/config:$ACCUMULO_CONF_DIR/client.conf:/etc/accumulo/client.conf")
+      + "If omitted, the path searched can be specified with $ACCUMULO_CLIENT_CONF_PATH, which "
+      + "defaults to ~/.accumulo/config:$ACCUMULO_CONF_DIR/client.conf:/etc/accumulo/client.conf")
   public String clientConfigFile = null;
 
   public void startDebugLogging() {
diff --git a/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOnRequiredTable.java b/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOnRequiredTable.java
index 79b59e7..96ada88 100644
--- a/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOnRequiredTable.java
+++ b/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOnRequiredTable.java
@@ -30,7 +30,7 @@ public class MapReduceClientOnRequiredTable extends MapReduceClientOpts {
   private String tableName;
 
   @Parameter(names = {"-tf", "--tokenFile"},
-      description = "File in hdfs containing the user's authentication token create with \"bin/accumulo create-token\"")
+      description = "User's token file in HDFS created with \"bin/accumulo create-token\"")
   private String tokenFile = "";
 
   @Override
diff --git a/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOpts.java b/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOpts.java
index 71d8e1c..d4eb23b 100644
--- a/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOpts.java
+++ b/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOpts.java
@@ -65,8 +65,10 @@ public class MapReduceClientOpts extends ClientOpts {
         if (!conn.securityOperations().hasSystemPermission(conn.whoami(),
             SystemPermission.OBTAIN_DELEGATION_TOKEN)) {
           log.error(
-              "{} doesn't have the {} SystemPermission neccesary to obtain a delegation token. MapReduce tasks cannot automatically use the client's"
-                  + " credentials on remote servers. Delegation tokens provide a means to run MapReduce without distributing the user's credentials.",
+              "{} doesn't have the {} SystemPermission neccesary to obtain a delegation"
+                  + " token. MapReduce tasks cannot automatically use the client's"
+                  + " credentials on remote servers. Delegation tokens provide a means to run"
+                  + " MapReduce without distributing the user's credentials.",
               user.getUserName(), SystemPermission.OBTAIN_DELEGATION_TOKEN.name());
           throw new IllegalStateException(
               conn.whoami() + " does not have permission to obtain a delegation token");
diff --git a/core/src/main/java/org/apache/accumulo/core/client/AccumuloSecurityException.java b/core/src/main/java/org/apache/accumulo/core/client/AccumuloSecurityException.java
index 0881ac2..f9bcc89 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/AccumuloSecurityException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/AccumuloSecurityException.java
@@ -57,7 +57,8 @@ public class AccumuloSecurityException extends Exception {
       case TOKEN_EXPIRED:
         return "The supplied token expired, please update and try again";
       case INSUFFICIENT_PROPERTIES:
-        return "The login properties supplied are not sufficient for authentication. Please check the requested properties and try again";
+        return "The login properties supplied are not sufficient for authentication. "
+            + "Please check the requested properties and try again";
       case DEFAULT_SECURITY_ERROR:
       default:
         return "Unknown security exception";
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 09c9e8b..5f2be86 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
@@ -106,7 +106,8 @@ public class ClientConfiguration extends CompositeConfiguration {
      * @since 1.7.0
      */
     KERBEROS_SERVER_PRIMARY("kerberos.server.primary", "accumulo", PropertyType.STRING,
-        "The first component of the Kerberos principal, the 'primary', that Accumulo servers use to login");
+        "The first component of the Kerberos principal, the 'primary', "
+            + "that Accumulo servers use to login");
 
     private String key;
     private String defaultValue;
@@ -217,9 +218,9 @@ public class ClientConfiguration extends CompositeConfiguration {
         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');
         }
       }
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 b940941..ab05a12 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
@@ -50,11 +50,19 @@ import org.apache.hadoop.io.Text;
 /**
  * A scanner that instantiates iterators on the client side instead of on the tablet server. This
  * can be useful for testing iterators or in cases where you don't want iterators affecting the
- * performance of tablet servers.<br>
- * <br>
- * Suggested usage:<br>
- * <code>Scanner scanner = new ClientSideIteratorScanner(connector.createScanner(tableName, authorizations));</code><br>
- * <br>
+ * performance of tablet servers.
+ *
+ * <p>
+ * Suggested usage:
+ *
+ * <pre>
+ * <code>
+ * Scanner scanner = connector.createScanner(tableName, authorizations);
+ * scanner = new ClientSideIteratorScanner(scanner);
+ * </code>
+ * </pre>
+ *
+ * <p>
  * Iterators added to this scanner will be run in the client JVM. Separate scan iterators can be run
  * on the server side and client side by adding iterators to the source scanner (which will execute
  * server side) and to the client side scanner (which will execute client side).
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 8bade1c..4fb6a2c 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
@@ -174,9 +174,12 @@ public class MutationsRejectedException extends AccumuloException {
    * @deprecated since 1.7.0 see {@link #getSecurityErrorCodes()}
    */
   @Deprecated
-  public Map<org.apache.accumulo.core.data.KeyExtent,Set<SecurityErrorCode>> getAuthorizationFailuresMap() {
+  // @formatter:off
+  public Map<org.apache.accumulo.core.data.KeyExtent,Set<SecurityErrorCode>>
+    getAuthorizationFailuresMap() {
     return transformKeys(af, TabletIdImpl.TID_2_KE_OLD);
   }
+  // @formatter:on
 
   /**
    * @return the internal mapping of TabletID to SecurityErrorCodes
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 6ec3618..503d307 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
@@ -201,7 +201,8 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>>, AutoCloseable {
    * <pre>
    * <code>
    *   // could cache this if creating many scanners to avoid RPCs.
-   *   SamplerConfiguration samplerConfig = connector.tableOperations().getSamplerConfiguration(table);
+   *   SamplerConfiguration samplerConfig =
+   *     connector.tableOperations().getSamplerConfiguration(table);
    *   // verify table's sample data is generated in an expected way before using
    *   userCode.verifySamplerConfig(samplerConfig);
    *   scanner.setSamplerCongiguration(samplerConfig);
diff --git a/core/src/main/java/org/apache/accumulo/core/client/ZooKeeperInstance.java b/core/src/main/java/org/apache/accumulo/core/client/ZooKeeperInstance.java
index 201de62..563f2a9 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/ZooKeeperInstance.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/ZooKeeperInstance.java
@@ -197,8 +197,9 @@ public class ZooKeeperInstance implements Instance {
       String instanceNamePath = Constants.ZROOT + Constants.ZINSTANCES + "/" + instanceName;
       byte[] iidb = zooCache.get(instanceNamePath);
       if (iidb == null) {
-        throw new RuntimeException("Instance name " + instanceName
-            + " does not exist in zookeeper.  Run \"accumulo org.apache.accumulo.server.util.ListInstances\" to see a list.");
+        throw new RuntimeException(
+            "Instance name " + instanceName + " does not exist in zookeeper. "
+                + "Run \"accumulo org.apache.accumulo.server.util.ListInstances\" to see a list.");
       }
       instanceId = new String(iidb, UTF_8);
     }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionConfig.java b/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionConfig.java
index 7a220a7..766867f 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionConfig.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionConfig.java
@@ -18,13 +18,13 @@
 package org.apache.accumulo.core.client.admin;
 
 import static java.util.Objects.requireNonNull;
+import static org.apache.accumulo.core.client.impl.CompactionStrategyConfigUtil.DEFAULT_STRATEGY;
 
 import java.util.ArrayList;
 import java.util.Collections;
 import java.util.List;
 
 import org.apache.accumulo.core.client.IteratorSetting;
-import org.apache.accumulo.core.client.impl.CompactionStrategyConfigUtil;
 import org.apache.hadoop.io.Text;
 
 /**
@@ -39,7 +39,7 @@ public class CompactionConfig {
   private boolean flush = true;
   private boolean wait = true;
   private List<IteratorSetting> iterators = Collections.emptyList();
-  private CompactionStrategyConfig compactionStrategy = CompactionStrategyConfigUtil.DEFAULT_STRATEGY;
+  private CompactionStrategyConfig compactionStrategy = DEFAULT_STRATEGY;
 
   /**
    * @param start
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ClientContext.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ClientContext.java
index 0f53992..05cd058 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ClientContext.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ClientContext.java
@@ -243,14 +243,12 @@ public class ClientContext {
                 log.trace("Loaded sensitive value for {} from CredentialProvider", key);
                 return new String(value);
               } else {
-                log.trace(
-                    "Tried to load sensitive value for {} from CredentialProvider, but none was found",
-                    key);
+                log.trace("Tried to load sensitive value for {} from CredentialProvider, "
+                    + "but none was found", key);
               }
             } catch (IOException e) {
-              log.warn(
-                  "Failed to extract sensitive property ({}) from Hadoop CredentialProvider, falling back to base AccumuloConfiguration",
-                  key, e);
+              log.warn("Failed to extract sensitive property ({}) from Hadoop CredentialProvider,"
+                  + " falling back to base AccumuloConfiguration", key, e);
             }
           }
         }
@@ -312,9 +310,8 @@ public class ClientContext {
               }
             }
           } catch (IOException e) {
-            log.warn(
-                "Failed to extract sensitive properties from Hadoop CredentialProvider, falling back to accumulo-site.xml",
-                e);
+            log.warn("Failed to extract sensitive properties from Hadoop CredentialProvider, "
+                + "falling back to accumulo-site.xml", e);
           }
         }
       }
@@ -323,9 +320,9 @@ public class ClientContext {
         String credProviderPaths = config
             .getString(Property.GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS.getKey());
         if (null != credProviderPaths && !credProviderPaths.isEmpty()) {
-          org.apache.hadoop.conf.Configuration hadoopConf = new org.apache.hadoop.conf.Configuration();
-          hadoopConf.set(CredentialProviderFactoryShim.CREDENTIAL_PROVIDER_PATH, credProviderPaths);
-          return hadoopConf;
+          org.apache.hadoop.conf.Configuration hConf = new org.apache.hadoop.conf.Configuration();
+          hConf.set(CredentialProviderFactoryShim.CREDENTIAL_PROVIDER_PATH, credProviderPaths);
+          return hConf;
         }
 
         log.trace("Did not find credential provider configuration in ClientConfiguration");
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ConnectorImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ConnectorImpl.java
index ebf4f30..359800d 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ConnectorImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ConnectorImpl.java
@@ -46,7 +46,8 @@ import org.apache.accumulo.core.security.Authorizations;
 import org.apache.accumulo.core.trace.Tracer;
 
 public class ConnectorImpl extends Connector {
-  private static final String SYSTEM_TOKEN_NAME = "org.apache.accumulo.server.security.SystemCredentials$SystemToken";
+  private static final String SYSTEM_TOKEN_NAME = "org.apache.accumulo.server.security."
+      + "SystemCredentials$SystemToken";
   private final ClientContext context;
   private SecurityOperations secops = null;
   private TableOperationsImpl tableops = null;
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/SecurityOperationsImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/SecurityOperationsImpl.java
index 71059b1..0b2860d 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/SecurityOperationsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/SecurityOperationsImpl.java
@@ -17,6 +17,7 @@
 package org.apache.accumulo.core.client.impl;
 
 import static com.google.common.base.Preconditions.checkArgument;
+import static org.apache.accumulo.core.client.security.SecurityErrorCode.NAMESPACE_DOESNT_EXIST;
 
 import java.nio.ByteBuffer;
 import java.util.Set;
@@ -245,8 +246,7 @@ public class SecurityOperationsImpl implements SecurityOperations {
         }
       });
     } catch (AccumuloSecurityException e) {
-      if (e
-          .getSecurityErrorCode() == org.apache.accumulo.core.client.security.SecurityErrorCode.NAMESPACE_DOESNT_EXIST)
+      if (e.getSecurityErrorCode() == NAMESPACE_DOESNT_EXIST)
         throw new AccumuloSecurityException(null, SecurityErrorCode.TABLE_DOESNT_EXIST, e);
       else
         throw e;
@@ -297,8 +297,7 @@ public class SecurityOperationsImpl implements SecurityOperations {
         }
       });
     } catch (AccumuloSecurityException e) {
-      if (e
-          .getSecurityErrorCode() == org.apache.accumulo.core.client.security.SecurityErrorCode.NAMESPACE_DOESNT_EXIST)
+      if (e.getSecurityErrorCode() == NAMESPACE_DOESNT_EXIST)
         throw new AccumuloSecurityException(null, SecurityErrorCode.TABLE_DOESNT_EXIST, e);
       else
         throw e;
@@ -349,8 +348,7 @@ public class SecurityOperationsImpl implements SecurityOperations {
         }
       });
     } catch (AccumuloSecurityException e) {
-      if (e
-          .getSecurityErrorCode() == org.apache.accumulo.core.client.security.SecurityErrorCode.NAMESPACE_DOESNT_EXIST)
+      if (e.getSecurityErrorCode() == NAMESPACE_DOESNT_EXIST)
         throw new AccumuloSecurityException(null, SecurityErrorCode.TABLE_DOESNT_EXIST, e);
       else
         throw e;
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/TableOperationsImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/TableOperationsImpl.java
index 9632cc0..2cb4bf1 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/TableOperationsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/TableOperationsImpl.java
@@ -551,9 +551,8 @@ public class TableOperationsImpl extends TableOperationsHelper {
           // Do not silently spin when we repeatedly fail to get the location for a tablet
           locationFailures++;
           if (5 == locationFailures || 0 == locationFailures % 50) {
-            log.warn(
-                "Having difficulty locating hosting tabletserver for split {} on table {}. Seen {} failures.",
-                split, tableName, locationFailures);
+            log.warn("Having difficulty locating hosting tabletserver for split {} on table {}."
+                + " Seen {} failures.", split, tableName, locationFailures);
           }
 
           tabLocator.invalidateCache(tl.tablet_extent);
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchReaderIterator.java b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchReaderIterator.java
index f00d95a..d6dae58 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchReaderIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchReaderIterator.java
@@ -185,10 +185,12 @@ public class TabletServerBatchReaderIterator implements Iterator<Entry<Key,Value
             throw new RuntimeException(fatalException);
 
         if (queryThreadPool.isShutdown()) {
-          String shortMsg = "The BatchScanner was unexpectedly closed while this Iterator was still in use.";
+          String shortMsg = "The BatchScanner was unexpectedly closed while this Iterator "
+              + "was still in use.";
           log.error(shortMsg
-              + " Ensure that a reference to the BatchScanner is retained so that it can be closed when this Iterator is exhausted."
-              + " Not retaining a reference to the BatchScanner guarantees that you are leaking threads in your client JVM.");
+              + " Ensure that a reference to the BatchScanner is retained so that it can be closed"
+              + " when this Iterator is exhausted. Not retaining a reference to the BatchScanner"
+              + " guarantees that you are leaking threads in your client JVM.");
           throw new RuntimeException(shortMsg + " Ensure proper handling of the BatchScanner.");
         }
 
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java
index 3fb8651..0226b6a 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java
@@ -83,24 +83,23 @@ import com.google.common.base.Joiner;
 /*
  * Differences from previous TabletServerBatchWriter
  *   + As background threads finish sending mutations to tablet servers they decrement memory usage
- *   + Once the queue of unprocessed mutations reaches 50% it is always pushed to the background threads,
- *      even if they are currently processing... new mutations are merged with mutations currently
- *      processing in the background
+ *   + Once the queue of unprocessed mutations reaches 50% it is always pushed
+ *     to the background threads, even if they are currently processing... new
+ *     mutations are merged with mutations currently processing in the background
  *   + Failed mutations are held for 1000ms and then re-added to the unprocessed queue
  *   + Flush holds adding of new mutations so it does not wait indefinitely
  *
  * Considerations
  *   + All background threads must catch and note Throwable
- *   + mutations for a single tablet server are only processed by one thread concurrently (if new mutations
- *      come in for a tablet server while one thread is processing mutations for it, no other thread should
- *      start processing those mutations)
+ *   + mutations for a single tablet server are only processed by one thread
+ *     concurrently (if new mutations come in for a tablet server while one
+ *     thread is processing mutations for it, no other thread should
+ *     start processing those mutations)
  *
  * Memory accounting
  *   + when a mutation enters the system memory is incremented
  *   + when a mutation successfully leaves the system memory is decremented
  *
- *
- *
  */
 
 public class TabletServerBatchWriter {
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 d2d0bc5..e5db4b9 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
@@ -33,18 +33,15 @@ import org.apache.accumulo.core.util.ComparablePair;
  * component a date which is reverse sorted, we can do so with the following example:
  *
  * <pre>
- * {
- *   &#064;code
- *   StringLexicoder stringEncoder = new StringLexicoder();
- *   ReverseLexicoder&lt;Date&gt; dateEncoder = new ReverseLexicoder&lt;Date&gt;(new DateLexicoder());
- *   PairLexicoder&lt;String,Date&gt; pairLexicoder = new PairLexicoder&lt;String,Date&gt;(stringEncoder,
- *       dateEncoder);
- *   byte[] pair1 = pairLexicoder.encode(new ComparablePair&lt;String,Date&gt;(&quot;com.google&quot;, new Date()));
- *   byte[] pair2 = pairLexicoder.encode(
- *       new ComparablePair&lt;String,Date&gt;(&quot;com.google&quot;, new Date(System.currentTimeMillis() + 500)));
- *   byte[] pair3 = pairLexicoder.encode(new ComparablePair&lt;String,Date&gt;(&quot;org.apache&quot;,
- *       new Date(System.currentTimeMillis() + 1000)));
- * }
+ * <code>
+ * StringLexicoder strEncoder = new StringLexicoder();
+ * ReverseLexicoder&lt;Date&gt; dateEnc = new ReverseLexicoder&lt;&gt;(new DateLexicoder());
+ * PairLexicoder&lt;String,Date&gt; pair = new PairLexicoder&lt;&gt;(strEncoder, dateEnc);
+ * long now = System.currentTimeMillis();
+ * byte[] pair1 = pair.encode(new ComparablePair&lt;&gt;(&quot;com&quot;, new Date(now)));
+ * byte[] pair2 = pair.encode(new ComparablePair&lt;&gt;(&quot;com&quot;, new Date(now + 500)));
+ * byte[] pair3 = pair.encode(new ComparablePair&lt;&gt;(&quot;org&quot;, new Date(now + 1000)));
+ * </code>
  * </pre>
  *
  * In the example, pair2 will be sorted before pair1. pair3 will occur last since 'org' is sorted
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 9c7700b..4e80c18 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
@@ -144,9 +144,8 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
         Connector conn = instance.getConnector(principal, token);
         token = conn.securityOperations().getDelegationToken(new DelegationTokenConfig());
       } catch (Exception e) {
-        log.warn(
-            "Failed to automatically obtain DelegationToken, Mappers/Reducers will likely fail to communicate with Accumulo",
-            e);
+        log.warn("Failed to automatically obtain DelegationToken, Mappers/Reducers will likely"
+            + " fail to communicate with Accumulo", e);
       }
     }
     // DelegationTokens can be passed securely from user to task without serializing insecurely in
@@ -722,8 +721,8 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
       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");
+        throw new IllegalArgumentException("BatchScanner optimization not available for offline"
+            + " scan, isolated, or local iterators");
 
       boolean autoAdjust = tableConfig.shouldAutoAdjustRanges();
       if (batchScan && !autoAdjust)
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloInputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloInputFormat.java
index 6f1a872..a30f2de 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloInputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloInputFormat.java
@@ -57,7 +57,10 @@ public class AccumuloInputFormat extends InputFormatBase<Key,Value> {
     // Override the log level from the configuration as if the RangeInputSplit has one it's the more
     // correct one to use.
     if (split instanceof org.apache.accumulo.core.client.mapreduce.RangeInputSplit) {
-      org.apache.accumulo.core.client.mapreduce.RangeInputSplit accSplit = (org.apache.accumulo.core.client.mapreduce.RangeInputSplit) split;
+      // @formatter:off
+      org.apache.accumulo.core.client.mapreduce.RangeInputSplit accSplit =
+        (org.apache.accumulo.core.client.mapreduce.RangeInputSplit) split;
+      // @formatter:on
       Level level = accSplit.getLogLevel();
       if (null != level) {
         log.setLevel(level);
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloMultiTableInputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloMultiTableInputFormat.java
index a29d690..6604bf0 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloMultiTableInputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloMultiTableInputFormat.java
@@ -20,6 +20,7 @@ import java.io.IOException;
 import java.util.Map;
 
 import org.apache.accumulo.core.client.ClientConfiguration;
+import org.apache.accumulo.core.client.mapred.InputFormatBase.RecordReaderBase;
 import org.apache.accumulo.core.client.mapreduce.InputTableConfig;
 import org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator;
 import org.apache.accumulo.core.data.Key;
@@ -67,7 +68,7 @@ public class AccumuloMultiTableInputFormat extends AbstractInputFormat<Key,Value
   public RecordReader<Key,Value> getRecordReader(InputSplit split, JobConf job, Reporter reporter)
       throws IOException {
     log.setLevel(getLogLevel(job));
-    InputFormatBase.RecordReaderBase<Key,Value> recordReader = new InputFormatBase.RecordReaderBase<Key,Value>() {
+    RecordReaderBase<Key,Value> recordReader = new RecordReaderBase<Key,Value>() {
 
       @Override
       public boolean next(Key key, Value value) throws IOException {
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloOutputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloOutputFormat.java
index 2752fd3..e287f49 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloOutputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloOutputFormat.java
@@ -111,9 +111,8 @@ public class AccumuloOutputFormat implements OutputFormat<Text,Mutation> {
         Connector conn = instance.getConnector(principal, token);
         token = conn.securityOperations().getDelegationToken(new DelegationTokenConfig());
       } catch (Exception e) {
-        log.warn(
-            "Failed to automatically obtain DelegationToken, Mappers/Reducers will likely fail to communicate with Accumulo",
-            e);
+        log.warn("Failed to automatically obtain DelegationToken, "
+            + "Mappers/Reducers will likely fail to communicate with Accumulo", e);
       }
     }
     // DelegationTokens can be passed securely from user to task without serializing insecurely in
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloRowInputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloRowInputFormat.java
index aeec37d..787eacb 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloRowInputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloRowInputFormat.java
@@ -56,35 +56,39 @@ public class AccumuloRowInputFormat
   public RecordReader<Text,PeekingIterator<Entry<Key,Value>>> getRecordReader(InputSplit split,
       JobConf job, Reporter reporter) throws IOException {
     log.setLevel(getLogLevel(job));
-    RecordReaderBase<Text,PeekingIterator<Entry<Key,Value>>> recordReader = new RecordReaderBase<Text,PeekingIterator<Entry<Key,Value>>>() {
-      RowIterator rowIterator;
+    // @formatter:off
+    RecordReaderBase<Text,PeekingIterator<Entry<Key,Value>>> recordReader =
+      new RecordReaderBase<Text,PeekingIterator<Entry<Key,Value>>>() {
+    // @formatter:on
+          RowIterator rowIterator;
 
-      @Override
-      public void initialize(InputSplit inSplit, JobConf job) throws IOException {
-        super.initialize(inSplit, job);
-        rowIterator = new RowIterator(scannerIterator);
-      }
+          @Override
+          public void initialize(InputSplit inSplit, JobConf job) throws IOException {
+            super.initialize(inSplit, job);
+            rowIterator = new RowIterator(scannerIterator);
+          }
 
-      @Override
-      public boolean next(Text key, PeekingIterator<Entry<Key,Value>> value) throws IOException {
-        if (!rowIterator.hasNext())
-          return false;
-        value.initialize(rowIterator.next());
-        numKeysRead = rowIterator.getKVCount();
-        key.set((currentKey = value.peek().getKey()).getRow());
-        return true;
-      }
+          @Override
+          public boolean next(Text key, PeekingIterator<Entry<Key,Value>> value)
+              throws IOException {
+            if (!rowIterator.hasNext())
+              return false;
+            value.initialize(rowIterator.next());
+            numKeysRead = rowIterator.getKVCount();
+            key.set((currentKey = value.peek().getKey()).getRow());
+            return true;
+          }
 
-      @Override
-      public Text createKey() {
-        return new Text();
-      }
+          @Override
+          public Text createKey() {
+            return new Text();
+          }
 
-      @Override
-      public PeekingIterator<Entry<Key,Value>> createValue() {
-        return new PeekingIterator<>();
-      }
-    };
+          @Override
+          public PeekingIterator<Entry<Key,Value>> createValue() {
+            return new PeekingIterator<>();
+          }
+        };
     recordReader.initialize(split, job);
     return recordReader;
   }
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 b81d930..169fcd3 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
@@ -147,9 +147,8 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
         Connector conn = instance.getConnector(principal, token);
         token = conn.securityOperations().getDelegationToken(new DelegationTokenConfig());
       } catch (Exception e) {
-        log.warn(
-            "Failed to automatically obtain DelegationToken, Mappers/Reducers will likely fail to communicate with Accumulo",
-            e);
+        log.warn("Failed to automatically obtain DelegationToken, "
+            + "Mappers/Reducers will likely fail to communicate with Accumulo", e);
       }
     }
     // DelegationTokens can be passed securely from user to task without serializing insecurely in
@@ -771,8 +770,8 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
       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");
+        throw new IllegalArgumentException("BatchScanner optimization not available for offline"
+            + " scan, isolated, or local iterators");
 
       boolean autoAdjust = tableConfig.shouldAutoAdjustRanges();
       if (batchScan && !autoAdjust)
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 5c5fa18..c4515a2 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
@@ -56,7 +56,10 @@ public class AccumuloInputFormat extends InputFormatBase<Key,Value> {
     // Override the log level from the configuration as if the InputSplit has one it's the more
     // correct one to use.
     if (split instanceof org.apache.accumulo.core.client.mapreduce.RangeInputSplit) {
-      org.apache.accumulo.core.client.mapreduce.RangeInputSplit accSplit = (org.apache.accumulo.core.client.mapreduce.RangeInputSplit) split;
+      // @formatter:off
+      org.apache.accumulo.core.client.mapreduce.RangeInputSplit accSplit =
+        (org.apache.accumulo.core.client.mapreduce.RangeInputSplit) split;
+      // @formatter:on
       Level level = accSplit.getLogLevel();
       if (null != level) {
         log.setLevel(level);
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloOutputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloOutputFormat.java
index a4ebf3a..8b82e7c 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloOutputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloOutputFormat.java
@@ -112,9 +112,8 @@ public class AccumuloOutputFormat extends OutputFormat<Text,Mutation> {
         Connector conn = instance.getConnector(principal, token);
         token = conn.securityOperations().getDelegationToken(new DelegationTokenConfig());
       } catch (Exception e) {
-        log.warn(
-            "Failed to automatically obtain DelegationToken, Mappers/Reducers will likely fail to communicate with Accumulo",
-            e);
+        log.warn("Failed to automatically obtain DelegationToken, "
+            + "Mappers/Reducers will likely fail to communicate with Accumulo", e);
       }
     }
     // DelegationTokens can be passed securely from user to task without serializing insecurely in
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/InputConfigurator.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/InputConfigurator.java
index b5fd34c..e99a0e6 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/InputConfigurator.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/InputConfigurator.java
@@ -685,8 +685,8 @@ public class InputConfigurator extends ConfiguratorBase {
         mapWritable.readFields(new DataInputStream(bais));
         bais.close();
       } catch (IOException e) {
-        throw new IllegalStateException(
-            "The table query configurations could not be deserialized from the given configuration");
+        throw new IllegalStateException("The table query configurations could not be deserialized"
+            + " from the given configuration");
       }
     }
     for (Map.Entry<Writable,Writable> entry : mapWritable.entrySet())
diff --git a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileWriter.java b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileWriter.java
index 0fb5919..a0703fd 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileWriter.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileWriter.java
@@ -35,14 +35,13 @@ import org.apache.commons.collections.map.LRUMap;
 
 import com.google.common.base.Preconditions;
 
-//formatter was adding spaces that checkstyle did not like, so turned off formatter
-//@formatter:off
 /**
- * This class provides an API for writing RFiles. It can be used to create file for bulk import into Accumulo using
- * {@link TableOperations#importDirectory(String, String, String, boolean)}
+ * This class provides an API for writing RFiles. It can be used to create file for bulk import into
+ * Accumulo using {@link TableOperations#importDirectory(String, String, String, boolean)}
  *
  * <p>
- * A RFileWriter has the following constraints. Violating these constraints will result in runtime exceptions.
+ * A RFileWriter has the following constraints. Violating these constraints will result in runtime
+ * exceptions.
  *
  * <ul>
  * <li>Keys must be appended in sorted order within a locality group.</li>
@@ -70,9 +69,11 @@ import com.google.common.base.Preconditions;
  *       writer.startNewLocalityGroup("groupB", "columnFam3", "columnFam4");
  *       writer.append(localityGroup2Data);
  *
- *       // The default locality group must be started last. The column families for the default group do not need to be specified.
+ *       // The default locality group must be started last.
+ *       // The column families for the default group do not need to be specified.
  *       writer.startDefaultLocalityGroup();
- *       // Data appended here can not contain any column families specified in previous locality groups.
+ *       // Data appended here can not contain any
+ *       // column families specified in previous locality groups.
  *       writer.append(defaultGroupData);
  *
  *       // This is a try-with-resources so the writer is closed here at the end of the code block.
@@ -85,7 +86,6 @@ import com.google.common.base.Preconditions;
  *
  * @since 1.8.0
  */
-// @formatter:on
 public class RFileWriter implements AutoCloseable {
 
   private FileSKVWriter writer;
diff --git a/core/src/main/java/org/apache/accumulo/core/client/sample/RowColumnSampler.java b/core/src/main/java/org/apache/accumulo/core/client/sample/RowColumnSampler.java
index 69dfe7a..82cd577 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/sample/RowColumnSampler.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/sample/RowColumnSampler.java
@@ -48,8 +48,12 @@ import com.google.common.collect.ImmutableSet;
  * To configure Accumulo to generate sample data on one thousandth of the column qualifiers, the
  * following SamplerConfiguration could be created and used to configure a table.
  *
- * <p>
- * {@code new SamplerConfiguration(RowColumnSampler.class.getName()).setOptions(ImmutableMap.of("hasher","murmur3_32","modulus","1009","qualifier","true"))}
+ * <pre>
+ * <code>
+ * new SamplerConfiguration(RowColumnSampler.class.getName()).setOptions(
+ *   ImmutableMap.of("hasher","murmur3_32","modulus","1009","qualifier","true"));
+ * </code>
+ * </pre>
  *
  * <p>
  * With this configuration, if a column qualifier is selected then all key values contains that
diff --git a/core/src/main/java/org/apache/accumulo/core/client/sample/RowSampler.java b/core/src/main/java/org/apache/accumulo/core/client/sample/RowSampler.java
index 7526394..5c202f0 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/sample/RowSampler.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/sample/RowSampler.java
@@ -35,8 +35,12 @@ import org.apache.accumulo.core.data.Key;
  * To configure Accumulo to generate sample data on one thousandth of the rows, the following
  * SamplerConfiguration could be created and used to configure a table.
  *
- * <p>
- * {@code new SamplerConfiguration(RowSampler.class.getName()).setOptions(ImmutableMap.of("hasher","murmur3_32","modulus","1009"))}
+ * <pre>
+ * <code>
+ * new SamplerConfiguration(RowSampler.class.getName()).setOptions(
+ *   ImmutableMap.of("hasher","murmur3_32","modulus","1009"));
+ * </code>
+ * </pre>
  *
  * @since 1.8.0
  */
diff --git a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/AuthenticationToken.java b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/AuthenticationToken.java
index 5e955d3..dcb1dff 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/AuthenticationToken.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/AuthenticationToken.java
@@ -95,9 +95,11 @@ public interface AuthenticationToken extends Writable, Destroyable, Cloneable {
     public static AuthenticationToken deserialize(String tokenClassName, byte[] tokenBytes) {
       Class<? extends AuthenticationToken> tokenType = null;
       try {
+        // @formatter:off
         @SuppressWarnings("unchecked")
-        Class<? extends AuthenticationToken> tmpTokenType = (Class<? extends AuthenticationToken>) Class
-            .forName(tokenClassName);
+        Class<? extends AuthenticationToken> tmpTokenType =
+          (Class<? extends AuthenticationToken>) Class.forName(tokenClassName);
+        // @formatter:on
         tokenType = tmpTokenType;
       } catch (ClassNotFoundException e) {
         throw new IllegalArgumentException("Class not available " + tokenClassName, e);
diff --git a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/KerberosToken.java b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/KerberosToken.java
index 99f68df..8a8bae8 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/KerberosToken.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/KerberosToken.java
@@ -70,8 +70,8 @@ public class KerberosToken implements AuthenticationToken {
     // There is also KERBEROS_SSL but that appears to be deprecated/OBE
     checkArgument(
         AuthenticationMethod.KERBEROS == authMethod || AuthenticationMethod.PROXY == authMethod,
-        "KerberosToken expects KERBEROS or PROXY authentication for the current UserGroupInformation user. Saw "
-            + authMethod);
+        "KerberosToken expects KERBEROS or PROXY authentication for the current "
+            + "UserGroupInformation user. Saw " + authMethod);
   }
 
   /**
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/AccumuloConfiguration.java b/core/src/main/java/org/apache/accumulo/core/conf/AccumuloConfiguration.java
index 28c44e6..8763875 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/AccumuloConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/AccumuloConfiguration.java
@@ -442,8 +442,8 @@ public abstract class AccumuloConfiguration implements Iterable<Entry<String,Str
           ports[0] = port;
         }
       } catch (NumberFormatException e1) {
-        throw new IllegalArgumentException(
-            "Invalid port syntax. Must be a single positive integers or a range (M-N) of positive integers");
+        throw new IllegalArgumentException("Invalid port syntax. Must be a single positive "
+            + "integers or a range (M-N) of positive integers");
       }
     }
     return ports;
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/CredentialProviderFactoryShim.java b/core/src/main/java/org/apache/accumulo/core/conf/CredentialProviderFactoryShim.java
index e837c81..8df237b 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/CredentialProviderFactoryShim.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/CredentialProviderFactoryShim.java
@@ -42,17 +42,25 @@ import org.slf4j.LoggerFactory;
 public class CredentialProviderFactoryShim {
   private static final Logger log = LoggerFactory.getLogger(CredentialProviderFactoryShim.class);
 
-  public static final String HADOOP_CRED_PROVIDER_FACTORY_CLASS_NAME = "org.apache.hadoop.security.alias.JavaKeyStoreProvider$Factory";
-  public static final String HADOOP_CRED_PROVIDER_FACTORY_GET_PROVIDERS_METHOD_NAME = "getProviders";
-
-  public static final String HADOOP_CRED_PROVIDER_CLASS_NAME = "org.apache.hadoop.security.alias.CredentialProvider";
-  public static final String HADOOP_CRED_PROVIDER_GET_CREDENTIAL_ENTRY_METHOD_NAME = "getCredentialEntry";
+  // @formatter:off
+  public static final String HADOOP_CRED_PROVIDER_FACTORY_CLASS_NAME =
+    "org.apache.hadoop.security.alias.JavaKeyStoreProvider$Factory";
+  public static final String HADOOP_CRED_PROVIDER_FACTORY_GET_PROVIDERS_METHOD_NAME =
+    "getProviders";
+
+  public static final String HADOOP_CRED_PROVIDER_CLASS_NAME =
+    "org.apache.hadoop.security.alias.CredentialProvider";
+  public static final String HADOOP_CRED_PROVIDER_GET_CREDENTIAL_ENTRY_METHOD_NAME =
+    "getCredentialEntry";
   public static final String HADOOP_CRED_PROVIDER_GET_ALIASES_METHOD_NAME = "getAliases";
-  public static final String HADOOP_CRED_PROVIDER_CREATE_CREDENTIAL_ENTRY_METHOD_NAME = "createCredentialEntry";
+  public static final String HADOOP_CRED_PROVIDER_CREATE_CREDENTIAL_ENTRY_METHOD_NAME =
+    "createCredentialEntry";
   public static final String HADOOP_CRED_PROVIDER_FLUSH_METHOD_NAME = "flush";
 
-  public static final String HADOOP_CRED_ENTRY_CLASS_NAME = "org.apache.hadoop.security.alias.CredentialProvider$CredentialEntry";
+  public static final String HADOOP_CRED_ENTRY_CLASS_NAME =
+    "org.apache.hadoop.security.alias.CredentialProvider$CredentialEntry";
   public static final String HADOOP_CRED_ENTRY_GET_CREDENTIAL_METHOD_NAME = "getCredential";
+  // @formatter:on
 
   public static final String CREDENTIAL_PROVIDER_PATH = "hadoop.security.credential.provider.path";
 
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 5c93195..eea039f 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
@@ -46,29 +46,34 @@ public enum Property {
   // Crypto-related properties
   @Experimental
   CRYPTO_PREFIX("crypto.", null, PropertyType.PREFIX,
-      "Properties in this category related to the configuration of both default and custom crypto modules."),
+      "Properties in this category related to the configuration of both default and custom crypto"
+          + " modules."),
   @Experimental
   CRYPTO_MODULE_CLASS("crypto.module.class", "NullCryptoModule", PropertyType.STRING,
-      "Fully qualified class name of the class that implements the CryptoModule interface, to be used in setting up encryption at rest for the WAL and "
-          + "(future) other parts of the code."),
+      "Fully qualified class name of the class that implements the CryptoModule"
+          + " interface, to be used in setting up encryption at rest for the WAL and"
+          + " (future) other parts of the code."),
   @Experimental
   CRYPTO_CIPHER_SUITE("crypto.cipher.suite", "NullCipher", PropertyType.STRING,
       "Describes the cipher suite to use for the write-ahead log"),
   @Experimental
   CRYPTO_CIPHER_ALGORITHM_NAME("crypto.cipher.algorithm.name", "NullCipher", PropertyType.STRING,
-      "States the name of the algorithm used in the corresponding cipher suite. Do not make these different, unless you enjoy mysterious exceptions and bugs."),
+      "States the name of the algorithm used in the corresponding cipher suite. "
+          + "Do not make these different, unless you enjoy mysterious exceptions and bugs."),
   @Experimental
   CRYPTO_BLOCK_STREAM_SIZE("crypto.block.stream.size", "1K", PropertyType.MEMORY,
-      "The size of the buffer above the cipher stream. Used for reading files and padding walog entries."),
+      "The size of the buffer above the cipher stream."
+          + " Used for reading files and padding walog entries."),
   @Experimental
   CRYPTO_CIPHER_KEY_LENGTH("crypto.cipher.key.length", "128", PropertyType.STRING,
-      "Specifies the key length *in bits* to use for the symmetric key, should probably be 128 or 256 unless you really know what you're doing"),
+      "Specifies the key length *in bits* to use for the symmetric key, "
+          + "should probably be 128 or 256 unless you really know what you're doing"),
   @Experimental
   CRYPTO_SECURE_RNG("crypto.secure.rng", "SHA1PRNG", PropertyType.STRING,
-      "States the secure random number generator to use, and defaults to the built-in Sun SHA1PRNG"),
+      "States the secure random number generator to use, and defaults to the built-in SHA1PRNG"),
   @Experimental
   CRYPTO_SECURE_RNG_PROVIDER("crypto.secure.rng.provider", "SUN", PropertyType.STRING,
-      "States the secure random number generator provider to use, and defaults to the built-in SUN provider"),
+      "States the secure random number generator provider to use."),
   @Experimental
   CRYPTO_SECRET_KEY_ENCRYPTION_STRATEGY_CLASS("crypto.secret.key.encryption.strategy.class",
       "NullSecretKeyEncryptionStrategy", PropertyType.STRING,
@@ -76,32 +81,41 @@ public enum Property {
   @Experimental
   CRYPTO_DEFAULT_KEY_STRATEGY_HDFS_URI("crypto.default.key.strategy.hdfs.uri", "",
       PropertyType.STRING,
-      "The path relative to the top level instance directory (instance.dfs.dir) where to store the key encryption key within HDFS."),
+      "The path relative to the top level instance directory (instance.dfs.dir) where to store"
+          + " the key encryption key within HDFS."),
   @Experimental
   CRYPTO_DEFAULT_KEY_STRATEGY_KEY_LOCATION("crypto.default.key.strategy.key.location",
       "/crypto/secret/keyEncryptionKey", PropertyType.ABSOLUTEPATH,
-      "The path relative to the top level instance directory (instance.dfs.dir) where to store the key encryption key within HDFS."),
+      "The path relative to the top level instance directory (instance.dfs.dir) where to store"
+          + " the key encryption key within HDFS."),
   @Experimental
   CRYPTO_DEFAULT_KEY_STRATEGY_CIPHER_SUITE("crypto.default.key.strategy.cipher.suite", "NullCipher",
       PropertyType.STRING,
-      "The cipher suite to use when encrypting session keys with a key encryption keyThis should be set to match the overall encryption algorithm "
-          + "but with ECB mode and no padding unless you really know what you're doing and are sure you won't break internal file formats"),
+      "The cipher suite to use when encrypting session keys with a key"
+          + " encryption keyThis should be set to match the overall encryption"
+          + " algorithm but with ECB mode and no padding unless you really know what"
+          + " you're doing and are sure you won't break internal file formats"),
   @Experimental
   CRYPTO_OVERRIDE_KEY_STRATEGY_WITH_CONFIGURED_STRATEGY(
       "crypto.override.key.strategy.with.configured.strategy", "false", PropertyType.BOOLEAN,
-      "The default behavior is to record the key encryption strategy with the encrypted file, and continue to use that strategy for the life "
-          + "of that file. Sometimes, you change your strategy and want to use the new strategy, not the old one. (Most commonly, this will be "
-          + "because you have moved key material from one spot to another.)  If you want to override the recorded key strategy with the one in "
-          + "the configuration file, set this property to true."),
+      "The default behavior is to record the key encryption strategy with the"
+          + " encrypted file, and continue to use that strategy for the life of that"
+          + " file. Sometimes, you change your strategy and want to use the new"
+          + " strategy, not the old one. (Most commonly, this will be because you have"
+          + " moved key material from one spot to another.) If you want to override"
+          + " the recorded key strategy with the one in the configuration file, set"
+          + " this property to true."),
   // SSL properties local to each node (see also instance.ssl.enabled which must be consistent
   // across all nodes in an instance)
   RPC_PREFIX("rpc.", null, PropertyType.PREFIX,
-      "Properties in this category related to the configuration of SSL keys for RPC. See also instance.ssl.enabled"),
+      "Properties in this category related to the configuration of SSL keys for RPC."
+          + " See also instance.ssl.enabled"),
   RPC_SSL_KEYSTORE_PATH("rpc.javax.net.ssl.keyStore", "$ACCUMULO_CONF_DIR/ssl/keystore.jks",
       PropertyType.PATH, "Path of the keystore file for the servers' private SSL key"),
   @Sensitive
   RPC_SSL_KEYSTORE_PASSWORD("rpc.javax.net.ssl.keyStorePassword", "", PropertyType.STRING,
-      "Password used to encrypt the SSL private keystore. Leave blank to use the Accumulo instance secret"),
+      "Password used to encrypt the SSL private keystore. "
+          + "Leave blank to use the Accumulo instance secret"),
   RPC_SSL_KEYSTORE_TYPE("rpc.javax.net.ssl.keyStoreType", "jks", PropertyType.STRING,
       "Type of SSL keystore"),
   RPC_SSL_TRUSTSTORE_PATH("rpc.javax.net.ssl.trustStore", "$ACCUMULO_CONF_DIR/ssl/truststore.jks",
@@ -121,109 +135,140 @@ public enum Property {
       "Comma separated list of protocols that can be used to accept connections"),
   // TLSv1.2 should be used as the default when JDK6 support is dropped
   RPC_SSL_CLIENT_PROTOCOL("rpc.ssl.client.protocol", "TLSv1", PropertyType.STRING,
-      "The protocol used to connect to a secure server, must be in the list of enabled protocols on the server side (rpc.ssl.server.enabled.protocols)"),
+      "The protocol used to connect to a secure server, must be in the list of enabled protocols "
+          + "on the server side (rpc.ssl.server.enabled.protocols)"),
   /**
    * @since 1.7.0
    */
   RPC_SASL_QOP("rpc.sasl.qop", "auth", PropertyType.STRING,
-      "The quality of protection to be used with SASL. Valid values are 'auth', 'auth-int', and 'auth-conf'"),
+      "The quality of protection to be used with SASL. Valid values are 'auth', 'auth-int',"
+          + " and 'auth-conf'"),
 
   // instance properties (must be the same for every node in an instance)
   INSTANCE_PREFIX("instance.", null, PropertyType.PREFIX,
-      "Properties in this category must be consistent throughout a cloud. This is enforced and servers won't be able to communicate if these differ."),
+      "Properties in this category must be consistent throughout a cloud. "
+          + "This is enforced and servers won't be able to communicate if these differ."),
   INSTANCE_ZK_HOST("instance.zookeeper.host", "localhost:2181", PropertyType.HOSTLIST,
       "Comma separated list of zookeeper servers"),
   INSTANCE_ZK_TIMEOUT("instance.zookeeper.timeout", "30s", PropertyType.TIMEDURATION,
-      "Zookeeper session timeout; max value when represented as milliseconds should be no larger than "
+      "Zookeeper session timeout; "
+          + "max value when represented as milliseconds should be no larger than "
           + Integer.MAX_VALUE),
   @Deprecated
   INSTANCE_DFS_URI("instance.dfs.uri", "", PropertyType.URI,
-      "A url accumulo should use to connect to DFS. If this is empty, accumulo will obtain this information from the hadoop configuration. This property "
-          + "will only be used when creating new files if instance.volumes is empty. After an upgrade to 1.6.0 Accumulo will start using absolute paths to "
-          + "reference files. Files created before a 1.6.0 upgrade are referenced via relative paths. Relative paths will always be resolved using this "
-          + "config (if empty using the hadoop config)."),
+      "A url accumulo should use to connect to DFS. If this is empty, accumulo"
+          + " will obtain this information from the hadoop configuration. This property"
+          + " will only be used when creating new files if instance.volumes is empty."
+          + " After an upgrade to 1.6.0 Accumulo will start using absolute paths to"
+          + " reference files. Files created before a 1.6.0 upgrade are referenced via"
+          + " relative paths. Relative paths will always be resolved using this config"
+          + " (if empty using the hadoop config)."),
   @Deprecated
   INSTANCE_DFS_DIR("instance.dfs.dir", "/accumulo", PropertyType.ABSOLUTEPATH,
-      "HDFS directory in which accumulo instance will run. Do not change after accumulo is initialized."),
+      "HDFS directory in which accumulo instance will run. "
+          + "Do not change after accumulo is initialized."),
   @Sensitive
   INSTANCE_SECRET("instance.secret", "DEFAULT", PropertyType.STRING,
-      "A secret unique to a given instance that all servers must know in order to communicate with one another."
-          + "It should be changed prior to the initialization of Accumulo. To change it after Accumulo has been initialized, use the ChangeSecret tool "
-          + "and then update conf/accumulo-site.xml everywhere. Before using the ChangeSecret tool, make sure Accumulo is not running and you are logged "
-          + "in as the user that controls Accumulo files in HDFS.  To use the ChangeSecret tool, run the command: "
-          + "./bin/accumulo org.apache.accumulo.server.util.ChangeSecret"),
+      "A secret unique to a given instance that all servers must know in order"
+          + " to communicate with one another. It should be changed prior to the"
+          + " initialization of Accumulo. To change it after Accumulo has been"
+          + " initialized, use the ChangeSecret tool and then update"
+          + " conf/accumulo-site.xml everywhere. Before using the ChangeSecret tool,"
+          + " make sure Accumulo is not running and you are logged in as the user that"
+          + " controls Accumulo files in HDFS. To use the ChangeSecret tool, run the"
+          + " command: ./bin/accumulo org.apache.accumulo.server.util.ChangeSecret"),
   INSTANCE_VOLUMES("instance.volumes", "", PropertyType.STRING,
-      "A comma seperated list of dfs uris to use. Files will be stored across these filesystems. If this is empty, then instance.dfs.uri will be used. "
-          + "After adding uris to this list, run 'accumulo init --add-volume' and then restart tservers. If entries are removed from this list then tservers "
-          + "will need to be restarted. After a uri is removed from the list Accumulo will not create new files in that location, however Accumulo can still "
-          + "reference files created at that location before the config change. To use a comma or other reserved characters in a URI use standard URI hex "
-          + "encoding. For example replace commas with %2C."),
+      "A comma seperated list of dfs uris to use. Files will be stored across"
+          + " these filesystems. If this is empty, then instance.dfs.uri will be used."
+          + " After adding uris to this list, run 'accumulo init --add-volume' and then"
+          + " restart tservers. If entries are removed from this list then tservers"
+          + " will need to be restarted. After a uri is removed from the list Accumulo"
+          + " will not create new files in that location, however Accumulo can still"
+          + " reference files created at that location before the config change. To use"
+          + " a comma or other reserved characters in a URI use standard URI hex"
+          + " encoding. For example replace commas with %2C."),
   INSTANCE_VOLUMES_REPLACEMENTS("instance.volumes.replacements", "", PropertyType.STRING,
-      "Since accumulo stores absolute URIs changing the location of a namenode could prevent Accumulo from starting. The property helps deal with that "
-          + "situation. Provide a comma separated list of uri replacement pairs here if a namenode location changes. Each pair shold be separated with a "
-          + "space. For example, if hdfs://nn1 was replaced with hdfs://nnA and hdfs://nn2 was replaced with hdfs://nnB, then set this property to "
-          + "'hdfs://nn1 hdfs://nnA,hdfs://nn2 hdfs://nnB' Replacements must be configured for use. To see which volumes are currently in use, run "
-          + "'accumulo admin volumes -l'. To use a comma or other reserved characters in a URI use standard URI hex encoding. For example replace commas with "
-          + "%2C."),
+      "Since accumulo stores absolute URIs changing the location of a namenode "
+          + "could prevent Accumulo from starting. The property helps deal with "
+          + "that situation. Provide a comma separated list of uri replacement "
+          + "pairs here if a namenode location changes. Each pair shold be separated "
+          + "with a space. For example, if hdfs://nn1 was replaced with "
+          + "hdfs://nnA and hdfs://nn2 was replaced with hdfs://nnB, then set this "
+          + "property to 'hdfs://nn1 hdfs://nnA,hdfs://nn2 hdfs://nnB' "
+          + "Replacements must be configured for use. To see which volumes are "
+          + "currently in use, run 'accumulo admin volumes -l'. To use a comma or "
+          + "other reserved characters in a URI use standard URI hex encoding. For "
+          + "example replace commas with %2C."),
   INSTANCE_SECURITY_AUTHENTICATOR("instance.security.authenticator",
       "org.apache.accumulo.server.security.handler.ZKAuthenticator", PropertyType.CLASSNAME,
-      "The authenticator class that accumulo will use to determine if a user has privilege to perform an action"),
+      "The authenticator class that accumulo will use to determine if a user "
+          + "has privilege to perform an action"),
   INSTANCE_SECURITY_AUTHORIZOR("instance.security.authorizor",
       "org.apache.accumulo.server.security.handler.ZKAuthorizor", PropertyType.CLASSNAME,
-      "The authorizor class that accumulo will use to determine what labels a user has privilege to see"),
+      "The authorizor class that accumulo will use to determine what labels a "
+          + "user has privilege to see"),
   INSTANCE_SECURITY_PERMISSION_HANDLER("instance.security.permissionHandler",
       "org.apache.accumulo.server.security.handler.ZKPermHandler", PropertyType.CLASSNAME,
-      "The permission handler class that accumulo will use to determine if a user has privilege to perform an action"),
+      "The permission handler class that accumulo will use to determine if a "
+          + "user has privilege to perform an action"),
   INSTANCE_RPC_SSL_ENABLED("instance.rpc.ssl.enabled", "false", PropertyType.BOOLEAN,
-      "Use SSL for socket connections from clients and among accumulo services. Mutually exclusive with SASL RPC configuration."),
+      "Use SSL for socket connections from clients and among accumulo services. "
+          + "Mutually exclusive with SASL RPC configuration."),
   INSTANCE_RPC_SSL_CLIENT_AUTH("instance.rpc.ssl.clientAuth", "false", PropertyType.BOOLEAN,
       "Require clients to present certs signed by a trusted root"),
   /**
    * @since 1.7.0
    */
   INSTANCE_RPC_SASL_ENABLED("instance.rpc.sasl.enabled", "false", PropertyType.BOOLEAN,
-      "Configures Thrift RPCs to require SASL with GSSAPI which supports Kerberos authentication. Mutually exclusive with SSL RPC configuration."),
+      "Configures Thrift RPCs to require SASL with GSSAPI which supports "
+          + "Kerberos authentication. Mutually exclusive with SSL RPC configuration."),
   @Deprecated
   INSTANCE_RPC_SASL_PROXYUSERS("instance.rpc.sasl.impersonation.", null, PropertyType.PREFIX,
       "Prefix that allows configuration of users that are allowed to impersonate other users"),
   INSTANCE_RPC_SASL_ALLOWED_USER_IMPERSONATION("instance.rpc.sasl.allowed.user.impersonation", "",
       PropertyType.STRING,
-      "One-line configuration property controlling what users are allowed to impersonate other users"),
+      "One-line configuration property controlling what users are allowed to "
+          + "impersonate other users"),
   INSTANCE_RPC_SASL_ALLOWED_HOST_IMPERSONATION("instance.rpc.sasl.allowed.host.impersonation", "",
       PropertyType.STRING,
-      "One-line configuration property controlling the network locations (hostnames) that are allowed to impersonate other users"),
+      "One-line configuration property controlling the network locations "
+          + "(hostnames) that are allowed to impersonate other users"),
 
   // general properties
   GENERAL_PREFIX("general.", null, PropertyType.PREFIX,
-      "Properties in this category affect the behavior of accumulo overall, but do not have to be consistent throughout a cloud."),
+      "Properties in this category affect the behavior of accumulo overall, but "
+          + "do not have to be consistent throughout a cloud."),
   GENERAL_CLASSPATHS(AccumuloClassLoader.CLASSPATH_PROPERTY_NAME,
       AccumuloClassLoader.ACCUMULO_CLASSPATH_VALUE, PropertyType.STRING,
-      "A list of all of the places to look for a class. Order does matter, as it will look for the jar "
-          + "starting in the first location to the last. Please note, hadoop conf and hadoop lib directories NEED to be here, "
-          + "along with accumulo lib and zookeeper directory. Supports full regex on filename alone."), // needs
-                                                                                                        // special
-                                                                                                        // treatment
-                                                                                                        // in
-                                                                                                        // accumulo
-                                                                                                        // start
-                                                                                                        // jar
+      "A list of all of the places to look for a class. Order does matter, as "
+          + "it will look for the jar starting in the first location to the last. "
+          + "Please note, hadoop conf and hadoop lib directories NEED to be here, "
+          + "along with accumulo lib and zookeeper directory. Supports full regex on "
+          + " filename alone."),
+
+  // needs special treatment in accumulo start jar
   GENERAL_DYNAMIC_CLASSPATHS(AccumuloVFSClassLoader.DYNAMIC_CLASSPATH_PROPERTY_NAME,
       AccumuloVFSClassLoader.DEFAULT_DYNAMIC_CLASSPATH_VALUE, PropertyType.STRING,
-      "A list of all of the places where changes in jars or classes will force a reload of the classloader."),
+      "A list of all of the places where changes in jars or classes will force "
+          + "a reload of the classloader."),
   GENERAL_RPC_TIMEOUT("general.rpc.timeout", "120s", PropertyType.TIMEDURATION,
       "Time to wait on I/O for simple, short RPC calls"),
   @Experimental
   GENERAL_RPC_SERVER_TYPE("general.rpc.server.type", "", PropertyType.STRING,
-      "Type of Thrift server to instantiate, see org.apache.accumulo.server.rpc.ThriftServerType for more information. Only useful for benchmarking thrift servers"),
+      "Type of Thrift server to instantiate, see "
+          + "org.apache.accumulo.server.rpc.ThriftServerType for more information. "
+          + "Only useful for benchmarking thrift servers"),
   GENERAL_KERBEROS_KEYTAB("general.kerberos.keytab", "", PropertyType.PATH,
       "Path to the kerberos keytab to use. Leave blank if not using kerberoized hdfs"),
   GENERAL_KERBEROS_PRINCIPAL("general.kerberos.principal", "", PropertyType.STRING,
       "Name of the kerberos principal to use. _HOST will automatically be "
-          + "replaced by the machines hostname in the hostname portion of the principal. Leave blank if not using kerberoized hdfs"),
+          + "replaced by the machines hostname in the hostname portion of the "
+          + "principal. Leave blank if not using kerberoized hdfs"),
   GENERAL_KERBEROS_RENEWAL_PERIOD("general.kerberos.renewal.period", "30s",
       PropertyType.TIMEDURATION,
-      "The amount of time between attempts to perform "
-          + "Kerberos ticket renewals. This does not equate to how often tickets are actually renewed (which is performed at 80% of the ticket lifetime)."),
+      "The amount of time between attempts to perform Kerberos ticket renewals. "
+          + "This does not equate to how often tickets are actually renewed (which is "
+          + "performed at 80% of the ticket lifetime)."),
   GENERAL_MAX_MESSAGE_SIZE("general.server.message.size.max", "1G", PropertyType.MEMORY,
       "The maximum size of a message that can be sent to a server."),
   GENERAL_SIMPLETIMER_THREADPOOL_SIZE("general.server.simpletimer.threadpool.size", "1",
@@ -237,7 +282,8 @@ public enum Property {
   GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS("general.security.credential.provider.paths", "",
       PropertyType.STRING, "Comma-separated list of paths to CredentialProviders"),
   GENERAL_LEGACY_METRICS("general.legacy.metrics", "false", PropertyType.BOOLEAN,
-      "Use the old metric infrastructure configured by accumulo-metrics.xml, instead of Hadoop Metrics2"),
+      "Use the old metric infrastructure configured by accumulo-metrics.xml, "
+          + "instead of Hadoop Metrics2"),
   GENERAL_DELEGATION_TOKEN_LIFETIME("general.delegation.token.lifetime", "7d",
       PropertyType.TIMEDURATION,
       "The length of time that delegation tokens and secret keys are valid"),
@@ -254,7 +300,8 @@ public enum Property {
       "The port used for handling client connections on the master"),
   MASTER_TABLET_BALANCER("master.tablet.balancer",
       "org.apache.accumulo.server.master.balancer.TableLoadBalancer", PropertyType.CLASSNAME,
-      "The balancer class that accumulo will use to make tablet assignment and migration decisions."),
+      "The balancer class that accumulo will use to make tablet assignment and "
+          + "migration decisions."),
   MASTER_RECOVERY_MAXAGE("master.recovery.max.age", "60m", PropertyType.TIMEDURATION,
       "Recovery files older than this age will be removed."),
   MASTER_RECOVERY_MAXTIME("master.recovery.time.max", "30m", PropertyType.TIMEDURATION,
@@ -266,13 +313,15 @@ public enum Property {
   MASTER_BULK_TIMEOUT("master.bulk.timeout", "5m", PropertyType.TIMEDURATION,
       "The time to wait for a tablet server to process a bulk import request"),
   MASTER_BULK_RENAME_THREADS("master.bulk.rename.threadpool.size", "20", PropertyType.COUNT,
-      "The number of threads to use when moving user files to bulk ingest directories under accumulo control"),
+      "The number of threads to use when moving user files to bulk ingest "
+          + "directories under accumulo control"),
   MASTER_MINTHREADS("master.server.threads.minimum", "20", PropertyType.COUNT,
       "The minimum number of threads to use to handle incoming requests."),
   MASTER_THREADCHECK("master.server.threadcheck.time", "1s", PropertyType.TIMEDURATION,
       "The time between adjustments of the server thread pool."),
   MASTER_RECOVERY_DELAY("master.recovery.delay", "10s", PropertyType.TIMEDURATION,
-      "When a tablet server's lock is deleted, it takes time for it to completely quit. This delay gives it time before log recoveries begin."),
+      "When a tablet server's lock is deleted, it takes time for it to "
+          + "completely quit. This delay gives it time before log recoveries begin."),
   MASTER_LEASE_RECOVERY_WAITING_PERIOD("master.lease.recovery.interval", "5s",
       PropertyType.TIMEDURATION,
       "The amount of time to wait after requesting a WAL file to be recovered"),
@@ -280,10 +329,12 @@ public enum Property {
       "org.apache.accumulo.server.master.recovery.HadoopLogCloser", PropertyType.CLASSNAME,
       "A class that implements a mechansim to steal write access to a file"),
   MASTER_FATE_THREADPOOL_SIZE("master.fate.threadpool.size", "4", PropertyType.COUNT,
-      "The number of threads used to run FAult-Tolerant Executions. These are primarily table operations like merge."),
+      "The number of threads used to run FAult-Tolerant Executions. These are "
+          + "primarily table operations like merge."),
   MASTER_REPLICATION_SCAN_INTERVAL("master.replication.status.scan.interval", "30s",
       PropertyType.TIMEDURATION,
-      "Amount of time to sleep before scanning the status section of the replication table for new data"),
+      "Amount of time to sleep before scanning the status section of the "
+          + "replication table for new data"),
   MASTER_REPLICATION_COORDINATOR_PORT("master.replication.coordinator.port", "10001",
       PropertyType.PORT, "Port for the replication coordinator service"),
   MASTER_REPLICATION_COORDINATOR_MINTHREADS("master.replication.coordinator.minthreads", "4",
@@ -315,25 +366,31 @@ public enum Property {
   @Deprecated
   TSERV_MUTATION_QUEUE_MAX("tserver.mutation.queue.max", "1M", PropertyType.MEMORY,
       "This setting is deprecated. See tserver.total.mutation.queue.max. "
-          + "The amount of memory to use to store write-ahead-log mutations-per-session before flushing them. Since the buffer is per write session, consider the"
-          + " max number of concurrent writer when configuring. When using Hadoop 2, Accumulo will call hsync() on the WAL . For a small number of "
-          + "concurrent writers, increasing this buffer size decreases the frequncy of hsync calls. For a large number of concurrent writers a small buffers "
-          + "size is ok because of group commit."),
+          + "The amount of memory to use to store write-ahead-log "
+          + "mutations-per-session before flushing them. Since the buffer is per "
+          + "write session, consider the max number of concurrent writer when "
+          + "configuring. When using Hadoop 2, Accumulo will call hsync() on the WAL. "
+          + "For a small number of concurrent writers, increasing this buffer size "
+          + "decreases the frequncy of hsync calls. For a large number of concurrent "
+          + "writers a small buffers size is ok because of group commit."),
   TSERV_TOTAL_MUTATION_QUEUE_MAX("tserver.total.mutation.queue.max", "50M", PropertyType.MEMORY,
       "The amount of memory used to store write-ahead-log mutations before flushing them."),
   TSERV_TABLET_SPLIT_FINDMIDPOINT_MAXOPEN("tserver.tablet.split.midpoint.files.max", "300",
       PropertyType.COUNT,
-      "To find a tablets split points, all index files are opened. This setting determines how many index "
-          + "files can be opened at once. When there are more index files than this setting multiple passes "
-          + "must be made, which is slower. However opening too many files at once can cause problems."),
+      "To find a tablets split points, all index files are opened. This setting "
+          + "determines how many index files can be opened at once. When there are "
+          + "more index files than this setting multiple passes must be made, which is "
+          + "slower. However opening too many files at once can cause problems."),
   TSERV_WALOG_MAX_SIZE("tserver.walog.max.size", "1G", PropertyType.MEMORY,
-      "The maximum size for each write-ahead log. See comment for property tserver.memory.maps.max"),
+      "The maximum size for each write-ahead log. See comment for tserver.memory.maps.max"),
   TSERV_WALOG_MAX_AGE("tserver.walog.max.age", "24h", PropertyType.TIMEDURATION,
       "The maximum age for each write-ahead log."),
   TSERV_WALOG_TOLERATED_CREATION_FAILURES("tserver.walog.tolerated.creation.failures", "50",
       PropertyType.COUNT,
-      "The maximum number of failures tolerated when creating a new WAL file.  Values < 0 will allow unlimited creation failures."
-          + " Exceeding this number of failures consecutively trying to create a new WAL causes the TabletServer to exit."),
+      "The maximum number of failures tolerated when creating a new WAL file. "
+          + "Negative values will allow unlimited creation failures. Exceeding this "
+          + "number of failures consecutively trying to create a new WAL causes the "
+          + "TabletServer to exit."),
   TSERV_WALOG_TOLERATED_WAIT_INCREMENT("tserver.walog.tolerated.wait.increment", "1000ms",
       PropertyType.TIMEDURATION,
       "The amount of time to wait between failures to create or write a WALog."),
@@ -348,23 +405,29 @@ public enum Property {
   TSERV_SCAN_MAX_OPENFILES("tserver.scan.files.open.max", "100", PropertyType.COUNT,
       "Maximum total files that all tablets in a tablet server can open for scans. "),
   TSERV_MAX_IDLE("tserver.files.open.idle", "1m", PropertyType.TIMEDURATION,
-      "Tablet servers leave previously used files open for future queries. "
-          + "This setting determines how much time an unused file should be kept open until it is closed."),
+      "Tablet servers leave previously used files open for future queries. This "
+          + "setting determines how much time an unused file should be kept open until "
+          + "it is closed."),
   TSERV_NATIVEMAP_ENABLED("tserver.memory.maps.native.enabled", "true", PropertyType.BOOLEAN,
-      "An in-memory data store for accumulo implemented in c++ that increases the amount of data accumulo can hold in memory and avoids Java GC pauses."),
+      "An in-memory data store for accumulo implemented in c++ that increases "
+          + "the amount of data accumulo can hold in memory and avoids Java GC " + "pauses."),
   TSERV_MAXMEM("tserver.memory.maps.max", "1G", PropertyType.MEMORY,
-      "Maximum amount of memory that can be used to buffer data written to a tablet server. There are two other properties that can effectively limit memory"
-          + " usage table.compaction.minor.logs.threshold and tserver.walog.max.size. Ensure that table.compaction.minor.logs.threshold *"
-          + " tserver.walog.max.size >= this property."),
+      "Maximum amount of memory that can be used to buffer data written to a"
+          + " tablet server. There are two other properties that can effectively limit"
+          + " memory usage table.compaction.minor.logs.threshold and"
+          + " tserver.walog.max.size. Ensure that table.compaction.minor.logs.threshold"
+          + " * tserver.walog.max.size >= this property."),
   TSERV_MEM_MGMT("tserver.memory.manager",
       "org.apache.accumulo.server.tabletserver.LargestFirstMemoryManager", PropertyType.CLASSNAME,
       "An implementation of MemoryManger that accumulo will use."),
   TSERV_SESSION_MAXIDLE("tserver.session.idle.max", "1m", PropertyType.TIMEDURATION,
-      "When a tablet server's SimpleTimer thread triggers to check "
-          + "idle sessions, this configurable option will be used to evaluate scan sessions to determine if they can be closed due to inactivity"),
+      "When a tablet server's SimpleTimer thread triggers to check idle"
+          + " sessions, this configurable option will be used to evaluate scan sessions"
+          + " to determine if they can be closed due to inactivity"),
   TSERV_UPDATE_SESSION_MAXIDLE("tserver.session.update.idle.max", "1m", PropertyType.TIMEDURATION,
-      "When a tablet server's SimpleTimer thread triggers to check "
-          + "idle sessions, this configurable option will be used to evaluate update sessions to determine if they can be closed due to inactivity"),
+      "When a tablet server's SimpleTimer thread triggers to check idle"
+          + " sessions, this configurable option will be used to evaluate update"
+          + " sessions to determine if they can be closed due to inactivity"),
   TSERV_READ_AHEAD_MAXCONCURRENT("tserver.readahead.concurrent.max", "16", PropertyType.COUNT,
       "The maximum number of concurrent read ahead that will execute. This effectively"
           + " limits the number of long running scans that can run concurrently per tserver."),
@@ -376,7 +439,8 @@ public enum Property {
   TSERV_MAJC_MAXCONCURRENT("tserver.compaction.major.concurrent.max", "3", PropertyType.COUNT,
       "The maximum number of concurrent major compactions for a tablet server"),
   TSERV_MAJC_THROUGHPUT("tserver.compaction.major.throughput", "0B", PropertyType.MEMORY,
-      "Maximum number of bytes to read or write per second over all major compactions on a TabletServer, or 0B for unlimited."),
+      "Maximum number of bytes to read or write per second over all major"
+          + " compactions on a TabletServer, or 0B for unlimited."),
   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,
@@ -389,20 +453,27 @@ public enum Property {
       "The number of concurrent threads that will load bloom filters in the background. "
           + "Setting this to zero will make bloom filters load in the foreground."),
   TSERV_MONITOR_FS("tserver.monitor.fs", "true", PropertyType.BOOLEAN,
-      "When enabled the tserver will monitor file systems and kill itself when one switches from rw to ro. This is usually and indication that Linux has"
+      "When enabled the tserver will monitor file systems and kill itself when"
+          + " one switches from rw to ro. This is usually and indication that Linux has"
           + " detected a bad disk."),
   TSERV_MEMDUMP_DIR("tserver.dir.memdump", "/tmp", PropertyType.PATH,
-      "A long running scan could possibly hold memory that has been minor compacted. To prevent this, the in memory map is dumped to a local file and the "
-          + "scan is switched to that local file. We can not switch to the minor compacted file because it may have been modified by iterators. The file "
-          + "dumped to the local dir is an exact copy of what was in memory."),
+      "A long running scan could possibly hold memory that has been minor"
+          + " compacted. To prevent this, the in memory map is dumped to a local file"
+          + " and the scan is switched to that local file. We can not switch to the"
+          + " minor compacted file because it may have been modified by iterators. The"
+          + " file dumped to the local dir is an exact copy of what was in memory."),
   TSERV_BULK_PROCESS_THREADS("tserver.bulk.process.threads", "1", PropertyType.COUNT,
-      "The master will task a tablet server with pre-processing a bulk file prior to assigning it to the appropriate tablet servers. This configuration"
-          + " value controls the number of threads used to process the files."),
+      "The master will task a tablet server with pre-processing a bulk file"
+          + " prior to assigning it to the appropriate tablet servers. This"
+          + " configuration value controls the number of threads used to process the" + " files."),
   TSERV_BULK_ASSIGNMENT_THREADS("tserver.bulk.assign.threads", "1", PropertyType.COUNT,
-      "The master delegates bulk file processing and assignment to tablet servers. After the bulk file has been processed, the tablet server will assign"
-          + " the file to the appropriate tablets on all servers. This property controls the number of threads used to communicate to the other servers."),
+      "The master delegates bulk file processing and assignment to tablet"
+          + " servers. After the bulk file has been processed, the tablet server will"
+          + " assign the file to the appropriate tablets on all servers. This property"
+          + " controls the number of threads used to communicate to the other servers."),
   TSERV_BULK_RETRY("tserver.bulk.retry.max", "5", PropertyType.COUNT,
-      "The number of times the tablet server will attempt to assign a file to a tablet as it migrates and splits."),
+      "The number of times the tablet server will attempt to assign a file to a"
+          + " tablet as it migrates and splits."),
   TSERV_BULK_TIMEOUT("tserver.bulk.timeout", "5m", PropertyType.TIMEDURATION,
       "The time to wait for a tablet server to process a bulk import request."),
   TSERV_MINTHREADS("tserver.server.threads.minimum", "20", PropertyType.COUNT,
@@ -412,13 +483,17 @@ public enum Property {
   TSERV_MAX_MESSAGE_SIZE("tserver.server.message.size.max", "1G", PropertyType.MEMORY,
       "The maximum size of a message that can be sent to a tablet server."),
   TSERV_HOLD_TIME_SUICIDE("tserver.hold.time.max", "5m", PropertyType.TIMEDURATION,
-      "The maximum time for a tablet server to be in the \"memory full\" state. If the tablet server cannot write out memory"
-          + " in this much time, it will assume there is some failure local to its node, and quit. A value of zero is equivalent to forever."),
+      "The maximum time for a tablet server to be in the \"memory full\" state."
+          + " If the tablet server cannot write out memory in this much time, it will"
+          + " assume there is some failure local to its node, and quit. A value of zero"
+          + " is equivalent to forever."),
   TSERV_WAL_BLOCKSIZE("tserver.wal.blocksize", "0", PropertyType.MEMORY,
-      "The size of the HDFS blocks used to write to the Write-Ahead log. If zero, it will be 110% of tserver.walog.max.size (that is, try to use just one"
-          + " block)"),
+      "The size of the HDFS blocks used to write to the Write-Ahead log. If"
+          + " zero, it will be 110% of tserver.walog.max.size (that is, try to use"
+          + " just one block)"),
   TSERV_WAL_REPLICATION("tserver.wal.replication", "0", PropertyType.COUNT,
-      "The replication to use when writing the Write-Ahead log to HDFS. If zero, it will use the HDFS default replication setting."),
+      "The replication to use when writing the Write-Ahead log to HDFS. If"
+          + " zero, it will use the HDFS default replication setting."),
   TSERV_RECOVERY_MAX_CONCURRENT("tserver.recovery.concurrent.max", "2", PropertyType.COUNT,
       "The maximum number of threads to use to sort logs during" + " recovery"),
   TSERV_SORT_BUFFER_SIZE("tserver.sort.buffer.size", "200M", PropertyType.MEMORY,
@@ -426,16 +501,19 @@ public enum Property {
   TSERV_ARCHIVE_WALOGS("tserver.archive.walogs", "false", PropertyType.BOOLEAN,
       "Keep copies of the WALOGs for debugging purposes"),
   TSERV_WORKQ_THREADS("tserver.workq.threads", "2", PropertyType.COUNT,
-      "The number of threads for the distributed work queue. These threads are used for copying failed bulk files."),
+      "The number of threads for the distributed work queue. These threads are"
+          + " used for copying failed bulk files."),
   TSERV_WAL_SYNC("tserver.wal.sync", "true", PropertyType.BOOLEAN,
-      "Use the SYNC_BLOCK create flag to sync WAL writes to disk. Prevents problems recovering from sudden system resets."),
+      "Use the SYNC_BLOCK create flag to sync WAL writes to disk. Prevents"
+          + " problems recovering from sudden system resets."),
   @Deprecated
   TSERV_WAL_SYNC_METHOD("tserver.wal.sync.method", "hsync", PropertyType.STRING,
       "This property is deprecated. Use table.durability instead."),
   TSERV_ASSIGNMENT_DURATION_WARNING("tserver.assignment.duration.warning", "10m",
       PropertyType.TIMEDURATION,
-      "The amount of time an assignment can run "
-          + " before the server will print a warning along with the current stack trace. Meant to help debug stuck assignments"),
+      "The amount of time an assignment can run before the server will print a"
+          + " warning along with the current stack trace. Meant to help debug stuck"
+          + " assignments"),
   TSERV_REPLICATION_REPLAYERS("tserver.replication.replayer.", null, PropertyType.PREFIX,
       "Allows configuration of implementation used to apply replicated data"),
   TSERV_REPLICATION_DEFAULT_HANDLER("tserver.replication.default.replayer",
@@ -446,7 +524,8 @@ public enum Property {
   TSERV_ASSIGNMENT_MAXCONCURRENT("tserver.assignment.concurrent.max", "2", PropertyType.COUNT,
       "The number of threads available to load tablets. Recoveries are still performed serially."),
   TSERV_SLOW_FLUSH_MILLIS("tserver.slow.flush.time", "100ms", PropertyType.TIMEDURATION,
-      "If a flush to the write-ahead log takes longer than this period of time, debugging information will written, and may result in a log rollover."),
+      "If a flush to the write-ahead log takes longer than this period of time,"
+          + " debugging information will written, and may result in a log rollover."),
 
   // accumulo garbage collector properties
   GC_PREFIX("gc.", null, PropertyType.PREFIX,
@@ -496,9 +575,11 @@ public enum Property {
   MONITOR_SSL_TRUSTSTORETYPE("monitor.ssl.trustStoreType", "jks", PropertyType.STRING,
       "Type of SSL truststore"),
   MONITOR_SSL_INCLUDE_CIPHERS("monitor.ssl.include.ciphers", "", PropertyType.STRING,
-      "A comma-separated list of allows SSL Ciphers, see monitor.ssl.exclude.ciphers to disallow ciphers"),
+      "A comma-separated list of allows SSL Ciphers, see"
+          + " monitor.ssl.exclude.ciphers to disallow ciphers"),
   MONITOR_SSL_EXCLUDE_CIPHERS("monitor.ssl.exclude.ciphers", "", PropertyType.STRING,
-      "A comma-separated list of disallowed SSL Ciphers, see mmonitor.ssl.include.ciphers to allow ciphers"),
+      "A comma-separated list of disallowed SSL Ciphers, see"
+          + " monitor.ssl.include.ciphers to allow ciphers"),
   MONITOR_SSL_INCLUDE_PROTOCOLS("monitor.ssl.include.protocols", "TLSv1,TLSv1.1,TLSv1.2",
       PropertyType.STRING, "A comma-separate list of allowed SSL protocols"),
 
@@ -527,43 +608,51 @@ public enum Property {
       "The password for the user used to store distributed traces"),
   @Sensitive
   TRACE_TOKEN_PROPERTY_PREFIX("trace.token.property.", null, PropertyType.PREFIX,
-      "The prefix used to create a token for storing distributed traces. For each propetry required by trace.token.type, place this prefix in front of it."),
+      "The prefix used to create a token for storing distributed traces. For"
+          + " each propetry required by trace.token.type, place this prefix in front of it."),
   TRACE_TOKEN_TYPE("trace.token.type", PasswordToken.class.getName(), PropertyType.CLASSNAME,
       "An AuthenticationToken type supported by the authorizer"),
 
   // per table properties
   TABLE_PREFIX("table.", null, PropertyType.PREFIX,
-      "Properties in this category affect tablet server treatment of tablets, but can be configured "
-          + "on a per-table basis. Setting these properties in the site file will override the default globally "
-          + "for all tables and not any specific table. However, both the default and the global setting can be "
-          + "overridden per table using the table operations API or in the shell, which sets the overridden value "
-          + "in zookeeper. Restarting accumulo tablet servers after setting these properties in the site file "
-          + "will cause the global setting to take effect. However, you must use the API or the shell to change "
-          + "properties in zookeeper that are set on a table."),
+      "Properties in this category affect tablet server treatment of tablets,"
+          + " but can be configured on a per-table basis. Setting these properties in"
+          + " the site file will override the default globally for all tables and not"
+          + " any specific table. However, both the default and the global setting can"
+          + " be overridden per table using the table operations API or in the shell,"
+          + " which sets the overridden value in zookeeper. Restarting accumulo tablet"
+          + " servers after setting these properties in the site file will cause the"
+          + " global setting to take effect. However, you must use the API or the shell"
+          + " to change properties in zookeeper that are set on a table."),
   TABLE_ARBITRARY_PROP_PREFIX("table.custom.", null, PropertyType.PREFIX,
       "Prefix to be used for user defined arbitrary properties."),
   TABLE_MAJC_RATIO("table.compaction.major.ratio", "3", PropertyType.FRACTION,
-      "minimum ratio of total input size to maximum input file size for running a major compactionWhen adjusting this property you may want to also "
-          + "adjust table.file.max. Want to avoid the situation where only merging minor compactions occur."),
+      "minimum ratio of total input size to maximum input file size for running"
+          + " a major compactionWhen adjusting this property you may want to also"
+          + " adjust table.file.max. Want to avoid the situation where only merging"
+          + " minor compactions occur."),
   TABLE_MAJC_COMPACTALL_IDLETIME("table.compaction.major.everything.idle", "1h",
       PropertyType.TIMEDURATION,
-      "After a tablet has been idle (no mutations) for this time period it may have all "
-          + "of its files compacted into one. There is no guarantee an idle tablet will be compacted. "
-          + "Compactions of idle tablets are only started when regular compactions are not running. Idle "
-          + "compactions only take place for tablets that have one or more files."),
+      "After a tablet has been idle (no mutations) for this time period it may"
+          + " have all of its files compacted into one. There is no guarantee an idle"
+          + " tablet will be compacted. Compactions of idle tablets are only started"
+          + " when regular compactions are not running. Idle compactions only take"
+          + " place for tablets that have one or more files."),
   TABLE_SPLIT_THRESHOLD("table.split.threshold", "1G", PropertyType.MEMORY,
       "When combined size of files exceeds this amount a tablet is split."),
   TABLE_MAX_END_ROW_SIZE("table.split.endrow.size.max", "10K", PropertyType.MEMORY,
       "Maximum size of end row"),
   TABLE_MINC_LOGS_MAX("table.compaction.minor.logs.threshold", "3", PropertyType.COUNT,
-      "When there are more than this many write-ahead logs against a tablet, it will be minor compacted. See comment for property tserver.memory.maps.max"),
+      "When there are more than this many write-ahead logs against a tablet, it"
+          + " will be minor compacted. See comment for property" + " tserver.memory.maps.max"),
   TABLE_MINC_COMPACT_IDLETIME("table.compaction.minor.idle", "5m", PropertyType.TIMEDURATION,
       "After a tablet has been idle (no mutations) for this time period it may have its "
           + "in-memory map flushed to disk in a minor compaction. There is no guarantee an idle "
           + "tablet will be compacted."),
   TABLE_MINC_MAX_MERGE_FILE_SIZE("table.compaction.minor.merge.file.size.max", "0",
       PropertyType.MEMORY,
-      "The max file size used for a merging minor compaction. The default value of 0 disables a max file size."),
+      "The max file size used for a merging minor compaction. The default value"
+          + " of 0 disables a max file size."),
   TABLE_SCAN_MAXMEM("table.scan.max.memory", "512K", PropertyType.MEMORY,
       "The maximum amount of memory that will be used to cache results of a client query/scan. "
           + "Once this limit is reached, the buffered data is sent to the client."),
@@ -571,85 +660,104 @@ public enum Property {
       "Change the type of file a table writes"),
   TABLE_LOAD_BALANCER("table.balancer",
       "org.apache.accumulo.server.master.balancer.DefaultLoadBalancer", PropertyType.STRING,
-      "This property can be set to allow the LoadBalanceByTable load balancer to change the called Load Balancer for this table"),
+      "This property can be set to allow the LoadBalanceByTable load balancer"
+          + " to change the called Load Balancer for this table"),
   TABLE_FILE_COMPRESSION_TYPE("table.file.compress.type", "gz", PropertyType.STRING,
       "One of gz,snappy,lzo,none"),
   TABLE_FILE_COMPRESSED_BLOCK_SIZE("table.file.compress.blocksize", "100K", PropertyType.MEMORY,
-      "Similar to the hadoop io.seqfile.compress.blocksize setting, so that files have better query performance. The maximum value for this is "
-          + Integer.MAX_VALUE
-          + ". (This setting is the size threshold prior to compression, and applies even compression is disabled.)"),
+      "Similar to the hadoop io.seqfile.compress.blocksize setting, so that"
+          + " files have better query performance. The maximum value for this is "
+          + Integer.MAX_VALUE + ". (This setting is the size threshold prior to"
+          + " compression, and applies even compression is disabled.)"),
   TABLE_FILE_COMPRESSED_BLOCK_SIZE_INDEX("table.file.compress.blocksize.index", "128K",
       PropertyType.MEMORY,
-      "Determines how large index blocks can be in files that support multilevel indexes. The maximum value for this is "
-          + Integer.MAX_VALUE + "."
-          + " (This setting is the size threshold prior to compression, and applies even compression is disabled.)"),
+      "Determines how large index blocks can be in files that support"
+          + " multilevel indexes. The maximum value for this is " + Integer.MAX_VALUE
+          + ". (This setting is the size threshold prior to compression, and applies"
+          + " even compression is disabled.)"),
   TABLE_FILE_BLOCK_SIZE("table.file.blocksize", "0B", PropertyType.MEMORY,
-      "Overrides the hadoop dfs.block.size setting so that files have better query performance. The maximum value for this is "
-          + Integer.MAX_VALUE),
+      "Overrides the hadoop dfs.block.size setting so that files have better"
+          + " query performance. The maximum value for this is " + Integer.MAX_VALUE),
   TABLE_FILE_REPLICATION("table.file.replication", "0", PropertyType.COUNT,
       "Determines how many replicas to keep of a tables' files in HDFS. "
           + "When this value is LTE 0, HDFS defaults are used."),
   TABLE_FILE_MAX("table.file.max", "15", PropertyType.COUNT,
-      "Determines the max # of files each tablet in a table can have. When adjusting this property you may want to consider adjusting"
-          + " table.compaction.major.ratio also. Setting this property to 0 will make it default to tserver.scan.files.open.max-1, this will prevent a"
-          + " tablet from having more files than can be opened. Setting this property low may throttle ingest and increase query performance."),
+      "Determines the max # of files each tablet in a table can have. When"
+          + " adjusting this property you may want to consider adjusting"
+          + " table.compaction.major.ratio also. Setting this property to 0 will make"
+          + " it default to tserver.scan.files.open.max-1, this will prevent a tablet"
+          + " from having more files than can be opened. Setting this property low may"
+          + " throttle ingest and increase query performance."),
   @Deprecated
   TABLE_WALOG_ENABLED("table.walog.enabled", "true", PropertyType.BOOLEAN,
       "This setting is deprecated.  Use table.durability=none instead."),
   TABLE_BLOOM_ENABLED("table.bloom.enabled", "false", PropertyType.BOOLEAN,
       "Use bloom filters on this table."),
   TABLE_BLOOM_LOAD_THRESHOLD("table.bloom.load.threshold", "1", PropertyType.COUNT,
-      "This number of seeks that would actually use a bloom filter must occur before a file's bloom filter is loaded."
-          + " Set this to zero to initiate loading of bloom filters when a file is opened."),
+      "This number of seeks that would actually use a bloom filter must occur"
+          + " before a file's bloom filter is loaded. Set this to zero to initiate"
+          + " loading of bloom filters when a file is opened."),
   TABLE_BLOOM_SIZE("table.bloom.size", "1048576", PropertyType.COUNT,
       "Bloom filter size, as number of keys."),
   TABLE_BLOOM_ERRORRATE("table.bloom.error.rate", "0.5%", PropertyType.FRACTION,
       "Bloom filter error rate."),
   TABLE_BLOOM_KEY_FUNCTOR("table.bloom.key.functor",
       "org.apache.accumulo.core.file.keyfunctor.RowFunctor", PropertyType.CLASSNAME,
-      "A function that can transform the key prior to insertion and check of bloom filter. org.apache.accumulo.core.file.keyfunctor.RowFunctor,"
-          + ",org.apache.accumulo.core.file.keyfunctor.ColumnFamilyFunctor, and org.apache.accumulo.core.file.keyfunctor.ColumnQualifierFunctor are"
-          + " allowable values. One can extend any of the above mentioned classes to perform specialized parsing of the key. "),
+      "A function that can transform the key prior to insertion and check of"
+          + " bloom filter. org.apache.accumulo.core.file.keyfunctor.RowFunctor,"
+          + " org.apache.accumulo.core.file.keyfunctor.ColumnFamilyFunctor, and"
+          + " org.apache.accumulo.core.file.keyfunctor.ColumnQualifierFunctor are"
+          + " allowable values. One can extend any of the above mentioned classes to"
+          + " perform specialized parsing of the key. "),
   TABLE_BLOOM_HASHTYPE("table.bloom.hash.type", "murmur", PropertyType.STRING,
       "The bloom filter hash type"),
   TABLE_DURABILITY("table.durability", "sync", PropertyType.DURABILITY,
-      "The durability used to write to the write-ahead log."
-          + " Legal values are: none, which skips the write-ahead log; "
-          + "log, which sends the data to the write-ahead log, but does nothing to make it durable; "
-          + "flush, which pushes data to the file system; and "
-          + "sync, which ensures the data is written to disk."),
+      "The durability used to write to the write-ahead log. Legal values are:"
+          + " none, which skips the write-ahead log; log, which sends the data to the"
+          + " write-ahead log, but does nothing to make it durable; flush, which pushes"
+          + " data to the file system; and sync, which ensures the data is written to disk."),
   TABLE_FAILURES_IGNORE("table.failures.ignore", "false", PropertyType.BOOLEAN,
-      "If you want queries for your table to hang or fail when data is missing from the system, "
-          + "then set this to false. When this set to true missing data will be reported but queries "
-          + "will still run possibly returning a subset of the data."),
+      "If you want queries for your table to hang or fail when data is missing"
+          + " from the system, then set this to false. When this set to true missing"
+          + " data will be reported but queries will still run possibly returning a"
+          + " subset of the data."),
   TABLE_DEFAULT_SCANTIME_VISIBILITY("table.security.scan.visibility.default", "",
       PropertyType.STRING,
-      "The security label that will be assumed at scan time if an entry does not have a visibility set.\n"
-          + "Note: An empty security label is displayed as []. The scan results will show an empty visibility even if "
-          + "the visibility from this setting is applied to the entry.\n"
-          + "CAUTION: If a particular key has an empty security label AND its table's default visibility is also empty, "
-          + "access will ALWAYS be granted for users with permission to that table. Additionally, if this field is changed, "
-          + "all existing data with an empty visibility label will be interpreted with the new label on the next scan."),
+      "The security label that will be assumed at scan time if an entry does"
+          + " not have a visibility expression.\n"
+          + "Note: An empty security label is displayed as []. The scan results"
+          + " will show an empty visibility even if the visibility from this"
+          + " setting is applied to the entry.\n"
+          + "CAUTION: If a particular key has an empty security label AND its"
+          + " table's default visibility is also empty, access will ALWAYS be"
+          + " granted for users with permission to that table. Additionally, if this"
+          + " field is changed, all existing data with an empty visibility label"
+          + " will be interpreted with the new label on the next scan."),
   TABLE_LOCALITY_GROUPS("table.groups.enabled", "", PropertyType.STRING,
       "A comma separated list of locality group names to enable for this table."),
   TABLE_CONSTRAINT_PREFIX("table.constraint.", null, PropertyType.PREFIX,
-      "Properties in this category are per-table properties that add constraints to a table. "
-          + "These properties start with the category prefix, followed by a number, and their values "
-          + "correspond to a fully qualified Java class that implements the Constraint interface.\n"
-          + "For example:\ntable.constraint.1 = org.apache.accumulo.core.constraints.MyCustomConstraint\n"
-          + "and:\ntable.constraint.2 = my.package.constraints.MySecondConstraint"),
+      "Properties in this category are per-table properties that add"
+          + " constraints to a table. These properties start with the category"
+          + " prefix, followed by a number, and their values correspond to a fully"
+          + " qualified Java class that implements the Constraint interface.\n" + "For example:\n"
+          + "table.constraint.1 = org.apache.accumulo.core.constraints.MyCustomConstraint\n"
+          + "and:\n" + " table.constraint.2 = my.package.constraints.MySecondConstraint"),
   TABLE_INDEXCACHE_ENABLED("table.cache.index.enable", "true", PropertyType.BOOLEAN,
       "Determines whether index cache is enabled."),
   TABLE_BLOCKCACHE_ENABLED("table.cache.block.enable", "false", PropertyType.BOOLEAN,
       "Determines whether file block cache is enabled."),
   TABLE_ITERATOR_PREFIX("table.iterator.", null, PropertyType.PREFIX,
-      "Properties in this category specify iterators that are applied at various stages (scopes) of interaction "
-          + "with a table. These properties start with the category prefix, followed by a scope (minc, majc, scan, etc.), "
-          + "followed by a period, followed by a name, as in table.iterator.scan.vers, or table.iterator.scan.custom. "
-          + "The values for these properties are a number indicating the ordering in which it is applied, and a class name "
-          + "such as:\n table.iterator.scan.vers = 10,org.apache.accumulo.core.iterators.VersioningIterator\n "
-          + "These iterators can take options if additional properties are set that look like this property, "
-          + "but are suffixed with a period, followed by 'opt' followed by another period, and a property name.\n"
+      "Properties in this category specify iterators that are applied at"
+          + " various stages (scopes) of interaction with a table. These properties"
+          + " start with the category prefix, followed by a scope (minc, majc, scan,"
+          + " etc.), followed by a period, followed by a name, as in"
+          + " table.iterator.scan.vers, or table.iterator.scan.custom. The values for"
+          + " these properties are a number indicating the ordering in which it is"
+          + " applied, and a class name such as:\n"
+          + "table.iterator.scan.vers = 10,org.apache.accumulo.core.iterators.VersioningIterator\n"
+          + "These iterators can take options if additional properties are set that"
+          + " look like this property, but are suffixed with a period, followed by 'opt'"
+          + " followed by another period, and a property name.\n"
           + "For example, table.iterator.minc.vers.opt.maxVersions = 3"),
   TABLE_ITERATOR_SCAN_PREFIX(TABLE_ITERATOR_PREFIX.getKey() + IteratorScope.scan.name() + ".", null,
       PropertyType.PREFIX, "Convenience prefix to find options for the scan iterator scope"),
@@ -658,12 +766,15 @@ public enum Property {
   TABLE_ITERATOR_MAJC_PREFIX(TABLE_ITERATOR_PREFIX.getKey() + IteratorScope.majc.name() + ".", null,
       PropertyType.PREFIX, "Convenience prefix to find options for the majc iterator scope"),
   TABLE_LOCALITY_GROUP_PREFIX("table.group.", null, PropertyType.PREFIX,
-      "Properties in this category are per-table properties that define locality groups in a table. These properties start "
-          + "with the category prefix, followed by a name, followed by a period, and followed by a property for that group.\n"
-          + "For example table.group.group1=x,y,z sets the column families for a group called group1. Once configured, "
-          + "group1 can be enabled by adding it to the list of groups in the "
-          + TABLE_LOCALITY_GROUPS.getKey() + " property.\n"
-          + "Additional group options may be specified for a named group by setting table.group.<name>.opt.<key>=<value>."),
+      "Properties in this category are per-table properties that define"
+          + " locality groups in a table. These properties start with the category"
+          + " prefix, followed by a name, followed by a period, and followed by a"
+          + " property for that group.\n"
+          + "For example table.group.group1=x,y,z sets the column families for a"
+          + " group called group1. Once configured, group1 can be enabled by adding"
+          + " it to the list of groups in the " + TABLE_LOCALITY_GROUPS.getKey() + " property.\n"
+          + "Additional group options may be specified for a named group by setting"
+          + " table.group.<name>.opt.<key>=<value>."),
   TABLE_FORMATTER_CLASS("table.formatter", DefaultFormatter.class.getName(), PropertyType.STRING,
       "The Formatter class to apply on results in the shell"),
   TABLE_INTERPRETER_CLASS("table.interepreter", DefaultScanInterpreter.class.getName(),
@@ -679,42 +790,57 @@ public enum Property {
   TABLE_REPLICATION("table.replication", "false", PropertyType.BOOLEAN,
       "Is replication enabled for the given table"),
   TABLE_REPLICATION_TARGET("table.replication.target.", null, PropertyType.PREFIX,
-      "Enumerate a mapping of other systems which this table should "
-          + "replicate their data to. The key suffix is the identifying cluster name and the value is an identifier for a location on the target system, "
-          + "e.g. the ID of the table on the target to replicate to"),
+      "Enumerate a mapping of other systems which this table should replicate"
+          + " their data to. The key suffix is the identifying cluster name and the"
+          + " value is an identifier for a location on the target system,"
+          + " e.g. the ID of the table on the target to replicate to"),
   @Experimental
   TABLE_VOLUME_CHOOSER("table.volume.chooser", "org.apache.accumulo.server.fs.RandomVolumeChooser",
       PropertyType.CLASSNAME,
-      "The class that will be used to select which volume will be used to create new files for this table."),
+      "The class that will be used to select which volume will be used to"
+          + " create new files for this table."),
   TABLE_SAMPLER("table.sampler", "", PropertyType.CLASSNAME,
-      "The name of a class that implements org.apache.accumulo.core.Sampler.  Setting this option enables storing a sample of data which can be scanned."
-          + "  Always having a current sample can useful for query optimization and data comprehension.   After enabling sampling for an existing table, a compaction "
-          + "is needed to compute the sample for existing data.  The compact command in the shell has an option to only compact files without sample data."),
+      "The name of a class that implements org.apache.accumulo.core.Sampler."
+          + " Setting this option enables storing a sample of data which can be"
+          + " scanned. Always having a current sample can useful for query optimization"
+          + " and data comprehension. After enabling sampling for an existing table,"
+          + " a compaction is needed to compute the sample for existing data. The"
+          + " compact command in the shell has an option to only compact files without"
+          + " sample data."),
   TABLE_SAMPLER_OPTS("table.sampler.opt.", null, PropertyType.PREFIX,
-      "The property is used to set options for a sampler.  If a sample had two options like hasher and modulous, then the two properties "
-          + "table.sampler.opt.hasher=${hash algorithm} and table.sampler.opt.modulous=${mod} would be set."),
+      "The property is used to set options for a sampler. If a sample had two"
+          + " options like hasher and modulous, then the two properties"
+          + " table.sampler.opt.hasher=${hash algorithm} and"
+          + " table.sampler.opt.modulous=${mod} would be set."),
   TABLE_SUSPEND_DURATION("table.suspend.duration", "0s", PropertyType.TIMEDURATION,
-      "For tablets belonging to this table: When a tablet server dies, allow the tablet server this duration to revive before reassigning its tablets"
-          + "to other tablet servers."),
+      "For tablets belonging to this table: When a tablet server dies, allow"
+          + " the tablet server this duration to revive before reassigning its tablets"
+          + " to other tablet servers."),
 
   // VFS ClassLoader properties
   VFS_CLASSLOADER_SYSTEM_CLASSPATH_PROPERTY(
       AccumuloVFSClassLoader.VFS_CLASSLOADER_SYSTEM_CLASSPATH_PROPERTY, "", PropertyType.STRING,
-      "Configuration for a system level vfs classloader. Accumulo jar can be configured here and loaded out of HDFS."),
+      "Configuration for a system level vfs classloader. Accumulo jar can be"
+          + " configured here and loaded out of HDFS."),
   VFS_CONTEXT_CLASSPATH_PROPERTY(AccumuloVFSClassLoader.VFS_CONTEXT_CLASSPATH_PROPERTY, null,
       PropertyType.PREFIX,
-      "Properties in this category are define a classpath. These properties start  with the category prefix, followed by a context name. "
-          + "The value is a comma seperated list of URIs. Supports full regex on filename alone. For example, "
-          + "general.vfs.context.classpath.cx1=hdfs://nn1:9902/mylibdir/*.jar. "
-          + "You can enable post delegation for a context, which will load classes from the context first instead of the parent first. "
-          + "Do this by setting general.vfs.context.classpath.<name>.delegation=post, where <name> is your context name"
-          + "If delegation is not specified, it defaults to loading from parent classloader first."),
+      "Properties in this category are define a classpath. These properties"
+          + " start  with the category prefix, followed by a context name. The value is"
+          + " a comma seperated list of URIs. Supports full regex on filename alone."
+          + " For example, general.vfs.context.classpath.cx1=hdfs://nn1:9902/mylibdir/*.jar."
+          + " You can enable post delegation for a context, which will load classes from the"
+          + " context first instead of the parent first. Do this by setting"
+          + " general.vfs.context.classpath.<name>.delegation=post, where <name> is"
+          + " your context name. If delegation is not specified, it defaults to loading"
+          + " from parent classloader first."),
   @Interpolated
   VFS_CLASSLOADER_CACHE_DIR(AccumuloVFSClassLoader.VFS_CACHE_DIR,
       "${java.io.tmpdir}" + File.separator + "accumulo-vfs-cache-${user.name}",
       PropertyType.ABSOLUTEPATH,
-      "Directory to use for the vfs cache. The cache will keep a soft reference to all of the classes loaded in the VM."
-          + " This should be on local disk on each node with sufficient space. It defaults to ${java.io.tmpdir}/accumulo-vfs-cache-${user.name}"),
+      "Directory to use for the vfs cache. The cache will keep a soft reference"
+          + " to all of the classes loaded in the VM. This should be on local disk on"
+          + " each node with sufficient space. It defaults to"
+          + " ${java.io.tmpdir}/accumulo-vfs-cache-${user.name}"),
 
   @Interpolated
   @Experimental
@@ -735,7 +861,8 @@ public enum Property {
   REPLICATION_PEER_KEYTAB("replication.peer.keytab.", null, PropertyType.PREFIX,
       "The keytab to use when authenticating with the given peer"),
   REPLICATION_NAME("replication.name", "", PropertyType.STRING,
-      "Name of this cluster with respect to replication. Used to identify this instance from other peers"),
+      "Name of this cluster with respect to replication. Used to identify this"
+          + " instance from other peers"),
   REPLICATION_MAX_WORK_QUEUE("replication.max.work.queue", "1000", PropertyType.COUNT,
       "Upper bound of the number of files queued for replication"),
   REPLICATION_WORK_ASSIGNMENT_SLEEP("replication.work.assignment.sleep", "30s",
@@ -745,7 +872,8 @@ public enum Property {
   REPLICATION_RECEIPT_SERVICE_PORT("replication.receipt.service.port", "10002", PropertyType.PORT,
       "Listen port used by thrift service in tserver listening for replication"),
   REPLICATION_WORK_ATTEMPTS("replication.work.attempts", "10", PropertyType.COUNT,
-      "Number of attempts to try to replicate some data before giving up and letting it naturally be retried later"),
+      "Number of attempts to try to replicate some data before giving up and"
+          + " letting it naturally be retried later"),
   REPLICATION_MIN_THREADS("replication.receiver.min.threads", "1", PropertyType.COUNT,
       "Minimum number of threads for replication"),
   REPLICATION_THREADCHECK("replication.receiver.threadcheck.time", "30s", PropertyType.TIMEDURATION,
@@ -759,14 +887,17 @@ public enum Property {
       "Amount of time to wait before the replication work loop begins in the master."),
   REPLICATION_WORK_PROCESSOR_DELAY("replication.work.processor.delay", "0s",
       PropertyType.TIMEDURATION,
-      "Amount of time to wait before first checking for replication work, not useful outside of tests"),
+      "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"),
+      "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_RPC_TIMEOUT("replication.rpc.timeout", "2m", PropertyType.TIMEDURATION,
-      "Amount of time for a single replication RPC call to last before failing the attempt. See replication.work.attempts."),
+      "Amount of time for a single replication RPC call to last before failing"
+          + " the attempt. See replication.work.attempts."),
 
   ;
 
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/PropertyType.java b/core/src/main/java/org/apache/accumulo/core/conf/PropertyType.java
index 6f7cfd9..0fc500a 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/PropertyType.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/PropertyType.java
@@ -41,45 +41,56 @@ public enum PropertyType {
   PREFIX(null, Predicates.<String> alwaysFalse(), null),
 
   TIMEDURATION("duration", boundedUnits(0, Long.MAX_VALUE, true, "", "ms", "s", "m", "h", "d"),
-      "A non-negative integer optionally followed by a unit of time (whitespace disallowed), as in 30s.\n"
-          + "If no unit of time is specified, seconds are assumed. Valid units are 'ms', 's', 'm', 'h' for milliseconds, seconds, minutes, and hours.\n"
-          + "Examples of valid durations are '600', '30s', '45m', '30000ms', '3d', and '1h'.\n"
-          + "Examples of invalid durations are '1w', '1h30m', '1s 200ms', 'ms', '', and 'a'.\n"
-          + "Unless otherwise stated, the max value for the duration represented in milliseconds is "
-          + Long.MAX_VALUE),
+      "A non-negative integer optionally followed by a unit of time (whitespace"
+          + " disallowed), as in 30s.\n"
+          + "If no unit of time is specified, seconds are assumed. Valid units"
+          + " are 'ms', 's', 'm', 'h' for milliseconds, seconds," + " minutes, and" + " hours.\n"
+          + "Examples of valid durations are '600', '30s', '45m', '30000ms'," + " '3d', and '1h'.\n"
+          + "Examples of invalid durations are '1w', '1h30m', '1s 200ms', 'ms', '',"
+          + " and 'a'.\nUnless otherwise stated, the max value for the duration"
+          + " represented in milliseconds is " + Long.MAX_VALUE),
 
   MEMORY("memory", boundedUnits(0, Long.MAX_VALUE, false, "", "B", "K", "M", "G"),
-      "A positive integer optionally followed by a unit of memory (whitespace disallowed), as in 2G.\n"
-          + "If no unit is specified, bytes are assumed. Valid units are 'B', 'K', 'M', 'G', for bytes, kilobytes, megabytes, and gigabytes.\n"
+      "A positive integer optionally followed by a unit of memory (whitespace"
+          + " disallowed), as in 2G.\n"
+          + "If no unit is specified, bytes are assumed. Valid units are 'B', 'K',"
+          + " 'M', 'G', for bytes, kilobytes, megabytes, and gigabytes.\n"
           + "Examples of valid memories are '1024', '20B', '100K', '1500M', '2G'.\n"
-          + "Examples of invalid memories are '1M500K', '1M 2K', '1MB', '1.5G', '1,024K', '', and 'a'.\n"
-          + "Unless otherwise stated, the max value for the memory represented in bytes is "
+          + "Examples of invalid memories are '1M500K', '1M 2K', '1MB', '1.5G',"
+          + " '1,024K', '', and 'a'.\n"
+          + "Unless otherwise stated, the max value for the memory represented in" + " bytes is "
           + Long.MAX_VALUE),
 
   HOSTLIST("host list",
       new Matches(
           "[\\w-]+(?:\\.[\\w-]+)*(?:\\:\\d{1,5})?(?:,[\\w-]+(?:\\.[\\w-]+)*(?:\\:\\d{1,5})?)*"),
       "A comma-separated list of hostnames or ip addresses, with optional port numbers.\n"
-          + "Examples of valid host lists are 'localhost:2000,www.example.com,10.10.1.1:500' and 'localhost'.\n"
+          + "Examples of valid host lists are"
+          + " 'localhost:2000,www.example.com,10.10.1.1:500' and 'localhost'.\n"
           + "Examples of invalid host lists are '', ':1000', and 'localhost:80000'"),
 
   @SuppressWarnings("unchecked")
   PORT("port",
       Predicates.or(new Bounds(1024, 65535), in(true, "0"), new PortRange("\\d{4,5}-\\d{4,5}")),
-      "An positive integer in the range 1024-65535 (not already in use or specified elsewhere in the configuration),\n"
-          + "zero to indicate any open ephemeral port, or a range of positive integers specified as M-N"),
+      "An positive integer in the range 1024-65535 (not already in use or"
+          + " specified elsewhere in the configuration),\n"
+          + "zero to indicate any open ephemeral port, or a range of positive"
+          + " integers specified as M-N"),
 
   COUNT("count", new Bounds(0, Integer.MAX_VALUE),
       "A non-negative integer in the range of 0-" + Integer.MAX_VALUE),
 
   FRACTION("fraction/percentage", new FractionPredicate(),
-      "A floating point number that represents either a fraction or, if suffixed with the '%' character, a percentage.\n"
-          + "Examples of valid fractions/percentages are '10', '1000%', '0.05', '5%', '0.2%', '0.0005'.\n"
-          + "Examples of invalid fractions/percentages are '', '10 percent', 'Hulk Hogan'"),
+      "A floating point number that represents either a fraction or, if"
+          + " suffixed with the '%' character, a percentage.\n"
+          + "Examples of valid fractions/percentages are '10', '1000%', '0.05',"
+          + " '5%', '0.2%', '0.0005'.\n"
+          + "Examples of invalid fractions/percentages are '', '10 percent'," + " 'Hulk Hogan'"),
 
   PATH("path", Predicates.<String> alwaysTrue(),
-      "A string that represents a filesystem path, which can be either relative or absolute to some directory. The filesystem depends on the property. The "
-          + "following environment variables will be substituted: "
+      "A string that represents a filesystem path, which can be either relative"
+          + " or absolute to some directory. The filesystem depends on the property."
+          + " The following environment variables will be substituted: "
           + Constants.PATH_PROPERTY_ENV_VARS),
 
   ABSOLUTEPATH("absolute path", new Predicate<String>() {
@@ -87,7 +98,8 @@ public enum PropertyType {
     public boolean apply(final String input) {
       return input == null || input.trim().isEmpty() || new Path(input.trim()).isAbsolute();
     }
-  }, "An absolute filesystem path. The filesystem depends on the property. This is the same as path, but enforces that its root is explicitly specified."),
+  }, "An absolute filesystem path. The filesystem depends on the property."
+      + " This is the same as path, but enforces that its root is explicitly" + " specified."),
 
   CLASSNAME("java class", new Matches("[\\w$.]*"),
       "A fully qualified java class name representing a class on the classpath.\n"
@@ -101,7 +113,8 @@ public enum PropertyType {
       "One of 'none', 'log', 'flush' or 'sync'."),
 
   STRING("string", Predicates.<String> alwaysTrue(),
-      "An arbitrary string of characters whose format is unspecified and interpreted based on the context of the property to which it applies."),
+      "An arbitrary string of characters whose format is unspecified and"
+          + " interpreted based on the context of the property to which it applies."),
 
   BOOLEAN("boolean", in(false, null, "true", "false"),
       "Has a value of either 'true' or 'false' (case-insensitive)"),
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/SiteConfiguration.java b/core/src/main/java/org/apache/accumulo/core/conf/SiteConfiguration.java
index 089f442..14c5183 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/SiteConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/SiteConfiguration.java
@@ -164,9 +164,8 @@ public class SiteConfiguration extends AccumuloConfiguration {
           }
         }
       } catch (IOException e) {
-        log.warn(
-            "Failed to extract sensitive properties from Hadoop CredentialProvider, falling back to accumulo-site.xml",
-            e);
+        log.warn("Failed to extract sensitive properties from Hadoop"
+            + " CredentialProvider, falling back to accumulo-site.xml", e);
       }
     }
   }
diff --git a/core/src/main/java/org/apache/accumulo/core/data/ConstraintViolationSummary.java b/core/src/main/java/org/apache/accumulo/core/data/ConstraintViolationSummary.java
index 59fe632..e04a8ff 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/ConstraintViolationSummary.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/ConstraintViolationSummary.java
@@ -78,7 +78,8 @@ public class ConstraintViolationSummary {
   @Override
   public String toString() {
     return String.format(
-        "ConstraintViolationSummary(constrainClass:%s, violationCode:%d, violationDescription:%s, numberOfViolatingMutations:%d)",
+        "ConstraintViolationSummary(constrainClass:%s, violationCode:%d,"
+            + " violationDescription:%s, numberOfViolatingMutations:%d)",
         constrainClass, violationCode, violationDescription, numberOfViolatingMutations);
   }
 
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 fb0b99a..81486e0 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
@@ -28,7 +28,9 @@ public class TabletIdImpl implements TabletId {
   private KeyExtent ke;
 
   @SuppressWarnings("deprecation")
-  public static final Function<org.apache.accumulo.core.data.KeyExtent,TabletId> KE_2_TID_OLD = new Function<org.apache.accumulo.core.data.KeyExtent,TabletId>() {
+  // @formatter:off
+  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
@@ -40,9 +42,12 @@ public class TabletIdImpl implements TabletId {
       return new TabletIdImpl(input);
     }
   };
+  // @formatter:on
 
   @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>() {
+  // @formatter:off
+  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)
@@ -50,8 +55,8 @@ public class TabletIdImpl implements TabletId {
       return new org.apache.accumulo.core.data.KeyExtent(input.getTableId(), input.getEndRow(),
           input.getPrevEndRow());
     }
-
   };
+  // @formatter:on
 
   @Deprecated
   public TabletIdImpl(org.apache.accumulo.core.data.KeyExtent ke) {
diff --git a/core/src/main/java/org/apache/accumulo/core/file/FileOperations.java b/core/src/main/java/org/apache/accumulo/core/file/FileOperations.java
index 7300d7c..5608d18 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/FileOperations.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/FileOperations.java
@@ -137,7 +137,10 @@ public abstract class FileOperations {
    */
   @SuppressWarnings("unchecked")
   public NeedsFile<NeedsRange<OpenScanReaderOperationBuilder>> newScanReaderBuilder() {
-    return (NeedsFile<NeedsRange<OpenScanReaderOperationBuilder>>) (NeedsFile<?>) new OpenScanReaderOperation();
+    // @formatter:off
+    return (NeedsFile<NeedsRange<OpenScanReaderOperationBuilder>>)
+      (NeedsFile<?>) new OpenScanReaderOperation();
+    // @formatter:on
   }
 
   /**
@@ -173,7 +176,10 @@ public abstract class FileOperations {
   /**
    * Options common to all FileOperations.
    */
-  protected static class FileAccessOperation<SubclassType extends FileAccessOperation<SubclassType>> {
+  // @formatter:off
+  protected static class
+    FileAccessOperation<SubclassType extends FileAccessOperation<SubclassType>> {
+  // @formatter:on
     private AccumuloConfiguration tableConfiguration;
 
     private String filename;
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/LruBlockCache.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/LruBlockCache.java
index e28a7bc..b8a29ac 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/LruBlockCache.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/LruBlockCache.java
@@ -410,7 +410,8 @@ public class LruBlockCache implements BlockCache, HeapSize {
       float memoryMB = ((float) bucketMemory.totalSize()) / ((float) (1024 * 1024));
 
       log.trace(
-          "Block cache LRU eviction completed. Freed {} bytes. Priority Sizes: Single={}MB ({}), Multi={}MB ({}), Memory={}MB ({})",
+          "Block cache LRU eviction completed. Freed {} bytes. Priority Sizes:"
+              + " Single={}MB ({}), Multi={}MB ({}), Memory={}MB ({})",
           bytesFreed, singleMB, bucketSingle.totalSize(), multiMB, bucketMulti.totalSize(),
           memoryMB, bucketMemory.totalSize());
 
@@ -599,8 +600,10 @@ public class LruBlockCache implements BlockCache, HeapSize {
     float freeMB = ((float) freeSize) / ((float) (1024 * 1024));
     float maxMB = ((float) maxSize) / ((float) (1024 * 1024));
     log.debug(
-        "Cache Stats: Sizes: Total={}MB ({}), Free={}MB ({}), Max={}MB ({}), Counts: Blocks={}, Access={}, Hit={}, Miss={}, Evictions={}, Evicted={},"
-            + "Ratios: Hit Ratio={}%, Miss Ratio={}%, Evicted/Run={}, Duplicate Reads={}",
+        "Cache Stats: Sizes: Total={}MB ({}), Free={}MB ({}), Max={}MB"
+            + " ({}), Counts: Blocks={}, Access={}, Hit={}, Miss={}, Evictions={},"
+            + " Evicted={}, Ratios: Hit Ratio={}%, Miss Ratio={}%, Evicted/Run={},"
+            + " Duplicate Reads={}",
         sizeMB, totalSize, freeMB, freeSize, maxMB, maxSize, size(), stats.getRequestCount(),
         stats.getHitCount(), stats.getMissCount(), stats.getEvictionCount(),
         stats.getEvictedCount(), stats.getHitRatio() * 100, stats.getMissRatio() * 100,
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/CreateEmpty.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/CreateEmpty.java
index 92d3082..64b3501 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/CreateEmpty.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/CreateEmpty.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -65,8 +65,10 @@ public class CreateEmpty {
     @Parameter(names = {"-c", "--codec"}, description = "the compression codec to use.",
         validateWith = IsSupportedCompressionAlgorithm.class)
     String codec = Compression.COMPRESSION_NONE;
-    @Parameter(description = " <path> { <path> ... } Each path given is a URL. "
-        + "Relative paths are resolved according to the default filesystem defined in your Hadoop configuration, which is usually an HDFS instance.",
+    @Parameter(
+        description = " <path> { <path> ... } Each path given is a URL."
+            + " Relative paths are resolved according to the default filesystem defined in"
+            + " your Hadoop configuration, which is usually an HDFS instance.",
         required = true, validateWith = NamedLikeRFile.class)
     List<String> files = new ArrayList<>();
   }
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/KeyShortener.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/KeyShortener.java
index 9ee17ac..590659d 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/KeyShortener.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/KeyShortener.java
@@ -27,8 +27,9 @@ import com.google.common.annotations.VisibleForTesting;
 import com.google.common.base.Preconditions;
 import com.google.common.primitives.Bytes;
 
-/*
- * Code to shorten keys that will be placed into RFile indexes. This code attempts to find a key thats between two keys that shorter.
+/**
+ * Code to shorten keys that will be placed into RFile indexes. This code attempts to find a key
+ * thats between two keys that shorter.
  */
 public class KeyShortener {
 
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 bf10e88..14c7018 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
@@ -1385,9 +1385,8 @@ public class RFile {
         ArrayList<ByteSequence> setCF;
 
         if (lcg.columnFamilies == null) {
-          Preconditions.checkState(lcg.isDefaultLG,
-              " Group %s has null families. Only expect default locality group to have null families.",
-              lcg.name);
+          Preconditions.checkState(lcg.isDefaultLG, "Group %s has null families. "
+              + "Only expect default locality group to have null families.", lcg.name);
           setCF = new ArrayList<>();
         } else {
           setCF = new ArrayList<>(lcg.columnFamilies.keySet());
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/BCFile.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/BCFile.java
index bd6120a..778be3b 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/BCFile.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/BCFile.java
@@ -17,6 +17,8 @@
 
 package org.apache.accumulo.core.file.rfile.bcfile;
 
+import static java.nio.charset.StandardCharsets.UTF_8;
+
 import java.io.ByteArrayOutputStream;
 import java.io.Closeable;
 import java.io.DataInput;
@@ -26,7 +28,6 @@ import java.io.DataOutputStream;
 import java.io.IOException;
 import java.io.InputStream;
 import java.io.OutputStream;
-import java.nio.charset.StandardCharsets;
 import java.util.ArrayList;
 import java.util.Arrays;
 import java.util.Collections;
@@ -555,8 +556,10 @@ public final class BCFile {
   }
 
   // sha256 of some random data
-  private static final byte[] NO_CPYPTO_KEY = "ce18cf53c4c5077f771249b38033fa14bcb31cca0e5e95a371ee72daa8342ea2"
-      .getBytes(StandardCharsets.UTF_8);
+  // @formatter:off
+  private static final byte[] NO_CPYPTO_KEY =
+    "ce18cf53c4c5077f771249b38033fa14bcb31cca0e5e95a371ee72daa8342ea2".getBytes(UTF_8);
+  // @formatter:on
 
   // This class is used as a place holder in the cache for RFiles that have no crypto....
   private static final BCFileCryptoModuleParameters NO_CRYPTO = new BCFileCryptoModuleParameters() {
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 e9666d4..e80c24d 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
@@ -43,7 +43,10 @@ import org.slf4j.LoggerFactory;
 public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, OptionDescriber {
 
   private SortedKeyValueIterator<Key,Value> iterator;
-  private ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> aggregators;
+  // @formatter:off
+  private ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator>
+    aggregators;
+  // @formatter:on
 
   private Key workKey = new Key();
 
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/Combiner.java b/core/src/main/java/org/apache/accumulo/core/iterators/Combiner.java
index 279917b..be686e1 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/Combiner.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/Combiner.java
@@ -81,7 +81,10 @@ public abstract class Combiner extends WrappingIterator implements OptionDescrib
 
   protected static final String COLUMNS_OPTION = "columns";
   protected static final String ALL_OPTION = "all";
-  protected static final String REDUCE_ON_FULL_COMPACTION_ONLY_OPTION = "reduceOnFullCompactionOnly";
+  // @formatter:off
+  protected static final String REDUCE_ON_FULL_COMPACTION_ONLY_OPTION =
+    "reduceOnFullCompactionOnly";
+  // @formatter:on
 
   private boolean isMajorCompaction;
   private boolean reduceOnFullCompactionOnly;
@@ -190,9 +193,9 @@ public abstract class Combiner extends WrappingIterator implements OptionDescrib
         loggedMsgCache.get(this.getClass().getName(), new Callable<Boolean>() {
           @Override
           public Boolean call() throws Exception {
-            sawDeleteLog.error(
-                "Combiner of type {} saw a delete during a partial compaction.  This could cause undesired results.  See ACCUMULO-2232.  Will not log subsequent "
-                    + "occurences for at least 1 hour.",
+            sawDeleteLog.error("Combiner of type {} saw a delete during a"
+                + " partial compaction. This could cause undesired results. See"
+                + " ACCUMULO-2232. Will not log subsequent occurences for at least" + " 1 hour.",
                 Combiner.this.getClass().getSimpleName());
             // the value is not used and does not matter
             return Boolean.TRUE;
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/Filter.java b/core/src/main/java/org/apache/accumulo/core/iterators/Filter.java
index 96c1665..8c39fef 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/Filter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/Filter.java
@@ -100,8 +100,8 @@ public abstract class Filter extends WrappingIterator implements OptionDescriber
   @Override
   public IteratorOptions describeOptions() {
     return new IteratorOptions("filter", "Filter accepts or rejects each Key/Value pair",
-        Collections.singletonMap("negate",
-            "default false keeps k/v that pass accept method, true rejects k/v that pass accept method"),
+        Collections.singletonMap("negate", "default false keeps k/v that pass"
+            + " accept method, true rejects k/v that pass accept method"),
         null);
   }
 
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/IteratorEnvironment.java b/core/src/main/java/org/apache/accumulo/core/iterators/IteratorEnvironment.java
index 73cde2a..39a73b6 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/IteratorEnvironment.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/IteratorEnvironment.java
@@ -55,7 +55,8 @@ public interface IteratorEnvironment {
    *     SortedKeyValueIterator&lt;Key,Value&gt; source;
    *     SortedKeyValueIterator&lt;Key,Value&gt; sampleIter;
    *     &#64;Override
-   *     void init(SortedKeyValueIterator&lt;Key,Value&gt; source, Map&lt;String,String&gt; options, IteratorEnvironment env) {
+   *     void init(SortedKeyValueIterator&lt;Key,Value&gt; source, Map&lt;String,String&gt; options,
+   *       IteratorEnvironment env) {
    *       IteratorEnvironment sampleEnv = env.cloneWithSamplingEnabled();
    *       //do some sanity checks on sampling config
    *       validateSamplingConfiguration(sampleEnv.getSamplerConfiguration());
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 a8e8128..ce603d3 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
@@ -193,18 +193,24 @@ public class IteratorUtil {
     Collections.sort(iters, new IterInfoComparator());
   }
 
-  public static <K extends WritableComparable<?>,V extends Writable> SortedKeyValueIterator<K,V> loadIterators(
-      IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent,
-      AccumuloConfiguration conf, IteratorEnvironment env) throws IOException {
+  // @formatter:off
+  public static <K extends WritableComparable<?>,V extends Writable> SortedKeyValueIterator<K,V>
+    loadIterators(
+  // @formatter:on
+          IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent,
+          AccumuloConfiguration conf, IteratorEnvironment env) throws IOException {
     List<IterInfo> emptyList = Collections.emptyList();
     Map<String,Map<String,String>> emptyMap = Collections.emptyMap();
     return loadIterators(scope, source, extent, conf, emptyList, emptyMap, env);
   }
 
-  public static <K extends WritableComparable<?>,V extends Writable> SortedKeyValueIterator<K,V> loadIterators(
-      IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent,
-      AccumuloConfiguration conf, List<IteratorSetting> iterators, IteratorEnvironment env)
-      throws IOException {
+  // @formatter:off
+  public static <K extends WritableComparable<?>,V extends Writable> SortedKeyValueIterator<K,V>
+    loadIterators(
+  // @formatter:on
+          IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent,
+          AccumuloConfiguration conf, List<IteratorSetting> iterators, IteratorEnvironment env)
+          throws IOException {
 
     List<IterInfo> ssiList = new ArrayList<>();
     Map<String,Map<String,String>> ssio = new HashMap<>();
@@ -217,10 +223,13 @@ public class IteratorUtil {
     return loadIterators(scope, source, extent, conf, ssiList, ssio, env, true);
   }
 
-  public static <K extends WritableComparable<?>,V extends Writable> SortedKeyValueIterator<K,V> loadIterators(
-      IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent,
-      AccumuloConfiguration conf, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio,
-      IteratorEnvironment env) throws IOException {
+  // @formatter:off
+  public static <K extends WritableComparable<?>,V extends Writable> SortedKeyValueIterator<K,V>
+    loadIterators(
+  // @formatter:on
+          IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent,
+          AccumuloConfiguration conf, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio,
+          IteratorEnvironment env) throws IOException {
     return loadIterators(scope, source, extent, conf, ssiList, ssio, env, true);
   }
 
@@ -246,10 +255,13 @@ public class IteratorUtil {
     }
   }
 
-  public static <K extends WritableComparable<?>,V extends Writable> SortedKeyValueIterator<K,V> loadIterators(
-      IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent,
-      AccumuloConfiguration conf, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio,
-      IteratorEnvironment env, boolean useAccumuloClassLoader) throws IOException {
+  // @formatter:off
+  public static <K extends WritableComparable<?>,V extends Writable> SortedKeyValueIterator<K,V>
+    loadIterators(
+  // @formatter:on
+          IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent,
+          AccumuloConfiguration conf, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio,
+          IteratorEnvironment env, boolean useAccumuloClassLoader) throws IOException {
     List<IterInfo> iters = new ArrayList<>(ssiList);
     Map<String,Map<String,String>> allOptions = new HashMap<>();
     parseIteratorConfiguration(scope, iters, ssio, allOptions, conf);
@@ -257,11 +269,14 @@ public class IteratorUtil {
         conf.get(Property.TABLE_CLASSPATH));
   }
 
-  public static <K extends WritableComparable<?>,V extends Writable> SortedKeyValueIterator<K,V> loadIterators(
-      IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent,
-      AccumuloConfiguration conf, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio,
-      IteratorEnvironment env, boolean useAccumuloClassLoader, String classLoaderContext)
-      throws IOException {
+  // @formatter:off
+  public static <K extends WritableComparable<?>,V extends Writable> SortedKeyValueIterator<K,V>
+    loadIterators(
+  // @formatter:on
+          IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent,
+          AccumuloConfiguration conf, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio,
+          IteratorEnvironment env, boolean useAccumuloClassLoader, String classLoaderContext)
+          throws IOException {
     List<IterInfo> iters = new ArrayList<>(ssiList);
     Map<String,Map<String,String>> allOptions = new HashMap<>();
     parseIteratorConfiguration(scope, iters, ssio, allOptions, conf);
@@ -269,18 +284,24 @@ public class IteratorUtil {
         classLoaderContext);
   }
 
-  public static <K extends WritableComparable<?>,V extends Writable> SortedKeyValueIterator<K,V> loadIterators(
-      SortedKeyValueIterator<K,V> source, Collection<IterInfo> iters,
-      Map<String,Map<String,String>> iterOpts, IteratorEnvironment env,
-      boolean useAccumuloClassLoader, String context) throws IOException {
+  // @formatter:off
+  public static <K extends WritableComparable<?>,V extends Writable> SortedKeyValueIterator<K,V>
+    loadIterators(
+  // @formatter:on
+          SortedKeyValueIterator<K,V> source, Collection<IterInfo> iters,
+          Map<String,Map<String,String>> iterOpts, IteratorEnvironment env,
+          boolean useAccumuloClassLoader, String context) throws IOException {
     return loadIterators(source, iters, iterOpts, env, useAccumuloClassLoader, context, null);
   }
 
-  public static <K extends WritableComparable<?>,V extends Writable> SortedKeyValueIterator<K,V> loadIterators(
-      SortedKeyValueIterator<K,V> source, Collection<IterInfo> iters,
-      Map<String,Map<String,String>> iterOpts, IteratorEnvironment env,
-      boolean useAccumuloClassLoader, String context,
-      Map<String,Class<? extends SortedKeyValueIterator<K,V>>> classCache) throws IOException {
+  // @formatter:off
+  public static <K extends WritableComparable<?>,V extends Writable> SortedKeyValueIterator<K,V>
+    loadIterators(
+  // @formatter:on
+          SortedKeyValueIterator<K,V> source, Collection<IterInfo> iters,
+          Map<String,Map<String,String>> iterOpts, IteratorEnvironment env,
+          boolean useAccumuloClassLoader, String context,
+          Map<String,Class<? extends SortedKeyValueIterator<K,V>>> classCache) throws IOException {
     // wrap the source in a SynchronizedIterator in case any of the additional configured iterators
     // want to use threading
     SortedKeyValueIterator<K,V> prev = new SynchronizedIterator<>(source);
@@ -324,9 +345,13 @@ public class IteratorUtil {
   }
 
   @SuppressWarnings("unchecked")
-  private static <K extends WritableComparable<?>,V extends Writable> Class<? extends SortedKeyValueIterator<K,V>> loadClass(
-      boolean useAccumuloClassLoader, String context, IterInfo iterInfo)
-      throws ClassNotFoundException, IOException {
+  // @formatter:off
+  private static
+  <K extends WritableComparable<?>,V extends Writable> Class<? extends SortedKeyValueIterator<K,V>>
+    loadClass(
+  // @formatter:on
+          boolean useAccumuloClassLoader, String context, IterInfo iterInfo)
+          throws ClassNotFoundException, IOException {
     Class<? extends SortedKeyValueIterator<K,V>> clazz;
     if (useAccumuloClassLoader) {
       if (context != null && !context.equals(""))
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 a555f7c..0753b47 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
@@ -104,8 +104,8 @@ public abstract class LongCombiner extends TypedValueCombiner<Long> {
   public IteratorOptions describeOptions() {
     IteratorOptions io = super.describeOptions();
     io.setName("longcombiner");
-    io.setDescription(
-        "LongCombiner can interpret Values as Longs in a variety of encodings (variable length, fixed length, or string) before combining");
+    io.setDescription("LongCombiner can interpret Values as Longs in a variety of encodings"
+        + " (variable length, fixed length, or string) before combining");
     io.addNamedOption(TYPE, "<VARLEN|FIXEDLEN|STRING|fullClassName>");
     return io;
   }
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/OptionDescriber.java b/core/src/main/java/org/apache/accumulo/core/iterators/OptionDescriber.java
index 6cadb9e..dc897a5 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/OptionDescriber.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/OptionDescriber.java
@@ -55,8 +55,9 @@ public interface OptionDescriber {
      *          is a list of descriptions of additional options that don't have fixed names (null if
      *          unused). The descriptions are intended to describe a category, and the user will
      *          provide parameter names and values in that category; e.g., the FilteringIterator
-     *          needs a list of Filters intended to be named by their priority numbers, so its<br>
-     *          {@code unnamedOptionDescriptions = Collections.singletonList("<filterPriorityNumber> <ageoff|regex|filterClass>")}
+     *          needs a list of Filters intended to be named by their priority numbers, so it's<br>
+     *          {@code unnamedOptionDescriptions = Collections}<br>
+     *          {@code .singletonList("<filterPriorityNumber> <ageoff|regex|filterClass>")}
      */
     public IteratorOptions(String name, String description, Map<String,String> namedOptions,
         List<String> unnamedOptionDescriptions) {
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/TypedValueCombiner.java b/core/src/main/java/org/apache/accumulo/core/iterators/TypedValueCombiner.java
index f22f8c4..7b5925e 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/TypedValueCombiner.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/TypedValueCombiner.java
@@ -209,8 +209,8 @@ public abstract class TypedValueCombiner<V> extends Combiner {
   @Override
   public IteratorOptions describeOptions() {
     IteratorOptions io = super.describeOptions();
-    io.addNamedOption(LOSSY,
-        "if true, failed decodes are ignored. Otherwise combiner will error on failed decodes (default false): <TRUE|FALSE>");
+    io.addNamedOption(LOSSY, "if true, failed decodes are ignored. Otherwise"
+        + " combiner will error on failed decodes (default false): <TRUE|FALSE>");
     return io;
   }
 
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/AgeOffFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/AgeOffFilter.java
index a84cfdc..2e83155 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/AgeOffFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/AgeOffFilter.java
@@ -85,8 +85,8 @@ public class AgeOffFilter extends Filter {
   public IteratorOptions describeOptions() {
     IteratorOptions io = super.describeOptions();
     io.addNamedOption(TTL, "time to live (milliseconds)");
-    io.addNamedOption(CURRENT_TIME,
-        "if set, use the given value as the absolute time in milliseconds as the current time of day");
+    io.addNamedOption(CURRENT_TIME, "if set, use the given value as the"
+        + " absolute time in milliseconds as the current time of day");
     io.setName("ageoff");
     io.setDescription(
         "AgeOffFilter removes entries with timestamps more than <ttl> milliseconds old");
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceOpts.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceOpts.java
index 30e7107..128bffc 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceOpts.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceOpts.java
@@ -27,34 +27,38 @@ import org.apache.hadoop.io.Text;
 
 public class CfCqSliceOpts {
   public static final String OPT_MIN_CF = "minCf";
-  public static final String OPT_MIN_CF_DESC = "UTF-8 encoded string representing minimum column family. "
-      + "Optional parameter. If minCf and minCq are undefined, the column slice will start at the first column "
-      + "of each row. If you want to do an exact match on column families, it's more efficient to leave minCf "
-      + "and maxCf undefined and use the scanner's fetchColumnFamily method.";
+  public static final String OPT_MIN_CF_DESC = "UTF-8 encoded string"
+      + " representing minimum column family. Optional parameter. If minCf and minCq"
+      + " are undefined, the column slice will start at the first column of each row."
+      + " If you want to do an exact match on column families, it's more efficient to"
+      + " leave minCf and maxCf undefined and use the scanner's fetchColumnFamily" + " method.";
 
   public static final String OPT_MIN_CQ = "minCq";
-  public static final String OPT_MIN_CQ_DESC = "UTF-8 encoded string representing minimum column qualifier. "
-      + "Optional parameter. If minCf and minCq are undefined, the column slice will start at the first column "
-      + "of each row.";
+  public static final String OPT_MIN_CQ_DESC = "UTF-8 encoded string"
+      + " representing minimum column qualifier. Optional parameter. If minCf and"
+      + " minCq are undefined, the column slice will start at the first column of" + " each row.";
 
   public static final String OPT_MAX_CF = "maxCf";
-  public static final String OPT_MAX_CF_DESC = "UTF-8 encoded string representing maximum column family. "
-      + "Optional parameter. If minCf and minCq are undefined, the column slice will start at the first column "
-      + "of each row. If you want to do an exact match on column families, it's more efficient to leave minCf "
-      + "and maxCf undefined and use the scanner's fetchColumnFamily method.";
+  public static final String OPT_MAX_CF_DESC = "UTF-8 encoded string"
+      + " representing maximum column family. Optional parameter. If minCf and minCq"
+      + " are undefined, the column slice will start at the first column of each row."
+      + " If you want to do an exact match on column families, it's more efficient to"
+      + " leave minCf and maxCf undefined and use the scanner's fetchColumnFamily" + " method.";
 
   public static final String OPT_MAX_CQ = "maxCq";
-  public static final String OPT_MAX_CQ_DESC = "UTF-8 encoded string representing maximum column qualifier. "
-      + "Optional parameter. If maxCf and MaxCq are undefined, the column slice will end at the last column of "
-      + "each row.";
+  public static final String OPT_MAX_CQ_DESC = "UTF-8 encoded string"
+      + " representing maximum column qualifier. Optional parameter. If maxCf and"
+      + " MaxCq are undefined, the column slice will end at the last column of each" + " row.";
 
   public static final String OPT_MIN_INCLUSIVE = "minInclusive";
-  public static final String OPT_MIN_INCLUSIVE_DESC = "UTF-8 encoded string indicating whether to include the "
-      + "minimum column in the slice range. Optional parameter, default is true.";
+  public static final String OPT_MIN_INCLUSIVE_DESC = "UTF-8 encoded string"
+      + " indicating whether to include the minimum column in the slice range."
+      + " Optional parameter, default is true.";
 
   public static final String OPT_MAX_INCLUSIVE = "maxInclusive";
-  public static final String OPT_MAX_INCLUSIVE_DESC = "UTF-8 encoded string indicating whether to include the "
-      + "maximum column in the slice range. Optional parameter, default is true.";
+  public static final String OPT_MAX_INCLUSIVE_DESC = "UTF-8 encoded string"
+      + " indicating whether to include the maximum column in the slice range."
+      + " Optional parameter, default is true.";
 
   Text minCf;
   Text minCq;
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/ColumnAgeOffFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/ColumnAgeOffFilter.java
index 1e2485b..7cd34f7 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/ColumnAgeOffFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/ColumnAgeOffFilter.java
@@ -100,8 +100,8 @@ public class ColumnAgeOffFilter extends Filter {
   public IteratorOptions describeOptions() {
     IteratorOptions io = super.describeOptions();
     io.setName("colageoff");
-    io.setDescription(
-        "ColumnAgeOffFilter ages off columns at different rates given a time to live in milliseconds for each column");
+    io.setDescription("ColumnAgeOffFilter ages off columns at different rates"
+        + " given a time to live in milliseconds for each column");
     io.addUnnamedOption("<col fam>[:<col qual>] <Long> (escape non-alphanum chars using %<hex>)");
     return io;
   }
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/ColumnSliceFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/ColumnSliceFilter.java
index bd18fd5..99e5dbd 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/ColumnSliceFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/ColumnSliceFilter.java
@@ -79,8 +79,8 @@ public class ColumnSliceFilter extends Filter {
   public IteratorOptions describeOptions() {
     IteratorOptions io = super.describeOptions();
     io.setName("columnSlice");
-    io.setDescription(
-        "The ColumnSliceFilter/Iterator allows you to filter for key/value pairs based on a lexicographic range of column qualifier names");
+    io.setDescription("The ColumnSliceFilter/Iterator allows you to filter for"
+        + " key/value pairs based on a lexicographic range of column qualifier" + " names");
     io.addNamedOption(START_BOUND, "start string in slice");
     io.addNamedOption(END_BOUND, "end string in slice");
     io.addNamedOption(START_INCLUSIVE, "include the start bound in the result set");
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/LargeRowFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/LargeRowFilter.java
index 2592649..6bbcf6c 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/LargeRowFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/LargeRowFilter.java
@@ -256,7 +256,8 @@ public class LargeRowFilter implements SortedKeyValueIterator<Key,Value>, Option
 
   @Override
   public IteratorOptions describeOptions() {
-    String description = "This iterator suppresses rows that exceed a specified number of columns. Once\n"
+    String description = "This iterator suppresses rows that exceed a specified"
+        + " number of columns. Once\n"
         + "a row exceeds the threshold, a marker is emitted and the row is always\n"
         + "suppressed by this iterator after that point in time.\n"
         + " This iterator works in a similar way to the RowDeletingIterator. See its\n"
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/MaxCombiner.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/MaxCombiner.java
index 20632ec..967b224 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/MaxCombiner.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/MaxCombiner.java
@@ -40,8 +40,9 @@ public class MaxCombiner extends LongCombiner {
   public IteratorOptions describeOptions() {
     IteratorOptions io = super.describeOptions();
     io.setName("max");
-    io.setDescription(
-        "MaxCombiner interprets Values as Longs and finds their maximum.  A variety of encodings (variable length, fixed length, or string) are available");
+    io.setDescription("MaxCombiner interprets Values as Longs and finds their"
+        + " maximum.  A variety of encodings (variable length, fixed length, or"
+        + " string) are available");
     return io;
   }
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/MinCombiner.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/MinCombiner.java
index 2aa2550..da69f49 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/MinCombiner.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/MinCombiner.java
@@ -40,8 +40,9 @@ public class MinCombiner extends LongCombiner {
   public IteratorOptions describeOptions() {
     IteratorOptions io = super.describeOptions();
     io.setName("min");
-    io.setDescription(
-        "MinCombiner interprets Values as Longs and finds their minimum.  A variety of encodings (variable length, fixed length, or string) are available");
+    io.setDescription("MinCombiner interprets Values as Longs and finds their"
+        + " minimum.  A variety of encodings (variable length, fixed length, or"
+        + " string) are available");
     return io;
   }
 }
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 a4134ea..f65baa6 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
@@ -153,8 +153,8 @@ public class RegExFilter extends Filter {
   public IteratorOptions describeOptions() {
     IteratorOptions io = super.describeOptions();
     io.setName("regex");
-    io.setDescription(
-        "The RegExFilter/Iterator allows you to filter for key/value pairs based on regular expressions");
+    io.setDescription("The RegExFilter/Iterator allows you to filter for"
+        + " key/value pairs based on regular expressions");
     io.addNamedOption(RegExFilter.ROW_REGEX, "regular expression on row");
     io.addNamedOption(RegExFilter.COLF_REGEX, "regular expression on column family");
     io.addNamedOption(RegExFilter.COLQ_REGEX, "regular expression on column qualifier");
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 00a64e9..e4a2825 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
@@ -172,8 +172,10 @@ public abstract class RowEncodingIterator
 
   @Override
   public IteratorOptions describeOptions() {
-    String desc = "This iterator encapsulates an entire row of Key/Value pairs into a single Key/Value pair.";
-    String bufferDesc = "Maximum buffer size (in accumulo memory spec) to use for buffering keys before throwing a BufferOverflowException.";
+    String desc = "This iterator encapsulates an entire row of Key/Value pairs"
+        + " into a single Key/Value pair.";
+    String bufferDesc = "Maximum buffer size (in accumulo memory spec) to use"
+        + " for buffering keys before throwing a BufferOverflowException.";
     HashMap<String,String> namedOptions = new HashMap<>();
     namedOptions.put(MAX_BUFFER_SIZE_OPT, bufferDesc);
     return new IteratorOptions(getClass().getSimpleName(), desc, namedOptions, null);
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/SummingArrayCombiner.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/SummingArrayCombiner.java
index 7ee018d..35ee47f 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/SummingArrayCombiner.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/SummingArrayCombiner.java
@@ -128,9 +128,9 @@ public class SummingArrayCombiner extends TypedValueCombiner<List<Long>> {
   public IteratorOptions describeOptions() {
     IteratorOptions io = super.describeOptions();
     io.setName("sumarray");
-    io.setDescription(
-        "SummingArrayCombiner can interpret Values as arrays of Longs using a variety of encodings "
-            + "(arrays of variable length longs or fixed length longs, or comma-separated strings) before summing element-wise.");
+    io.setDescription("SummingArrayCombiner can interpret Values as arrays of"
+        + " Longs using a variety of encodings (arrays of variable length longs or"
+        + " fixed length longs, or comma-separated strings) before summing" + " element-wise.");
     io.addNamedOption(TYPE, "<VARLEN|FIXEDLEN|STRING|fullClassName>");
     return io;
   }
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/SummingCombiner.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/SummingCombiner.java
index cf0da3c..f3e147e 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/SummingCombiner.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/SummingCombiner.java
@@ -39,8 +39,9 @@ public class SummingCombiner extends LongCombiner {
   public IteratorOptions describeOptions() {
     IteratorOptions io = super.describeOptions();
     io.setName("sum");
-    io.setDescription(
-        "SummingCombiner interprets Values as Longs and adds them together.  A variety of encodings (variable length, fixed length, or string) are available");
+    io.setDescription("SummingCombiner interprets Values as Longs and adds them"
+        + " together.  A variety of encodings (variable length, fixed length, or"
+        + " string) are available");
     return io;
   }
 }
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 9adf32b..fb5022d 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
@@ -142,12 +142,16 @@ abstract public class TransformingIterator extends WrappingIterator implements O
 
   @Override
   public IteratorOptions describeOptions() {
-    String desc = "This iterator allows ranges of key to be transformed (with the exception of row transformations).";
+    String desc = "This iterator allows ranges of key to be transformed (with"
+        + " the exception of row transformations).";
     String authDesc = "Comma-separated list of user's scan authorizations.  "
         + "If excluded or empty, then no visibility check is performed on transformed keys.";
-    String bufferDesc = "Maximum buffer size (in accumulo memory spec) to use for buffering keys before throwing a BufferOverflowException.  "
-        + "Users should keep this limit in mind when deciding what to transform.  That is, if transforming the column family for example, then all "
-        + "keys sharing the same row and column family must fit within this limit (along with their associated values)";
+    String bufferDesc = "Maximum buffer size (in accumulo memory spec) to use"
+        + " for buffering keys before throwing a BufferOverflowException. Users"
+        + " should keep this limit in mind when deciding what to transform. That"
+        + " is, if transforming the column family for example, then all keys"
+        + " sharing the same row and column family must fit within this limit"
+        + " (along with their associated values)";
     HashMap<String,String> namedOptions = new HashMap<>();
     namedOptions.put(AUTH_OPT, authDesc);
     namedOptions.put(MAX_BUFFER_SIZE_OPT, bufferDesc);
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/VisibilityFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/VisibilityFilter.java
index fe8adbc..0b741fd 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/VisibilityFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/VisibilityFilter.java
@@ -112,12 +112,14 @@ public class VisibilityFilter extends Filter implements OptionDescriber {
   public IteratorOptions describeOptions() {
     IteratorOptions io = super.describeOptions();
     io.setName("visibilityFilter");
-    io.setDescription(
-        "The VisibilityFilter allows you to filter for key/value pairs by a set of authorizations or filter invalid labels from corrupt files.");
+    io.setDescription("The VisibilityFilter allows you to filter for key/value"
+        + " pairs by a set of authorizations or filter invalid labels from corrupt" + " files.");
     io.addNamedOption(FILTER_INVALID_ONLY,
-        "if 'true', the iterator is instructed to ignore the authorizations and only filter invalid visibility labels (default: false)");
+        "if 'true', the iterator is instructed to ignore the authorizations and"
+            + " only filter invalid visibility labels (default: false)");
     io.addNamedOption(AUTHS,
-        "the serialized set of authorizations to filter against (default: empty string, accepts only entries visible by all)");
+        "the serialized set of authorizations to filter against (default: empty"
+            + " string, accepts only entries visible by all)");
     return io;
   }
 
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 aaf1163..1a96340 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
@@ -246,8 +246,12 @@ public class MetadataSchema {
 
   /**
    * Holds references to files that need replication
-   * <p>
-   * <code>~replhdfs://localhost:8020/accumulo/wal/tserver+port/WAL stat:local_table_id [] -&gt; protobuf</code>
+   *
+   * <pre>
+   * <code>
+   * ~replhdfs://localhost:8020/accumulo/wal/tserver+port/WAL stat:local_table_id [] -&gt; protobuf
+   * </code>
+   * </pre>
    */
   public static class ReplicationSection {
     public static final Text COLF = new Text("stat");
diff --git a/core/src/main/java/org/apache/accumulo/core/replication/ReplicationSchema.java b/core/src/main/java/org/apache/accumulo/core/replication/ReplicationSchema.java
index 53f8236..6100c67 100644
--- a/core/src/main/java/org/apache/accumulo/core/replication/ReplicationSchema.java
+++ b/core/src/main/java/org/apache/accumulo/core/replication/ReplicationSchema.java
@@ -43,8 +43,13 @@ public class ReplicationSchema {
   /**
    * Portion of a file that must be replication to the given target: peer and some identifying
    * location on that peer, e.g. remote table ID
-   * <p>
-   * <code>hdfs://localhost:8020/accumulo/wal/tserver+port/WAL work:serialized_ReplicationTarget [] -&gt; Status Protobuf</code>
+   *
+   * <pre>
+   * <code>
+   * hdfs://localhost:8020/accumulo/wal/tserver+port/WAL work:serialized_ReplicationTarget []
+   * -&gt; Status Protobuf
+   * </code>
+   * </pre>
    */
   public static class WorkSection {
     public static final Text NAME = new Text("work");
@@ -85,8 +90,13 @@ public class ReplicationSchema {
 
   /**
    * Holds replication markers tracking status for files
-   * <p>
-   * <code>hdfs://localhost:8020/accumulo/wal/tserver+port/WAL repl:local_table_id [] -&gt; Status Protobuf</code>
+   *
+   * <pre>
+   * <code>
+   * hdfs://localhost:8020/accumulo/wal/tserver+port/WAL repl:local_table_id []
+   *  -&gt; Status Protobuf
+   * </code>
+   * </pre>
    */
   public static class StatusSection {
     public static final Text NAME = new Text("repl");
@@ -138,8 +148,13 @@ public class ReplicationSchema {
    * Holds the order in which files needed for replication were closed. The intent is to be able to
    * guarantee that files which were closed earlier were replicated first and we don't replay data
    * in the wrong order on our peers
-   * <p>
-   * <code>encodedTimeOfClosure\x00hdfs://localhost:8020/accumulo/wal/tserver+port/WAL order:source_table_id [] -&gt; Status Protobuf</code>
+   *
+   * <pre>
+   * <code>
+   * encodedTimeOfClosure\x00hdfs://localhost:8020/accumulo/wal/tserver+port/WAL
+   *   order:source_table_id [] -&gt; Status Protobuf
+   * </code>
+   * </pre>
    */
   public static class OrderSection {
     public static final Text NAME = new Text("order");
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/FilterTransport.java b/core/src/main/java/org/apache/accumulo/core/rpc/FilterTransport.java
index f8c4147..903ec2d 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/FilterTransport.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/FilterTransport.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/ThriftUtil.java b/core/src/main/java/org/apache/accumulo/core/rpc/ThriftUtil.java
index 9ae0cf0..bf717b1 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/ThriftUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/ThriftUtil.java
@@ -271,8 +271,11 @@ public class ThriftUtil {
 
           // Wrap the real factory with our own that will set the protocol on the Socket before
           // returning it
-          ProtocolOverridingSSLSocketFactory wrappingSslSockFactory = new ProtocolOverridingSSLSocketFactory(
-              sslSockFactory, new String[] {sslParams.getClientProtocol()});
+          // @formatter:off
+          ProtocolOverridingSSLSocketFactory wrappingSslSockFactory =
+            new ProtocolOverridingSSLSocketFactory(sslSockFactory,
+                new String[] {sslParams.getClientProtocol()});
+          // @formatter:on
 
           // Create the TSocket from that
           transport = createClient(wrappingSslSockFactory, address.getHost(), address.getPort(),
@@ -312,9 +315,8 @@ public class ThriftUtil {
               // The current user has no credentials, let it fail naturally at the RPC layer (no
               // ticket)
               // We know this won't work, but we can't do anything else
-              log.warn(
-                  "The current user is a proxy user but there is no underlying real user (likely that RPCs will fail): {}",
-                  currentUser);
+              log.warn("The current user is a proxy user but there is no"
+                  + " underlying real user (likely that RPCs will fail): {}", currentUser);
               userForRpc = currentUser;
             }
           } else {
@@ -349,8 +351,8 @@ public class ThriftUtil {
           // will attempt to re-login to make the next attempt work.
           // Sadly, we have no way to determine the actual reason we got this TTransportException
           // other than inspecting the exception msg.
-          log.debug(
-              "Caught TTransportException opening SASL transport, checking if re-login is necessary before propagating the exception.");
+          log.debug("Caught TTransportException opening SASL transport,"
+              + " checking if re-login is necessary before propagating the" + " exception.");
           attemptClientReLogin();
 
           throw e;
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/UGIAssumingTransport.java b/core/src/main/java/org/apache/accumulo/core/rpc/UGIAssumingTransport.java
index b23157b..20f4398 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/UGIAssumingTransport.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/UGIAssumingTransport.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/core/src/main/java/org/apache/accumulo/core/security/ColumnVisibility.java b/core/src/main/java/org/apache/accumulo/core/security/ColumnVisibility.java
index faffdcc..e73d8ee 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/ColumnVisibility.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/ColumnVisibility.java
@@ -218,7 +218,7 @@ public class ColumnVisibility {
   /*
    * Walks an expression's AST in order to:
    *  1) roll up expressions with the same operant (`a&(b&c) becomes a&b&c`)
-   *  2) sorts labels lexicographically (permutations of `a&b&c` are re-ordered to appear as `a&b&c`)
+   *  2) sort labels lexicographically (permutations of `a&b&c` are re-ordered to appear as `a&b&c`)
    *  3) dedupes labels (`a&b&a` becomes `a&b`)
    */
   // @formatter:on
@@ -540,7 +540,8 @@ public class ColumnVisibility {
    *   .
    *   .
    *   .
-   * ColumnVisibility cv = new ColumnVisibility(quote(&quot;A#C&quot;) + &quot;&amp;&quot; + quote(&quot;FOO&quot;));
+   * String s = quote(&quot;A#C&quot;) + &quot;&amp;&quot; + quote(&quot;FOO&quot;);
+   * ColumnVisibility cv = new ColumnVisibility(s);
    * </pre>
    *
    * @param term
diff --git a/core/src/main/java/org/apache/accumulo/core/security/crypto/BlockedOutputStream.java b/core/src/main/java/org/apache/accumulo/core/security/crypto/BlockedOutputStream.java
index 041d518..ac8fa98 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/crypto/BlockedOutputStream.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/crypto/BlockedOutputStream.java
@@ -21,8 +21,11 @@ import java.io.IOException;
 import java.io.OutputStream;
 import java.nio.ByteBuffer;
 
-// Buffers all input in a growing buffer until flush() is called. Then entire buffer is written, with size information, and padding to force the underlying
-// crypto output stream to also fully flush
+/*
+ * Buffers all input in a growing buffer until flush() is called. Then entire
+ * buffer is written, with size information, and padding to force the
+ * underlying crypto output stream to also fully flush
+*/
 public class BlockedOutputStream extends OutputStream {
   int blockSize;
   DataOutputStream out;
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 c6049bd..809a904 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
@@ -28,8 +28,6 @@ import org.slf4j.LoggerFactory;
 
 /**
  * This factory module exists to assist other classes in loading crypto modules.
- *
- *
  */
 public class CryptoModuleFactory {
 
@@ -110,13 +108,15 @@ public class CryptoModuleFactory {
 
       } catch (InstantiationException e) {
         log.warn(String.format(
-            "Got instantiation exception %s when instantiating crypto module \"%s\".  No encryption will be used.",
+            "Got instantiation exception %s when"
+                + " instantiating crypto module \"%s\". No encryption will be used.",
             e.getCause().getClass().getName(), cryptoModuleClassname));
         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.",
+            "Got illegal access exception when trying to"
+                + " instantiate crypto module \"%s\". No encryption will be used.",
             cryptoModuleClassname));
         log.warn("IllegalAccessException", e);
         return new NullCryptoModule();
@@ -165,9 +165,8 @@ public class CryptoModuleFactory {
     try {
       keyEncryptionStrategyClazz = AccumuloVFSClassLoader.loadClass(className);
     } catch (ClassNotFoundException e1) {
-      log.warn(String.format(
-          "Could not find configured secret key encryption strategy \"%s\".  No encryption will be used.",
-          className));
+      log.warn(String.format("Could not find configured secret key encryption"
+          + " strategy \"%s\". No encryption will be used.", className));
       return new NullSecretKeyEncryptionStrategy();
     }
 
@@ -183,8 +182,9 @@ public class CryptoModuleFactory {
     }
 
     if (!implementsSecretKeyStrategy) {
-      log.warn(
-          "Configured Accumulo secret key encryption strategy \"%s\" does not implement the SecretKeyEncryptionStrategy interface. No encryption will be used.");
+      log.warn("Configured Accumulo secret key encryption strategy \"%s\" does"
+          + " not implement the SecretKeyEncryptionStrategy interface. No"
+          + " encryption will be used.");
       return new NullSecretKeyEncryptionStrategy();
     } else {
       try {
@@ -193,15 +193,15 @@ public class CryptoModuleFactory {
         log.debug("Successfully instantiated secret key encryption strategy " + className);
 
       } 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(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());
         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(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);
         return new NullSecretKeyEncryptionStrategy();
       }
diff --git a/core/src/main/java/org/apache/accumulo/core/security/crypto/DefaultCryptoModule.java b/core/src/main/java/org/apache/accumulo/core/security/crypto/DefaultCryptoModule.java
index f1be91a..b7ba44f 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/crypto/DefaultCryptoModule.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/crypto/DefaultCryptoModule.java
@@ -63,7 +63,8 @@ public class DefaultCryptoModule implements CryptoModule {
     String cipherTransformation = getCipherTransformation(params);
 
     log.trace(String.format(
-        "Using cipher suite \"%s\" with key length %d with RNG \"%s\" and RNG provider \"%s\" and key encryption strategy \"%s\"",
+        "Using cipher suite \"%s\" with key length %d with"
+            + " RNG \"%s\" and RNG provider \"%s\" and key encryption strategy" + " \"%s\"",
         cipherTransformation, params.getKeyLength(), params.getRandomNumberGenerator(),
         params.getRandomNumberGeneratorProvider(), params.getKeyEncryptionStrategyClass()));
 
@@ -81,8 +82,8 @@ public class DefaultCryptoModule implements CryptoModule {
             new SecretKeySpec(params.getPlaintextKey(), params.getAlgorithmName()),
             params.getSecureRandom());
       } catch (InvalidKeyException e) {
-        log.error(
-            "Accumulo encountered an unknown error in generating the secret key object (SecretKeySpec) for an encrypted stream");
+        log.error("Accumulo encountered an unknown error in generating the"
+            + " secret key object (SecretKeySpec) for an encrypted stream");
         throw new RuntimeException(e);
       }
 
@@ -94,12 +95,12 @@ public class DefaultCryptoModule implements CryptoModule {
             new SecretKeySpec(params.getPlaintextKey(), params.getAlgorithmName()),
             new IvParameterSpec(params.getInitializationVector()));
       } catch (InvalidKeyException e) {
-        log.error(
-            "Accumulo encountered an unknown error in generating the secret key object (SecretKeySpec) for an encrypted stream");
+        log.error("Accumulo encountered an unknown error in generating the"
+            + " secret key object (SecretKeySpec) for an encrypted stream");
         throw new RuntimeException(e);
       } catch (InvalidAlgorithmParameterException e) {
-        log.error(
-            "Accumulo encountered an unknown error in setting up the initialization vector for an encrypted stream");
+        log.error("Accumulo encountered an unknown error in setting up the"
+            + " initialization vector for an encrypted stream");
         throw new RuntimeException(e);
       }
     }
@@ -157,8 +158,9 @@ public class DefaultCryptoModule implements CryptoModule {
 
     if (cipherMode == Cipher.ENCRYPT_MODE) {
 
-      StringBuilder errorBuf = new StringBuilder(
-          "The following problems were found with the CryptoModuleParameters object you provided for an encrypt operation:\n");
+      StringBuilder errorBuf = new StringBuilder("The following problems were"
+          + " found with the CryptoModuleParameters object you provided for an"
+          + " encrypt operation:\n");
       boolean allIsWell = true;
 
       allIsWell = validateNotEmpty(params.getAlgorithmName(), allIsWell, errorBuf,
@@ -190,8 +192,9 @@ public class DefaultCryptoModule implements CryptoModule {
       return allIsWell;
 
     } else if (cipherMode == Cipher.DECRYPT_MODE) {
-      StringBuilder errorBuf = new StringBuilder(
-          "The following problems were found with the CryptoModuleParameters object you provided for a decrypt operation:\n");
+      StringBuilder errorBuf = new StringBuilder("The following problems were"
+          + " found with the CryptoModuleParameters object you provided for a"
+          + " decrypt operation:\n");
       boolean allIsWell = true;
 
       allIsWell = validateNotEmpty(params.getPadding(), allIsWell, errorBuf,
@@ -404,11 +407,11 @@ public class DefaultCryptoModule implements CryptoModule {
           params.setBlockStreamSize(0);
       } else {
 
-        log.trace(
-            "Read something off of the encrypted input stream that was not the encryption header marker, so pushing back bytes and returning the given stream");
+        log.trace("Read something off of the encrypted input stream that was"
+            + " not the encryption header marker, so pushing back bytes and"
+            + " returning the given stream");
         // Push these bytes back on to the stream. This method is a bit roundabout but isolates our
-        // code
-        // from having to understand the format that DataOuputStream uses for its bytes.
+        // code from having to understand the format that DataOuputStream uses for its bytes.
         ByteArrayOutputStream tempByteOut = new ByteArrayOutputStream();
         DataOutputStream tempOut = new DataOutputStream(tempByteOut);
         tempOut.writeUTF(marker);
diff --git a/core/src/main/java/org/apache/accumulo/core/security/crypto/DefaultCryptoModuleUtils.java b/core/src/main/java/org/apache/accumulo/core/security/crypto/DefaultCryptoModuleUtils.java
index fdfc971..d32cdf9 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/crypto/DefaultCryptoModuleUtils.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/crypto/DefaultCryptoModuleUtils.java
@@ -41,14 +41,12 @@ public class DefaultCryptoModuleUtils {
       secureRandom.nextBytes(throwAway);
 
     } catch (NoSuchAlgorithmException e) {
-      log.error(String.format(
-          "Accumulo configuration file specified a secure random generator \"%s\" that was not found by any provider.",
-          secureRNG));
+      log.error(String.format("Accumulo configuration file specified a secure"
+          + " random generator \"%s\" that was not found by any provider.", secureRNG));
       throw new RuntimeException(e);
     } catch (NoSuchProviderException e) {
-      log.error(String.format(
-          "Accumulo configuration file specified a secure random provider \"%s\" that does not exist",
-          secureRNGProvider));
+      log.error(String.format("Accumulo configuration file specified a secure"
+          + " random provider \"%s\" that does not exist", secureRNGProvider));
       throw new RuntimeException(e);
     }
     return secureRandom;
@@ -63,13 +61,13 @@ public class DefaultCryptoModuleUtils {
       try {
         cipher = Cipher.getInstance(cipherSuite);
       } catch (NoSuchAlgorithmException e) {
-        log.error(String.format(
-            "Accumulo configuration file contained a cipher suite \"%s\" that was not recognized by any providers",
-            cipherSuite));
+        log.error(String.format("Accumulo configuration file contained a cipher"
+            + " suite \"%s\" that was not recognized by any providers", cipherSuite));
         throw new RuntimeException(e);
       } catch (NoSuchPaddingException e) {
         log.error(String.format(
-            "Accumulo configuration file contained a cipher, \"%s\" with a padding that was not recognized by any providers",
+            "Accumulo configuration file contained a"
+                + " cipher, \"%s\" with a padding that was not recognized by any" + " providers",
             cipherSuite));
         throw new RuntimeException(e);
       }
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 7a4e1cc..bfe207a 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
@@ -49,8 +49,10 @@ public class NonCachingSecretKeyEncryptionStrategy implements SecretKeyEncryptio
       if (!fs.exists(pathToKey)) {
 
         if (encryptionMode == Cipher.UNWRAP_MODE) {
-          log.error("There was a call to decrypt the session key but no key encryption key exists. "
-              + "Either restore it, reconfigure the conf file to point to it in HDFS, or throw the affected data away and begin again.");
+          log.error("There was a call to decrypt the session key but no key"
+              + " encryption key exists. Either restore it, reconfigure the conf"
+              + " file to point to it in HDFS, or throw the affected data away and"
+              + " begin again.");
           throw new RuntimeException(
               "Could not find key encryption key file in configured location in HDFS ("
                   + pathToKeyName + ")");
diff --git a/core/src/main/java/org/apache/accumulo/core/util/CreateToken.java b/core/src/main/java/org/apache/accumulo/core/util/CreateToken.java
index 98ade0d..a42198e 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/CreateToken.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/CreateToken.java
@@ -66,8 +66,9 @@ public class CreateToken implements KeywordExecutable {
     public String tokenClassName = PasswordToken.class.getName();
 
     @Parameter(names = {"-f", "--file"},
-        description = "The filename to save the auth token to. Multiple tokens can be stored in the same file,"
-            + " but only the first for each user will be recognized.")
+        description = "The filename to save the auth token to. Multiple tokens"
+            + " can be stored in the same file, but only the first for each user will"
+            + " be recognized.")
     public String tokenFile = null;
   }
 
diff --git a/core/src/main/java/org/apache/accumulo/core/util/Merge.java b/core/src/main/java/org/apache/accumulo/core/util/Merge.java
index 2439ced..4b01131 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/Merge.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/Merge.java
@@ -71,7 +71,8 @@ public class Merge {
         converter = MemoryConverter.class)
     Long goalSize = null;
     @Parameter(names = {"-f", "--force"},
-        description = "merge small tablets even if merging them to larger tablets might cause a split")
+        description = "merge small tablets even if merging them to larger"
+            + " tablets might cause a split")
     boolean force = false;
     @Parameter(names = {"-b", "--begin"}, description = "start tablet",
         converter = TextConverter.class)
diff --git a/core/src/main/java/org/apache/accumulo/core/volume/NonConfiguredVolume.java b/core/src/main/java/org/apache/accumulo/core/volume/NonConfiguredVolume.java
index 19310dc..2d0b4a6 100644
--- a/core/src/main/java/org/apache/accumulo/core/volume/NonConfiguredVolume.java
+++ b/core/src/main/java/org/apache/accumulo/core/volume/NonConfiguredVolume.java
@@ -60,8 +60,8 @@ public class NonConfiguredVolume implements Volume {
 
   @Override
   public boolean isValidPath(Path p) {
-    throw new UnsupportedOperationException(
-        "Cannot determine if path is valid because this Volume isn't configured in accumulo-site.xml");
+    throw new UnsupportedOperationException("Cannot determine if path is valid"
+        + " because this Volume isn't configured in accumulo-site.xml");
   }
 
   @Override
diff --git a/core/src/test/java/org/apache/accumulo/core/client/security/SecurityErrorCodeTest.java b/core/src/test/java/org/apache/accumulo/core/client/security/SecurityErrorCodeTest.java
index e10ce23..5c42876 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/security/SecurityErrorCodeTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/security/SecurityErrorCodeTest.java
@@ -34,9 +34,12 @@ public class SecurityErrorCodeTest {
     for (SecurityErrorCode sec : SecurityErrorCode.values())
       secNames1.add(sec.name());
 
-    for (org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode sec : org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
+    // @formatter:off
+    for (org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode sec :
+        org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
         .values())
       secNames2.add(sec.name());
+    // @formatter:on
 
     Assert.assertEquals(secNames1, secNames2);
   }
diff --git a/core/src/test/java/org/apache/accumulo/core/conf/PropertyTypeTest.java b/core/src/test/java/org/apache/accumulo/core/conf/PropertyTypeTest.java
index 97cca59..3dcf0fd 100644
--- a/core/src/test/java/org/apache/accumulo/core/conf/PropertyTypeTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/conf/PropertyTypeTest.java
@@ -55,7 +55,8 @@ public class PropertyTypeTest {
   @Test
   public void testGetFormatDescription() {
     assertEquals(
-        "An arbitrary string of characters whose format is unspecified and interpreted based on the context of the property to which it applies.",
+        "An arbitrary string of characters whose format is unspecified"
+            + " and interpreted based on the context of the property to which it" + " applies.",
         PropertyType.STRING.getFormatDescription());
   }
 
diff --git a/core/src/test/java/org/apache/accumulo/core/data/ConstraintViolationSummaryTest.java b/core/src/test/java/org/apache/accumulo/core/data/ConstraintViolationSummaryTest.java
index 4aa5dfb..d6a6a70 100644
--- a/core/src/test/java/org/apache/accumulo/core/data/ConstraintViolationSummaryTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/data/ConstraintViolationSummaryTest.java
@@ -26,13 +26,14 @@ public class ConstraintViolationSummaryTest {
   public void testToString() {
     ConstraintViolationSummary cvs = new ConstraintViolationSummary("fooClass", (short) 1,
         "fooDescription", 100L);
-    assertEquals(
-        "ConstraintViolationSummary(constrainClass:fooClass, violationCode:1, violationDescription:fooDescription, numberOfViolatingMutations:100)",
-        cvs.toString());
+    assertEquals("ConstraintViolationSummary(constrainClass:fooClass,"
+        + " violationCode:1, violationDescription:fooDescription,"
+        + " numberOfViolatingMutations:100)", cvs.toString());
 
     cvs = new ConstraintViolationSummary(null, (short) 2, null, 101L);
     assertEquals(
-        "ConstraintViolationSummary(constrainClass:null, violationCode:2, violationDescription:null, numberOfViolatingMutations:101)",
+        "ConstraintViolationSummary(constrainClass:null,"
+            + " violationCode:2, violationDescription:null," + " numberOfViolatingMutations:101)",
         cvs.toString());
   }
 }
diff --git a/core/src/test/java/org/apache/accumulo/core/data/MutationTest.java b/core/src/test/java/org/apache/accumulo/core/data/MutationTest.java
index 6c4b208..5bbd2b5 100644
--- a/core/src/test/java/org/apache/accumulo/core/data/MutationTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/data/MutationTest.java
@@ -488,9 +488,9 @@ public class MutationTest {
       }
       sb.append(" ");
     }
-    assertEquals(
-        "80322031 32333435 36373839 20313233 34353637 38392031 32333435 36373839 20313233 34353637 38392031 32333435 36373839 06000000 00000001 ",
-        sb.toString());
+    assertEquals("80322031 32333435 36373839 20313233 34353637"
+        + " 38392031 32333435 36373839 20313233 34353637"
+        + " 38392031 32333435 36373839 06000000 00000001 ", sb.toString());
 
   }
 
@@ -673,8 +673,8 @@ public class MutationTest {
     try {
       m.put("cf", "cq", "v");
     } catch (IllegalStateException e) {
-      fail(
-          "Calling Mutation#hashCode then Mutation#put should not result in an IllegalStateException.");
+      fail("Calling Mutation#hashCode then Mutation#put should not result in an"
+          + " IllegalStateException.");
     }
   }
 
@@ -687,8 +687,8 @@ public class MutationTest {
       m.put("cf", "cq", "v");
       m2.put("cf", "cq", "v");
     } catch (IllegalStateException e) {
-      fail(
-          "Calling Mutation#equals then Mutation#put should not result in an IllegalStateException.");
+      fail("Calling Mutation#equals then Mutation#put should not result in an"
+          + " IllegalStateException.");
     }
   }
 }
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
index fa3f687..373fcb6 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
@@ -47,11 +47,14 @@ public class AggregatorConfigurationTest {
   @SuppressWarnings("deprecation")
   private void runTest(Text colf) {
     String encodedCols;
-    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac3 = new org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig(
-        colf, "com.foo.SuperAgg");
+    // @formatter:off
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac3 =
+      new org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig(colf, "com.foo.SuperAgg");
     encodedCols = ac3.encodeColumns();
-    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac4 = org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac4 =
+      org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
         .decodeColumns(encodedCols, "com.foo.SuperAgg");
+    // @formatter:on
 
     assertEquals(colf, ac4.getColumnFamily());
     assertNull(ac4.getColumnQualifier());
@@ -59,11 +62,15 @@ public class AggregatorConfigurationTest {
 
   @SuppressWarnings("deprecation")
   private void runTest(Text colf, Text colq) {
-    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac = new org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig(
-        colf, colq, "com.foo.SuperAgg");
+    // @formatter:off
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac =
+      new org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig(colf, colq,
+        "com.foo.SuperAgg");
     String encodedCols = ac.encodeColumns();
-    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac2 = org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac2 =
+      org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
         .decodeColumns(encodedCols, "com.foo.SuperAgg");
+    // @formatter:on
 
     assertEquals(colf, ac2.getColumnFamily());
     assertEquals(colq, ac2.getColumnQualifier());
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/user/VisibilityFilterTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/user/VisibilityFilterTest.java
index 583f457..0243791 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/user/VisibilityFilterTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/user/VisibilityFilterTest.java
@@ -88,7 +88,8 @@ public class VisibilityFilterTest {
     int count = 0;
     while (filter.hasTop()) {
       count++;
-      // System.out.println(DefaultFormatter.formatEntry(Collections.singletonMap(filter.getTopKey(),
+      // System.out.println(DefaultFormatter.formatEntry(
+      // Collections.singletonMap(filter.getTopKey(),
       // filter.getTopValue()).entrySet().iterator().next(),
       // false));
       assertEquals(expectedCF, filter.getTopKey().getColumnFamily());
diff --git a/core/src/test/java/org/apache/accumulo/core/security/crypto/CryptoTest.java b/core/src/test/java/org/apache/accumulo/core/security/crypto/CryptoTest.java
index fc4c500..b3045ce 100644
--- a/core/src/test/java/org/apache/accumulo/core/security/crypto/CryptoTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/security/crypto/CryptoTest.java
@@ -59,7 +59,10 @@ public class CryptoTest {
   public static final String CONFIG_FILE_SYSTEM_PROP = "org.apache.accumulo.config.file";
   public static final String CRYPTO_ON_CONF = "crypto-on-accumulo-site.xml";
   public static final String CRYPTO_OFF_CONF = "crypto-off-accumulo-site.xml";
-  public static final String CRYPTO_ON_KEK_OFF_CONF = "crypto-on-no-key-encryption-accumulo-site.xml";
+  // @formatter:off
+  public static final String CRYPTO_ON_KEK_OFF_CONF =
+    "crypto-on-no-key-encryption-accumulo-site.xml";
+  // @formatter:on
 
   @Rule
   public ExpectedException exception = ExpectedException.none();
diff --git a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchWriter.java b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchWriter.java
index fcc8f75..3ead254 100644
--- a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchWriter.java
+++ b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchWriter.java
@@ -130,10 +130,10 @@ public class RandomBatchWriter {
     opts.parseArgs(RandomBatchWriter.class.getName(), args, bwOpts);
     if ((opts.max - opts.min) < 1L * opts.num) { // right-side multiplied by 1L to convert to long
                                                  // in a way that doesn't trigger FindBugs
-      System.err.println(String.format(
-          "You must specify a min and a max that allow for at least num possible values. "
-              + "For example, you requested %d rows, but a min of %d and a max of %d (exclusive), which only allows for %d rows.",
-          opts.num, opts.min, opts.max, (opts.max - opts.min)));
+      System.err.println(String.format("You must specify a min and a max that"
+          + " allow for at least num possible values. For example, you requested"
+          + " %d rows, but a min of %d and a max of %d (exclusive), which only"
+          + " allows for %d rows.", opts.num, opts.min, opts.max, (opts.max - opts.min)));
       System.exit(1);
     }
     Random r;
diff --git a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/mapreduce/TableToFile.java b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/mapreduce/TableToFile.java
index 60b957d..01f1f1e 100644
--- a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/mapreduce/TableToFile.java
+++ b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/mapreduce/TableToFile.java
@@ -43,7 +43,16 @@ import com.beust.jcommander.Parameter;
 
 /**
  * Takes a table and outputs the specified column to a set of part files on hdfs
- * {@code accumulo accumulo.examples.mapreduce.TableToFile <username> <password> <tablename> <column> <hdfs-output-path>}
+ *
+ * <p>
+ * CLI options (in order):
+ * <ul>
+ * <li>username
+ * <li>password
+ * <li>tablename
+ * <li>column
+ * <li>hdfs-output-path
+ * </ul>
  */
 public class TableToFile extends Configured implements Tool {
 
diff --git a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/sample/SampleExample.java b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/sample/SampleExample.java
index e5709db..5000d7d 100644
--- a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/sample/SampleExample.java
+++ b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/sample/SampleExample.java
@@ -91,8 +91,8 @@ public class SampleExample {
     print(scanner);
     System.out.println();
 
-    System.out.println(
-        "Scanning with sampler configuration.  Data was written before sampler was set on table, scan should fail.");
+    System.out.println("Scanning with sampler configuration. Data was written"
+        + " before sampler was set on table, scan should fail.");
     scanner.setSamplerConfiguration(sc1);
     try {
       print(scanner);
@@ -113,8 +113,8 @@ public class SampleExample {
     bw.addMutation(createMutation("2317", "milk, eggs, bread, parmigiano-reggiano, butter",
         "file://groceries/9/txt"));
     bw.close();
-    System.out.println(
-        "Scanning sample after updating content for docId 2317 (should see content change in sample data) : ");
+    System.out.println("Scanning sample after updating content for docId 2317"
+        + " (should see content change in sample data) : ");
     print(scanner);
     System.out.println();
 
@@ -126,8 +126,8 @@ public class SampleExample {
     conn.tableOperations().compact(opts.getTableName(),
         new CompactionConfig().setCompactionStrategy(NO_SAMPLE_STRATEGY));
 
-    System.out.println(
-        "Scanning with old sampler configuration.  Sample data was created using new configuration with a compaction.  Scan should fail.");
+    System.out.println("Scanning with old sampler configuration. Sample data"
+        + " was created using new configuration with a compaction. Scan should fail.");
     try {
       // try scanning with old sampler configuration
       print(scanner);
diff --git a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/Query.java b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/Query.java
index 22fdb1e..432610d 100644
--- a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/Query.java
+++ b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/Query.java
@@ -50,11 +50,13 @@ public class Query {
     List<String> terms = new ArrayList<>();
 
     @Parameter(names = {"--sample"},
-        description = "Do queries against sample, useful when sample is built using column qualifier")
+        description = "Do queries against sample, useful when sample is built"
+            + " using column qualifier")
     private boolean useSample = false;
 
     @Parameter(names = {"--sampleCutoff"},
-        description = "Use sample data to determine if a query might return a number of documents over the cutoff.  This check is per tablet.")
+        description = "Use sample data to determine if a query might return a"
+            + " number of documents over the cutoff. This check is per tablet.")
     private Integer sampleCutoff = null;
   }
 
diff --git a/fate/src/main/java/org/apache/accumulo/fate/util/AddressUtil.java b/fate/src/main/java/org/apache/accumulo/fate/util/AddressUtil.java
index eb1fe22..2f8c33f 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/util/AddressUtil.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/util/AddressUtil.java
@@ -44,24 +44,23 @@ public class AddressUtil {
     try {
       negativeTtl = Integer.parseInt(Security.getProperty("networkaddress.cache.negative.ttl"));
     } catch (NumberFormatException exception) {
-      log.warn(
-          "Failed to get JVM negative DNS respones cache TTL due to format problem (e.g. this JVM might not have the "
-              + "property). Falling back to default based on Oracle JVM 1.4+ (10s)",
-          exception);
+      log.warn("Failed to get JVM negative DNS respones cache TTL due to format problem "
+          + "(e.g. this JVM might not have the property). "
+          + "Falling back to default based on Oracle JVM 1.4+ (10s)", exception);
     } catch (SecurityException exception) {
-      log.warn(
-          "Failed to get JVM negative DNS response cache TTL due to security manager. Falling back to default based on Oracle JVM 1.4+ (10s)",
-          exception);
+      log.warn("Failed to get JVM negative DNS response cache TTL due to security manager. "
+          + "Falling back to default based on Oracle JVM 1.4+ (10s)", exception);
     }
     if (-1 == negativeTtl) {
       log.error(
-          "JVM negative DNS repsonse cache TTL is set to 'forever' and host lookup failed. TTL can be changed with security property "
+          "JVM negative DNS repsonse cache TTL is set to 'forever' and host lookup failed. "
+              + "TTL can be changed with security property "
               + "'networkaddress.cache.negative.ttl', see java.net.InetAddress.",
           originalException);
       throw new IllegalArgumentException(originalException);
     } else if (0 > negativeTtl) {
-      log.warn(
-          "JVM specified negative DNS response cache TTL was negative (and not 'forever'). Falling back to default based on Oracle JVM 1.4+ (10s)");
+      log.warn("JVM specified negative DNS response cache TTL was negative (and not 'forever'). "
+          + "Falling back to default based on Oracle JVM 1.4+ (10s)");
       negativeTtl = 10;
     }
     return negativeTtl;
diff --git a/fate/src/test/java/org/apache/accumulo/fate/util/AddressUtilTest.java b/fate/src/test/java/org/apache/accumulo/fate/util/AddressUtilTest.java
index 9c7ff62..1241c36 100644
--- a/fate/src/test/java/org/apache/accumulo/fate/util/AddressUtilTest.java
+++ b/fate/src/test/java/org/apache/accumulo/fate/util/AddressUtilTest.java
@@ -62,20 +62,20 @@ public class AddressUtilTest extends TestCase {
     }
     try {
       if (expectException) {
-        log.info(
-            "AddressUtil is (hopefully) going to spit out an error about DNS lookups. you can ignore it.");
+        log.info("AddressUtil is (hopefully) going to spit out an error about DNS lookups. "
+            + "you can ignore it.");
       }
       int result = AddressUtil.getAddressCacheNegativeTtl(null);
       if (expectException) {
-        fail(
-            "The JVM Security settings cache DNS failures forever. In this case we expect an exception but didn't get one.");
+        fail("The JVM Security settings cache DNS failures forever. "
+            + "In this case we expect an exception but didn't get one.");
       }
       assertEquals("Didn't get the ttl we expected", expectedTtl, result);
     } catch (IllegalArgumentException exception) {
       if (!expectException) {
         log.error("Got an exception when we weren't expecting.", exception);
-        fail(
-            "We only expect to throw an IllegalArgumentException when the JVM caches DNS failures forever.");
+        fail("We only expect to throw an IllegalArgumentException when the JVM "
+            + "caches DNS failures forever.");
       }
     }
   }
@@ -90,8 +90,8 @@ public class AddressUtilTest extends TestCase {
       return;
     }
     try {
-      log.info(
-          "AddressUtil is (hopefully) going to spit out an error about DNS lookups. you can ignore it.");
+      log.info("AddressUtil is (hopefully) going to spit out an error about DNS lookups. "
+          + "you can ignore it.");
       AddressUtil.getAddressCacheNegativeTtl(null);
       fail("The JVM Security settings cache DNS failures forever, this should cause an exception.");
     } catch (IllegalArgumentException exception) {
diff --git a/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/testcases/MultipleHasTopCalls.java b/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/testcases/MultipleHasTopCalls.java
index 467d552..8974ce3 100644
--- a/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/testcases/MultipleHasTopCalls.java
+++ b/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/testcases/MultipleHasTopCalls.java
@@ -82,8 +82,8 @@ public class MultipleHasTopCalls extends OutputVerifyingTestCase {
   }
 
   IllegalStateException badStateException(boolean expectedState) {
-    return new IllegalStateException(
-        "Multiple sequential calls to hasTop should not alter the state or return value of the iterator. Expected '"
-            + expectedState + ", but got '" + !expectedState + "'.");
+    return new IllegalStateException("Multiple sequential calls to hasTop"
+        + " should not alter the state or return value of the iterator. Expected '" + expectedState
+        + ", but got '" + !expectedState + "'.");
   }
 }
diff --git a/minicluster/src/main/java/org/apache/accumulo/minicluster/MiniAccumuloRunner.java b/minicluster/src/main/java/org/apache/accumulo/minicluster/MiniAccumuloRunner.java
index cdc345a..02c0723 100644
--- a/minicluster/src/main/java/org/apache/accumulo/minicluster/MiniAccumuloRunner.java
+++ b/minicluster/src/main/java/org/apache/accumulo/minicluster/MiniAccumuloRunner.java
@@ -81,8 +81,8 @@ public class MiniAccumuloRunner {
   private static void printProperties() {
     System.out.println("#mini Accumulo cluster runner properties.");
     System.out.println("#");
-    System.out.println(
-        "#uncomment following propeties to use, propeties not set will use default or random value");
+    System.out.println("#uncomment following propeties to use, propeties not"
+        + " set will use default or random value");
     System.out.println();
     System.out.println("#" + INSTANCE_NAME_PROP + "=devTest");
     System.out.println("#" + DIRECTORY_PROP + "=/tmp/mac1");
diff --git a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloConfigImpl.java b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloConfigImpl.java
index b2adba5..afcb9c3 100644
--- a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloConfigImpl.java
+++ b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloConfigImpl.java
@@ -193,8 +193,8 @@ public class MiniAccumuloConfigImpl {
     }
 
     if (!CredentialProviderFactoryShim.isHadoopCredentialProviderAvailable()) {
-      throw new RuntimeException(
-          "Cannot use CredentialProvider when implementation is not available. Be sure to use >=Hadoop-2.6.0");
+      throw new RuntimeException("Cannot use CredentialProvider when"
+          + " implementation is not available. Be sure to use >=Hadoop-2.6.0");
     }
 
     File keystoreFile = new File(getConfDir(), "credential-provider.jks");
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/Proxy.java b/proxy/src/main/java/org/apache/accumulo/proxy/Proxy.java
index 49f19a0..89c755d 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/Proxy.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/Proxy.java
@@ -126,8 +126,8 @@ public class Proxy implements KeywordExecutable {
     String zookeepers = opts.prop.getProperty(ZOOKEEPERS_KEY);
 
     if (!useMini && !useMock && instance == null) {
-      System.err.println(
-          "Properties file must contain one of : useMiniAccumulo=true, useMockInstance=true, or instance=<instance name>");
+      System.err.println("Properties file must contain one of : useMiniAccumulo=true,"
+          + " useMockInstance=true, or instance=<instance name>");
       System.exit(1);
     }
 
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java b/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java
index 074c458..c5aeb9c 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java
@@ -131,7 +131,8 @@ import com.google.common.cache.RemovalNotification;
 public class ProxyServer implements AccumuloProxy.Iface {
 
   public static final Logger logger = LoggerFactory.getLogger(ProxyServer.class);
-  public static final String RPC_ACCUMULO_PRINCIPAL_MISMATCH_MSG = "RPC principal did not match requested Accumulo principal";
+  public static final String RPC_ACCUMULO_PRINCIPAL_MISMATCH_MSG = "RPC"
+      + " principal did not match requested Accumulo principal";
   protected Instance instance;
 
   protected Class<? extends AuthenticationToken> tokenClass;
@@ -414,8 +415,11 @@ public class ProxyServer implements AccumuloProxy.Iface {
           .setIterators(getIteratorSettings(iterators)).setFlush(flush).setWait(wait);
 
       if (compactionStrategy != null) {
-        org.apache.accumulo.core.client.admin.CompactionStrategyConfig ccc = new org.apache.accumulo.core.client.admin.CompactionStrategyConfig(
+        // @formatter:off
+        org.apache.accumulo.core.client.admin.CompactionStrategyConfig ccc =
+          new org.apache.accumulo.core.client.admin.CompactionStrategyConfig(
             compactionStrategy.getClassName());
+        // @formatter:on
         if (compactionStrategy.options != null)
           ccc.setOptions(compactionStrategy.options);
         compactionConfig.setCompactionStrategy(ccc);
@@ -808,7 +812,10 @@ public class ProxyServer implements AccumuloProxy.Iface {
       List<ActiveScan> activeScans = getConnector(login).instanceOperations()
           .getActiveScans(tserver);
       for (ActiveScan scan : activeScans) {
-        org.apache.accumulo.proxy.thrift.ActiveScan pscan = new org.apache.accumulo.proxy.thrift.ActiveScan();
+        // @formatter:off
+        org.apache.accumulo.proxy.thrift.ActiveScan pscan =
+          new org.apache.accumulo.proxy.thrift.ActiveScan();
+        // @formatter:on
         pscan.client = scan.getClient();
         pscan.user = scan.getUser();
         pscan.table = scan.getTable();
@@ -822,7 +829,10 @@ public class ProxyServer implements AccumuloProxy.Iface {
         pscan.columns = new ArrayList<>();
         if (scan.getColumns() != null) {
           for (Column c : scan.getColumns()) {
-            org.apache.accumulo.proxy.thrift.Column column = new org.apache.accumulo.proxy.thrift.Column();
+            // @formatter:off
+            org.apache.accumulo.proxy.thrift.Column column =
+              new org.apache.accumulo.proxy.thrift.Column();
+            // @formatter:on
             column.setColFamily(c.getColumnFamily());
             column.setColQualifier(c.getColumnQualifier());
             column.setColVisibility(c.getColumnVisibility());
@@ -836,8 +846,11 @@ public class ProxyServer implements AccumuloProxy.Iface {
             String name = parts[0];
             int priority = Integer.parseInt(parts[1]);
             String classname = parts[2];
-            org.apache.accumulo.proxy.thrift.IteratorSetting settings = new org.apache.accumulo.proxy.thrift.IteratorSetting(
+            // @formatter:off
+            org.apache.accumulo.proxy.thrift.IteratorSetting settings =
+              new org.apache.accumulo.proxy.thrift.IteratorSetting(
                 priority, name, classname, scan.getSsio().get(name));
+            // @formatter:on
             pscan.iterators.add(settings);
           }
         }
@@ -866,7 +879,10 @@ public class ProxyServer implements AccumuloProxy.Iface {
       List<ActiveCompaction> active = getConnector(login).instanceOperations()
           .getActiveCompactions(tserver);
       for (ActiveCompaction comp : active) {
-        org.apache.accumulo.proxy.thrift.ActiveCompaction pcomp = new org.apache.accumulo.proxy.thrift.ActiveCompaction();
+        // @formatter:off
+        org.apache.accumulo.proxy.thrift.ActiveCompaction pcomp =
+          new org.apache.accumulo.proxy.thrift.ActiveCompaction();
+        // @formatter:on
         pcomp.age = comp.getAge();
         pcomp.entriesRead = comp.getEntriesRead();
         pcomp.entriesWritten = comp.getEntriesWritten();
@@ -885,9 +901,12 @@ public class ProxyServer implements AccumuloProxy.Iface {
         pcomp.iterators = new ArrayList<>();
         if (comp.getIterators() != null) {
           for (IteratorSetting setting : comp.getIterators()) {
-            org.apache.accumulo.proxy.thrift.IteratorSetting psetting = new org.apache.accumulo.proxy.thrift.IteratorSetting(
+            // @formatter:off
+            org.apache.accumulo.proxy.thrift.IteratorSetting psetting =
+              new org.apache.accumulo.proxy.thrift.IteratorSetting(
                 setting.getPriority(), setting.getName(), setting.getIteratorClass(),
                 setting.getOptions());
+            // @formatter:on
             pcomp.iterators.add(psetting);
           }
         }
@@ -2174,8 +2193,11 @@ public class ProxyServer implements AccumuloProxy.Iface {
         ConditionalMutation cmut = new ConditionalMutation(ByteBufferUtil.toBytes(cu.getKey()));
 
         for (Condition tcond : cu.getValue().conditions) {
-          org.apache.accumulo.core.data.Condition cond = new org.apache.accumulo.core.data.Condition(
+          // @formatter:off
+          org.apache.accumulo.core.data.Condition cond =
+            new org.apache.accumulo.core.data.Condition(
               tcond.column.getColFamily(), tcond.column.getColQualifier());
+          // @formatter:on
 
           if (tcond.getColumn().getColVisibility() != null
               && tcond.getColumn().getColVisibility().length > 0) {
diff --git a/server/base/src/main/java/org/apache/accumulo/server/Accumulo.java b/server/base/src/main/java/org/apache/accumulo/server/Accumulo.java
index 2a454c9..2f98fdd 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/Accumulo.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/Accumulo.java
@@ -252,8 +252,9 @@ public class Accumulo {
               setting = setting.trim();
               if (bytes > 0 && Integer.parseInt(setting) > 10) {
                 log.warn("System swappiness setting is greater than ten (" + setting
-                    + ") which can cause time-sensitive operations to be delayed. "
-                    + " Accumulo is time sensitive because it needs to maintain distributed lock agreement.");
+                    + ") which can cause time-sensitive operations to"
+                    + " be delayed. Accumulo is time sensitive because it needs to"
+                    + " maintain distributed lock agreement.");
               }
             } finally {
               is.close();
@@ -340,9 +341,10 @@ public class Accumulo {
           new ZooStore<Accumulo>(ZooUtil.getRoot(HdfsZooInstance.getInstance()) + Constants.ZFATE,
               ZooReaderWriter.getInstance()));
       if (!(fate.list().isEmpty())) {
-        throw new AccumuloException(
-            "Aborting upgrade because there are outstanding FATE transactions from a previous Accumulo version. "
-                + "Please see the README document for instructions on what to do under your previous version.");
+        throw new AccumuloException("Aborting upgrade because there are"
+            + " outstanding FATE transactions from a previous Accumulo version."
+            + " Please see the README document for instructions on what to do under"
+            + " your previous version.");
       }
     } catch (Exception exception) {
       log.fatal("Problem verifying Fate readiness", exception);
diff --git a/server/base/src/main/java/org/apache/accumulo/server/GarbageCollectionLogger.java b/server/base/src/main/java/org/apache/accumulo/server/GarbageCollectionLogger.java
index c2560c0..b39a2c0 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/GarbageCollectionLogger.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/GarbageCollectionLogger.java
@@ -100,8 +100,8 @@ public class GarbageCollectionLogger {
     if (lastMemoryCheckTime > 0 && lastMemoryCheckTime < now) {
       final long diff = now - lastMemoryCheckTime;
       if (diff > keepAliveTimeout + 1000) {
-        log.warn(String.format(
-            "GC pause checker not called in a timely fashion. Expected every %.1f seconds but was %.1f seconds since last check",
+        log.warn(String.format("GC pause checker not called in a timely"
+            + " fashion. Expected every %.1f seconds but was %.1f seconds since" + " last check",
             keepAliveTimeout / 1000., diff / 1000.));
       }
       lastMemoryCheckTime = now;
diff --git a/server/base/src/main/java/org/apache/accumulo/server/fs/PreferredVolumeChooser.java b/server/base/src/main/java/org/apache/accumulo/server/fs/PreferredVolumeChooser.java
index a55a827..1f03fee 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/fs/PreferredVolumeChooser.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/fs/PreferredVolumeChooser.java
@@ -110,8 +110,8 @@ public class PreferredVolumeChooser extends RandomVolumeChooser {
     // If there are no preferred volumes left, then warn the user and choose randomly from the
     // instance volumes
     if (filteredOptions.isEmpty()) {
-      log.warn(
-          "Preferred volumes are not instance volumes. Defaulting to randomly choosing from instance volumes");
+      log.warn("Preferred volumes are not instance volumes. Defaulting to"
+          + " randomly choosing from instance volumes");
       return super.choose(env, options);
     }
 
diff --git a/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeManagerImpl.java b/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeManagerImpl.java
index d3045bf..2557595 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeManagerImpl.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeManagerImpl.java
@@ -227,8 +227,9 @@ public class VolumeManagerImpl implements VolumeManager {
           synchronized (WARNED_ABOUT_SYNCONCLOSE) {
             if (!WARNED_ABOUT_SYNCONCLOSE.contains(entry.getKey())) {
               WARNED_ABOUT_SYNCONCLOSE.add(entry.getKey());
-              log.warn(DFS_DATANODE_SYNCONCLOSE
-                  + " set to false in hdfs-site.xml: data loss is possible on hard system reset or power loss");
+              log.warn(DFS_DATANODE_SYNCONCLOSE + " set to false in"
+                  + " hdfs-site.xml: data loss is possible on hard system reset or"
+                  + " power loss");
             }
           }
         }
@@ -492,8 +493,9 @@ public class VolumeManagerImpl implements VolumeManager {
     final String choice = chooser.choose(env, options);
     if (!(ArrayUtils.contains(options, choice))) {
       log.error("The configured volume chooser, '" + chooser.getClass()
-          + "', or one of its delegates returned a volume not in the set of options provided; "
-          + "will continue by relying on a RandomVolumeChooser. You should investigate and correct the named chooser.");
+          + "', or one of its delegates returned a volume not in the set of"
+          + " options provided; will continue by relying on a RandomVolumeChooser."
+          + " You should investigate and correct the named chooser.");
       return failsafeChooser.choose(env, options);
     }
     return choice;
diff --git a/server/base/src/main/java/org/apache/accumulo/server/init/Initialize.java b/server/base/src/main/java/org/apache/accumulo/server/init/Initialize.java
index be6ca8b..4fab114 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/init/Initialize.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/init/Initialize.java
@@ -247,8 +247,8 @@ public class Initialize implements KeywordExecutable {
     log.info("Accumulo data dirs are "
         + Arrays.asList(VolumeConfiguration.getVolumeUris(SiteConfiguration.getInstance())));
     log.info("Zookeeper server is " + sconf.get(Property.INSTANCE_ZK_HOST));
-    log.info(
-        "Checking if Zookeeper is available. If this hangs, then you need to make sure zookeeper is running");
+    log.info("Checking if Zookeeper is available. If this hangs, then you need"
+        + " to make sure zookeeper is running");
     if (!zookeeperAvailable()) {
       // ACCUMULO-3651 Changed level to error and added FATAL to message for slf4j compatibility
       log.error("FATAL Zookeeper needs to be up and running in order to init. Exiting ...");
@@ -259,16 +259,16 @@ public class Initialize implements KeywordExecutable {
       c.beep();
       c.println();
       c.println();
-      c.println(
-          "Warning!!! Your instance secret is still set to the default, this is not secure. We highly recommend you change it.");
+      c.println("Warning!!! Your instance secret is still set to the default,"
+          + " this is not secure. We highly recommend you change it.");
       c.println();
       c.println();
       c.println("You can change the instance secret in accumulo by using:");
       c.println("   bin/accumulo " + org.apache.accumulo.server.util.ChangeSecret.class.getName()
           + " oldPassword newPassword.");
-      c.println(
-          "You will also need to edit your secret in your configuration file by adding the property instance.secret to your conf/accumulo-site.xml. "
-              + "Without this accumulo will not operate correctly");
+      c.println("You will also need to edit your secret in your configuration"
+          + " file by adding the property instance.secret to your"
+          + " conf/accumulo-site.xml. Without this accumulo will not operate" + " correctly");
     }
     try {
       if (isInitialized(fs)) {
@@ -382,8 +382,8 @@ public class Initialize implements KeywordExecutable {
         if (defaultFsUri.equals(fsDefaultName) && defaultFsUri.equals(fsDefaultFS)) {
           log.error("FATAL: Default filesystem value ('fs.defaultFS' or 'fs.default.name') of '"
               + defaultFsUri + "' was found in the Hadoop configuration");
-          log.error(
-              "FATAL: Please ensure that the Hadoop core-site.xml is on the classpath using 'general.classpaths' in accumulo-site.xml");
+          log.error("FATAL: Please ensure that the Hadoop core-site.xml is on"
+              + " the classpath using 'general.classpaths' in accumulo-site.xml");
         }
       }
 
@@ -409,8 +409,8 @@ public class Initialize implements KeywordExecutable {
           // Fail if the site configuration doesn't contain appropriate credentials to login as
           // servers
           if (StringUtils.isBlank(accumuloKeytab) || StringUtils.isBlank(accumuloPrincipal)) {
-            log.error(
-                "FATAL: No Kerberos credentials provided, and Accumulo is not properly configured for server login");
+            log.error("FATAL: No Kerberos credentials provided, and Accumulo is"
+                + " not properly configured for server login");
             return false;
           }
 
@@ -814,7 +814,8 @@ public class Initialize implements KeywordExecutable {
       if (aBasePath.equals(replacementVolume.getFirst()))
         log.error(aBasePath + " is set to be replaced in " + Property.INSTANCE_VOLUMES_REPLACEMENTS
             + " and should not appear in " + Property.INSTANCE_VOLUMES
-            + ". It is highly recommended that this property be removed as data could still be written to this volume.");
+            + ". It is highly recommended that this property be removed as data"
+            + " could still be written to this volume.");
     }
 
     if (ServerConstants.DATA_VERSION != Accumulo.getAccumuloPersistentVersion(
diff --git a/server/base/src/main/java/org/apache/accumulo/server/log/WalStateManager.java b/server/base/src/main/java/org/apache/accumulo/server/log/WalStateManager.java
index 75d129b..22e9ee1 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/log/WalStateManager.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/log/WalStateManager.java
@@ -37,27 +37,33 @@ import org.apache.zookeeper.KeeperException;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-/*
- * This class governs the space in Zookeeper that advertises the status of Write-Ahead Logs
- * in use by tablet servers and the replication machinery.
+/**
+ * This class governs the space in Zookeeper that advertises the status of Write-Ahead Logs in use
+ * by tablet servers and the replication machinery.
  *
- * The Master needs to know the state of the WALs to mark tablets during recovery.
- * The GC needs to know when a log is no longer needed so it can be removed.
- * The replication mechanism needs to know when a log is closed and can be forwarded to the destination table.
+ * <p>
+ * The Master needs to know the state of the WALs to mark tablets during recovery. The GC needs to
+ * know when a log is no longer needed so it can be removed. The replication mechanism needs to know
+ * when a log is closed and can be forwarded to the destination table.
  *
- * The state of the WALs is kept in Zookeeper under /accumulo/<instanceid>/wals.
- * For each server, there is a znode formatted like the TServerInstance.toString(): "host:port[sessionid]".
- * Under the server znode, is a node for each log, using the UUID for the log.
- * In each of the WAL znodes, is the current state of the log, and the full path to the log.
+ * <p>
+ * The state of the WALs is kept in Zookeeper under /accumulo/&lt;instanceid&gt;/wals. For each
+ * server, there is a znode formatted like the TServerInstance.toString(): "host:port[sessionid]".
+ * Under the server znode, is a node for each log, using the UUID for the log. In each of the WAL
+ * znodes, is the current state of the log, and the full path to the log.
  *
- * The state [OPEN, CLOSED, UNREFERENCED] is what the tablet server believes to be the state of the file.
+ * <p>
+ * The state [OPEN, CLOSED, UNREFERENCED] is what the tablet server believes to be the state of the
+ * file.
  *
- * In the event of a recovery, the log is identified as belonging to a dead server.  The master will update
- * the tablets assigned to that server with log references. Once all tablets have been reassigned and the log
- * references are removed, the log will be eligible for deletion.
+ * <p>
+ * In the event of a recovery, the log is identified as belonging to a dead server. The master will
+ * update the tablets assigned to that server with log references. Once all tablets have been
+ * reassigned and the log references are removed, the log will be eligible for deletion.
  *
- * Even when a log is UNREFERENCED by the tablet server, the replication mechanism may still need the log.
- * The GC will defer log removal until replication is finished with it.
+ * <p>
+ * Even when a log is UNREFERENCED by the tablet server, the replication mechanism may still need
+ * the log. The GC will defer log removal until replication is finished with it.
  *
  */
 public class WalStateManager {
diff --git a/server/base/src/main/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancer.java b/server/base/src/main/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancer.java
index 31db7de..b2beaa5 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancer.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancer.java
@@ -86,24 +86,25 @@ import com.google.common.collect.Multimap;
  */
 public class HostRegexTableLoadBalancer extends TableLoadBalancer implements ConfigurationObserver {
 
+  private static final String PROP_PREFIX = Property.TABLE_ARBITRARY_PROP_PREFIX.getKey();
+
   private static final Logger LOG = LoggerFactory.getLogger(HostRegexTableLoadBalancer.class);
-  public static final String HOST_BALANCER_PREFIX = Property.TABLE_ARBITRARY_PROP_PREFIX.getKey()
-      + "balancer.host.regex.";
-  public static final String HOST_BALANCER_OOB_CHECK_KEY = Property.TABLE_ARBITRARY_PROP_PREFIX
-      .getKey() + "balancer.host.regex.oob.period";
+  public static final String HOST_BALANCER_PREFIX = PROP_PREFIX + "balancer.host.regex.";
+  public static final String HOST_BALANCER_OOB_CHECK_KEY = PROP_PREFIX
+      + "balancer.host.regex.oob.period";
   private static final String HOST_BALANCER_OOB_DEFAULT = "5m";
   @Deprecated
-  public static final String HOST_BALANCER_POOL_RECHECK_KEY = Property.TABLE_ARBITRARY_PROP_PREFIX
-      .getKey() + "balancer.host.regex.pool.check";
-  public static final String HOST_BALANCER_REGEX_USING_IPS_KEY = Property.TABLE_ARBITRARY_PROP_PREFIX
-      .getKey() + "balancer.host.regex.is.ip";
-  public static final String HOST_BALANCER_REGEX_MAX_MIGRATIONS_KEY = Property.TABLE_ARBITRARY_PROP_PREFIX
-      .getKey() + "balancer.host.regex.concurrent.migrations";
+  public static final String HOST_BALANCER_POOL_RECHECK_KEY = PROP_PREFIX
+      + "balancer.host.regex.pool.check";
+  public static final String HOST_BALANCER_REGEX_USING_IPS_KEY = PROP_PREFIX
+      + "balancer.host.regex.is.ip";
+  public static final String HOST_BALANCER_REGEX_MAX_MIGRATIONS_KEY = PROP_PREFIX
+      + "balancer.host.regex.concurrent.migrations";
   private static final int HOST_BALANCER_REGEX_MAX_MIGRATIONS_DEFAULT = 250;
   protected static final String DEFAULT_POOL = "HostTableLoadBalancer.ALL";
   private static final int DEFAULT_OUTSTANDING_MIGRATIONS = 0;
-  public static final String HOST_BALANCER_OUTSTANDING_MIGRATIONS_KEY = Property.TABLE_ARBITRARY_PROP_PREFIX
-      .getKey() + "balancer.host.regex.max.outstanding.migrations";
+  public static final String HOST_BALANCER_OUTSTANDING_MIGRATIONS_KEY = PROP_PREFIX
+      + "balancer.host.regex.max.outstanding.migrations";
 
   protected long oobCheckMillis = AccumuloConfiguration.getTimeInMillis(HOST_BALANCER_OOB_DEFAULT);
 
@@ -130,8 +131,10 @@ public class HostRegexTableLoadBalancer extends TableLoadBalancer implements Con
    *          map of current tservers
    * @return current servers grouped by pool name, if not a match it is put into a default pool.
    */
-  protected synchronized Map<String,SortedMap<TServerInstance,TabletServerStatus>> splitCurrentByRegex(
-      SortedMap<TServerInstance,TabletServerStatus> current) {
+  // @formatter:off
+  protected synchronized Map<String,SortedMap<TServerInstance,TabletServerStatus>>
+    splitCurrentByRegex(SortedMap<TServerInstance,TabletServerStatus> current) {
+  // @formatter:on
     LOG.debug("Performing pool recheck - regrouping tablet servers based on regular expressions");
     Map<String,SortedMap<TServerInstance,TabletServerStatus>> newPools = new HashMap<>();
     for (Entry<TServerInstance,TabletServerStatus> e : current.entrySet()) {
@@ -373,9 +376,8 @@ public class HostRegexTableLoadBalancer extends TableLoadBalancer implements Con
             }
             String tid = tableIdMap.get(table);
             if (null == tid) {
-              LOG.warn(
-                  "Unable to check for out of bounds tablets for table {}, it may have been deleted or renamed.",
-                  table);
+              LOG.warn("Unable to check for out of bounds tablets for table {},"
+                  + " it may have been deleted or renamed.", table);
               continue;
             }
             try {
@@ -400,17 +402,15 @@ public class HostRegexTableLoadBalancer extends TableLoadBalancer implements Con
                     iter.next();
                   }
                   TServerInstance nextTS = iter.next();
-                  LOG.info(
-                      "Tablet {} is currently outside the bounds of the regex, migrating from {} to {}",
-                      ke, e.getKey(), nextTS);
+                  LOG.info("Tablet {} is currently outside the bounds of the"
+                      + " regex, migrating from {} to {}", ke, e.getKey(), nextTS);
                   migrationsOut.add(new TabletMigration(ke, e.getKey(), nextTS));
                   if (migrationsOut.size() >= this.maxTServerMigrations) {
                     break;
                   }
                 } else {
-                  LOG.warn(
-                      "No tablet servers online for pool {}, unable to migrate out of bounds tablets",
-                      poolName);
+                  LOG.warn("No tablet servers online for pool {}, unable to"
+                      + " migrate out of bounds tablets", poolName);
                 }
               }
             } catch (TException e1) {
diff --git a/server/base/src/main/java/org/apache/accumulo/server/metrics/MetricsConfiguration.java b/server/base/src/main/java/org/apache/accumulo/server/metrics/MetricsConfiguration.java
index 6263a9d..f73e511 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/metrics/MetricsConfiguration.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/metrics/MetricsConfiguration.java
@@ -187,8 +187,8 @@ public class MetricsConfiguration {
       }
     } else {
       if (!alreadyWarned)
-        log.warn(
-            "ACCUMULO_CONF_DIR variable not found in environment. Metrics collection will be disabled.");
+        log.warn("ACCUMULO_CONF_DIR variable not found in environment. Metrics"
+            + " collection will be disabled.");
       alreadyWarned = true;
       notFound = true;
       return;
@@ -215,8 +215,7 @@ public class MetricsConfiguration {
   public static void main(String[] args) throws Exception {
     MetricsConfiguration mc = new MetricsConfiguration("master");
     while (true) {
-      System.out.println(
-          "------------------------------------------------------------------------------------------------");
+      System.out.println("-----------------------------------------------------------------------");
       long t1 = System.currentTimeMillis();
       System.out.println(mc.isEnabled() + " took: " + (System.currentTimeMillis() - t1));
       Thread.sleep(1000);
diff --git a/server/base/src/main/java/org/apache/accumulo/server/rpc/TCredentialsUpdatingInvocationHandler.java b/server/base/src/main/java/org/apache/accumulo/server/rpc/TCredentialsUpdatingInvocationHandler.java
index 653eb8f..1e5f177 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/rpc/TCredentialsUpdatingInvocationHandler.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/rpc/TCredentialsUpdatingInvocationHandler.java
@@ -84,8 +84,8 @@ public class TCredentialsUpdatingInvocationHandler<I> implements InvocationHandl
     if (null == tcreds) {
       // Not all calls require authentication (e.g. closeMultiScan). We need to let these pass
       // through.
-      log.trace(
-          "Did not find a TCredentials object in the first two positions of the argument list, not updating principal");
+      log.trace("Did not find a TCredentials object in the first two positions"
+          + " of the argument list, not updating principal");
       return;
     }
 
@@ -99,9 +99,8 @@ public class TCredentialsUpdatingInvocationHandler<I> implements InvocationHandl
     if (SaslMechanism.DIGEST_MD5 == UGIAssumingProcessor.rpcMechanism()
         && DelegationTokenImpl.class.isAssignableFrom(tokenClass)) {
       if (!principal.equals(tcreds.principal)) {
-        log.warn(
-            "{} issued RPC with delegation token over DIGEST-MD5 as the Accumulo principal {}. Disallowing RPC",
-            principal, tcreds.principal);
+        log.warn("{} issued RPC with delegation token over DIGEST-MD5 as the"
+            + "Accumulo principal {}. Disallowing RPC", principal, tcreds.principal);
         throw new ThriftSecurityException("RPC principal did not match provided Accumulo principal",
             SecurityErrorCode.BAD_CREDENTIALS);
       }
@@ -138,8 +137,8 @@ public class TCredentialsUpdatingInvocationHandler<I> implements InvocationHandl
       }
       String clientAddr = TServerUtils.clientAddress.get();
       if (!usersWithHosts.getHosts().contains(clientAddr)) {
-        final String msg = "Principal in credentials object allowed mismatched Kerberos principals, but not on "
-            + clientAddr;
+        final String msg = "Principal in credentials object allowed mismatched"
+            + " Kerberos principals, but not on " + clientAddr;
         log.warn(msg);
         throw new ThriftSecurityException(msg, SecurityErrorCode.BAD_CREDENTIALS);
       }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/rpc/TServerUtils.java b/server/base/src/main/java/org/apache/accumulo/server/rpc/TServerUtils.java
index 48fe407..f2a4bd9 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/rpc/TServerUtils.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/rpc/TServerUtils.java
@@ -457,12 +457,12 @@ public class TServerUtils {
     // this host, fail quickly and inform them to update
     // their configuration.
     if (!hostname.equals(fqdn)) {
-      log.error(
-          "Expected hostname of '{}' but got '{}'. Ensure the entries in the Accumulo hosts files (e.g. masters, slaves) are the FQDN for each host when using SASL.",
-          fqdn, hostname);
+      log.error("Expected hostname of '{}' but got '{}'. Ensure the entries in"
+          + " the Accumulo hosts files (e.g. masters, slaves) are the FQDN for each"
+          + " host when using SASL.", fqdn, hostname);
       transport.close();
-      throw new RuntimeException(
-          "SASL requires that the address the thrift server listens on is the same as the FQDN for this host");
+      throw new RuntimeException("SASL requires that the address the thrift"
+          + " server listens on is the same as the FQDN for this host");
     }
 
     final UserGroupInformation serverUser;
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/AuditedSecurityOperation.java b/server/base/src/main/java/org/apache/accumulo/server/security/AuditedSecurityOperation.java
index 52dc4f9..321dd93 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/AuditedSecurityOperation.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/AuditedSecurityOperation.java
@@ -135,7 +135,9 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_SCAN_AUDIT_TEMPLATE = "action: scan; targetTable: %s; authorizations: %s; range: %s; columns: %s; iterators: %s; iteratorOptions: %s;";
+  public static final String CAN_SCAN_AUDIT_TEMPLATE = "action: scan;"
+      + " targetTable: %s; authorizations: %s; range: %s; columns: %s;"
+      + " iterators: %s; iteratorOptions: %s;";
   private static final int MAX_ELEMENTS_TO_LOG = 10;
 
   private static List<String> truncate(Collection<?> list) {
@@ -177,7 +179,9 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_SCAN_BATCH_AUDIT_TEMPLATE = "action: scan; targetTable: %s; authorizations: %s; range: %s; columns: %s; iterators: %s; iteratorOptions: %s;";
+  public static final String CAN_SCAN_BATCH_AUDIT_TEMPLATE = "action: scan;"
+      + " targetTable: %s; authorizations: %s; range: %s; columns: %s;"
+      + " iterators: %s; iteratorOptions: %s;";
 
   @Override
   public boolean canScan(TCredentials credentials, String tableId, String namespaceId,
@@ -213,7 +217,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CHANGE_AUTHORIZATIONS_AUDIT_TEMPLATE = "action: changeAuthorizations; targetUser: %s; authorizations: %s";
+  public static final String CHANGE_AUTHORIZATIONS_AUDIT_TEMPLATE = "action:"
+      + " changeAuthorizations; targetUser: %s; authorizations: %s";
 
   @Override
   public void changeAuthorizations(TCredentials credentials, String user,
@@ -227,7 +232,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CHANGE_PASSWORD_AUDIT_TEMPLATE = "action: changePassword; targetUser: %s;";
+  public static final String CHANGE_PASSWORD_AUDIT_TEMPLATE = "action:"
+      + " changePassword; targetUser: %s;";
 
   @Override
   public void changePassword(TCredentials credentials, Credentials newInfo)
@@ -241,7 +247,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CREATE_USER_AUDIT_TEMPLATE = "action: createUser; targetUser: %s; Authorizations: %s;";
+  public static final String CREATE_USER_AUDIT_TEMPLATE = "action: createUser;"
+      + " targetUser: %s; Authorizations: %s;";
 
   @Override
   public void createUser(TCredentials credentials, Credentials newUser,
@@ -255,7 +262,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_CREATE_TABLE_AUDIT_TEMPLATE = "action: createTable; targetTable: %s;";
+  public static final String CAN_CREATE_TABLE_AUDIT_TEMPLATE = "action:"
+      + " createTable; targetTable: %s;";
 
   @Override
   public boolean canCreateTable(TCredentials c, String tableName, String namespaceId)
@@ -270,7 +278,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_DELETE_TABLE_AUDIT_TEMPLATE = "action: deleteTable; targetTable: %s;";
+  public static final String CAN_DELETE_TABLE_AUDIT_TEMPLATE = "action:"
+      + " deleteTable; targetTable: %s;";
 
   @Override
   public boolean canDeleteTable(TCredentials c, String tableId, String namespaceId)
@@ -286,7 +295,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_RENAME_TABLE_AUDIT_TEMPLATE = "action: renameTable; targetTable: %s; newTableName: %s;";
+  public static final String CAN_RENAME_TABLE_AUDIT_TEMPLATE = "action:"
+      + " renameTable; targetTable: %s; newTableName: %s;";
 
   @Override
   public boolean canRenameTable(TCredentials c, String tableId, String oldTableName,
@@ -301,7 +311,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_SPLIT_TABLE_AUDIT_TEMPLATE = "action: splitTable; targetTable: %s; targetNamespace: %s;";
+  public static final String CAN_SPLIT_TABLE_AUDIT_TEMPLATE = "action:"
+      + " splitTable; targetTable: %s; targetNamespace: %s;";
 
   @Override
   public boolean canSplitTablet(TCredentials credentials, String table, String namespaceId)
@@ -316,7 +327,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_PERFORM_SYSTEM_ACTION_AUDIT_TEMPLATE = "action: performSystemAction; principal: %s;";
+  public static final String CAN_PERFORM_SYSTEM_ACTION_AUDIT_TEMPLATE = "action:"
+      + " performSystemAction; principal: %s;";
 
   @Override
   public boolean canPerformSystemActions(TCredentials credentials) throws ThriftSecurityException {
@@ -331,7 +343,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_FLUSH_TABLE_AUDIT_TEMPLATE = "action: flushTable; targetTable: %s; targetNamespace: %s;";
+  public static final String CAN_FLUSH_TABLE_AUDIT_TEMPLATE = "action:"
+      + " flushTable; targetTable: %s; targetNamespace: %s;";
 
   @Override
   public boolean canFlush(TCredentials c, String tableId, String namespaceId)
@@ -346,7 +359,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_ALTER_TABLE_AUDIT_TEMPLATE = "action: alterTable; targetTable: %s; targetNamespace: %s;";
+  public static final String CAN_ALTER_TABLE_AUDIT_TEMPLATE = "action:"
+      + " alterTable; targetTable: %s; targetNamespace: %s;";
 
   @Override
   public boolean canAlterTable(TCredentials c, String tableId, String namespaceId)
@@ -361,7 +375,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_CLONE_TABLE_AUDIT_TEMPLATE = "action: cloneTable; targetTable: %s; newTableName: %s";
+  public static final String CAN_CLONE_TABLE_AUDIT_TEMPLATE = "action:"
+      + " cloneTable; targetTable: %s; newTableName: %s";
 
   @Override
   public boolean canCloneTable(TCredentials c, String tableId, String tableName,
@@ -378,7 +393,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_DELETE_RANGE_AUDIT_TEMPLATE = "action: deleteData; targetTable: %s; startRange: %s; endRange: %s;";
+  public static final String CAN_DELETE_RANGE_AUDIT_TEMPLATE = "action:"
+      + " deleteData; targetTable: %s; startRange: %s; endRange: %s;";
 
   @Override
   public boolean canDeleteRange(TCredentials c, String tableId, String tableName, Text startRow,
@@ -395,7 +411,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_BULK_IMPORT_AUDIT_TEMPLATE = "action: bulkImport; targetTable: %s; dataDir: %s; failDir: %s;";
+  public static final String CAN_BULK_IMPORT_AUDIT_TEMPLATE = "action:"
+      + " bulkImport; targetTable: %s; dataDir: %s; failDir: %s;";
 
   @Override
   public boolean canBulkImport(TCredentials c, String tableId, String tableName, String dir,
@@ -410,7 +427,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_COMPACT_TABLE_AUDIT_TEMPLATE = "action: compactTable; targetTable: %s; targetNamespace: %s;";
+  public static final String CAN_COMPACT_TABLE_AUDIT_TEMPLATE = "action:"
+      + " compactTable; targetTable: %s; targetNamespace: %s;";
 
   @Override
   public boolean canCompact(TCredentials c, String tableId, String namespaceId)
@@ -425,7 +443,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_CHANGE_AUTHORIZATIONS_AUDIT_TEMPLATE = "action: changeAuthorizations; targetUser: %s;";
+  public static final String CAN_CHANGE_AUTHORIZATIONS_AUDIT_TEMPLATE = "action:"
+      + " changeAuthorizations; targetUser: %s;";
 
   @Override
   public boolean canChangeAuthorizations(TCredentials c, String user)
@@ -440,7 +459,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_CHANGE_PASSWORD_AUDIT_TEMPLATE = "action: changePassword; targetUser: %s;";
+  public static final String CAN_CHANGE_PASSWORD_AUDIT_TEMPLATE = "action:"
+      + " changePassword; targetUser: %s;";
 
   @Override
   public boolean canChangePassword(TCredentials c, String user) throws ThriftSecurityException {
@@ -483,7 +503,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_GRANT_SYSTEM_AUDIT_TEMPLATE = "action: grantSystem; targetUser: %s; targetPermission: %s;";
+  public static final String CAN_GRANT_SYSTEM_AUDIT_TEMPLATE = "action:"
+      + " grantSystem; targetUser: %s; targetPermission: %s;";
 
   @Override
   public boolean canGrantSystem(TCredentials c, String user, SystemPermission sysPerm)
@@ -500,7 +521,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_GRANT_TABLE_AUDIT_TEMPLATE = "action: grantTable; targetUser: %s; targetTable: %s; targetNamespace: %s;";
+  public static final String CAN_GRANT_TABLE_AUDIT_TEMPLATE = "action:"
+      + " grantTable; targetUser: %s; targetTable: %s; targetNamespace: %s;";
 
   @Override
   public boolean canGrantTable(TCredentials c, String user, String table, String namespaceId)
@@ -515,7 +537,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_REVOKE_SYSTEM_AUDIT_TEMPLATE = "action: revokeSystem; targetUser: %s;, targetPermission: %s;";
+  public static final String CAN_REVOKE_SYSTEM_AUDIT_TEMPLATE = "action:"
+      + " revokeSystem; targetUser: %s;, targetPermission: %s;";
 
   @Override
   public boolean canRevokeSystem(TCredentials c, String user, SystemPermission sysPerm)
@@ -530,7 +553,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_REVOKE_TABLE_AUDIT_TEMPLATE = "action: revokeTable; targetUser: %s; targetTable %s; targetNamespace: %s;";
+  public static final String CAN_REVOKE_TABLE_AUDIT_TEMPLATE = "action:"
+      + " revokeTable; targetUser: %s; targetTable %s; targetNamespace: %s;";
 
   @Override
   public boolean canRevokeTable(TCredentials c, String user, String table, String namespaceId)
@@ -545,7 +569,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_IMPORT_AUDIT_TEMPLATE = "action: import; targetTable: %s; dataDir: %s;";
+  public static final String CAN_IMPORT_AUDIT_TEMPLATE = "action: import;"
+      + " targetTable: %s; dataDir: %s;";
 
   @Override
   public boolean canImport(TCredentials credentials, String tableName, String importDir,
@@ -561,7 +586,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_EXPORT_AUDIT_TEMPLATE = "action: export; targetTable: %s; dataDir: %s;";
+  public static final String CAN_EXPORT_AUDIT_TEMPLATE = "action: export;"
+      + " targetTable: %s; dataDir: %s;";
 
   @Override
   public boolean canExport(TCredentials credentials, String tableId, String tableName,
@@ -590,7 +616,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String GRANT_SYSTEM_PERMISSION_AUDIT_TEMPLATE = "action: grantSystemPermission; permission: %s; targetUser: %s;";
+  public static final String GRANT_SYSTEM_PERMISSION_AUDIT_TEMPLATE = "action:"
+      + " grantSystemPermission; permission: %s; targetUser: %s;";
 
   @Override
   public void grantSystemPermission(TCredentials credentials, String user,
@@ -604,7 +631,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String GRANT_TABLE_PERMISSION_AUDIT_TEMPLATE = "action: grantTablePermission; permission: %s; targetTable: %s; targetUser: %s;";
+  public static final String GRANT_TABLE_PERMISSION_AUDIT_TEMPLATE = "action:"
+      + " grantTablePermission; permission: %s; targetTable: %s; targetUser: %s;";
 
   @Override
   public void grantTablePermission(TCredentials credentials, String user, String tableId,
@@ -619,7 +647,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String REVOKE_SYSTEM_PERMISSION_AUDIT_TEMPLATE = "action: revokeSystemPermission; permission: %s; targetUser: %s;";
+  public static final String REVOKE_SYSTEM_PERMISSION_AUDIT_TEMPLATE = "action:"
+      + " revokeSystemPermission; permission: %s; targetUser: %s;";
 
   @Override
   public void revokeSystemPermission(TCredentials credentials, String user,
@@ -634,7 +663,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String REVOKE_TABLE_PERMISSION_AUDIT_TEMPLATE = "action: revokeTablePermission; permission: %s; targetTable: %s; targetUser: %s;";
+  public static final String REVOKE_TABLE_PERMISSION_AUDIT_TEMPLATE = "action:"
+      + " revokeTablePermission; permission: %s; targetTable: %s; targetUser: %s;";
 
   @Override
   public void revokeTablePermission(TCredentials credentials, String user, String tableId,
@@ -649,7 +679,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String HAS_SYSTEM_PERMISSION_AUDIT_TEMPLATE = "action: hasSystemPermission; permission: %s; targetUser: %s;";
+  public static final String HAS_SYSTEM_PERMISSION_AUDIT_TEMPLATE = "action:"
+      + " hasSystemPermission; permission: %s; targetUser: %s;";
 
   @Override
   public boolean hasSystemPermission(TCredentials credentials, String user,
@@ -664,7 +695,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_ONLINE_OFFLINE_TABLE_AUDIT_TEMPLATE = "action: %s; targetTable: %s;";
+  public static final String CAN_ONLINE_OFFLINE_TABLE_AUDIT_TEMPLATE = "action:"
+      + " %s; targetTable: %s;";
 
   @Override
   public boolean canOnlineOfflineTable(TCredentials credentials, String tableId, FateOperation op,
@@ -687,7 +719,8 @@ public class AuditedSecurityOperation extends SecurityOperation {
     }
   }
 
-  public static final String CAN_MERGE_TABLE_AUDIT_TEMPLATE = "action: mergeTable; targetTable: %s; targetNamespace: %s;";
+  public static final String CAN_MERGE_TABLE_AUDIT_TEMPLATE = "action:"
+      + " mergeTable; targetTable: %s; targetNamespace: %s;";
 
   @Override
   public boolean canMerge(TCredentials c, String tableId, String namespaceId)
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java b/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java
index 032081a..d9d599c 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java
@@ -128,7 +128,8 @@ public class SecurityOperation {
         || !authenticator.validSecurityHandlers(authorizor, pm)
         || !permHandle.validSecurityHandlers(authent, author))
       throw new RuntimeException(authorizor + ", " + authenticator + ", and " + pm
-          + " do not play nice with eachother. Please choose authentication and authorization mechanisms that are compatible with one another.");
+          + " do not play nice with eachother. Please choose authentication and"
+          + " authorization mechanisms that are compatible with one another.");
 
     isKerberos = KerberosAuthenticator.class.isAssignableFrom(authenticator.getClass());
   }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/UserImpersonation.java b/server/base/src/main/java/org/apache/accumulo/server/security/UserImpersonation.java
index 95ea076..93a3205 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/UserImpersonation.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/UserImpersonation.java
@@ -36,9 +36,13 @@ import org.slf4j.LoggerFactory;
  * users capable of impersonating another user, the users which may be impersonated and the hosts in
  * which the impersonator may issue requests from.
  *
- * <code>INSTANCE_RPC_SASL_PROXYUSERS=rpc_user={allowed_accumulo_users=[...], allowed_client_hosts=[...]</code>
- * <code>INSTANCE_RPC_SASL_ALLOWED_USER_IMPERSONATION=rpc_user:user,user,user;...</code>
- * <code>INSTANCE_RPC_SASL_ALLOWED_HOST_IMPERSONATION=host,host:host...</code>
+ * <pre>
+ * <code>
+ * INSTANCE_RPC_SASL_PROXYUSERS=rpc_user={allowed_accumulo_users=[...], allowed_client_hosts=[...]
+ * INSTANCE_RPC_SASL_ALLOWED_USER_IMPERSONATION=rpc_user:user,user,user;...
+ * INSTANCE_RPC_SASL_ALLOWED_HOST_IMPERSONATION=host,host:host...
+ * </code>
+ * </pre>
  *
  * @see Property#INSTANCE_RPC_SASL_ALLOWED_USER_IMPERSONATION
  * @see Property#INSTANCE_RPC_SASL_ALLOWED_HOST_IMPERSONATION
@@ -216,8 +220,8 @@ public class UserImpersonation {
     }
 
     if (userConfigs.length != hostConfigs.length) {
-      String msg = String.format(
-          "Should have equal number of user and host impersonation elements in configuration. Got %d and %d elements, respectively.",
+      String msg = String.format("Should have equal number of user and host"
+          + " impersonation elements in configuration. Got %d and %d elements," + " respectively.",
           userConfigs.length, hostConfigs.length);
       throw new IllegalArgumentException(msg);
     }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKAuthenticator.java b/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKAuthenticator.java
index 8ae1cca..3685030 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKAuthenticator.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKAuthenticator.java
@@ -174,9 +174,8 @@ public final class ZKAuthenticator implements Authenticator {
         throw new AccumuloSecurityException(principal, SecurityErrorCode.DEFAULT_SECURITY_ERROR, e);
       }
     } else
-      throw new AccumuloSecurityException(principal, SecurityErrorCode.USER_DOESNT_EXIST); // user
-                                                                                           // doesn't
-                                                                                           // exist
+      // user doesn't exist
+      throw new AccumuloSecurityException(principal, SecurityErrorCode.USER_DOESNT_EXIST);
   }
 
   @Override
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/FileUtil.java b/server/base/src/main/java/org/apache/accumulo/server/util/FileUtil.java
index 0c68c35..6128324 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/FileUtil.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/FileUtil.java
@@ -241,8 +241,10 @@ public class FileUtil {
         return .5;
       }
 
-      List<SortedKeyValueIterator<Key,Value>> iters = new ArrayList<SortedKeyValueIterator<Key,Value>>(
-          readers);
+      // @formatter:off
+      List<SortedKeyValueIterator<Key,Value>> iters =
+        new ArrayList<SortedKeyValueIterator<Key,Value>>(readers);
+      // @formatter:on
       MultiIterator mmfi = new MultiIterator(iters, true);
 
       // skip the prevendrow
@@ -324,9 +326,9 @@ public class FileUtil {
 
       if (numKeys == 0) {
         if (useIndex) {
-          log.warn(
-              "Failed to find mid point using indexes, falling back to data files which is slower. No entries between "
-                  + prevEndRow + " and " + endRow + " for " + mapFiles);
+          log.warn("Failed to find mid point using indexes, falling back to"
+              + " data files which is slower. No entries between " + prevEndRow + " and " + endRow
+              + " for " + mapFiles);
           // need to pass original map files, not possibly reduced indexes
           return findMidPoint(fs, acuConf, prevEndRow, endRow, origMapFiles, minSplit, false);
         }
@@ -334,8 +336,10 @@ public class FileUtil {
             + endRow + " for " + mapFiles);
       }
 
-      List<SortedKeyValueIterator<Key,Value>> iters = new ArrayList<SortedKeyValueIterator<Key,Value>>(
-          readers);
+      // @formatter:off
+      List<SortedKeyValueIterator<Key,Value>> iters =
+        new ArrayList<SortedKeyValueIterator<Key,Value>>(readers);
+      // @formatter:on
       MultiIterator mmfi = new MultiIterator(iters, true);
 
       // skip the prevendrow
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/SendLogToChainsaw.java b/server/base/src/main/java/org/apache/accumulo/server/util/SendLogToChainsaw.java
index 2c9b2c4..67fe7be 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/SendLogToChainsaw.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/SendLogToChainsaw.java
@@ -56,9 +56,9 @@ import com.beust.jcommander.Parameter;
 
 public class SendLogToChainsaw extends XMLLayout {
 
-  private static Pattern logPattern = Pattern.compile(
-      "^(\\d\\d)\\s(\\d\\d):(\\d\\d):(\\d\\d),(\\d\\d\\d)\\s\\[(.*)\\]\\s(TRACE|DEBUG|INFO|WARN|FATAL|ERROR)\\s*?:(.*)$",
-      Pattern.UNIX_LINES);
+  private static Pattern logPattern = Pattern
+      .compile("^(\\d\\d)\\s(\\d\\d):(\\d\\d):(\\d\\d),(\\d\\d\\d)\\s\\[(.*)\\]\\s"
+          + "(TRACE|DEBUG|INFO|WARN|FATAL|ERROR)\\s*?:(.*)$", Pattern.UNIX_LINES);
 
   private File[] logFiles = null;
 
diff --git a/server/base/src/test/java/org/apache/accumulo/server/util/FileSystemMonitorTest.java b/server/base/src/test/java/org/apache/accumulo/server/util/FileSystemMonitorTest.java
index 9bffbb1..dac2673 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/util/FileSystemMonitorTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/util/FileSystemMonitorTest.java
@@ -46,7 +46,8 @@ public class FileSystemMonitorTest {
         "devpts /dev/pts devpts rw,seclabel,nosuid,noexec,relatime,gid=5,mode=620,ptmxmode=000 0 0",
         "tmpfs /run tmpfs rw,seclabel,nosuid,nodev,mode=755 0 0",
         "tmpfs /sys/fs/cgroup tmpfs ro,seclabel,nosuid,nodev,noexec,mode=755 0 0",
-        "cgroup /sys/fs/cgroup/systemd cgroup rw,nosuid,nodev,noexec,relatime,xattr,release_agent=/usr/lib/systemd/systemd-cgroups-agent,name=systemd 0 0",
+        "cgroup /sys/fs/cgroup/systemd cgroup rw,nosuid,nodev,noexec,relatime,xattr,"
+            + "release_agent=/usr/lib/systemd/systemd-cgroups-agent,name=systemd 0 0",
         "pstore /sys/fs/pstore pstore rw,nosuid,nodev,noexec,relatime 0 0",
         "cgroup /sys/fs/cgroup/cpuset cgroup rw,nosuid,nodev,noexec,relatime,cpuset 0 0",
         "cgroup /sys/fs/cgroup/cpu,cpuacct cgroup rw,nosuid,nodev,noexec,relatime,cpuacct,cpu 0 0",
@@ -62,7 +63,8 @@ public class FileSystemMonitorTest {
         "/dev/vda2 /ignoreme reiserfs rw 0 0",
         "rpc_pipefs /var/lib/nfs/rpc_pipefs rpc_pipefs rw,relatime 0 0",
         "selinuxfs /sys/fs/selinux selinuxfs rw,relatime 0 0",
-        "systemd-1 /proc/sys/fs/binfmt_misc autofs rw,relatime,fd=32,pgrp=1,timeout=300,minproto=5,maxproto=5,direct 0 0",
+        "systemd-1 /proc/sys/fs/binfmt_misc autofs rw,relatime,fd=32,pgrp=1,"
+            + "timeout=300,minproto=5,maxproto=5,direct 0 0",
         "debugfs /sys/kernel/debug debugfs rw,relatime 0 0",
         "mqueue /dev/mqueue mqueue rw,seclabel,relatime 0 0",
         "hugetlbfs /dev/hugepages hugetlbfs rw,seclabel,relatime 0 0",
diff --git a/server/gc/src/main/java/org/apache/accumulo/gc/SimpleGarbageCollector.java b/server/gc/src/main/java/org/apache/accumulo/gc/SimpleGarbageCollector.java
index e01e22c..0aeaaea 100644
--- a/server/gc/src/main/java/org/apache/accumulo/gc/SimpleGarbageCollector.java
+++ b/server/gc/src/main/java/org/apache/accumulo/gc/SimpleGarbageCollector.java
@@ -273,8 +273,8 @@ public class SimpleGarbageCollector extends AccumuloServerContext implements Ifa
             .substring(MetadataSchema.DeletesSection.getRowPrefix().length());
         result.add(cand);
         if (almostOutOfMemory(Runtime.getRuntime())) {
-          log.info(
-              "List of delete candidates has exceeded the memory threshold. Attempting to delete what has been gathered so far.");
+          log.info("List of delete candidates has exceeded the memory"
+              + " threshold. Attempting to delete what has been gathered so far.");
           return true;
         }
       }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/Master.java b/server/master/src/main/java/org/apache/accumulo/master/Master.java
index 1f6871e..9414b98 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/Master.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/Master.java
@@ -234,14 +234,14 @@ public class Master extends AccumuloServerContext
   static final boolean O = false;
   // @formatter:off
   static final boolean transitionOK[][] = {
-      //                              INITIAL HAVE_LOCK SAFE_MODE NORMAL UNLOAD_META UNLOAD_ROOT STOP
-      /* INITIAL */                   {X,     X,        O,        O,      O,         O,          X},
-      /* HAVE_LOCK */                 {O,     X,        X,        X,      O,         O,          X},
-      /* SAFE_MODE */                 {O,     O,        X,        X,      X,         O,          X},
-      /* NORMAL */                    {O,     O,        X,        X,      X,         O,          X},
-      /* UNLOAD_METADATA_TABLETS */   {O,     O,        X,        X,      X,         X,          X},
-      /* UNLOAD_ROOT_TABLET */        {O,     O,        O,        X,      X,         X,          X},
-      /* STOP */                      {O,     O,        O,        O,      O,         X,          X}};
+      //                            INITIAL HAVE_LOCK SAFE_MODE NORMAL UNLOAD_META UNLOAD_ROOT STOP
+      /* INITIAL */                 {X,     X,        O,        O,      O,         O,          X},
+      /* HAVE_LOCK */               {O,     X,        X,        X,      O,         O,          X},
+      /* SAFE_MODE */               {O,     O,        X,        X,      X,         O,          X},
+      /* NORMAL */                  {O,     O,        X,        X,      X,         O,          X},
+      /* UNLOAD_METADATA_TABLETS */ {O,     O,        X,        X,      X,         X,          X},
+      /* UNLOAD_ROOT_TABLET */      {O,     O,        O,        X,      X,         X,          X},
+      /* STOP */                    {O,     O,        O,        O,      O,         X,          X}};
   //@formatter:on
   synchronized void setMasterState(MasterState newState) {
     if (state.equals(newState))
@@ -327,8 +327,9 @@ public class Master extends AccumuloServerContext
       // the upgrade.
       // Change to Guava's Verify once we use Guava 17.
       if (null != fate) {
-        throw new IllegalStateException(
-            "Access to Fate should not have been initialized prior to the Master transitioning to active. Please save all logs and file a bug.");
+        throw new IllegalStateException("Access to Fate should not have been"
+            + " initialized prior to the Master transitioning to active. Please"
+            + " save all logs and file a bug.");
       }
       Accumulo.abortIfFateTransactions();
       try {
@@ -493,12 +494,14 @@ public class Master extends AccumuloServerContext
         // Fate still hasn't been started.
         // Change both to use Guava's Verify once we use Guava 17.
         if (!haveUpgradedZooKeeper) {
-          throw new IllegalStateException(
-              "We should only attempt to upgrade Accumulo's metadata table if we've already upgraded ZooKeeper. Please save all logs and file a bug.");
+          throw new IllegalStateException("We should only attempt to upgrade"
+              + " Accumulo's metadata table if we've already upgraded ZooKeeper."
+              + " Please save all logs and file a bug.");
         }
         if (null != fate) {
-          throw new IllegalStateException(
-              "Access to Fate should not have been initialized prior to the Master finishing upgrades. Please save all logs and file a bug.");
+          throw new IllegalStateException("Access to Fate should not have been"
+              + " initialized prior to the Master finishing upgrades. Please save"
+              + " all logs and file a bug.");
         }
         Runnable upgradeTask = new Runnable() {
           int version = accumuloPersistentVersion;
@@ -1044,9 +1047,8 @@ public class Master extends AccumuloServerContext
               }
           }
         } catch (Throwable t) {
-          log.error(
-              "Error occurred reading / switching master goal state. Will continue with attempt to update status",
-              t);
+          log.error("Error occurred reading / switching master goal state. Will"
+              + " continue with attempt to update status", t);
         }
 
         try {
@@ -1352,9 +1354,12 @@ public class Master extends AccumuloServerContext
 
     // Start the replication coordinator which assigns tservers to service replication requests
     MasterReplicationCoordinator impl = new MasterReplicationCoordinator(this);
-    ReplicationCoordinator.Processor<ReplicationCoordinator.Iface> replicationCoordinatorProcessor = new ReplicationCoordinator.Processor<>(
-        RpcWrapper.service(impl,
-            new ReplicationCoordinator.Processor<ReplicationCoordinator.Iface>(impl)));
+    // @formatter:off
+    ReplicationCoordinator.Processor<ReplicationCoordinator.Iface> replicationCoordinatorProcessor =
+      new ReplicationCoordinator.Processor<>(
+    // @formatter:on
+            RpcWrapper.service(impl,
+                new ReplicationCoordinator.Processor<ReplicationCoordinator.Iface>(impl)));
     ServerAddress replAddress = TServerUtils.startServer(this, hostname,
         Property.MASTER_REPLICATION_COORDINATOR_PORT, replicationCoordinatorProcessor,
         "Master Replication Coordinator", "Replication Coordinator", null,
diff --git a/server/master/src/main/java/org/apache/accumulo/master/replication/DistributedWorkQueueWorkAssigner.java b/server/master/src/main/java/org/apache/accumulo/master/replication/DistributedWorkQueueWorkAssigner.java
index 3d942c6..d6f31e7 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/replication/DistributedWorkQueueWorkAssigner.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/replication/DistributedWorkQueueWorkAssigner.java
@@ -168,9 +168,8 @@ public abstract class DistributedWorkQueueWorkAssigner implements WorkAssigner {
       // continuing
       // to add more work entries
       if (getQueueSize() > maxQueueSize) {
-        log.warn(
-            "Queued replication work exceeds configured maximum ({}), sleeping to allow work to occur",
-            maxQueueSize);
+        log.warn("Queued replication work exceeds configured maximum ({}),"
+            + " sleeping to allow work to occur", maxQueueSize);
         return;
       }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/replication/FinishedWorkUpdater.java b/server/master/src/main/java/org/apache/accumulo/master/replication/FinishedWorkUpdater.java
index 3dba90b..4495aae 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/replication/FinishedWorkUpdater.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/replication/FinishedWorkUpdater.java
@@ -163,9 +163,8 @@ public class FinishedWorkUpdater implements Runnable {
           try {
             replBw.addMutation(replMutation);
           } catch (MutationsRejectedException e) {
-            log.error(
-                "Error writing mutations to update replication Status messages in StatusSection, will retry",
-                e);
+            log.error("Error writing mutations to update replication Status"
+                + " messages in StatusSection, will retry", e);
             return;
           }
         }
@@ -178,9 +177,8 @@ public class FinishedWorkUpdater implements Runnable {
       try {
         replBw.close();
       } catch (MutationsRejectedException e) {
-        log.error(
-            "Error writing mutations to update replication Status messages in StatusSection, will retry",
-            e);
+        log.error("Error writing mutations to update replication Status"
+            + " messages in StatusSection, will retry", e);
       }
     }
   }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/replication/RemoveCompleteReplicationRecords.java b/server/master/src/main/java/org/apache/accumulo/master/replication/RemoveCompleteReplicationRecords.java
index d72decd..aa6cc4d 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/replication/RemoveCompleteReplicationRecords.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/replication/RemoveCompleteReplicationRecords.java
@@ -71,12 +71,11 @@ public class RemoveCompleteReplicationRecords implements Runnable {
       bw = ReplicationTable.getBatchWriter(conn);
 
       if (bs == null || bw == null)
-        throw new AssertionError(
-            "Inconceivable; an exception should have been thrown, but 'bs' or 'bw' was null instead");
+        throw new AssertionError("Inconceivable; an exception should have been"
+            + " thrown, but 'bs' or 'bw' was null instead");
     } catch (ReplicationTableOfflineException e) {
-      log.debug(
-          "Not attempting to remove complete replication records as the table ({}) isn't yet online",
-          ReplicationTable.NAME);
+      log.debug("Not attempting to remove complete replication records as the"
+          + " table ({}) isn't yet online", ReplicationTable.NAME);
       return;
     }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/util/FateAdmin.java b/server/master/src/main/java/org/apache/accumulo/master/util/FateAdmin.java
index 2691fca..c4c2ea4 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/util/FateAdmin.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/util/FateAdmin.java
@@ -73,8 +73,9 @@ public class FateAdmin {
       System.exit(1);
     }
 
-    System.err.printf(
-        "This tool has been deprecated%nFATE administration now available within 'accumulo shell'%n$ fate fail <txid>... | delete <txid>... | print [<txid>...]%n%n");
+    System.err.printf("This tool has been deprecated%nFATE administration now"
+        + " available within 'accumulo shell'%n$ fate fail <txid>... | delete"
+        + " <txid>... | print [<txid>...]%n%n");
 
     AdminUtil<Master> admin = new AdminUtil<>();
 
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/BasicServlet.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/BasicServlet.java
index 48d0129..af90b6e 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/BasicServlet.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/BasicServlet.java
@@ -146,12 +146,12 @@ abstract public class BasicServlet extends HttpServlet {
     sb.append("<link rel='stylesheet' type='text/css' href='/web/screen.css' media='screen' />\n");
     sb.append("<script src='/web/functions.js' type='text/javascript'></script>\n");
 
-    sb.append(
-        "<!--[if lte IE 8]><script language=\"javascript\" type=\"text/javascript\" src=\"/web/flot/excanvas.js\"></script><![endif]-->\n");
-    sb.append(
-        "<script language=\"javascript\" type=\"text/javascript\" src=\"/web/flot/jquery.js\"></script>\n");
-    sb.append(
-        "<script language=\"javascript\" type=\"text/javascript\" src=\"/web/flot/jquery.flot.js\"></script>\n");
+    sb.append("<!--[if lte IE 8]><script language=\"javascript\" type=\"text/javascript\""
+        + " src=\"/web/flot/excanvas.js\"></script><![endif]-->\n");
+    sb.append("<script language=\"javascript\" type=\"text/javascript\""
+        + " src=\"/web/flot/jquery.js\"></script>\n");
+    sb.append("<script language=\"javascript\" type=\"text/javascript\""
+        + " src=\"/web/flot/jquery.flot.js\"></script>\n");
 
     sb.append("</head>\n");
 
@@ -203,9 +203,8 @@ abstract public class BasicServlet extends HttpServlet {
           + ")</a></span></span><br />\n");
     int numProblems = Monitor.getProblemSummary().entrySet().size();
     if (numProblems > 0)
-      sb.append(
-          "<span class='error'><a href='/problems'>Table&nbsp;Problems&nbsp;<span class='smalltext'>("
-              + numProblems + ")</a></span></span><br />\n");
+      sb.append("<span class='error'><a href='/problems'>Table&nbsp;Problems&nbsp;"
+          + "<span class='smalltext'>(" + numProblems + ")</a></span></span><br />\n");
     sb.append("<hr />\n");
     sb.append("<a href='/xml'>XML</a><br />\n");
     sb.append("<a href='/json'>JSON</a><hr />\n");
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/MasterServlet.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/MasterServlet.java
index 58ec6be..08adce4 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/MasterServlet.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/MasterServlet.java
@@ -163,7 +163,8 @@ public class MasterServlet extends BasicServlet {
               + " Note that deleted records are \"inserted\" and will make the ingest "
               + "rate increase in the near-term.");
       masterStatus.addSortableColumn("Entries<br />Read", new NumberType<Long>(),
-          "The total number of Key/Value pairs read on the server side.  Not all may be returned because of filtering.");
+          "The total number of Key/Value pairs read on the server side. Not"
+              + " all may be returned because of filtering.");
       masterStatus.addSortableColumn("Entries<br />Returned", new NumberType<Long>(),
           "The total number of Key/Value pairs returned as a result of scans.");
       masterStatus.addSortableColumn("Hold&nbsp;Time", new DurationType(0l, 0l),
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/ProblemServlet.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/ProblemServlet.java
index 0f3eb7f..2075c38 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/ProblemServlet.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/ProblemServlet.java
@@ -192,7 +192,8 @@ public class ProblemServlet extends BasicServlet {
         return "-";
       ProblemReport p = (ProblemReport) obj;
       return String.format(
-          "<a href='/op?table=%s&action=clearProblem&redir=%s&resource=%s&ptype=%s'>clear this problem</a>",
+          "<a href='/op?table=%s&action=clearProblem&redir=%s"
+              + "&resource=%s&ptype=%s'>clear this problem</a>",
           encode(p.getTableName()), currentPage, encode(p.getResource()),
           encode(p.getProblemType().name()));
     }
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/ShellServlet.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/ShellServlet.java
index 4f140e5..13b0759 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/ShellServlet.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/ShellServlet.java
@@ -113,8 +113,8 @@ public class ShellServlet extends BasicServlet {
     sb.append("<div id='shell'>\n");
     sb.append("<pre id='shellResponse'>").append(shellThread.getOutput()).append("</pre>\n");
     sb.append("<form><span id='shellPrompt'>").append(shellThread.getPrompt());
-    sb.append(
-        "</span><input type='text' name='cmd' id='cmd' onkeydown='return handleKeyDown(event.keyCode);'>\n");
+    sb.append("</span><input type='text' name='cmd' id='cmd' "
+        + "onkeydown='return handleKeyDown(event.keyCode);'>\n");
     sb.append("</form>\n</div>\n");
     sb.append("<script type='text/javascript'>\n");
     sb.append("var url = '").append(req.getRequestURL().toString()).append("';\n");
@@ -148,8 +148,8 @@ public class ShellServlet extends BasicServlet {
     sb.append("\n");
     sb.append("function submitCmd(cmd) {\n");
     sb.append("  if (cmd=='history') {\n");
-    sb.append(
-        "    document.getElementById('shellResponse').innerHTML += document.getElementById('shellPrompt').innerHTML+cmd+'\\n';\n");
+    sb.append("    document.getElementById('shellResponse').innerHTML += "
+        + "document.getElementById('shellPrompt').innerHTML+cmd+'\\n';\n");
     sb.append("    document.getElementById('shellResponse').innerHTML += history.join('\\n');\n");
     sb.append("    return\n");
     sb.append("  }\n");
@@ -174,15 +174,15 @@ public class ShellServlet extends BasicServlet {
         "    document.getElementById('shellResponse').innerHTML += text.substring(0,index+1);\n");
     sb.append("    document.getElementById('shellPrompt').innerHTML = text.substring(index+1);\n");
     sb.append("    document.getElementById('cmd').value = '';\n");
-    sb.append(
-        "    document.getElementById('shell').scrollTop = document.getElementById('cmd').offsetTop;\n");
+    sb.append("    document.getElementById('shell').scrollTop ="
+        + " document.getElementById('cmd').offsetTop;\n");
     sb.append("  } else {\n");
     sb.append("    window.location = url;\n");
     sb.append("  }\n");
     sb.append("}\n");
     sb.append("</script>\n");
-    sb.append(
-        "<script type='text/javascript'>window.onload = function() { document.getElementById('cmd').select(); }</script>\n");
+    sb.append("<script type='text/javascript'>window.onload = "
+        + "function() { document.getElementById('cmd').select(); }</script>\n");
   }
 
   @Override
@@ -232,8 +232,8 @@ public class ShellServlet extends BasicServlet {
   }
 
   private String authenticationForm(String requestURI, String csrfToken) {
-    return "<div id='login'><form method=POST action='" + requestURI + "'>"
-        + "<table><tr><td>Mock:&nbsp</td><td><input type='checkbox' name='mock' value='mock'></td></tr>"
+    return "<div id='login'><form method=POST action='" + requestURI + "'><table>"
+        + "<tr><td>Mock:&nbsp</td><td><input type='checkbox' name='mock' value='mock'></td></tr>"
         + "<tr><td>Username:&nbsp;</td><td><input type='text' name='user'></td></tr>"
         + "<tr><td>Password:&nbsp;</td><td><input type='password' name='pass'></td><td>"
         + "<input type='hidden' name='" + CSRF_KEY + "' value='" + csrfToken
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/TServersServlet.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/TServersServlet.java
index f5098f9..e443e04 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/TServersServlet.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/TServersServlet.java
@@ -104,8 +104,8 @@ public class TServersServlet extends BasicServlet {
         tservers.addAll(Monitor.getMmi().tServerInfo);
 
       Table tServerList = new Table("tservers", "Tablet&nbsp;Servers");
-      tServerList.setSubCaption(
-          "Click on the <span style='color: #0000ff;'>server address</span> to view detailed performance statistics for that server.");
+      tServerList.setSubCaption("Click on the <span style='color: #0000ff;'>server address</span>"
+          + " to view detailed performance statistics for that server.");
 
       doTserverList(req, sb, tservers, null, tServerList);
       return;
@@ -374,17 +374,22 @@ public class TServersServlet extends BasicServlet {
     tServerList.addSortableColumn("Running<br />Scans", new CompactionsType("scans"),
         "The number of scans running and queued on this tablet server.");
     tServerList.addSortableColumn("Minor<br />Compactions", new CompactionsType("minor"),
-        "The number of minor compactions running and (queued waiting for resources). Minor compactions are the operations where entries are flushed from memory to disk.");
+        "The number of minor compactions running and (queued waiting for"
+            + " resources). Minor compactions are the operations where entries are"
+            + " flushed from memory to disk.");
     tServerList.addSortableColumn("Major<br />Compactions", new CompactionsType("major"),
-        "The number of major compactions running and (queued waiting for resources). "
-            + "Major compactions are the operations where many smaller files are grouped into a larger file, eliminating duplicates and cleaning up deletes.");
+        "The number of major compactions running and (queued waiting for"
+            + " resources). Major compactions are the operations where many smaller"
+            + " files are grouped into a larger file, eliminating duplicates and"
+            + " cleaning up deletes.");
     tServerList.addSortableColumn("Index Cache<br />Hit Rate", new PercentageType(),
         "The recent index cache hit rate.");
     tServerList.addSortableColumn("Data Cache<br />Hit Rate", new PercentageType(),
         "The recent data cache hit rate.");
     tServerList.addSortableColumn("OS&nbsp;Load",
         new NumberType<>(0., guessHighLoad * 1., 0., guessHighLoad * 3.),
-        "The Unix one minute load average. The average number of processes in the run queue over a one minute interval.");
+        "The Unix one minute load average. The average number of processes in"
+            + " the run queue over a one minute interval.");
 
     log.debug("tableId: " + tableId);
     for (TabletServerStatus status : tservers) {
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/TablesServlet.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/TablesServlet.java
index 6c72b10..5bcc9f9 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/TablesServlet.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/TablesServlet.java
@@ -98,13 +98,17 @@ public class TablesServlet extends BasicServlet {
     tableList.addSortableColumn("Ingest", new NumberType<Long>(),
         "The number of Key/Value pairs inserted.  Note that deletes are 'inserted'.");
     tableList.addSortableColumn("Entries<br />Read", new NumberType<Long>(),
-        "The number of Key/Value pairs read on the server side.  Not all key values read may be returned to client because of filtering.");
+        "The number of Key/Value pairs read on the server side. Not all key"
+            + " values read may be returned to client because of filtering.");
     tableList.addSortableColumn("Entries<br />Returned", new NumberType<Long>(),
-        "The number of Key/Value pairs returned to clients during queries.  This is <b>not</b> the number of scans.");
+        "The number of Key/Value pairs returned to clients during queries."
+            + " This is <b>not</b> the number of scans.");
     tableList.addSortableColumn("Hold&nbsp;Time", new DurationType(0l, 0l),
-        "The amount of time that ingest operations are suspended while waiting for data to be written to disk.");
+        "The amount of time that ingest operations are suspended while waiting"
+            + " for data to be written to disk.");
     tableList.addSortableColumn("Running<br />Scans", new CompactionsType("scans"),
-        "Information about the scans threads.  Shows how many threads are running and how much work is queued for the threads.");
+        "Information about the scans threads. Shows how many threads are"
+            + " running and how much work is queued for the threads.");
     tableList.addSortableColumn("Minor<br />Compactions", new CompactionsType("minor"),
         "Flushing memory to disk is called a \"minor compaction.\" "
             + "Multiple tablets can be minor compacted simultaneously, but " + ""
@@ -113,9 +117,10 @@ public class TablesServlet extends BasicServlet {
             + "indicated using parentheses. So <tt> 2 (3)</tt> indicates there are "
             + "two compactions running and three queued waiting for resources.");
     tableList.addSortableColumn("Major<br />Compactions", new CompactionsType("major"),
-        "Gathering up many small files and rewriting them as one larger file is called a 'Major Compaction'. "
-            + "Major Compactions are performed as a consequence of new files created from Minor Compactions and Bulk Load operations.  "
-            + "They reduce the number of files used during queries.");
+        "Gathering up many small files and rewriting them as one larger file is"
+            + " called a 'Major Compaction'. Major Compactions are performed as a"
+            + " consequence of new files created from Minor Compactions and Bulk Load"
+            + " operations. They reduce the number of files used during queries.");
     SortedMap<String,TableInfo> tableStats = new TreeMap<>();
 
     if (Monitor.getMmi() != null && Monitor.getMmi().tableMap != null)
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/VisServlet.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/VisServlet.java
index 626aa3e..75209c6 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/VisServlet.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/VisServlet.java
@@ -171,21 +171,19 @@ public class VisServlet extends BasicServlet {
     sb.append("<div class='left'>\n");
     sb.append("<div id='parameters' class='nowrap'>\n");
     // shape select box
-    sb.append(
-        "<span class='viscontrol'>Shape: <select id='shape' onchange='setShape(this)'><option>Circles</option><option")
-        .append(!cfg.useCircles ? " selected='true'" : "")
+    sb.append("<span class='viscontrol'>Shape: <select id='shape' onchange='setShape(this)'>"
+        + "<option>Circles</option><option").append(!cfg.useCircles ? " selected='true'" : "")
         .append(">Squares</option></select></span>\n");
     // size select box
-    sb.append(
-        "&nbsp;&nbsp<span class='viscontrol'>Size: <select id='size' onchange='setSize(this)'><option")
-        .append(cfg.spacing == 10 ? " selected='true'" : "").append(">10</option><option")
-        .append(cfg.spacing == 20 ? " selected='true'" : "").append(">20</option><option")
-        .append(cfg.spacing == 40 ? " selected='true'" : "").append(">40</option><option")
-        .append(cfg.spacing == 80 ? " selected='true'" : "")
+    sb.append("&nbsp;&nbsp<span class='viscontrol'>Size: <select id='size' "
+        + "onchange='setSize(this)'><option").append(cfg.spacing == 10 ? " selected='true'" : "")
+        .append(">10</option><option").append(cfg.spacing == 20 ? " selected='true'" : "")
+        .append(">20</option><option").append(cfg.spacing == 40 ? " selected='true'" : "")
+        .append(">40</option><option").append(cfg.spacing == 80 ? " selected='true'" : "")
         .append(">80</option></select></span>\n");
     // motion select box
-    sb.append(
-        "&nbsp;&nbsp<span class='viscontrol'>Motion: <select id='motion' onchange='setMotion(this)'>");
+    sb.append("&nbsp;&nbsp<span class='viscontrol'>"
+        + "Motion: <select id='motion' onchange='setMotion(this)'>");
     sb.append("<option selected='true'></option>");
     addOptions(sb, null);
     sb.append("</select></span>\n");
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/trace/Basic.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/trace/Basic.java
index e6be664..30d7943 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/trace/Basic.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/trace/Basic.java
@@ -162,8 +162,8 @@ abstract class Basic extends BasicServlet {
           conn.securityOperations().getUserAuthorizations(principal));
       return scanner;
     } catch (AccumuloSecurityException ex) {
-      sb.append(
-          "<h2>Unable to read trace table: check trace username and password configuration.</h2>\n");
+      sb.append("<h2>Unable to read trace table: check trace username "
+          + "and password configuration.</h2>\n");
       return null;
     } catch (TableNotFoundException ex) {
       return new NullScanner();
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/trace/ShowTrace.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/trace/ShowTrace.java
index 992bedd..8970dd0 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/trace/ShowTrace.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/trace/ShowTrace.java
@@ -126,8 +126,8 @@ public class ShowTrace extends Basic {
     sb.append(
         String.format("<span class='table-caption'>Trace %s started at<br>%s</span></caption>", id,
             dateString(start)));
-    sb.append(
-        "<tr><th>Time</th><th>Start</th><th>Service@Location</th><th>Name</th><th>Addl Data</th></tr>");
+    sb.append("<tr><th>Time</th><th>Start</th><th>Service@Location</th>"
+        + "<th>Name</th><th>Addl Data</th></tr>");
 
     final long finalStart = start;
     Set<Long> visited = tree.visit(new SpanTreeVisitor() {
@@ -139,8 +139,8 @@ public class ShowTrace extends Basic {
     });
     tree.nodes.keySet().removeAll(visited);
     if (!tree.nodes.isEmpty()) {
-      sb.append(
-          "<tr><td colspan=10>The following spans are not rooted (probably due to a parent span of length 0ms):<td></tr>\n");
+      sb.append("<tr><td colspan=10>The following spans are not rooted"
+          + " (probably due to a parent span of length 0ms):<td></tr>\n");
       for (RemoteSpan span : TraceDump.sortByStart(tree.nodes.values())) {
         appendRow(sb, 0, span, finalStart);
       }
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/trace/Summary.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/trace/Summary.java
index 9cf07eb..a034d3f 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/trace/Summary.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/servlets/trace/Summary.java
@@ -189,7 +189,9 @@ public class Summary extends Basic {
     trace.addSortableColumn("max", new DurationType(), "Longest span duration");
     trace.addSortableColumn("avg", new DurationType(), "Average span duration");
     trace.addSortableColumn("Histogram", new HistogramType(),
-        "Counts of spans of different duration. Columns start at milliseconds, and each column is ten times longer: tens of milliseconds, seconds, tens of seconds, etc.");
+        "Counts of spans of different duration. Columns start at milliseconds,"
+            + " and each column is ten times longer: tens of milliseconds, seconds,"
+            + " tens of seconds, etc.");
 
     for (Entry<String,Stats> entry : summary.entrySet()) {
       Stats stat = entry.getValue();
diff --git a/server/tracer/src/main/java/org/apache/accumulo/tracer/AsyncSpanReceiver.java b/server/tracer/src/main/java/org/apache/accumulo/tracer/AsyncSpanReceiver.java
index e2e5cfe..7c3d4e7 100644
--- a/server/tracer/src/main/java/org/apache/accumulo/tracer/AsyncSpanReceiver.java
+++ b/server/tracer/src/main/java/org/apache/accumulo/tracer/AsyncSpanReceiver.java
@@ -173,7 +173,8 @@ public abstract class AsyncSpanReceiver<SpanKey,Destination> implements SpanRece
         if (now - lastNotificationOfDroppedSpans > 60 * 1000) {
           log.warn("Tracing spans are being dropped because there are already " + maxQueueSize
               + " spans queued for delivery.\n"
-              + "This does not affect performance, security or data integrity, but distributed tracing information is being lost.");
+              + "This does not affect performance, security or data integrity,"
+              + " but distributed tracing information is being lost.");
           lastNotificationOfDroppedSpans = now;
         }
         return;
diff --git a/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceServer.java b/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceServer.java
index 099e3e5..c32c59d 100644
--- a/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceServer.java
+++ b/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceServer.java
@@ -172,9 +172,8 @@ public class TraceServer implements Watcher {
         if (timeMutation != null)
           writer.addMutation(timeMutation);
       } catch (MutationsRejectedException exception) {
-        log.warn(
-            "Unable to write mutation to table; discarding span. set log level to DEBUG for span information and stacktrace. cause: "
-                + exception);
+        log.warn("Unable to write mutation to table; discarding span. set log"
+            + " level to DEBUG for span information and stacktrace. cause: " + exception);
         if (log.isDebugEnabled()) {
           log.debug("discarded span due to rejection of mutation: " + spanMutation, exception);
         }
@@ -183,9 +182,8 @@ public class TraceServer implements Watcher {
          * mutation to a writer that has been closed since we retrieved it
          */
       } catch (RuntimeException exception) {
-        log.warn(
-            "Unable to write mutation to table; discarding span. set log level to DEBUG for stacktrace. cause: "
-                + exception);
+        log.warn("Unable to write mutation to table; discarding span. set log"
+            + " level to DEBUG for stacktrace. cause: " + exception);
         log.debug("unable to write mutation to table due to exception.", exception);
       }
     }
@@ -319,16 +317,14 @@ public class TraceServer implements Watcher {
         }
       }
     } catch (MutationsRejectedException exception) {
-      log.warn(
-          "Problem flushing traces, resetting writer. Set log level to DEBUG to see stacktrace. cause: "
-              + exception);
+      log.warn("Problem flushing traces, resetting writer. Set log level to"
+          + " DEBUG to see stacktrace. cause: " + exception);
       log.debug("flushing traces failed due to exception", exception);
       resetWriter();
       /* XXX e.g. if the writer was closed between when we grabbed it and when we called flush. */
     } catch (RuntimeException exception) {
-      log.warn(
-          "Problem flushing traces, resetting writer. Set log level to DEBUG to see stacktrace. cause: "
-              + exception);
+      log.warn("Problem flushing traces, resetting writer. Set log level to"
+          + " DEBUG to see stacktrace. cause: " + exception);
       log.debug("flushing traces failed due to exception", exception);
       resetWriter();
     }
@@ -340,9 +336,8 @@ public class TraceServer implements Watcher {
       writer = connector.createBatchWriter(tableName,
           new BatchWriterConfig().setMaxLatency(BATCH_WRITER_MAX_LATENCY, TimeUnit.SECONDS));
     } catch (Exception ex) {
-      log.warn(
-          "Unable to create a batch writer, will retry. Set log level to DEBUG to see stacktrace. cause: "
-              + ex);
+      log.warn("Unable to create a batch writer, will retry. Set log level to"
+          + " DEBUG to see stacktrace. cause: " + ex);
       log.debug("batch writer creation failed with exception.", ex);
     } finally {
       /* Trade in the new writer (even if null) for the one we need to close. */
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/InMemoryMap.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/InMemoryMap.java
index 1eb6f4e..173e953 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/InMemoryMap.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/InMemoryMap.java
@@ -110,8 +110,10 @@ public class InMemoryMap {
   public static final String TYPE_LOCALITY_GROUP_MAP = "LocalityGroupMap";
   public static final String TYPE_LOCALITY_GROUP_MAP_NATIVE = "LocalityGroupMap with native";
 
-  private AtomicReference<Pair<SamplerConfigurationImpl,Sampler>> samplerRef = new AtomicReference<>(
-      null);
+  // @formatter:off
+  private AtomicReference<Pair<SamplerConfigurationImpl,Sampler>> samplerRef =
+    new AtomicReference<>(null);
+  // @formatter:on
 
   private AccumuloConfiguration config;
 
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
index 9e18f68..472b414 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
@@ -149,6 +149,7 @@ import org.apache.accumulo.core.util.ServerServices.Service;
 import org.apache.accumulo.core.util.SimpleThreadPool;
 import org.apache.accumulo.core.util.ratelimit.RateLimiter;
 import org.apache.accumulo.core.util.ratelimit.SharedRateLimiterFactory;
+import org.apache.accumulo.core.util.ratelimit.SharedRateLimiterFactory.RateProvider;
 import org.apache.accumulo.core.zookeeper.ZooUtil;
 import org.apache.accumulo.fate.util.LoggingRunnable;
 import org.apache.accumulo.fate.util.Retry;
@@ -811,7 +812,8 @@ public class TabletServer extends AccumuloServerContext implements Runnable {
 
       if (log.isDebugEnabled()) {
         log.debug(String.format(
-            "MultiScanSess %s %,d entries in %.2f secs (lookup_time:%.2f secs tablets:%,d ranges:%,d) ",
+            "MultiScanSess %s %,d entries in %.2f secs"
+                + " (lookup_time:%.2f secs tablets:%,d ranges:%,d) ",
             TServerUtils.clientAddress.get(), session.numEntries, (t2 - session.startTime) / 1000.0,
             session.totalLookupTime / 1000.0, session.numTablets, session.numRanges));
       }
@@ -1036,9 +1038,8 @@ public class TabletServer extends AccumuloServerContext implements Runnable {
             } catch (FSError ex) { // happens when DFS is localFS
               log.warn("logging mutations failed, retrying");
             } catch (Throwable t) {
-              log.error(
-                  "Unknown exception logging mutations, counts for mutations in flight not decremented!",
-                  t);
+              log.error("Unknown exception logging mutations, counts"
+                  + " for mutations in flight not decremented!", t);
               throw new RuntimeException(t);
             }
           }
@@ -1360,9 +1361,8 @@ public class TabletServer extends AccumuloServerContext implements Runnable {
           } catch (FSError ex) { // happens when DFS is localFS
             log.warn("logging mutations failed, retrying");
           } catch (Throwable t) {
-            log.error(
-                "Unknown exception logging mutations, counts for mutations in flight not decremented!",
-                t);
+            log.error("Unknown exception logging mutations, counts for"
+                + " mutations in flight not decremented!", t);
             throw new RuntimeException(t);
           }
         }
@@ -1606,9 +1606,8 @@ public class TabletServer extends AccumuloServerContext implements Runnable {
         log.warn("Got " + request + " message from unauthenticatable user: " + e.getUser());
         if (getCredentials().getToken().getClass().getName()
             .equals(credentials.getTokenClassName())) {
-          log.error(
-              "Got message from a service with a mismatched configuration. Please ensure a compatible configuration.",
-              e);
+          log.error("Got message from a service with a mismatched configuration."
+              + " Please ensure a compatible configuration.", e);
         }
         throw e;
       }
@@ -1952,9 +1951,9 @@ public class TabletServer extends AccumuloServerContext implements Runnable {
     public void removeLogs(TInfo tinfo, TCredentials credentials, List<String> filenames)
         throws TException {
       log.warn("Garbage collector is attempting to remove logs through the tablet server");
-      log.warn(
-          "This is probably because your file Garbage Collector is an older version than your tablet servers.\n"
-              + "Restart your file Garbage Collector.");
+      log.warn("This is probably because your file"
+          + " Garbage Collector is an older version than your tablet servers.\n"
+          + "Restart your file Garbage Collector.");
     }
   }
 
@@ -2530,8 +2529,10 @@ public class TabletServer extends AccumuloServerContext implements Runnable {
         new ReplicationServicer.Processor<ReplicationServicer.Iface>(handler));
     ReplicationServicer.Iface repl = TCredentialsUpdatingWrapper.service(rpcProxy,
         handler.getClass(), getConfiguration());
-    ReplicationServicer.Processor<ReplicationServicer.Iface> processor = new ReplicationServicer.Processor<>(
-        repl);
+    // @formatter:off
+    ReplicationServicer.Processor<ReplicationServicer.Iface> processor =
+      new ReplicationServicer.Processor<>(repl);
+    // @formatter:on
     AccumuloConfiguration conf = getServerConfigurationFactory().getConfiguration();
     Property maxMessageSizeProperty = (conf.get(Property.TSERV_MAX_MESSAGE_SIZE) != null
         ? Property.TSERV_MAX_MESSAGE_SIZE
@@ -2573,8 +2574,8 @@ public class TabletServer extends AccumuloServerContext implements Runnable {
         zoo.putPersistentData(zPath, new byte[] {}, NodeExistsPolicy.SKIP);
       } catch (KeeperException e) {
         if (KeeperException.Code.NOAUTH == e.code()) {
-          log.error(
-              "Failed to write to ZooKeeper. Ensure that accumulo-site.xml, specifically instance.secret, is consistent.");
+          log.error("Failed to write to ZooKeeper. Ensure that"
+              + " accumulo-site.xml, specifically instance.secret, is consistent.");
         }
         throw e;
       }
@@ -2666,9 +2667,8 @@ public class TabletServer extends AccumuloServerContext implements Runnable {
         // out here? AUTH_FAILURE?
         // If we get the error, do we just put it on a timer and retry the exists(String, Watcher)
         // call?
-        log.error(
-            "Failed to perform initial check for authentication tokens in ZooKeeper. Delegation token authentication will be unavailable.",
-            e);
+        log.error("Failed to perform initial check for authentication tokens in"
+            + " ZooKeeper. Delegation token authentication will be unavailable.", e);
       }
     }
 
@@ -3392,7 +3392,7 @@ public class TabletServer extends AccumuloServerContext implements Runnable {
 
   private static final String MAJC_READ_LIMITER_KEY = "tserv_majc_read";
   private static final String MAJC_WRITE_LIMITER_KEY = "tserv_majc_write";
-  private final SharedRateLimiterFactory.RateProvider rateProvider = new SharedRateLimiterFactory.RateProvider() {
+  private final RateProvider rateProvider = new RateProvider() {
     @Override
     public long getDesiredRate() {
       return getConfiguration().getMemoryInBytes(Property.TSERV_MAJC_THROUGHPUT);
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServerResourceManager.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServerResourceManager.java
index 6d3cbd3..ff8202e 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServerResourceManager.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServerResourceManager.java
@@ -176,12 +176,15 @@ public class TabletServerResourceManager {
       // Still check block cache sizes when using native maps.
       if (dCacheSize + iCacheSize + totalQueueSize > runtime.maxMemory()) {
         throw new IllegalArgumentException(String.format(
-            "Block cache sizes %,d and mutation queue size %,d is too large for this JVM configuration %,d",
+            "Block cache sizes %,d"
+                + " and mutation queue size %,d is too large for this JVM configuration %,d",
             dCacheSize + iCacheSize, totalQueueSize, runtime.maxMemory()));
       }
     } else if (maxMemory + dCacheSize + iCacheSize + totalQueueSize > runtime.maxMemory()) {
       throw new IllegalArgumentException(String.format(
-          "Maximum tablet server map memory %,d block cache sizes %,d and mutation queue size %,d is too large for this JVM configuration %,d",
+          "Maximum tablet server"
+              + " map memory %,d block cache sizes %,d and mutation queue size %,d is"
+              + " too large for this JVM configuration %,d",
           maxMemory, dCacheSize + iCacheSize, totalQueueSize, runtime.maxMemory()));
     }
     runtime.gc();
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/DfsLogger.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/DfsLogger.java
index ff70d78..6aa4964 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/DfsLogger.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/DfsLogger.java
@@ -402,8 +402,11 @@ public class DfsLogger implements Comparable<DfsLogger> {
 
             // The DefaultCryptoModule will want to read the parameters from the underlying file, so
             // we will put the file back to that spot.
-            org.apache.accumulo.core.security.crypto.CryptoModule cryptoModule = org.apache.accumulo.core.security.crypto.CryptoModuleFactory
+            // @formatter:off
+            org.apache.accumulo.core.security.crypto.CryptoModule cryptoModule =
+              org.apache.accumulo.core.security.crypto.CryptoModuleFactory
                 .getCryptoModule(DefaultCryptoModule.class.getName());
+            // @formatter:on
 
             CryptoModuleParameters params = CryptoModuleFactory
                 .createParamsObjectFromAccumuloConfiguration(conf);
@@ -428,8 +431,8 @@ public class DfsLogger implements Comparable<DfsLogger> {
 
       }
     } catch (EOFException e) {
-      log.warn(
-          "Got EOFException trying to read WAL header information, assuming the rest of the file has no data.");
+      log.warn("Got EOFException trying to read WAL header information,"
+          + " assuming the rest of the file has no data.");
       // A TabletServer might have died before the (complete) header was written
       throw new LogHeaderIncompleteException(e);
     }
@@ -475,8 +478,11 @@ public class DfsLogger implements Comparable<DfsLogger> {
       flush = logFile.getClass().getMethod("hflush");
 
       // Initialize the crypto operations.
-      org.apache.accumulo.core.security.crypto.CryptoModule cryptoModule = org.apache.accumulo.core.security.crypto.CryptoModuleFactory
+      // @formatter:off
+      org.apache.accumulo.core.security.crypto.CryptoModule cryptoModule =
+        org.apache.accumulo.core.security.crypto.CryptoModuleFactory
           .getCryptoModule(conf.getConfiguration().get(Property.CRYPTO_MODULE_CLASS));
+      // @formatter:on
 
       // Initialize the log file with a header and the crypto params used to set up this log file.
       logFile.write(LOG_FILE_HEADER_V3.getBytes(UTF_8));
@@ -600,8 +606,8 @@ public class DfsLogger implements Comparable<DfsLogger> {
     try {
       write(key, EMPTY);
     } catch (IllegalArgumentException e) {
-      log.error(
-          "Signature of sync method changed. Accumulo is likely incompatible with this version of Hadoop.");
+      log.error("Signature of sync method changed. Accumulo is likely"
+          + " incompatible with this version of Hadoop.");
       throw new RuntimeException(e);
     }
   }
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/SortedLogRecovery.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/SortedLogRecovery.java
index e7c369d..a850d2f 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/SortedLogRecovery.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/SortedLogRecovery.java
@@ -125,8 +125,8 @@ public class SortedLogRecovery {
     }
 
     if (lastStartToFinish.compactionStatus == Status.LOOKING_FOR_FINISH)
-      throw new RuntimeException(
-          "COMPACTION_FINISH (without preceding COMPACTION_START) not followed by successful minor compaction");
+      throw new RuntimeException("COMPACTION_FINISH (without preceding"
+          + " COMPACTION_START) not followed by successful minor compaction");
 
     for (int i = 0; i < recoveryLogs.size(); i++) {
       Path logfile = recoveryLogs.get(i);
@@ -170,8 +170,8 @@ public class SortedLogRecovery {
 
     if (key.tserverSession.compareTo(lastStartToFinish.tserverSession) != 0) {
       if (lastStartToFinish.compactionStatus == Status.LOOKING_FOR_FINISH)
-        throw new RuntimeException(
-            "COMPACTION_FINISH (without preceding COMPACTION_START) is not followed by a successful minor compaction.");
+        throw new RuntimeException("COMPACTION_FINISH (without preceding"
+            + " COMPACTION_START) is not followed by a successful minor compaction.");
       lastStartToFinish.update(key.tserverSession);
     }
     KeyExtent alternative = extent;
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/metrics/TabletServerUpdateMetrics.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/metrics/TabletServerUpdateMetrics.java
index 284cf66..e0c5cb2 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/metrics/TabletServerUpdateMetrics.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/metrics/TabletServerUpdateMetrics.java
@@ -34,9 +34,8 @@ public class TabletServerUpdateMetrics extends AbstractMetricsImpl
     super();
     reset();
     try {
-      OBJECT_NAME = new ObjectName(
-          "accumulo.server.metrics:service=TServerInfo,name=TabletServerUpdateMetricsMBean,instance="
-              + Thread.currentThread().getName());
+      OBJECT_NAME = new ObjectName("accumulo.server.metrics:service=TServerInfo,"
+          + "name=TabletServerUpdateMetricsMBean,instance=" + Thread.currentThread().getName());
     } catch (Exception e) {
       log.error("Exception setting MBean object name", e);
     }
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystem.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystem.java
index e98baae..c2505ff 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystem.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystem.java
@@ -280,9 +280,8 @@ public class AccumuloReplicaSystem implements ReplicaSystem {
 
         if (null == peerTserverStr) {
           // Something went wrong, and we didn't get a valid tserver from the remote for some reason
-          log.warn(
-              "Did not receive tserver from master at {}, cannot proceed with replication. Will retry.",
-              target);
+          log.warn("Did not receive tserver from master at {}, cannot proceed"
+              + " with replication. Will retry.", target);
           continue;
         }
 
@@ -322,9 +321,8 @@ public class AccumuloReplicaSystem implements ReplicaSystem {
         }
       }
 
-      log.info(
-          "No progress was made after {} attempts to replicate {}, returning so file can be re-queued",
-          numAttempts, p);
+      log.info("No progress was made after {} attempts to replicate {},"
+          + " returning so file can be re-queued", numAttempts, p);
 
       // We made no status, punt on it for now, and let it re-queue itself for work
       return status;
@@ -481,7 +479,8 @@ public class AccumuloReplicaSystem implements ReplicaSystem {
             }
           } catch (TableNotFoundException e) {
             log.error(
-                "Tried to update status in replication table for {} as {}, but the table did not exist",
+                "Tried to update status in replication table for {} as"
+                    + " {}, but the table did not exist",
                 p, ProtobufUtil.toString(currentStatus), e);
             throw new RuntimeException("Replication table did not exist, will retry", e);
           } finally {
@@ -508,9 +507,8 @@ public class AccumuloReplicaSystem implements ReplicaSystem {
         }
       }
     } catch (LogHeaderIncompleteException e) {
-      log.warn(
-          "Could not read header from {}, assuming that there is no data present in the WAL, therefore replication is complete",
-          p);
+      log.warn("Could not read header from {}, assuming that there is no data"
+          + " present in the WAL, therefore replication is complete", p);
       Status newStatus;
       // Bump up the begin to the (infinite) end, trying to be accurate
       if (status.getInfiniteEnd()) {
@@ -797,8 +795,8 @@ public class AccumuloReplicaSystem implements ReplicaSystem {
           }
           break;
         default:
-          log.trace(
-              "Ignorning WAL entry which doesn't contain mutations, should not have received such entries");
+          log.trace("Ignorning WAL entry which doesn't contain mutations,"
+              + " should not have received such entries");
           break;
       }
     }
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Compactor.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Compactor.java
index 7ce6bb9..5662c63 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Compactor.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Compactor.java
@@ -242,7 +242,8 @@ public class Compactor implements Callable<CompactionStats> {
       }
 
       log.debug(String.format(
-          "Compaction %s %,d read | %,d written | %,6d entries/sec | %,6.3f secs | %,12d bytes | %9.3f byte/sec",
+          "Compaction %s %,d read | %,d written | %,6d entries/sec"
+              + " | %,6.3f secs | %,12d bytes | %9.3f byte/sec",
           extent, majCStats.getEntriesRead(), majCStats.getEntriesWritten(),
           (int) (majCStats.getEntriesRead() / ((t2 - t1) / 1000.0)), (t2 - t1) / 1000.0,
           mfwTmp.getLength(), mfwTmp.getLength() / ((t2 - t1) / 1000.0)));
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/DatafileManager.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/DatafileManager.java
index c189ec2..af822ef 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/DatafileManager.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/DatafileManager.java
@@ -501,9 +501,8 @@ class DatafileManager {
     long splitSize = tablet.getTableConfiguration()
         .getMemoryInBytes(Property.TABLE_SPLIT_THRESHOLD);
     if (dfv.getSize() > splitSize) {
-      log.debug(String.format(
-          "Minor Compaction wrote out file larger than split threshold.  split threshold = %,d  file size = %,d",
-          splitSize, dfv.getSize()));
+      log.debug(String.format("Minor Compaction wrote out file larger than split threshold."
+          + " split threshold = %,d  file size = %,d", splitSize, dfv.getSize()));
     }
   }
 
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java
index 411a948..5018c97 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java
@@ -632,9 +632,9 @@ public class Tablet implements TabletCommitter {
           }
           if (!results.isEmpty()
               && yieldPosition.compareTo(results.get(results.size() - 1).getKey()) <= 0) {
-            throw new IOException(
-                "Underlying iterator yielded to a position that does not follow the last key returned: "
-                    + yieldPosition + " <= " + results.get(results.size() - 1).getKey());
+            throw new IOException("Underlying iterator yielded to a position"
+                + " that does not follow the last key returned: " + yieldPosition + " <= "
+                + results.get(results.size() - 1).getKey());
           }
           addUnfinishedRange(lookupResult, range, yieldPosition, false);
 
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/TabletCommitter.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/TabletCommitter.java
index 934ce20..c90f1e1 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/TabletCommitter.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/TabletCommitter.java
@@ -25,8 +25,9 @@ import org.apache.accumulo.server.conf.TableConfiguration;
 import org.apache.accumulo.tserver.InMemoryMap;
 import org.apache.accumulo.tserver.log.DfsLogger;
 
-/*
- * A partial interface of Tablet to allow for testing of CommitSession without needing a real Tablet.
+/**
+ * A partial interface of Tablet to allow for testing of CommitSession without needing a real
+ * Tablet.
  */
 public interface TabletCommitter {
 
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/LargestFirstMemoryManagerTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/LargestFirstMemoryManagerTest.java
index 067ade2..aba2280 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/LargestFirstMemoryManagerTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/LargestFirstMemoryManagerTest.java
@@ -203,8 +203,10 @@ public class LargestFirstMemoryManagerTest {
         return !deletedTableId.equals(tableId);
       }
     };
-    LargestFirstMemoryManagerWithExistenceCheck mgr = new LargestFirstMemoryManagerWithExistenceCheck(
-        existenceCheck);
+    // @formatter:off
+    LargestFirstMemoryManagerWithExistenceCheck mgr =
+      new LargestFirstMemoryManagerWithExistenceCheck(existenceCheck);
+    // @formatter:on
     ServerConfiguration config = new ServerConfiguration() {
       ServerConfigurationFactory delegate = new ServerConfigurationFactory(inst);
 
diff --git a/shell/src/main/java/org/apache/accumulo/shell/Shell.java b/shell/src/main/java/org/apache/accumulo/shell/Shell.java
index 0cc7283..31cd5d4 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/Shell.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/Shell.java
@@ -350,9 +350,10 @@ public class Shell extends ShellOptions implements KeywordExecutable {
 
       if (hasToken) { // implied hasTokenOptions
         // Fully qualified name so we don't shadow java.util.Properties
-        org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties props;
-        // and line wrap it because the package name is so long
-        props = new org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties();
+        // @formatter:off
+        org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties props =
+          new org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties();
+        // @formatter:on
 
         if (!loginOptions.isEmpty()) {
           props.putAllStrings(loginOptions);
@@ -1180,8 +1181,9 @@ public class Shell extends ShellOptions implements KeywordExecutable {
 
   public void checkTableState() {
     if (getTableName().isEmpty())
-      throw new IllegalStateException(
-          "Not in a table context. Please use 'table <tableName>' to switch to a table, or use '-t' to specify a table if option is available.");
+      throw new IllegalStateException("Not in a table context. Please use"
+          + " 'table <tableName>' to switch to a table, or use '-t' to specify a"
+          + " table if option is available.");
   }
 
   private final void printConstraintViolationException(ConstraintViolationException cve) {
diff --git a/shell/src/main/java/org/apache/accumulo/shell/ShellOptionsJC.java b/shell/src/main/java/org/apache/accumulo/shell/ShellOptionsJC.java
index 746bbce..2fab019 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/ShellOptionsJC.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/ShellOptionsJC.java
@@ -120,8 +120,9 @@ public class ShellOptionsJC {
 
   // Note: Don't use "password = true" because then it will prompt even if we have a token
   @Parameter(names = {"-p", "--password"},
-      description = "password (can be specified as 'pass:<password>', 'file:<local file containing the password>', "
-          + "'env:<variable containing the pass>', or stdin)",
+      description = "password (can be specified as 'pass:<password>',"
+          + " 'file:<local file containing the password>', 'env:<variable containing"
+          + " the pass>', or stdin)",
       converter = PasswordConverter.class)
   private String password;
 
@@ -178,8 +179,9 @@ public class ShellOptionsJC {
   private boolean hdfsZooInstance;
 
   @Parameter(names = {"-z", "--zooKeeperInstance"},
-      description = "use a zookeeper instance with the given instance name and list of zoo hosts. "
-          + "Syntax: -z <zoo-instance-name> <zoo-hosts>. Where <zoo-hosts> is a comma separated list of zookeeper servers.",
+      description = "use a zookeeper instance with the given instance name and"
+          + " list of zoo hosts. Syntax: -z <zoo-instance-name> <zoo-hosts>. Where"
+          + " <zoo-hosts> is a comma separated list of zookeeper servers.",
       arity = 2)
   private List<String> zooKeeperInstance = new ArrayList<>();
 
@@ -189,9 +191,11 @@ public class ShellOptionsJC {
   @Parameter(names = "--sasl", description = "use SASL to connect to Accumulo (Kerberos)")
   private boolean useSasl = false;
 
-  @Parameter(names = "--config-file", description = "read the given client config file. "
-      + "If omitted, the path searched can be specified with $ACCUMULO_CLIENT_CONF_PATH, "
-      + "which defaults to ~/.accumulo/config:$ACCUMULO_CONF_DIR/client.conf:/etc/accumulo/client.conf")
+  @Parameter(names = "--config-file",
+      description = "read the given client"
+          + " config file. If omitted, the path searched can be specified with"
+          + " $ACCUMULO_CLIENT_CONF_PATH, which defaults to"
+          + " ~/.accumulo/config:$ACCUMULO_CONF_DIR/client.conf:/etc/accumulo/client.conf")
   private String clientConfigFile = null;
 
   @Parameter(names = {"-zi", "--zooKeeperInstanceName"},
@@ -200,8 +204,8 @@ public class ShellOptionsJC {
   private String zooKeeperInstanceName;
 
   @Parameter(names = {"-zh", "--zooKeeperHosts"},
-      description = "use a zookeeper instance with the given comma separated list of zookeeper servers. "
-          + "This parameter is used in conjunction with -zi.")
+      description = "use a zookeeper instance with the given comma separated"
+          + " list of zookeeper servers. This parameter is used in conjunction with -zi.")
   private String zooKeeperHosts;
 
   @Parameter(names = "--auth-timeout",
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/ActiveScanIterator.java b/shell/src/main/java/org/apache/accumulo/shell/commands/ActiveScanIterator.java
index 233934c..80cf400 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/ActiveScanIterator.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/ActiveScanIterator.java
@@ -67,7 +67,8 @@ class ActiveScanIterator implements Iterator<String> {
     this.tsIter = tservers.iterator();
 
     final String header = String.format(
-        " %-21s| %-21s| %-9s| %-9s| %-7s| %-6s| %-8s| %-8s| %-10s| %-20s| %-10s| %-10s | %-20s | %s",
+        " %-21s| %-21s| %-9s| %-9s| %-7s| %-6s|"
+            + " %-8s| %-8s| %-10s| %-20s| %-10s| %-10s | %-20s | %s",
         "TABLET SERVER", "CLIENT", "AGE", "LAST", "STATE", "TYPE", "USER", "TABLE", "COLUMNS",
         "AUTHORIZATIONS", "TABLET", "SCAN ID", "ITERATORS", "ITERATOR OPTIONS");
 
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/CloneTableCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/CloneTableCommand.java
index 9fcd29f..46c0d66 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/CloneTableCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/CloneTableCommand.java
@@ -90,8 +90,8 @@ public class CloneTableCommand extends Command {
   @Override
   public Options getOptions() {
     final Options o = new Options();
-    setPropsOption = new Option("s", "set", true,
-        "set initial properties before the table comes online. Expects <prop>=<value>{,<prop>=<value>}");
+    setPropsOption = new Option("s", "set", true, "set initial properties"
+        + " before the table comes online. Expects <prop>=<value>{,<prop>=<value>}");
     o.addOption(setPropsOption);
     excludePropsOption = new Option("e", "exclude", true,
         "exclude properties that should not be copied from source table. Expects <prop>{,<prop>}");
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/CompactCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/CompactCommand.java
index 86c184e..da782fa 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/CompactCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/CompactCommand.java
@@ -47,9 +47,12 @@ public class CompactCommand extends TableOperation {
 
   @Override
   public String description() {
-    return "Initiates a major compaction on tablets within the specified range that have one or more files.  If no file selection options are specified, then "
-        + "all files will be compacted.  Options that configure output settings are only applied to this compaction and not later compactions.  If multiple "
-        + "concurrent user initiated compactions specify iterators or a compaction strategy, then all but one will fail to start.";
+    return "Initiates a major compaction on tablets within the specified range"
+        + " that have one or more files. If no file selection options are"
+        + " specified, then all files will be compacted. Options that configure"
+        + " output settings are only applied to this compaction and not later"
+        + " compactions. If multiple concurrent user initiated compactions specify"
+        + " iterators or a compaction strategy, then all but one will fail to" + " start.";
   }
 
   @Override
@@ -204,37 +207,48 @@ public class CompactCommand extends TableOperation {
     opts.addOption(cancelOpt);
 
     enoSampleOption = new Option(null, "sf-no-sample", false,
-        "Select files that have no sample data or sample data that differes from the table configuration.");
+        "Select files that have no sample data or sample data that differes"
+            + " from the table configuration.");
     opts.addOption(enoSampleOption);
     enameOption = newLAO("sf-ename",
-        "Select files using regular expression to match file names. Only matches against last part of path.");
+        "Select files using regular expression to match file names. Only"
+            + " matches against last part of path.");
     opts.addOption(enameOption);
     epathOption = newLAO("sf-epath",
-        "Select files using regular expression to match file paths to compact. Matches against full path.");
+        "Select files using regular expression to match file paths to compact."
+            + " Matches against full path.");
     opts.addOption(epathOption);
     sizeLtOption = newLAO("sf-lt-esize",
-        "Selects files less than specified size.  Uses the estimated size of file in metadata table.  Can use K,M, and G suffixes");
+        "Selects files less than specified size.  Uses the estimated size of"
+            + " file in metadata table. Can use K,M, and G suffixes");
     opts.addOption(sizeLtOption);
     sizeGtOption = newLAO("sf-gt-esize",
-        "Selects files greater than specified size.  Uses the estimated size of file in metadata table.  Can use K,M, and G suffixes");
+        "Selects files greater than specified size. Uses the estimated size of"
+            + " file in metadata table. Can use K,M, and G suffixes");
     opts.addOption(sizeGtOption);
     minFilesOption = newLAO("min-files",
-        "Only compacts if at least the specified number of files are selected.  When no file selection criteria are given, all files are selected.");
+        "Only compacts if at least the specified number of files are selected."
+            + " When no file selection criteria are given, all files are selected.");
     opts.addOption(minFilesOption);
     outBlockSizeOpt = newLAO("out-data-bs",
-        "Rfile data block size to use for compaction output file.  Can use K,M, and G suffixes. Uses table settings if not specified.");
+        "Rfile data block size to use for compaction output file. Can use K,M,"
+            + " and G suffixes. Uses table settings if not specified.");
     opts.addOption(outBlockSizeOpt);
     outHdfsBlockSizeOpt = newLAO("out-hdfs-bs",
-        "HDFS block size to use for compaction output file.  Can use K,M, and G suffixes. Uses table settings if not specified.");
+        "HDFS block size to use for compaction output file. Can use K,M, and G"
+            + " suffixes. Uses table settings if not specified.");
     opts.addOption(outHdfsBlockSizeOpt);
     outIndexBlockSizeOpt = newLAO("out-index-bs",
-        "Rfile index block size to use for compaction output file.  Can use K,M, and G suffixes. Uses table settings if not specified.");
+        "Rfile index block size to use for compaction output file. Can use"
+            + " K,M, and G suffixes. Uses table settings if not specified.");
     opts.addOption(outIndexBlockSizeOpt);
     outCompressionOpt = newLAO("out-compress",
-        "Compression to use for compaction output file. Either snappy, gz, lzo, or none. Uses table settings if not specified.");
+        "Compression to use for compaction output file. Either snappy, gz, lzo,"
+            + " or none. Uses table settings if not specified.");
     opts.addOption(outCompressionOpt);
     outReplication = newLAO("out-replication",
-        "HDFS replication to use for compaction output file. Uses table settings if not specified.");
+        "HDFS replication to use for compaction output file. Uses table"
+            + " settings if not specified.");
     opts.addOption(outReplication);
 
     return opts;
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/CreateTableCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/CreateTableCommand.java
index ae2818b..12f5682 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/CreateTableCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/CreateTableCommand.java
@@ -183,7 +183,8 @@ public class CreateTableCommand extends Command {
     createTableNoDefaultIters = new Option("ndi", "no-default-iterators", false,
         "prevent creation of the normal default iterator set");
     createTableOptEVC = new Option("evc", "enable-visibility-constraint", false,
-        "prevent users from writing data they cannot read.  When enabling this, consider disabling bulk import and alter table.");
+        "prevent users from writing data they cannot read. When enabling this,"
+            + " consider disabling bulk import and alter table.");
     createTableOptFormatter = new Option("f", "formatter", true, "default formatter to set");
     createTableOptInitProp = new Option("prop", "init-properties", true,
         "user defined initial properties");
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/DUCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/DUCommand.java
index 76e9060..fc64f9c 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/DUCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/DUCommand.java
@@ -94,8 +94,9 @@ public class DUCommand extends Command {
 
   @Override
   public String description() {
-    return "prints how much space, in bytes, is used by files referenced by a table.  "
-        + "When multiple tables are specified it prints how much space, in bytes, is used by files shared between tables, if any.";
+    return "prints how much space, in bytes, is used by files referenced by a"
+        + " table. When multiple tables are specified it prints how much space, in"
+        + " bytes, is used by files shared between tables, if any.";
   }
 
   @Override
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/DeleteCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/DeleteCommand.java
index b3d8a47..2ce9803 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/DeleteCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/DeleteCommand.java
@@ -100,7 +100,8 @@ public class DeleteCommand extends Command {
     o.addOption(timestampOpt);
 
     timeoutOption = new Option(null, "timeout", true,
-        "time before insert should fail if no data is written. If no unit is given assumes seconds.  Units d,h,m,s,and ms are supported.  e.g. 30s or 100ms");
+        "time before insert should fail if no data is written. If no unit is"
+            + " given assumes seconds. Units d,h,m,s,and ms are supported. e.g. 30s" + " or 100ms");
     timeoutOption.setArgName("timeout");
     o.addOption(timeoutOption);
 
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/DeleteRowsCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/DeleteRowsCommand.java
index c84db75..e9e1655 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/DeleteRowsCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/DeleteRowsCommand.java
@@ -43,7 +43,8 @@ public class DeleteRowsCommand extends Command {
 
   @Override
   public String description() {
-    return "deletes a range of rows in a table.  Note that rows matching the start row ARE NOT deleted, but rows matching the end row ARE deleted.";
+    return "deletes a range of rows in a table. Note that rows matching the"
+        + " start row ARE NOT deleted, but rows matching the end row ARE deleted.";
   }
 
   @Override
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/DeleteScanIterCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/DeleteScanIterCommand.java
index d391c6b..5414cad 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/DeleteScanIterCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/DeleteScanIterCommand.java
@@ -77,7 +77,8 @@ public class DeleteScanIterCommand extends Command {
 
   @Override
   public String description() {
-    return "deletes a table-specific scan iterator so it is no longer used during this shell session";
+    return "deletes a table-specific scan iterator so it is no longer used"
+        + " during this shell session";
   }
 
   @Override
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/EGrepCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/EGrepCommand.java
index 2a9b656..57638fc 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/EGrepCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/EGrepCommand.java
@@ -43,8 +43,9 @@ public class EGrepCommand extends GrepCommand {
 
   @Override
   public String description() {
-    return "searches each row, column family, column qualifier and value, in parallel, on the server side "
-        + "(using a java Matcher, so put .* before and after your term if you're not matching the whole element)";
+    return "searches each row, column family, column qualifier and value, in"
+        + " parallel, on the server side (using a java Matcher, so put .* before"
+        + " and after your term if you're not matching the whole element)";
   }
 
   @Override
@@ -56,7 +57,8 @@ public class EGrepCommand extends GrepCommand {
   public Options getOptions() {
     final Options opts = super.getOptions();
     matchSubstringOption = new Option("g", "global", false,
-        "forces the use of the find() expression matcher, causing substring matches to return true");
+        "forces the use of the find() expression matcher, causing substring"
+            + " matches to return true");
     opts.addOption(matchSubstringOption);
     return opts;
   }
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/FateCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/FateCommand.java
index a9cd37d..b8919dd 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/FateCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/FateCommand.java
@@ -252,7 +252,8 @@ public class FateCommand extends Command {
     secretOption.setOptionalArg(false);
     o.addOption(secretOption);
     statusOption = new Option("t", "status-type", true,
-        "filter 'print' on the transaction status type(s) {NEW, IN_PROGRESS, FAILED_IN_PROGRESS, FAILED, SUCCESSFUL}");
+        "filter 'print' on the transaction status type(s) {NEW, IN_PROGRESS,"
+            + " FAILED_IN_PROGRESS, FAILED, SUCCESSFUL}");
     statusOption.setArgs(Option.UNLIMITED_VALUES);
     statusOption.setOptionalArg(false);
     o.addOption(statusOption);
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/GrepCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/GrepCommand.java
index b1d1f6f..d2ccad1 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/GrepCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/GrepCommand.java
@@ -98,7 +98,8 @@ public class GrepCommand extends ScanCommand {
 
   @Override
   public String description() {
-    return "searches each row, column family, column qualifier and value in a table for a substring (not a regular expression), in parallel, on the server side";
+    return "searches each row, column family, column qualifier and value in a"
+        + " table for a substring (not a regular expression), in parallel, on the" + " server side";
   }
 
   @Override
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/HiddenCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/HiddenCommand.java
index e54b15f..5126113 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/HiddenCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/HiddenCommand.java
@@ -42,12 +42,14 @@ public class HiddenCommand extends Command {
     if (rand.nextInt(10) == 0) {
       shellState.getReader().beep();
       shellState.getReader().println();
-      shellState.getReader().println(new String(Base64.decodeBase64(
-          ("ICAgICAgIC4tLS4KICAgICAgLyAvXCBcCiAgICAgKCAvLS1cICkKICAgICAuPl8gIF88LgogICAgLyB8ICd8ICcgXAog"
-              + "ICAvICB8Xy58Xy4gIFwKICAvIC98ICAgICAgfFwgXAogfCB8IHwgfFwvfCB8IHwgfAogfF98IHwgfCAgfCB8IHxffAogICAgIC8gIF9fICBcCiAgICAvICAv"
-              + "ICBcICBcCiAgIC8gIC8gICAgXCAgXF8KIHwvICAvICAgICAgXCB8IHwKIHxfXy8gICAgICAgIFx8X3wK")
-                  .getBytes(UTF_8)),
-          UTF_8));
+      shellState.getReader()
+          .println(new String(Base64
+              .decodeBase64(("ICAgICAgIC4tLS4KICAgICAgLyAvXCBcCiAgICAgKCAvLS1cICkKICAgICAuPl8gIF88"
+                  + "LgogICAgLyB8ICd8ICcgXAogICAvICB8Xy58Xy4gIFwKICAvIC98ICAgICAgfFwgXAog"
+                  + "fCB8IHwgfFwvfCB8IHwgfAogfF98IHwgfCAgfCB8IHxffAogICAgIC8gIF9fICBcCiAg"
+                  + "ICAvICAvICBcICBcCiAgIC8gIC8gICAgXCAgXF8KIHwvICAvICAgICAgXCB8IHwKIHxf"
+                  + "Xy8gICAgICAgIFx8X3wK").getBytes(UTF_8)),
+              UTF_8));
     } else {
       throw new ShellCommandException(ErrorCode.UNRECOGNIZED_COMMAND, getName());
     }
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/ImportDirectoryCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/ImportDirectoryCommand.java
index 99e125b..ec1576b 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/ImportDirectoryCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/ImportDirectoryCommand.java
@@ -29,7 +29,8 @@ public class ImportDirectoryCommand extends Command {
 
   @Override
   public String description() {
-    return "bulk imports an entire directory of data files to the current table.  The boolean argument determines if accumulo sets the time.";
+    return "bulk imports an entire directory of data files to the current"
+        + " table. The boolean argument determines if accumulo sets the time.";
   }
 
   @Override
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/InsertCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/InsertCommand.java
index c58f7d0..21de8bc 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/InsertCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/InsertCommand.java
@@ -160,7 +160,8 @@ public class InsertCommand extends Command {
     o.addOption(timestampOpt);
 
     timeoutOption = new Option(null, "timeout", true,
-        "time before insert should fail if no data is written. If no unit is given assumes seconds.  Units d,h,m,s,and ms are supported.  e.g. 30s or 100ms");
+        "time before insert should fail if no data is written. If no unit is"
+            + " given assumes seconds. Units d,h,m,s,and ms are supported. e.g. 30s" + " or 100ms");
     timeoutOption.setArgName("timeout");
     o.addOption(timeoutOption);
 
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/ListCompactionsCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/ListCompactionsCommand.java
index 6229d68..3c264f6 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/ListCompactionsCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/ListCompactionsCommand.java
@@ -32,7 +32,9 @@ public class ListCompactionsCommand extends Command {
 
   @Override
   public String description() {
-    return "lists what compactions are currently running in accumulo. See the accumulo.core.client.admin.ActiveCompaciton javadoc for more information about columns.";
+    return "lists what compactions are currently running in accumulo. See the"
+        + " accumulo.core.client.admin.ActiveCompaciton javadoc for more information"
+        + " about columns.";
   }
 
   @Override
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/ListScansCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/ListScansCommand.java
index 36a0bdc..54e57d0 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/ListScansCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/ListScansCommand.java
@@ -32,7 +32,8 @@ public class ListScansCommand extends Command {
 
   @Override
   public String description() {
-    return "lists what scans are currently running in accumulo. See the accumulo.core.client.admin.ActiveScan javadoc for more information about columns.";
+    return "lists what scans are currently running in accumulo. See the"
+        + " accumulo.core.client.admin.ActiveScan javadoc for more information" + " about columns.";
   }
 
   @Override
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/MergeCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/MergeCommand.java
index 53a0920..ffa9fdf 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/MergeCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/MergeCommand.java
@@ -101,7 +101,8 @@ public class MergeCommand extends Command {
     forceOpt = new Option("f", "force", false,
         "merge small tablets to large tablets, even if it goes over the given size");
     allOpt = new Option("", "all", false,
-        "allow an entire table to be merged into one tablet without prompting the user for confirmation");
+        "allow an entire table to be merged into one tablet without prompting"
+            + " the user for confirmation");
     o.addOption(OptUtil.startRowOpt());
     o.addOption(OptUtil.endRowOpt());
     o.addOption(OptUtil.tableOpt("table to be merged"));
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/QuotedStringTokenizer.java b/shell/src/main/java/org/apache/accumulo/shell/commands/QuotedStringTokenizer.java
index 09bfbfc..117dea1 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/QuotedStringTokenizer.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/QuotedStringTokenizer.java
@@ -74,9 +74,8 @@ public class QuotedStringTokenizer implements Iterable<String> {
         } else if (ch == ' ' || ch == '\'' || ch == '"' || ch == '\\') {
           token[tokenLength++] = inputBytes[i];
         } else {
-          throw new BadArgumentException(
-              "can only escape single quotes, double quotes, the space character, the backslash, and hex input",
-              input, i);
+          throw new BadArgumentException("can only escape single quotes, double"
+              + " quotes, the space character, the backslash, and hex input", input, i);
         }
       } else if (hexChars != null) {
         // in a hex escape sequence
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/ScanCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/ScanCommand.java
index 75769e8..5298bbf 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/ScanCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/ScanCommand.java
@@ -342,7 +342,8 @@ public class ScanCommand extends Command {
     formatterInterpeterOpt = new Option("fi", "fmt-interpreter", true,
         "fully qualified name of a class that is a formatter and interpreter");
     timeoutOption = new Option(null, "timeout", true,
-        "time before scan should fail if no data is returned. If no unit is given assumes seconds.  Units d,h,m,s,and ms are supported.  e.g. 30s or 100ms");
+        "time before scan should fail if no data is returned. If no unit is"
+            + " given assumes seconds. Units d,h,m,s,and ms are supported. e.g. 30s" + " or 100ms");
     outputFileOpt = new Option("o", "output", true, "local file to write the scan output to");
     sampleOpt = new Option(null, "sample", false, "Show sample");
     contextOpt = new Option("cc", "context", true, "name of the classloader context");
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/SetIterCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/SetIterCommand.java
index d1603de..42a8418 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/SetIterCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/SetIterCommand.java
@@ -154,9 +154,11 @@ public class SetIterCommand extends Command {
     ScanCommand.ensureTserversCanLoadIterator(shellState, tableName, classname);
 
     final String aggregatorClass = options.get("aggregatorClass");
+    // @formatter:off
     @SuppressWarnings("deprecation")
-    String deprecatedAggregatorClassName = org.apache.accumulo.core.iterators.aggregation.Aggregator.class
-        .getName();
+    String deprecatedAggregatorClassName =
+      org.apache.accumulo.core.iterators.aggregation.Aggregator.class.getName();
+    // @formatter:on
     if (aggregatorClass != null && !shellState.getConnector().tableOperations()
         .testClassLoad(tableName, aggregatorClass, deprecatedAggregatorClassName)) {
       throw new ShellCommandException(ErrorCode.INITIALIZATION_FAILURE,
@@ -203,9 +205,11 @@ public class SetIterCommand extends Command {
     }
 
     final String aggregatorClass = options.get("aggregatorClass");
+    // @formatter:off
     @SuppressWarnings("deprecation")
-    String deprecatedAggregatorClassName = org.apache.accumulo.core.iterators.aggregation.Aggregator.class
-        .getName();
+    String deprecatedAggregatorClassName =
+      org.apache.accumulo.core.iterators.aggregation.Aggregator.class.getName();
+    // @formatter:on
     if (aggregatorClass != null && !shellState.getConnector().namespaceOperations()
         .testClassLoad(namespace, aggregatorClass, deprecatedAggregatorClassName)) {
       throw new ShellCommandException(ErrorCode.INITIALIZATION_FAILURE,
@@ -346,8 +350,8 @@ public class SetIterCommand extends Command {
       } while (!iterOptions.validateOptions(options));
     } else {
       reader.flush();
-      reader.println(
-          "The iterator class does not implement OptionDescriber. Consider this for better iterator configuration using this setiter command.");
+      reader.println("The iterator class does not implement OptionDescriber."
+          + " Consider this for better iterator configuration using this setiter" + " command.");
       iteratorName = reader.readLine("Name for iterator (enter to skip): ");
       if (null == iteratorName) {
         reader.println();
diff --git a/shell/src/test/java/org/apache/accumulo/shell/ShellTest.java b/shell/src/test/java/org/apache/accumulo/shell/ShellTest.java
index 33d208b..93cd707 100644
--- a/shell/src/test/java/org/apache/accumulo/shell/ShellTest.java
+++ b/shell/src/test/java/org/apache/accumulo/shell/ShellTest.java
@@ -396,7 +396,8 @@ public class ShellTest {
 
     input.set("\n\n");
     exec(
-        "setiter -scan -class org.apache.accumulo.core.iterators.ColumnFamilyCounter -p 30 -name foo",
+        "setiter -scan"
+            + " -class org.apache.accumulo.core.iterators.ColumnFamilyCounter -p 30 -name foo",
         true);
 
     input.set("bar\nname value\n");
diff --git a/shell/src/test/java/org/apache/accumulo/shell/commands/SetIterCommandTest.java b/shell/src/test/java/org/apache/accumulo/shell/commands/SetIterCommandTest.java
index ea79935..91324c2 100644
--- a/shell/src/test/java/org/apache/accumulo/shell/commands/SetIterCommandTest.java
+++ b/shell/src/test/java/org/apache/accumulo/shell/commands/SetIterCommandTest.java
@@ -121,7 +121,8 @@ public class SetIterCommandTest {
     EasyMock.replay(conn, cli, shellState, reader, tableOperations);
 
     cmd.execute(
-        "setiter -all -p 21 -t foo -class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter",
+        "setiter -all -p 21 -t foo"
+            + " -class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter",
         cli, shellState);
 
     EasyMock.verify(conn, cli, shellState, reader, tableOperations);
diff --git a/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java b/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
index 30c4be0..63a7f30 100644
--- a/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
+++ b/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
@@ -52,17 +52,18 @@ import org.slf4j.LoggerFactory;
  * SystemClassLoader that loads JVM classes
  *       ^
  *       |
- * AccumuloClassLoader loads jars from locations in general.classpaths. Usually the URLs for HADOOP_HOME, ZOOKEEPER_HOME, ACCUMULO_HOME and their associated directories
+ * AccumuloClassLoader loads jars from locations in general.classpaths.
+ * Usually the URLs for HADOOP_HOME, ZOOKEEPER_HOME, ACCUMULO_HOME and their associated directories
  *       ^
  *       |
- * VFSClassLoader that loads jars from locations in general.vfs.classpaths.  Can be used to load accumulo jar from HDFS
+ * VFSClassLoader that loads jars from locations in general.vfs.classpaths.
+ * Can be used to load accumulo jar from HDFS
  *       ^
  *       |
- * AccumuloReloadingVFSClassLoader That loads jars from locations in general.dynamic.classpaths.  Used to load jar dynamically.
- *
+ * AccumuloReloadingVFSClassLoader That loads jars from locations in general.dynamic.classpaths.
+ * Used to load jar dynamically.
  * </pre>
  *
- *
  */
 public class AccumuloVFSClassLoader {
 
@@ -352,12 +353,12 @@ public class AccumuloVFSClassLoader {
                 + ": Accumulo Classloader (loads everything defined by general.classpaths)";
             break;
           case 4:
-            classLoaderDescription = level
-                + ": Accumulo Dynamic Classloader (loads everything defined by general.dynamic.classpaths)";
+            classLoaderDescription = level + ": Accumulo Dynamic Classloader "
+                + "(loads everything defined by general.dynamic.classpaths)";
             break;
           default:
-            classLoaderDescription = level
-                + ": Mystery Classloader (someone probably added a classloader and didn't update the switch statement in "
+            classLoaderDescription = level + ": Mystery Classloader ("
+                + "someone probably added a classloader and didn't update the switch statement in "
                 + AccumuloVFSClassLoader.class.getName() + ")";
             break;
         }
diff --git a/test/src/main/java/org/apache/accumulo/harness/AccumuloClusterHarness.java b/test/src/main/java/org/apache/accumulo/harness/AccumuloClusterHarness.java
index f7f00a8..a5a2b5a 100644
--- a/test/src/main/java/org/apache/accumulo/harness/AccumuloClusterHarness.java
+++ b/test/src/main/java/org/apache/accumulo/harness/AccumuloClusterHarness.java
@@ -134,7 +134,10 @@ public abstract class AccumuloClusterHarness extends AccumuloITBase
         }
         break;
       case STANDALONE:
-        StandaloneAccumuloClusterConfiguration conf = (StandaloneAccumuloClusterConfiguration) clusterConf;
+        // @formatter:off
+        StandaloneAccumuloClusterConfiguration conf =
+          (StandaloneAccumuloClusterConfiguration) clusterConf;
+        // @formatter:on
         ClientConfiguration clientConf = conf.getClientConf();
         StandaloneAccumuloCluster standaloneCluster = new StandaloneAccumuloCluster(
             conf.getInstance(), clientConf, conf.getTmpDirectory(), conf.getUsers(),
diff --git a/test/src/main/java/org/apache/accumulo/harness/MiniClusterHarness.java b/test/src/main/java/org/apache/accumulo/harness/MiniClusterHarness.java
index f44adcf..7ddf114 100644
--- a/test/src/main/java/org/apache/accumulo/harness/MiniClusterHarness.java
+++ b/test/src/main/java/org/apache/accumulo/harness/MiniClusterHarness.java
@@ -54,10 +54,11 @@ public class MiniClusterHarness {
 
   private static final AtomicLong COUNTER = new AtomicLong(0);
 
-  public static final String USE_SSL_FOR_IT_OPTION = "org.apache.accumulo.test.functional.useSslForIT",
-      USE_CRED_PROVIDER_FOR_IT_OPTION = "org.apache.accumulo.test.functional.useCredProviderForIT",
-      USE_KERBEROS_FOR_IT_OPTION = "org.apache.accumulo.test.functional.useKrbForIT",
-      TRUE = Boolean.toString(true);
+  private static final String PROP_PREFIX = "org.apache.accumulo.test.functional.";
+  public static final String USE_SSL_FOR_IT_OPTION = PROP_PREFIX + "useSslForIT";
+  public static final String USE_CRED_PROVIDER_FOR_IT_OPTION = PROP_PREFIX + "useCredProviderForIT";
+  public static final String USE_KERBEROS_FOR_IT_OPTION = PROP_PREFIX + "useKrbForIT";
+  public static final String TRUE = Boolean.toString(true);
 
   // TODO These are defined in MiniKdc >= 2.6.0. Can be removed when minimum Hadoop dependency is
   // increased to that.
diff --git a/test/src/main/java/org/apache/accumulo/test/ConditionalWriterIT.java b/test/src/main/java/org/apache/accumulo/test/ConditionalWriterIT.java
index f2821ef..233d7e7 100644
--- a/test/src/main/java/org/apache/accumulo/test/ConditionalWriterIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ConditionalWriterIT.java
@@ -1325,9 +1325,8 @@ public class ConditionalWriterIT extends AccumuloClusterHarness {
       // Conditional-update to a table we only have read on should fail
       try {
         Status status = cw1.write(cm1).getStatus();
-        Assert.fail(
-            "Expected exception writing conditional mutation to table the user doesn't have write access to, Got status: "
-                + status);
+        Assert.fail("Expected exception writing conditional mutation to table"
+            + " the user doesn't have write access to, Got status: " + status);
       } catch (AccumuloSecurityException ase) {
 
       }
@@ -1335,9 +1334,8 @@ public class ConditionalWriterIT extends AccumuloClusterHarness {
       // Conditional-update to a table we only have writer on should fail
       try {
         Status status = cw2.write(cm1).getStatus();
-        Assert.fail(
-            "Expected exception writing conditional mutation to table the user doesn't have read access to. Got status: "
-                + status);
+        Assert.fail("Expected exception writing conditional mutation to table"
+            + " the user doesn't have read access to. Got status: " + status);
       } catch (AccumuloSecurityException ase) {
 
       }
@@ -1561,8 +1559,9 @@ public class ConditionalWriterIT extends AccumuloClusterHarness {
       log.info("Trace output:" + traceOutput);
       if (traceCount > 0) {
         int lastPos = 0;
-        for (String part : "traceTest, startScan,startConditionalUpdate,conditionalUpdate,Check conditions,apply conditional mutations"
-            .split(",")) {
+        String[] parts = ("traceTest, startScan,startConditionalUpdate,conditionalUpdate"
+            + ",Check conditions,apply conditional mutations").split(",");
+        for (String part : parts) {
           log.info("Looking in trace output for '" + part + "'");
           int pos = traceOutput.indexOf(part);
           if (-1 == pos) {
diff --git a/test/src/main/java/org/apache/accumulo/test/InMemoryMapIT.java b/test/src/main/java/org/apache/accumulo/test/InMemoryMapIT.java
index f674779..82b8ae9 100644
--- a/test/src/main/java/org/apache/accumulo/test/InMemoryMapIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/InMemoryMapIT.java
@@ -95,10 +95,8 @@ public class InMemoryMapIT {
     if (!NativeMap.isLoaded()) {
       fail("Missing the native library from " + nativeMapLocation.getAbsolutePath()
           + "\nYou need to build the libaccumulo binary first. "
-          + "\nTry running 'mvn clean install -Dit.test=InMemoryMapIT -Dtest=foo -DfailIfNoTests=false -Dfindbugs.skip -Dcheckstyle.skip'");
-      // afterwards, you can run the following
-      // mvn clean verify -Dit.test=InMemoryMapIT -Dtest=foo -DfailIfNoTests=false -Dfindbugs.skip
-      // -Dcheckstyle.skip -pl :accumulo-test
+          + "\nTry running 'mvn clean verify -Dit.test=InMemoryMapIT -Dtest=foo"
+          + " -DfailIfNoTests=false -Dfindbugs.skip -Dcheckstyle.skip'");
     }
     log.debug("Native map loaded");
 
diff --git a/test/src/main/java/org/apache/accumulo/test/MetaSplitIT.java b/test/src/main/java/org/apache/accumulo/test/MetaSplitIT.java
index 2f31add..3a247ed 100644
--- a/test/src/main/java/org/apache/accumulo/test/MetaSplitIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/MetaSplitIT.java
@@ -56,8 +56,8 @@ public class MetaSplitIT extends AccumuloClusterHarness {
       Collection<Text> splits = conn.tableOperations().listSplits(MetadataTable.NAME);
       // We expect a single split
       if (!splits.equals(Arrays.asList(new Text("~")))) {
-        log.info(
-            "Existing splits on metadata table. Saving them, and applying single original split of '~'");
+        log.info("Existing splits on metadata table. Saving them, and applying"
+            + " single original split of '~'");
         metadataSplits = splits;
         conn.tableOperations().merge(MetadataTable.NAME, null, null);
         conn.tableOperations().addSplits(MetadataTable.NAME,
diff --git a/test/src/main/java/org/apache/accumulo/test/NamespacesIT.java b/test/src/main/java/org/apache/accumulo/test/NamespacesIT.java
index 6f9d084..a5ab431 100644
--- a/test/src/main/java/org/apache/accumulo/test/NamespacesIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/NamespacesIT.java
@@ -86,8 +86,9 @@ import org.junit.Before;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
-// Testing default namespace configuration with inheritance requires altering the system state and restoring it back to normal
-// Punt on this for now and just let it use a minicluster.
+// Testing default namespace configuration with inheritance requires altering
+// the system state and restoring it back to normal. Punt on this for now and
+// just let it use a minicluster.
 @Category(MiniClusterOnlyTests.class)
 public class NamespacesIT extends AccumuloClusterHarness {
 
diff --git a/test/src/main/java/org/apache/accumulo/test/NativeMapPerformanceTest.java b/test/src/main/java/org/apache/accumulo/test/NativeMapPerformanceTest.java
index 1b666d8..e1b8757 100644
--- a/test/src/main/java/org/apache/accumulo/test/NativeMapPerformanceTest.java
+++ b/test/src/main/java/org/apache/accumulo/test/NativeMapPerformanceTest.java
@@ -177,7 +177,8 @@ public class NativeMapPerformanceTest {
     sleepUninterruptibly(3, TimeUnit.SECONDS);
 
     System.out.printf(
-        "mapType:%10s   put rate:%,6.2f  scan rate:%,6.2f  get rate:%,6.2f  delete time : %6.2f  mem : %,d%n",
+        "mapType:%10s   put rate:%,6.2f  scan rate:%,6.2f  get"
+            + " rate:%,6.2f  delete time : %6.2f  mem : %,d%n",
         "" + mapType, (numRows * numCols) / ((tpe - tps) / 1000.0), (size) / ((tie - tis) / 1000.0),
         numLookups / ((tge - tgs) / 1000.0), (tde - tds) / 1000.0, memUsed);
 
diff --git a/test/src/main/java/org/apache/accumulo/test/ShellConfigIT.java b/test/src/main/java/org/apache/accumulo/test/ShellConfigIT.java
index 9aef95d..f6c1a77 100644
--- a/test/src/main/java/org/apache/accumulo/test/ShellConfigIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ShellConfigIT.java
@@ -77,7 +77,10 @@ public class ShellConfigIT extends AccumuloClusterHarness {
         clientConfFile = mac.getConfig().getClientConfFile();
         break;
       case STANDALONE:
-        StandaloneAccumuloClusterConfiguration standaloneConf = (StandaloneAccumuloClusterConfiguration) getClusterConfiguration();
+        // @formatter:off
+        StandaloneAccumuloClusterConfiguration standaloneConf =
+          (StandaloneAccumuloClusterConfiguration) getClusterConfiguration();
+        // @formatter:on
         clientConfFile = standaloneConf.getClientConfFile();
         break;
       default:
diff --git a/test/src/main/java/org/apache/accumulo/test/ShellServerIT.java b/test/src/main/java/org/apache/accumulo/test/ShellServerIT.java
index e3f92b7..591e23d 100644
--- a/test/src/main/java/org/apache/accumulo/test/ShellServerIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ShellServerIT.java
@@ -801,9 +801,8 @@ public class ShellServerIT extends SharedMiniClusterBase {
   @Test
   public void classpath() throws Exception {
     // classpath
-    ts.exec("classpath", true,
-        "Level 2: Java Classloader (loads everything defined by java classpath) URL classpath items are",
-        true);
+    ts.exec("classpath", true, "Level 2: Java Classloader (loads everything"
+        + " defined by java classpath) URL classpath items are", true);
   }
 
   @Test
@@ -1010,9 +1009,9 @@ public class ShellServerIT extends SharedMiniClusterBase {
     assertEquals(3, countFiles(cloneId));
 
     String clone2 = table + "_clone_2";
-    ts.exec(
-        "clonetable -s table.sampler.opt.hasher=murmur3_32,table.sampler.opt.modulus=7,table.sampler="
-            + RowSampler.class.getName() + " " + clone + " " + clone2);
+    ts.exec("clonetable -s"
+        + " table.sampler.opt.hasher=murmur3_32,table.sampler.opt.modulus=7,table.sampler="
+        + RowSampler.class.getName() + " " + clone + " " + clone2);
     String clone2Id = getTableId(clone2);
 
     assertEquals(3, countFiles(clone2Id));
@@ -1060,9 +1059,9 @@ public class ShellServerIT extends SharedMiniClusterBase {
     ts.exec("insert 3900 doc uril file://final_project.txt");
 
     String clone1 = table + "_clone_1";
-    ts.exec(
-        "clonetable -s table.sampler.opt.hasher=murmur3_32,table.sampler.opt.modulus=3,table.sampler="
-            + RowSampler.class.getName() + " " + table + " " + clone1);
+    ts.exec("clonetable -s"
+        + " table.sampler.opt.hasher=murmur3_32,table.sampler.opt.modulus=3,table.sampler="
+        + RowSampler.class.getName() + " " + table + " " + clone1);
 
     ts.exec("compact -t " + clone1 + " -w --sf-no-sample");
 
@@ -1074,9 +1073,9 @@ public class ShellServerIT extends SharedMiniClusterBase {
 
     // create table where table sample config differs from whats in file
     String clone2 = table + "_clone_2";
-    ts.exec(
-        "clonetable -s table.sampler.opt.hasher=murmur3_32,table.sampler.opt.modulus=2,table.sampler="
-            + RowSampler.class.getName() + " " + clone1 + " " + clone2);
+    ts.exec("clonetable -s"
+        + " table.sampler.opt.hasher=murmur3_32,table.sampler.opt.modulus=2,table.sampler="
+        + RowSampler.class.getName() + " " + clone1 + " " + clone2);
 
     ts.exec("table " + clone2);
     ts.exec("scan --sample", false, "SampleNotPresentException", true);
@@ -1342,11 +1341,12 @@ public class ShellServerIT extends SharedMiniClusterBase {
         + "deleteiter deletescaniter listiter setiter setscaniter "
         + "grant revoke systempermissions tablepermissions userpermissions " + "execfile history "
         + "authenticate cls clear notable sleep table user whoami "
-        + "clonetable config createtable deletetable droptable du exporttable importtable offline online renametable tables "
+        + "clonetable config createtable deletetable droptable du exporttable "
+        + "importtable offline online renametable tables "
         + "addsplits compact constraint flush getgropus getsplits merge setgroups "
         + "addauths createuser deleteuser dropuser getauths passwd setauths users "
-        + "delete deletemany deleterows egrep formatter interpreter grep importdirectory insert maxrow scan")
-            .split(" ")) {
+        + "delete deletemany deleterows egrep formatter interpreter grep "
+        + "importdirectory insert maxrow scan").split(" ")) {
       ts.exec("help " + c, true);
     }
   }
@@ -1737,9 +1737,8 @@ public class ShellServerIT extends SharedMiniClusterBase {
     ts.exec("tables", true, "thing2.thingy", false);
 
     // put constraints on a namespace
-    ts.exec(
-        "constraint -ns thing3 -a org.apache.accumulo.examples.simple.constraints.NumericValueConstraint",
-        true);
+    ts.exec("constraint -ns thing3 -a"
+        + " org.apache.accumulo.examples.simple.constraints.NumericValueConstraint", true);
     ts.exec("createtable thing3.constrained", true);
     ts.exec("table thing3.constrained", true);
     ts.exec("constraint -d 1");
@@ -1909,8 +1908,10 @@ public class ShellServerIT extends SharedMiniClusterBase {
   private static final String REAL_CONTEXT = "REAL";
   private static final String REAL_CONTEXT_CLASSPATH = "file://" + System.getProperty("user.dir")
       + "/target/" + ShellServerIT.class.getSimpleName() + "-real-iterators.jar";
-  private static final String VALUE_REVERSING_ITERATOR = "org.apache.accumulo.test.functional.ValueReversingIterator";
-  private static final String SUMMING_COMBINER_ITERATOR = "org.apache.accumulo.core.iterators.user.SummingCombiner";
+  private static final String VALUE_REVERSING_ITERATOR = "org.apache.accumulo.test."
+      + "functional.ValueReversingIterator";
+  private static final String SUMMING_COMBINER_ITERATOR = "org.apache.accumulo.core."
+      + "iterators.user.SummingCombiner";
   private static final String COLUMN_FAMILY_COUNTER_ITERATOR = "org.apache.accumulo.core.iterators"
       + ".ColumnFamilyCounter";
 
diff --git a/test/src/main/java/org/apache/accumulo/test/TestBinaryRows.java b/test/src/main/java/org/apache/accumulo/test/TestBinaryRows.java
index 9b27895..19eb91f 100644
--- a/test/src/main/java/org/apache/accumulo/test/TestBinaryRows.java
+++ b/test/src/main/java/org/apache/accumulo/test/TestBinaryRows.java
@@ -76,7 +76,8 @@ public class TestBinaryRows {
 
   public static class Opts extends ClientOnRequiredTable {
     @Parameter(names = "--mode",
-        description = "either 'ingest', 'delete', 'randomLookups', 'split', 'verify', 'verifyDeleted'",
+        description = "either 'ingest', 'delete', 'randomLookups', 'split',"
+            + " 'verify', 'verifyDeleted'",
         required = true)
     public String mode;
     @Parameter(names = "--start", description = "the lowest numbered row")
diff --git a/test/src/main/java/org/apache/accumulo/test/TestIngest.java b/test/src/main/java/org/apache/accumulo/test/TestIngest.java
index 22a01e4..5d3cc57 100644
--- a/test/src/main/java/org/apache/accumulo/test/TestIngest.java
+++ b/test/src/main/java/org/apache/accumulo/test/TestIngest.java
@@ -78,8 +78,8 @@ public class TestIngest {
     @Parameter(names = "--cols", description = "the number of columns to ingest per row")
     public int cols = 1;
 
-    @Parameter(names = "--random",
-        description = "insert random rows and use the given number to seed the psuedo-random number generator")
+    @Parameter(names = "--random", description = "insert random rows and use"
+        + " the given number to seed the psuedo-random number generator")
     public Integer random = null;
 
     @Parameter(names = "--size", description = "the size of the value to ingest")
@@ -346,7 +346,8 @@ public class TestIngest {
     double elapsed = (stopTime - startTime) / 1000.0;
 
     System.out.printf(
-        "%,12d records written | %,8d records/sec | %,12d bytes written | %,8d bytes/sec | %6.3f secs   %n",
+        "%,12d records written | %,8d records/sec | %,12d bytes written"
+            + " | %,8d bytes/sec | %6.3f secs   %n",
         totalValues, (int) (totalValues / elapsed), bytesWritten, (int) (bytesWritten / elapsed),
         elapsed);
   }
diff --git a/test/src/main/java/org/apache/accumulo/test/VerifyIngest.java b/test/src/main/java/org/apache/accumulo/test/VerifyIngest.java
index b2b5f13..4de6ccd 100644
--- a/test/src/main/java/org/apache/accumulo/test/VerifyIngest.java
+++ b/test/src/main/java/org/apache/accumulo/test/VerifyIngest.java
@@ -239,7 +239,8 @@ public class VerifyIngest {
           + (expectedRow - opts.startRow) + " expected " + opts.rows);
     } else {
       System.out.printf(
-          "%,12d records read | %,8d records/sec | %,12d bytes read | %,8d bytes/sec | %6.3f secs   %n",
+          "%,12d records read | %,8d records/sec | %,12d bytes read |"
+              + " %,8d bytes/sec | %6.3f secs   %n",
           recsRead, (int) ((recsRead) / ((t2 - t1) / 1000.0)), bytesRead,
           (int) (bytesRead / ((t2 - t1) / 1000.0)), (t2 - t1) / 1000.0);
     }
diff --git a/test/src/main/java/org/apache/accumulo/test/continuous/ContinuousStatsCollector.java b/test/src/main/java/org/apache/accumulo/test/continuous/ContinuousStatsCollector.java
index ed1014a..02e4054 100644
--- a/test/src/main/java/org/apache/accumulo/test/continuous/ContinuousStatsCollector.java
+++ b/test/src/main/java/org/apache/accumulo/test/continuous/ContinuousStatsCollector.java
@@ -71,10 +71,12 @@ public class ContinuousStatsCollector {
       this.opts = opts;
       this.scanBatchSize = scanBatchSize;
       this.tableId = Tables.getNameToIdMap(opts.getInstance()).get(opts.getTableName());
-      System.out.println(
-          "TIME TABLET_SERVERS TOTAL_ENTRIES TOTAL_INGEST TOTAL_QUERY TABLE_RECS TABLE_RECS_IN_MEM TABLE_INGEST TABLE_QUERY TABLE_TABLETS TABLE_TABLETS_ONLINE"
-              + " ACCUMULO_DU ACCUMULO_DIRS ACCUMULO_FILES TABLE_DU TABLE_DIRS TABLE_FILES"
-              + " MAP_TASK MAX_MAP_TASK REDUCE_TASK MAX_REDUCE_TASK TASK_TRACKERS BLACK_LISTED MIN_FILES/TABLET MAX_FILES/TABLET AVG_FILES/TABLET STDDEV_FILES/TABLET");
+      System.out.println("TIME TABLET_SERVERS TOTAL_ENTRIES TOTAL_INGEST"
+          + " TOTAL_QUERY TABLE_RECS TABLE_RECS_IN_MEM TABLE_INGEST TABLE_QUERY"
+          + " TABLE_TABLETS TABLE_TABLETS_ONLINE ACCUMULO_DU ACCUMULO_DIRS"
+          + " ACCUMULO_FILES TABLE_DU TABLE_DIRS TABLE_FILES MAP_TASK MAX_MAP_TASK"
+          + " REDUCE_TASK MAX_REDUCE_TASK TASK_TRACKERS BLACK_LISTED"
+          + " MIN_FILES/TABLET MAX_FILES/TABLET AVG_FILES/TABLET" + " STDDEV_FILES/TABLET");
     }
 
     @Override
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/GarbageCollectorIT.java b/test/src/main/java/org/apache/accumulo/test/functional/GarbageCollectorIT.java
index faaf874..406fb2d 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/GarbageCollectorIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/GarbageCollectorIT.java
@@ -304,8 +304,8 @@ public class GarbageCollectorIT extends ConfigurableMacBase {
     for (int i = 0; i < 100000; ++i) {
       final Text emptyText = new Text("");
       Text row = new Text(String.format("%s/%020d/%s", MetadataSchema.DeletesSection.getRowPrefix(),
-          i,
-          "aaaaaaaaaabbbbbbbbbbccccccccccddddddddddeeeeeeeeeeffffffffffgggggggggghhhhhhhhhhiiiiiiiiiijjjjjjjjjj"));
+          i, "aaaaaaaaaabbbbbbbbbbccccccccccddddddddddeeeeeeeeee"
+              + "ffffffffffgggggggggghhhhhhhhhhiiiiiiiiiijjjjjjjjjj"));
       Mutation delFlag = new Mutation(row);
       delFlag.put(emptyText, emptyText, new Value(new byte[] {}));
       bw.addMutation(delFlag);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/PermissionsIT.java b/test/src/main/java/org/apache/accumulo/test/functional/PermissionsIT.java
index ab09d0d..2876ef2 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/PermissionsIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/PermissionsIT.java
@@ -61,8 +61,10 @@ import org.junit.experimental.categories.Category;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-// This test verifies the default permissions so a clean instance must be used. A shared instance might
-// not be representative of a fresh installation.
+/**
+ * This test verifies the default permissions so a clean instance must be used. A shared instance
+ * might not be representative of a fresh installation.
+ */
 @Category(MiniClusterOnlyTests.class)
 public class PermissionsIT extends AccumuloClusterHarness {
   private static final Logger log = LoggerFactory.getLogger(PermissionsIT.class);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/RecoveryWithEmptyRFileIT.java b/test/src/main/java/org/apache/accumulo/test/functional/RecoveryWithEmptyRFileIT.java
index 61b0eb1..1533392 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/RecoveryWithEmptyRFileIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/RecoveryWithEmptyRFileIT.java
@@ -67,8 +67,8 @@ public class RecoveryWithEmptyRFileIT extends ConfigurableMacBase {
 
   @Test
   public void replaceMissingRFile() throws Exception {
-    log.info(
-        "Ingest some data, verify it was stored properly, replace an underlying rfile with an empty one and verify we can scan.");
+    log.info("Ingest some data, verify it was stored properly, replace an"
+        + " underlying rfile with an empty one and verify we can scan.");
     Connector connector = getConnector();
     String tableName = getUniqueNames(1)[0];
     ReadWriteIT.ingest(connector, cluster.getClientConfig(), "root", ROWS, COLS, 50, 0, tableName);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/SessionBlockVerifyIT.java b/test/src/main/java/org/apache/accumulo/test/functional/SessionBlockVerifyIT.java
index 5c0d159..614c895 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/SessionBlockVerifyIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/SessionBlockVerifyIT.java
@@ -170,9 +170,8 @@ public class SessionBlockVerifyIT extends ScanSessionTimeOutIT {
      * will orphan the sessionsToCleanup in the sweep, leading to an inaccurate count within
      * sessionsFound.
      */
-    assertEquals(
-        "Must have ten sessions. Failure indicates a synchronization block within the sweep mechanism",
-        10, sessionsFound);
+    assertEquals("Must have ten sessions. Failure indicates a synchronization"
+        + " block within the sweep mechanism", 10, sessionsFound);
     for (Future<Boolean> callable : callables) {
       callable.cancel(true);
     }
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/WatchTheWatchCountIT.java b/test/src/main/java/org/apache/accumulo/test/functional/WatchTheWatchCountIT.java
index 5a25605..90dcb6e 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/WatchTheWatchCountIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/WatchTheWatchCountIT.java
@@ -66,9 +66,8 @@ public class WatchTheWatchCountIT extends ConfigurableMacBase {
         if (total > MIN && total < MAX) {
           break;
         }
-        log.debug(
-            "Expected number of watchers to be contained in ({}, {}), but actually was {}. Sleeping and retrying",
-            MIN, MAX, total);
+        log.debug("Expected number of watchers to be contained in ({}, {}), but"
+            + " actually was {}. Sleeping and retrying", MIN, MAX, total);
         Thread.sleep(5000);
       } finally {
         socket.close();
diff --git a/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloInputFormatIT.java b/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloInputFormatIT.java
index 9a35a95..ba3fc02 100644
--- a/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloInputFormatIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloInputFormatIT.java
@@ -514,7 +514,10 @@ public class AccumuloInputFormatIT extends AccumuloClusterHarness {
       List<InputSplit> splits = super.getSplits(context);
 
       for (InputSplit split : splits) {
-        org.apache.accumulo.core.client.mapreduce.RangeInputSplit rangeSplit = (org.apache.accumulo.core.client.mapreduce.RangeInputSplit) split;
+        // @formatter:off
+        org.apache.accumulo.core.client.mapreduce.RangeInputSplit rangeSplit =
+          (org.apache.accumulo.core.client.mapreduce.RangeInputSplit) split;
+        // @formatter:on
         rangeSplit.setToken(new PasswordToken("anythingelse"));
       }
 
@@ -534,8 +537,11 @@ public class AccumuloInputFormatIT extends AccumuloClusterHarness {
 
       // Copy only the necessary information
       for (InputSplit oldSplit : oldSplits) {
-        org.apache.accumulo.core.client.mapreduce.RangeInputSplit newSplit = new org.apache.accumulo.core.client.mapreduce.RangeInputSplit(
+        // @formatter:off
+        org.apache.accumulo.core.client.mapreduce.RangeInputSplit newSplit =
+          new org.apache.accumulo.core.client.mapreduce.RangeInputSplit(
             (org.apache.accumulo.core.client.mapreduce.RangeInputSplit) oldSplit);
+        // @formatter:on
         newSplits.add(newSplit);
       }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/proxy/SimpleProxyBase.java b/test/src/main/java/org/apache/accumulo/test/proxy/SimpleProxyBase.java
index df8349f..2df5abc 100644
--- a/test/src/main/java/org/apache/accumulo/test/proxy/SimpleProxyBase.java
+++ b/test/src/main/java/org/apache/accumulo/test/proxy/SimpleProxyBase.java
@@ -2388,8 +2388,8 @@ public abstract class SimpleProxyBase extends SharedMiniClusterBase {
       assertEquals(1, results.size());
       status = results.get(s2bb("00347"));
       if (ConditionalStatus.VIOLATED != status) {
-        log.info(
-            "ConditionalUpdate was not rejected by server due to table constraint. Sleeping and retrying");
+        log.info("ConditionalUpdate was not rejected by server due to table"
+            + " constraint. Sleeping and retrying");
         Thread.sleep(5000);
         continue;
       }
diff --git a/test/src/main/java/org/apache/accumulo/test/proxy/TestProxyReadWrite.java b/test/src/main/java/org/apache/accumulo/test/proxy/TestProxyReadWrite.java
index baba906..3867ba4 100644
--- a/test/src/main/java/org/apache/accumulo/test/proxy/TestProxyReadWrite.java
+++ b/test/src/main/java/org/apache/accumulo/test/proxy/TestProxyReadWrite.java
@@ -239,8 +239,10 @@ public class TestProxyReadWrite {
 
     String regex = ".*[02468]";
 
-    org.apache.accumulo.core.client.IteratorSetting is = new org.apache.accumulo.core.client.IteratorSetting(
-        50, regex, RegExFilter.class);
+    // @formatter:off
+    org.apache.accumulo.core.client.IteratorSetting is =
+      new org.apache.accumulo.core.client.IteratorSetting(50, regex, RegExFilter.class);
+    // @formatter:on
     RegExFilter.setRegexs(is, regex, null, null, null, false);
 
     IteratorSetting pis = Util.iteratorSetting2ProxyIteratorSetting(is);
@@ -318,8 +320,10 @@ public class TestProxyReadWrite {
 
     String regex = ".*[02468]";
 
-    org.apache.accumulo.core.client.IteratorSetting is = new org.apache.accumulo.core.client.IteratorSetting(
-        50, regex, RegExFilter.class);
+    // @formatter:off
+    org.apache.accumulo.core.client.IteratorSetting is =
+      new org.apache.accumulo.core.client.IteratorSetting(50, regex, RegExFilter.class);
+    // @formatter:on
     RegExFilter.setRegexs(is, regex, null, null, null, false);
 
     IteratorSetting pis = Util.iteratorSetting2ProxyIteratorSetting(is);
@@ -403,8 +407,10 @@ public class TestProxyReadWrite {
 
     String regex = ".*[02468]";
 
-    org.apache.accumulo.core.client.IteratorSetting is = new org.apache.accumulo.core.client.IteratorSetting(
-        50, regex, RegExFilter.class);
+    // @formatter:off
+    org.apache.accumulo.core.client.IteratorSetting is =
+      new org.apache.accumulo.core.client.IteratorSetting(50, regex, RegExFilter.class);
+    // @formatter:on
     RegExFilter.setRegexs(is, regex, null, null, null, false);
 
     IteratorSetting pis = Util.iteratorSetting2ProxyIteratorSetting(is);
diff --git a/test/src/main/java/org/apache/accumulo/test/randomwalk/Node.java b/test/src/main/java/org/apache/accumulo/test/randomwalk/Node.java
index a6b3795..9ad0bb3 100644
--- a/test/src/main/java/org/apache/accumulo/test/randomwalk/Node.java
+++ b/test/src/main/java/org/apache/accumulo/test/randomwalk/Node.java
@@ -91,8 +91,9 @@ public abstract class Node {
     }
 
     File libdir = new File(acuHome + "/lib");
-    for (String jar : "accumulo-core accumulo-server-base accumulo-fate accumulo-trace commons-math3 libthrift htrace-core"
-        .split(" ")) {
+    String[] jars = ("accumulo-core accumulo-server-base accumulo-fate accumulo-trace"
+        + " commons-math3 libthrift htrace-core").split(" ");
+    for (String jar : jars) {
       retval += String.format(",%s/%s.jar", libdir.getAbsolutePath(), jar);
     }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/randomwalk/multitable/CopyTool.java b/test/src/main/java/org/apache/accumulo/test/randomwalk/multitable/CopyTool.java
index ba4f2d3..3ad1246 100644
--- a/test/src/main/java/org/apache/accumulo/test/randomwalk/multitable/CopyTool.java
+++ b/test/src/main/java/org/apache/accumulo/test/randomwalk/multitable/CopyTool.java
@@ -93,10 +93,12 @@ public class CopyTool extends Configured implements Tool {
         // Do the explicit check to see if the user has the permission to get a delegation token
         if (!conn.securityOperations().hasSystemPermission(conn.whoami(),
             SystemPermission.OBTAIN_DELEGATION_TOKEN)) {
-          log.error(principal + " doesn't have the "
-              + SystemPermission.OBTAIN_DELEGATION_TOKEN.name()
-              + " SystemPermission neccesary to obtain a delegation token. MapReduce tasks cannot automatically use the client's"
-              + " credentials on remote servers. Delegation tokens provide a means to run MapReduce without distributing the user's credentials.");
+          log.error(
+              principal + " doesn't have the " + SystemPermission.OBTAIN_DELEGATION_TOKEN.name()
+                  + " SystemPermission neccesary to obtain a delegation token."
+                  + " MapReduce tasks cannot automatically use the client's credentials"
+                  + " on remote servers. Delegation tokens provide a means to run"
+                  + " MapReduce without distributing the user's credentials.");
           throw new IllegalStateException(
               conn.whoami() + " does not have permission to obtain a delegation token");
         }
diff --git a/test/src/main/java/org/apache/accumulo/test/randomwalk/security/Validate.java b/test/src/main/java/org/apache/accumulo/test/randomwalk/security/Validate.java
index 53375cc..c896f0d 100644
--- a/test/src/main/java/org/apache/accumulo/test/randomwalk/security/Validate.java
+++ b/test/src/main/java/org/apache/accumulo/test/randomwalk/security/Validate.java
@@ -121,13 +121,15 @@ public class Validate extends Test {
       accuAuths = conn.securityOperations()
           .getUserAuthorizations(WalkingSecurity.get(state, env).getTabUserName());
     } catch (ThriftSecurityException ae) {
-      if (ae
-          .getCode() == org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode.USER_DOESNT_EXIST) {
+      // @formatter:off
+      if (ae.getCode()
+          == org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode.USER_DOESNT_EXIST) {
         if (tableUserExists)
           throw new AccumuloException("Table user didn't exist when they should.", ae);
         else
           return;
       }
+      // @formatter:on
       throw new AccumuloException("Unexpected exception!", ae);
     }
     if (!auths.equals(accuAuths))
diff --git a/test/src/main/java/org/apache/accumulo/test/randomwalk/sequential/MapRedVerifyTool.java b/test/src/main/java/org/apache/accumulo/test/randomwalk/sequential/MapRedVerifyTool.java
index 83ddfb9..6717fa8 100644
--- a/test/src/main/java/org/apache/accumulo/test/randomwalk/sequential/MapRedVerifyTool.java
+++ b/test/src/main/java/org/apache/accumulo/test/randomwalk/sequential/MapRedVerifyTool.java
@@ -121,10 +121,12 @@ public class MapRedVerifyTool extends Configured implements Tool {
         // Do the explicit check to see if the user has the permission to get a delegation token
         if (!conn.securityOperations().hasSystemPermission(conn.whoami(),
             SystemPermission.OBTAIN_DELEGATION_TOKEN)) {
-          log.error(newPrincipal + " doesn't have the "
-              + SystemPermission.OBTAIN_DELEGATION_TOKEN.name()
-              + " SystemPermission neccesary to obtain a delegation token. MapReduce tasks cannot automatically use the client's"
-              + " credentials on remote servers. Delegation tokens provide a means to run MapReduce without distributing the user's credentials.");
+          log.error(
+              newPrincipal + " doesn't have the " + SystemPermission.OBTAIN_DELEGATION_TOKEN.name()
+                  + " SystemPermission neccesary to obtain a delegation token."
+                  + " MapReduce tasks cannot automatically use the client's credentials"
+                  + " on remote servers. Delegation tokens provide a means to run"
+                  + " MapReduce without distributing the user's credentials.");
           throw new IllegalStateException(
               conn.whoami() + " does not have permission to obtain a delegation token");
         }
diff --git a/test/src/main/java/org/apache/accumulo/test/replication/FinishedWorkUpdaterIT.java b/test/src/main/java/org/apache/accumulo/test/replication/FinishedWorkUpdaterIT.java
index d9909e8..2cdc853 100644
--- a/test/src/main/java/org/apache/accumulo/test/replication/FinishedWorkUpdaterIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/replication/FinishedWorkUpdaterIT.java
@@ -101,14 +101,15 @@ public class FinishedWorkUpdaterIT extends ConfigurableMacBase {
     ReplicationTable.setOnline(conn);
 
     String file = "/accumulo/wals/tserver+port/" + UUID.randomUUID();
-    // @formatter:off
-    Status stat1 = Status.newBuilder().setBegin(100).setEnd(1000).setClosed(true).setInfiniteEnd(false).build(),
-        stat2 = Status.newBuilder().setBegin(500).setEnd(1000).setClosed(true).setInfiniteEnd(false).build(),
-        stat3 = Status.newBuilder().setBegin(1).setEnd(1000).setClosed(true).setInfiniteEnd(false).build();
-    ReplicationTarget target1 = new ReplicationTarget("peer1", "table1", "1"),
-        target2 = new ReplicationTarget("peer2", "table2", "1"),
-        target3 = new ReplicationTarget("peer3", "table3", "1");
-    // @formatter:on
+    Status stat1 = Status.newBuilder().setBegin(100).setEnd(1000).setClosed(true)
+        .setInfiniteEnd(false).build();
+    Status stat2 = Status.newBuilder().setBegin(500).setEnd(1000).setClosed(true)
+        .setInfiniteEnd(false).build();
+    Status stat3 = Status.newBuilder().setBegin(1).setEnd(1000).setClosed(true)
+        .setInfiniteEnd(false).build();
+    ReplicationTarget target1 = new ReplicationTarget("peer1", "table1", "1");
+    ReplicationTarget target2 = new ReplicationTarget("peer2", "table2", "1");
+    ReplicationTarget target3 = new ReplicationTarget("peer3", "table3", "1");
 
     // Create a single work record for a file to some peer
     BatchWriter bw = ReplicationTable.getBatchWriter(conn);
@@ -143,14 +144,15 @@ public class FinishedWorkUpdaterIT extends ConfigurableMacBase {
     ReplicationTable.setOnline(conn);
 
     String file = "/accumulo/wals/tserver+port/" + UUID.randomUUID();
-    // @formatter:off
-    Status stat1 = Status.newBuilder().setBegin(100).setEnd(1000).setClosed(true).setInfiniteEnd(true).build(),
-        stat2 = Status.newBuilder().setBegin(1).setEnd(1000).setClosed(true).setInfiniteEnd(true).build(),
-        stat3 = Status.newBuilder().setBegin(500).setEnd(1000).setClosed(true).setInfiniteEnd(true).build();
-    ReplicationTarget target1 = new ReplicationTarget("peer1", "table1", "1"),
-        target2 = new ReplicationTarget("peer2", "table2", "1"),
-        target3 = new ReplicationTarget("peer3", "table3", "1");
-    // @formatter:on
+    Status stat1 = Status.newBuilder().setBegin(100).setEnd(1000).setClosed(true)
+        .setInfiniteEnd(true).build();
+    Status stat2 = Status.newBuilder().setBegin(1).setEnd(1000).setClosed(true).setInfiniteEnd(true)
+        .build();
+    Status stat3 = Status.newBuilder().setBegin(500).setEnd(1000).setClosed(true)
+        .setInfiniteEnd(true).build();
+    ReplicationTarget target1 = new ReplicationTarget("peer1", "table1", "1");
+    ReplicationTarget target2 = new ReplicationTarget("peer2", "table2", "1");
+    ReplicationTarget target3 = new ReplicationTarget("peer3", "table3", "1");
 
     // Create a single work record for a file to some peer
     BatchWriter bw = ReplicationTable.getBatchWriter(conn);
diff --git a/test/src/main/java/org/apache/accumulo/test/replication/GarbageCollectorCommunicatesWithTServersIT.java b/test/src/main/java/org/apache/accumulo/test/replication/GarbageCollectorCommunicatesWithTServersIT.java
index 33626c7..58eacc8 100644
--- a/test/src/main/java/org/apache/accumulo/test/replication/GarbageCollectorCommunicatesWithTServersIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/replication/GarbageCollectorCommunicatesWithTServersIT.java
@@ -414,8 +414,8 @@ public class GarbageCollectorCommunicatesWithTServersIT extends ConfigurableMacB
     Assert.assertNotEquals("Current active WAL on tserver should not be the original WAL we saw",
         walName, activeWal);
 
-    log.info(
-        "Ensuring that replication status does get closed after WAL is no longer in use by Tserver");
+    log.info("Ensuring that replication status does get closed after WAL is no"
+        + " longer in use by Tserver");
 
     do {
       Map<String,Status> replicationStatuses = getMetadataStatusForTable(table);
diff --git a/test/src/main/java/org/apache/accumulo/test/stress/random/WriteOptions.java b/test/src/main/java/org/apache/accumulo/test/stress/random/WriteOptions.java
index 00851d8..b82eb2d 100644
--- a/test/src/main/java/org/apache/accumulo/test/stress/random/WriteOptions.java
+++ b/test/src/main/java/org/apache/accumulo/test/stress/random/WriteOptions.java
@@ -129,9 +129,8 @@ class WriteOptions extends ClientOnDefaultTable {
 
     if (min_ref == null && max_ref != null) {
       // we don't support just specifying a max yet
-      throw new IllegalArgumentException(String.format(
-          "[%s] Maximum value supplied, but no minimum. Must supply a minimum with a maximum value.",
-          label));
+      throw new IllegalArgumentException(String.format("[%s] Maximum value supplied,"
+          + " but no minimum. Must supply a minimum with a maximum value.", label));
     } else if (min_ref != null && max_ref != null) {
       // if a user supplied lower and upper bounds, we need to verify
       // that min <= max
diff --git a/test/src/main/java/org/apache/accumulo/test/util/CertUtils.java b/test/src/main/java/org/apache/accumulo/test/util/CertUtils.java
index d4e60ee..85579c7 100644
--- a/test/src/main/java/org/apache/accumulo/test/util/CertUtils.java
+++ b/test/src/main/java/org/apache/accumulo/test/util/CertUtils.java
@@ -86,8 +86,8 @@ public class CertUtils {
     @Parameter(names = {"--local-keystore"}, description = "Target path for generated keystore")
     String localKeystore = null;
 
-    @Parameter(names = {"--root-keystore"},
-        description = "Path to root truststore, generated with generate-all, or used for signing with generate-local")
+    @Parameter(names = {"--root-keystore"}, description = "Path to root truststore,"
+        + " generated with generate-all, or used for signing with generate-local")
     String rootKeystore = null;
 
     @Parameter(names = {"--root-truststore"},
@@ -97,12 +97,14 @@ public class CertUtils {
     @Parameter(names = {"--keystore-type"}, description = "Type of keystore file to use")
     String keystoreType = "JKS";
 
-    @Parameter(names = {"--root-keystore-password"},
-        description = "Password for root keystore, falls back to --keystore-password if not provided")
+    @Parameter(names = {"--root-keystore-password"}, description = "Password for root keystore,"
+        + " falls back to --keystore-password if not provided")
     String rootKeystorePassword = null;
 
     @Parameter(names = {"--keystore-password"},
-        description = "Password used to encrypt keystores.  If omitted, the instance-wide secret will be used.  If specified, the password must also be explicitly configured in Accumulo.")
+        description = "Password used to encrypt keystores."
+            + " If omitted, the instance-wide secret will be used. If specified, the"
+            + " password must also be explicitly configured in Accumulo.")
     String keystorePassword = null;
 
     @Parameter(names = {"--truststore-password"},
diff --git a/test/src/test/java/org/apache/accumulo/test/TraceRepoDeserializationTest.java b/test/src/test/java/org/apache/accumulo/test/TraceRepoDeserializationTest.java
index 5999c65..0a64815 100644
--- a/test/src/test/java/org/apache/accumulo/test/TraceRepoDeserializationTest.java
+++ b/test/src/test/java/org/apache/accumulo/test/TraceRepoDeserializationTest.java
@@ -28,7 +28,8 @@ import org.junit.Test;
 public class TraceRepoDeserializationTest {
 
   // Zookeeper data for a merge request
-  static private final String oldValue = "rO0ABXNyAC1vcmcuYXBhY2hlLmFjY3VtdWxvLm1hc3Rlci50YWJsZU9wcy5UcmFjZVJlc"
+  static private final String oldValue = "rO0ABXNyAC1vcmcuYXBhY2hlLmFjY3VtdWx"
+      + "vLm1hc3Rlci50YWJsZU9wcy5UcmFjZVJlc"
       + "G8AAAAAAAAAAQIAAkwABHJlcG90AB9Mb3JnL2FwYWNoZS9hY2N1bXVsby9mYXRlL1Jl"
       + "cG87TAAFdGluZm90AChMb3JnL2FwYWNoZS9hY2N1bXVsby90cmFjZS90aHJpZnQvVEl"
       + "uZm87eHBzcgAwb3JnLmFwYWNoZS5hY2N1bXVsby5tYXN0ZXIudGFibGVPcHMuVGFibG"

-- 
To stop receiving notification emails like this one, please contact
ctubbsii@apache.org.

[accumulo] 02/05: Apply initial formatting changes to 100-char lines

Posted by ct...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

ctubbsii pushed a commit to branch 1.8
in repository https://gitbox.apache.org/repos/asf/accumulo.git

commit f4f43febbc3e68013d8a1bcd46d8b44275e2e55e
Author: Christopher Tubbs <ct...@apache.org>
AuthorDate: Fri Apr 6 00:00:56 2018 -0400

    Apply initial formatting changes to 100-char lines
    
    Apply formatting changes from running the following:
    mvn clean verify -Dfindbugs.skip -Dcheckstyle.skip -DskipITs -DskipTests
---
 .../java/org/apache/accumulo/core/Constants.java   |   3 +-
 .../accumulo/core/bloomfilter/BloomFilter.java     |  33 +-
 .../core/bloomfilter/DynamicBloomFilter.java       |  46 +-
 .../apache/accumulo/core/bloomfilter/Filter.java   |   5 +-
 .../apache/accumulo/core/cli/BatchScannerOpts.java |   3 +-
 .../apache/accumulo/core/cli/BatchWriterOpts.java  |  12 +-
 .../org/apache/accumulo/core/cli/ClientOpts.java   |  41 +-
 .../core/cli/MapReduceClientOnRequiredTable.java   |   3 +-
 .../accumulo/core/cli/MapReduceClientOpts.java     |  11 +-
 .../org/apache/accumulo/core/cli/ScannerOpts.java  |   3 +-
 .../core/client/AccumuloSecurityException.java     |  12 +-
 .../apache/accumulo/core/client/BatchScanner.java  |  26 +-
 .../apache/accumulo/core/client/BatchWriter.java   |  15 +-
 .../accumulo/core/client/BatchWriterConfig.java    |  49 +-
 .../accumulo/core/client/ClientConfiguration.java  | 359 ++++++----
 .../core/client/ClientSideIteratorScanner.java     |  43 +-
 .../accumulo/core/client/ConditionalWriter.java    |  30 +-
 .../core/client/ConditionalWriterConfig.java       |  25 +-
 .../org/apache/accumulo/core/client/Connector.java |  92 ++-
 .../apache/accumulo/core/client/Durability.java    |   6 +-
 .../org/apache/accumulo/core/client/Instance.java  |  40 +-
 .../accumulo/core/client/IsolatedScanner.java      |  16 +-
 .../accumulo/core/client/IteratorSetting.java      |  54 +-
 .../core/client/MultiTableBatchWriter.java         |   8 +-
 .../core/client/MutationsRejectedException.java    |  36 +-
 .../core/client/NamespaceExistsException.java      |  11 +-
 .../core/client/NamespaceNotEmptyException.java    |  11 +-
 .../core/client/NamespaceNotFoundException.java    |  11 +-
 .../apache/accumulo/core/client/RowIterator.java   |  11 +-
 .../core/client/SampleNotPresentException.java     |   3 +-
 .../org/apache/accumulo/core/client/Scanner.java   |  25 +-
 .../apache/accumulo/core/client/ScannerBase.java   |  90 ++-
 .../core/client/TableDeletedException.java         |   3 +-
 .../accumulo/core/client/TableExistsException.java |   8 +-
 .../core/client/TableNotFoundException.java        |  14 +-
 .../accumulo/core/client/TimedOutException.java    |   3 +-
 .../accumulo/core/client/ZooKeeperInstance.java    |  84 ++-
 .../core/client/admin/ActiveCompaction.java        |   3 +-
 .../core/client/admin/CompactionConfig.java        |  26 +-
 .../client/admin/CompactionStrategyConfig.java     |  14 +-
 .../core/client/admin/DelegationTokenConfig.java   |  10 +-
 .../apache/accumulo/core/client/admin/FindMax.java |  15 +-
 .../core/client/admin/InstanceOperations.java      |  35 +-
 .../accumulo/core/client/admin/Locations.java      |  12 +-
 .../core/client/admin/NamespaceOperations.java     |  82 ++-
 .../core/client/admin/NewTableConfiguration.java   |  16 +-
 .../core/client/admin/ReplicationOperations.java   |  34 +-
 .../core/client/admin/SecurityOperations.java      |  76 +-
 .../core/client/admin/TableOperations.java         | 280 +++++---
 .../accumulo/core/client/admin/TimeType.java       |   7 +-
 .../AcceptableThriftTableOperationException.java   |   6 +-
 .../core/client/impl/ActiveCompactionImpl.java     |   9 +-
 .../accumulo/core/client/impl/ActiveScanImpl.java  |   7 +-
 .../client/impl/AuthenticationTokenIdentifier.java |   3 +-
 .../core/client/impl/BaseIteratorEnvironment.java  |   8 +-
 .../accumulo/core/client/impl/ClientContext.java   |  62 +-
 .../core/client/impl/ConditionalWriterImpl.java    |  70 +-
 .../accumulo/core/client/impl/ConnectorImpl.java   |  59 +-
 .../accumulo/core/client/impl/Credentials.java     |  65 +-
 .../core/client/impl/DelegationTokenImpl.java      |  21 +-
 .../core/client/impl/InstanceOperationsImpl.java   |  61 +-
 .../accumulo/core/client/impl/MasterClient.java    |  29 +-
 .../client/impl/MultiTableBatchWriterImpl.java     |  18 +-
 .../client/impl/NamespaceOperationsHelper.java     |  80 ++-
 .../core/client/impl/NamespaceOperationsImpl.java  |  80 ++-
 .../accumulo/core/client/impl/Namespaces.java      |  27 +-
 .../accumulo/core/client/impl/OfflineIterator.java |  63 +-
 .../accumulo/core/client/impl/OfflineScanner.java  |   3 +-
 .../core/client/impl/ReplicationClient.java        |  44 +-
 .../client/impl/ReplicationOperationsImpl.java     |  32 +-
 .../core/client/impl/RootTabletLocator.java        |  27 +-
 .../accumulo/core/client/impl/ScannerImpl.java     |  13 +-
 .../accumulo/core/client/impl/ScannerIterator.java |  16 +-
 .../accumulo/core/client/impl/ScannerOptions.java  |   3 +-
 .../core/client/impl/SecurityOperationsImpl.java   | 128 ++--
 .../accumulo/core/client/impl/ServerClient.java    |  37 +-
 .../core/client/impl/SyncingTabletLocator.java     |  17 +-
 .../apache/accumulo/core/client/impl/TableMap.java |   3 +-
 .../core/client/impl/TableOperationsHelper.java    |  77 +-
 .../core/client/impl/TableOperationsImpl.java      | 412 +++++++----
 .../apache/accumulo/core/client/impl/Tables.java   |  58 +-
 .../accumulo/core/client/impl/TabletLocator.java   |  28 +-
 .../core/client/impl/TabletLocatorImpl.java        | 141 ++--
 .../core/client/impl/TabletServerBatchDeleter.java |   9 +-
 .../core/client/impl/TabletServerBatchReader.java  |  15 +-
 .../impl/TabletServerBatchReaderIterator.java      | 136 ++--
 .../core/client/impl/TabletServerBatchWriter.java  | 121 ++--
 .../accumulo/core/client/impl/TabletType.java      |   3 +-
 .../accumulo/core/client/impl/ThriftScanner.java   | 126 ++--
 .../core/client/impl/ThriftTransportKey.java       |   6 +-
 .../core/client/impl/ThriftTransportPool.java      |  48 +-
 .../core/client/impl/TimeoutTabletLocator.java     |  15 +-
 .../accumulo/core/client/impl/Translator.java      |  15 +-
 .../apache/accumulo/core/client/impl/Writer.java   |  12 +-
 .../core/client/lexicoder/AbstractEncoder.java     |  14 +-
 .../core/client/lexicoder/BigIntegerLexicoder.java |   6 +-
 .../core/client/lexicoder/BytesLexicoder.java      |  10 +-
 .../core/client/lexicoder/DateLexicoder.java       |   3 +-
 .../core/client/lexicoder/DoubleLexicoder.java     |   3 +-
 .../accumulo/core/client/lexicoder/Encoder.java    |   3 +-
 .../core/client/lexicoder/FloatLexicoder.java      |   3 +-
 .../core/client/lexicoder/IntegerLexicoder.java    |   7 +-
 .../accumulo/core/client/lexicoder/Lexicoder.java  |   4 +-
 .../core/client/lexicoder/ListLexicoder.java       |   6 +-
 .../core/client/lexicoder/LongLexicoder.java       |   4 +-
 .../core/client/lexicoder/PairLexicoder.java       |  35 +-
 .../core/client/lexicoder/ReverseLexicoder.java    |   7 +-
 .../core/client/lexicoder/StringLexicoder.java     |   7 +-
 .../core/client/lexicoder/TextLexicoder.java       |   7 +-
 .../core/client/lexicoder/UIntegerLexicoder.java   |   8 +-
 .../core/client/lexicoder/ULongLexicoder.java      |   8 +-
 .../core/client/lexicoder/UUIDLexicoder.java       |   7 +-
 .../lexicoder/impl/FixedByteArrayOutputStream.java |   3 +-
 .../core/client/mapred/AbstractInputFormat.java    | 141 ++--
 .../client/mapred/AccumuloFileOutputFormat.java    |  58 +-
 .../core/client/mapred/AccumuloInputFormat.java    |  10 +-
 .../mapred/AccumuloMultiTableInputFormat.java      |   8 +-
 .../core/client/mapred/AccumuloOutputFormat.java   |  83 ++-
 .../core/client/mapred/AccumuloRowInputFormat.java |  12 +-
 .../core/client/mapred/InputFormatBase.java        | 100 ++-
 .../core/client/mapred/RangeInputSplit.java        |   3 +-
 .../core/client/mapred/impl/BatchInputSplit.java   |   9 +-
 .../core/client/mapreduce/AbstractInputFormat.java | 152 ++--
 .../client/mapreduce/AccumuloFileOutputFormat.java |  52 +-
 .../core/client/mapreduce/AccumuloInputFormat.java |  10 +-
 .../mapreduce/AccumuloMultiTableInputFormat.java   |  11 +-
 .../client/mapreduce/AccumuloOutputFormat.java     |  86 ++-
 .../client/mapreduce/AccumuloRowInputFormat.java   |  13 +-
 .../core/client/mapreduce/InputFormatBase.java     | 106 +--
 .../core/client/mapreduce/InputTableConfig.java    |  58 +-
 .../core/client/mapreduce/RangeInputSplit.java     |  18 +-
 .../client/mapreduce/impl/BatchInputSplit.java     |  30 +-
 .../client/mapreduce/impl/DelegationTokenStub.java |   3 +-
 .../core/client/mapreduce/impl/SplitUtils.java     |  16 +-
 .../mapreduce/lib/impl/ConfiguratorBase.java       | 134 ++--
 .../mapreduce/lib/impl/FileOutputConfigurator.java |  83 ++-
 .../mapreduce/lib/impl/InputConfigurator.java      | 240 ++++---
 .../mapreduce/lib/impl/OutputConfigurator.java     |  36 +-
 .../client/mapreduce/lib/impl/package-info.java    |  27 +-
 .../lib/partition/KeyRangePartitioner.java         |   3 +-
 .../mapreduce/lib/partition/RangePartitioner.java  |   9 +-
 .../mapreduce/lib/util/ConfiguratorBase.java       |  72 +-
 .../mapreduce/lib/util/FileOutputConfigurator.java |  67 +-
 .../mapreduce/lib/util/InputConfigurator.java      | 167 +++--
 .../mapreduce/lib/util/OutputConfigurator.java     |  54 +-
 .../client/mapreduce/lib/util/package-info.java    |   1 -
 .../accumulo/core/client/mock/MockAccumulo.java    |  15 +-
 .../core/client/mock/MockBatchDeleter.java         |   9 +-
 .../core/client/mock/MockConfiguration.java        |   3 +-
 .../accumulo/core/client/mock/MockConnector.java   |  46 +-
 .../accumulo/core/client/mock/MockInstance.java    |  25 +-
 .../core/client/mock/MockInstanceOperations.java   |  18 +-
 .../client/mock/MockMultiTableBatchWriter.java     |   3 +-
 .../core/client/mock/MockNamespaceOperations.java  |  25 +-
 .../accumulo/core/client/mock/MockScannerBase.java |  14 +-
 .../core/client/mock/MockSecurityOperations.java   |  54 +-
 .../accumulo/core/client/mock/MockTable.java       |  14 +-
 .../core/client/mock/MockTableOperations.java      | 149 ++--
 .../core/client/mock/impl/MockTabletLocator.java   |  12 +-
 .../accumulo/core/client/mock/package-info.java    |   1 -
 .../client/replication/PeerExistsException.java    |   3 +-
 .../apache/accumulo/core/client/rfile/RFile.java   |  93 ++-
 .../accumulo/core/client/rfile/RFileScanner.java   |  33 +-
 .../core/client/rfile/RFileScannerBuilder.java     |   6 +-
 .../accumulo/core/client/rfile/RFileSource.java    |   4 +-
 .../accumulo/core/client/rfile/RFileWriter.java    |  40 +-
 .../core/client/rfile/RFileWriterBuilder.java      |   8 +-
 .../core/client/sample/AbstractHashSampler.java    |  13 +-
 .../core/client/sample/RowColumnSampler.java       |  15 +-
 .../accumulo/core/client/sample/RowSampler.java    |  10 +-
 .../accumulo/core/client/sample/Sampler.java       |  30 +-
 .../security/tokens/AuthenticationToken.java       |  24 +-
 .../security/tokens/CredentialProviderToken.java   |  24 +-
 .../client/security/tokens/DelegationToken.java    |  13 +-
 .../core/client/security/tokens/KerberosToken.java |  28 +-
 .../core/client/security/tokens/PasswordToken.java |  21 +-
 .../accumulo/core/conf/AccumuloConfiguration.java  |  67 +-
 .../accumulo/core/conf/ConfigSanityCheck.java      |  17 +-
 .../accumulo/core/conf/ConfigurationCopy.java      |   3 +-
 .../accumulo/core/conf/ConfigurationDocGen.java    |  38 +-
 .../core/conf/CredentialProviderFactoryShim.java   | 133 ++--
 .../accumulo/core/conf/DefaultConfiguration.java   |   3 +-
 .../apache/accumulo/core/conf/Interpolated.java    |   9 +-
 .../core/conf/ObservableConfiguration.java         |   6 +-
 .../org/apache/accumulo/core/conf/Property.java    | 742 +++++++++++++-------
 .../apache/accumulo/core/conf/PropertyType.java    |  66 +-
 .../org/apache/accumulo/core/conf/Sensitive.java   |   3 +-
 .../accumulo/core/conf/SiteConfiguration.java      |  44 +-
 .../accumulo/core/constraints/Constraint.java      |  14 +-
 .../core/constraints/VisibilityConstraint.java     |   3 +-
 .../accumulo/core/data/ArrayByteSequence.java      |  24 +-
 .../apache/accumulo/core/data/ByteSequence.java    |  17 +-
 .../java/org/apache/accumulo/core/data/Column.java |  10 +-
 .../apache/accumulo/core/data/ColumnUpdate.java    |  20 +-
 .../apache/accumulo/core/data/ComparableBytes.java |  11 +-
 .../org/apache/accumulo/core/data/Condition.java   |  55 +-
 .../accumulo/core/data/ConditionalMutation.java    |   6 +-
 .../core/data/ConstraintViolationSummary.java      |  12 +-
 .../java/org/apache/accumulo/core/data/Key.java    | 312 +++++----
 .../org/apache/accumulo/core/data/KeyExtent.java   |  36 +-
 .../org/apache/accumulo/core/data/Mutation.java    | 229 +++---
 .../org/apache/accumulo/core/data/PartialKey.java  |   6 +-
 .../java/org/apache/accumulo/core/data/Range.java  | 180 +++--
 .../org/apache/accumulo/core/data/TabletId.java    |   3 +-
 .../java/org/apache/accumulo/core/data/Value.java  |  32 +-
 .../accumulo/core/data/impl/ComparableBytes.java   |   3 +-
 .../apache/accumulo/core/data/impl/KeyExtent.java  |  76 +-
 .../accumulo/core/data/impl/TabletIdImpl.java      |   6 +-
 .../accumulo/core/file/BloomFilterLayer.java       |  71 +-
 .../accumulo/core/file/DispatchingFileFactory.java |   8 +-
 .../apache/accumulo/core/file/FileOperations.java  | 121 +++-
 .../accumulo/core/file/blockfile/ABlockReader.java |   3 +-
 .../core/file/blockfile/BlockFileReader.java       |   3 +-
 .../core/file/blockfile/BlockFileWriter.java       |   3 +-
 .../core/file/blockfile/cache/CachedBlock.java     |  16 +-
 .../file/blockfile/cache/CachedBlockQueue.java     |  15 +-
 .../core/file/blockfile/cache/ClassSize.java       |  18 +-
 .../core/file/blockfile/cache/HeapSize.java        |   9 +-
 .../core/file/blockfile/cache/LruBlockCache.java   | 109 +--
 .../file/blockfile/impl/CachableBlockFile.java     |  97 +--
 .../impl/SeekableByteArrayInputStream.java         |   9 +-
 .../file/keyfunctor/ColumnQualifierFunctor.java    |   3 +-
 .../accumulo/core/file/keyfunctor/RowFunctor.java  |   3 +-
 .../accumulo/core/file/map/MapFileOperations.java  |  19 +-
 .../apache/accumulo/core/file/map/MapFileUtil.java |   6 +-
 .../accumulo/core/file/rfile/BlockIndex.java       |  15 +-
 .../accumulo/core/file/rfile/CreateEmpty.java      |  15 +-
 .../accumulo/core/file/rfile/IndexIterator.java    |   6 +-
 .../accumulo/core/file/rfile/KeyShortener.java     |  22 +-
 .../accumulo/core/file/rfile/MetricsGatherer.java  |  10 +-
 .../core/file/rfile/MultiIndexIterator.java        |   6 +-
 .../accumulo/core/file/rfile/MultiLevelIndex.java  |  58 +-
 .../apache/accumulo/core/file/rfile/PrintInfo.java |  28 +-
 .../org/apache/accumulo/core/file/rfile/RFile.java | 230 ++++--
 .../accumulo/core/file/rfile/RFileOperations.java  |  15 +-
 .../accumulo/core/file/rfile/RelativeKey.java      |  33 +-
 .../accumulo/core/file/rfile/RollingStats.java     |  15 +-
 .../accumulo/core/file/rfile/SplitLarge.java       |  15 +-
 .../core/file/rfile/VisMetricsGatherer.java        |  19 +-
 .../accumulo/core/file/rfile/VisibilityMetric.java |  10 +-
 .../accumulo/core/file/rfile/bcfile/BCFile.java    | 204 ++++--
 .../core/file/rfile/bcfile/Compression.java        | 134 ++--
 .../accumulo/core/file/rfile/bcfile/PrintInfo.java |  15 +-
 .../core/file/rfile/bcfile/RawComparable.java      |  10 +-
 .../rfile/bcfile/SimpleBufferedOutputStream.java   |   3 +-
 .../accumulo/core/file/rfile/bcfile/Utils.java     |  67 +-
 .../file/streams/BoundedRangeFileInputStream.java  |  11 +-
 .../file/streams/PositionedDataOutputStream.java   |   6 +-
 .../core/file/streams/PositionedOutput.java        |   3 +-
 .../core/file/streams/PositionedOutputs.java       |   8 +-
 .../core/file/streams/RateLimitedInputStream.java  |   3 +-
 .../core/file/streams/SeekableDataInputStream.java |   3 +-
 .../core/iterators/AggregatingIterator.java        |  30 +-
 .../core/iterators/ColumnFamilyCounter.java        |   9 +-
 .../apache/accumulo/core/iterators/Combiner.java   | 125 ++--
 .../accumulo/core/iterators/DebugIterator.java     |  10 +-
 .../apache/accumulo/core/iterators/DevNull.java    |  10 +-
 .../core/iterators/FamilyIntersectingIterator.java |   3 +-
 .../org/apache/accumulo/core/iterators/Filter.java |  25 +-
 .../core/iterators/FirstEntryInRowIterator.java    |  16 +-
 .../core/iterators/IntersectingIterator.java       |   6 +-
 .../accumulo/core/iterators/IteratorAdapter.java   |   3 +-
 .../core/iterators/IteratorEnvironment.java        |  14 +-
 .../accumulo/core/iterators/IteratorUtil.java      | 116 ++--
 .../accumulo/core/iterators/LongCombiner.java      |  61 +-
 .../accumulo/core/iterators/OptionDescriber.java   |  36 +-
 .../apache/accumulo/core/iterators/OrIterator.java |  52 +-
 .../core/iterators/RowDeletingIterator.java        |   6 +-
 .../accumulo/core/iterators/SkippingIterator.java  |  10 +-
 .../accumulo/core/iterators/SortedKeyIterator.java |   4 +-
 .../core/iterators/SortedKeyValueIterator.java     |  86 ++-
 .../accumulo/core/iterators/SortedMapIterator.java |  13 +-
 .../core/iterators/TypedValueCombiner.java         |  38 +-
 .../core/iterators/VersioningIterator.java         |   3 +-
 .../accumulo/core/iterators/WholeRowIterator.java  |   3 +-
 .../accumulo/core/iterators/WrappingIterator.java  |  22 +-
 .../accumulo/core/iterators/YieldCallback.java     |   5 +-
 .../core/iterators/YieldingKeyValueIterator.java   |  18 +-
 .../core/iterators/aggregation/LongSummation.java  |  15 +-
 .../iterators/aggregation/NumArraySummation.java   |   3 +-
 .../core/iterators/aggregation/NumSummation.java   |   3 +-
 .../core/iterators/aggregation/StringMax.java      |   4 +-
 .../core/iterators/aggregation/StringMin.java      |   4 +-
 .../iterators/aggregation/StringSummation.java     |   3 +-
 .../aggregation/conf/AggregatorConfiguration.java  |   3 +-
 .../iterators/aggregation/conf/AggregatorSet.java  |   6 +-
 .../accumulo/core/iterators/conf/ColumnSet.java    |   6 +-
 .../core/iterators/conf/ColumnToClassMapping.java  |  12 +-
 .../accumulo/core/iterators/conf/ColumnUtil.java   |   9 +-
 .../iterators/conf/PerColumnIteratorConfig.java    |   6 +-
 .../system/ColumnFamilySkippingIterator.java       |  12 +-
 .../iterators/system/ColumnQualifierFilter.java    |   9 +-
 .../core/iterators/system/CountingIterator.java    |   3 +-
 .../core/iterators/system/DeletingIterator.java    |  15 +-
 .../core/iterators/system/EmptyIterator.java       |   6 +-
 .../core/iterators/system/HeapIterator.java        |   4 +-
 .../iterators/system/LocalityGroupIterator.java    |  43 +-
 .../core/iterators/system/MapFileIterator.java     |   9 +-
 .../core/iterators/system/MultiIterator.java       |   9 +-
 .../iterators/system/SequenceFileIterator.java     |   6 +-
 .../iterators/system/SourceSwitchingIterator.java  |  53 +-
 .../core/iterators/system/StatsIterator.java       |   6 +-
 .../iterators/system/SynchronizedIterator.java     |  14 +-
 .../core/iterators/system/TimeSettingIterator.java |   6 +-
 .../core/iterators/system/VisibilityFilter.java    |   9 +-
 .../accumulo/core/iterators/user/AgeOffFilter.java |  18 +-
 .../core/iterators/user/BigDecimalCombiner.java    |  12 +-
 .../core/iterators/user/CfCqSliceFilter.java       |  13 +-
 .../core/iterators/user/CfCqSliceOpts.java         |  18 +-
 .../iterators/user/CfCqSliceSeekingFilter.java     |  27 +-
 .../core/iterators/user/ColumnAgeOffFilter.java    |  17 +-
 .../core/iterators/user/ColumnSliceFilter.java     |  22 +-
 .../accumulo/core/iterators/user/GrepIterator.java |   9 +-
 .../core/iterators/user/IndexedDocIterator.java    |  38 +-
 .../core/iterators/user/IntersectingIterator.java  |  97 ++-
 .../core/iterators/user/LargeRowFilter.java        |  46 +-
 .../accumulo/core/iterators/user/MaxCombiner.java  |   3 +-
 .../accumulo/core/iterators/user/MinCombiner.java  |   3 +-
 .../accumulo/core/iterators/user/RegExFilter.java  |  26 +-
 .../core/iterators/user/RowDeletingIterator.java   |  45 +-
 .../core/iterators/user/RowEncodingIterator.java   |  55 +-
 .../accumulo/core/iterators/user/RowFilter.java    |  44 +-
 .../core/iterators/user/SeekingFilter.java         |  47 +-
 .../core/iterators/user/SummingArrayCombiner.java  |  26 +-
 .../core/iterators/user/SummingCombiner.java       |   3 +-
 .../core/iterators/user/TimestampFilter.java       |  15 +-
 .../core/iterators/user/TransformingIterator.java  | 219 +++---
 .../core/iterators/user/VersioningIterator.java    |  19 +-
 .../core/iterators/user/VisibilityFilter.java      |  12 +-
 .../iterators/user/WholeColumnFamilyIterator.java  |  52 +-
 .../core/iterators/user/WholeRowIterator.java      |  27 +-
 .../core/metadata/MetadataLocationObtainer.java    |  54 +-
 .../accumulo/core/metadata/MetadataServicer.java   |   9 +-
 .../apache/accumulo/core/metadata/RootTable.java   |   3 +-
 .../core/metadata/ServicerForRootTable.java        |   3 +-
 .../core/metadata/TableMetadataServicer.java       |  26 +-
 .../core/metadata/schema/MetadataSchema.java       |  42 +-
 .../replication/AccumuloReplicationReplayer.java   |   7 +-
 .../core/replication/ReplicationSchema.java        |  26 +-
 .../core/replication/ReplicationTable.java         |   9 +-
 .../core/replication/ReplicationTarget.java        |  10 +-
 .../apache/accumulo/core/rpc/FilterTransport.java  |   3 +-
 .../rpc/ProtocolOverridingSSLSocketFactory.java    |  24 +-
 .../core/rpc/SaslClientDigestCallbackHandler.java  |   5 +-
 .../accumulo/core/rpc/SaslConnectionParams.java    |  15 +-
 .../core/rpc/SaslDigestCallbackHandler.java        |   6 +-
 .../accumulo/core/rpc/SslConnectionParams.java     |  19 +-
 .../apache/accumulo/core/rpc/TBufferedSocket.java  |   3 +-
 .../accumulo/core/rpc/TTimeoutTransport.java       |   6 +-
 .../org/apache/accumulo/core/rpc/ThriftUtil.java   | 142 ++--
 .../accumulo/core/rpc/TraceProtocolFactory.java    |   3 +-
 .../accumulo/core/rpc/UGIAssumingTransport.java    |   6 +-
 .../core/sample/impl/SamplerConfigurationImpl.java |  18 +-
 .../accumulo/core/sample/impl/SamplerFactory.java  |   6 +-
 .../accumulo/core/security/Authorizations.java     |  24 +-
 .../accumulo/core/security/ColumnVisibility.java   |  86 ++-
 .../core/security/NamespacePermission.java         |   3 +-
 .../accumulo/core/security/SystemPermission.java   |   3 +-
 .../accumulo/core/security/TablePermission.java    |   3 +-
 .../core/security/VisibilityConstraint.java        |   8 +-
 .../core/security/VisibilityEvaluator.java         |  29 +-
 .../core/security/VisibilityParseException.java    |   3 +-
 .../core/security/crypto/BlockedInputStream.java   |  10 +-
 .../core/security/crypto/BlockedOutputStream.java  |  12 +-
 .../CachingHDFSSecretKeyEncryptionStrategy.java    |  27 +-
 .../core/security/crypto/CryptoModule.java         |  87 ++-
 .../core/security/crypto/CryptoModuleFactory.java  |  78 ++-
 .../security/crypto/CryptoModuleParameters.java    | 263 ++++---
 .../core/security/crypto/DefaultCryptoModule.java  | 173 +++--
 .../security/crypto/DefaultCryptoModuleUtils.java  |  16 +-
 .../NonCachingSecretKeyEncryptionStrategy.java     |  29 +-
 .../apache/accumulo/core/trace/CountSampler.java   |   3 +-
 .../accumulo/core/trace/DistributedTrace.java      |  43 +-
 .../accumulo/core/trace/ProbabilitySampler.java    |   3 +-
 .../java/org/apache/accumulo/core/trace/Span.java  |   3 +-
 .../java/org/apache/accumulo/core/trace/Trace.java |   3 +-
 .../accumulo/core/trace/wrappers/TraceWrap.java    |  11 +-
 .../org/apache/accumulo/core/util/AddressUtil.java |   6 +-
 .../accumulo/core/util/AsyncSocketAppender.java    |   8 +-
 .../java/org/apache/accumulo/core/util/Base64.java |  13 +-
 .../apache/accumulo/core/util/ByteBufferUtil.java  |  12 +-
 .../org/apache/accumulo/core/util/CleanUp.java     |  11 +-
 .../apache/accumulo/core/util/ComparablePair.java  |   3 +-
 .../org/apache/accumulo/core/util/CreateToken.java |  23 +-
 .../apache/accumulo/core/util/DeprecationUtil.java |  13 +-
 .../org/apache/accumulo/core/util/FastFormat.java  |   6 +-
 .../org/apache/accumulo/core/util/HostAndPort.java |  46 +-
 .../java/org/apache/accumulo/core/util/Jar.java    |   8 +-
 .../accumulo/core/util/LocalityGroupUtil.java      |  38 +-
 .../java/org/apache/accumulo/core/util/Merge.java  |  33 +-
 .../org/apache/accumulo/core/util/OpTimer.java     |  14 +-
 .../apache/accumulo/core/util/PeekingIterator.java |   3 +-
 .../accumulo/core/util/PreAllocatedArray.java      |   5 +-
 .../apache/accumulo/core/util/ServerServices.java  |   3 +-
 .../accumulo/core/util/SimpleThreadPool.java       |   3 +-
 .../accumulo/core/util/ThriftMessageUtil.java      |  13 +-
 .../accumulo/core/util/UnsynchronizedBuffer.java   |  26 +-
 .../org/apache/accumulo/core/util/Validator.java   |  15 +-
 .../accumulo/core/util/format/BinaryFormatter.java |  12 +-
 .../core/util/format/DateFormatSupplier.java       |  19 +-
 .../core/util/format/DateStringFormatter.java      |  17 +-
 .../core/util/format/DefaultFormatter.java         |   9 +-
 .../accumulo/core/util/format/FormatterConfig.java |   5 +-
 .../core/util/format/FormatterFactory.java         |   6 +-
 .../accumulo/core/util/format/HexFormatter.java    |   3 +-
 .../format/ShardedTableDistributionFormatter.java  |   7 +-
 .../util/format/StatisticsDisplayFormatter.java    |   5 +-
 .../core/util/interpret/HexScanInterpreter.java    |   5 +-
 .../core/util/interpret/ScanInterpreter.java       |   3 +-
 .../core/util/ratelimit/GuavaRateLimiter.java      |   9 +-
 .../util/ratelimit/SharedRateLimiterFactory.java   |  22 +-
 .../accumulo/core/volume/NonConfiguredVolume.java  |  21 +-
 .../org/apache/accumulo/core/volume/Volume.java    |   6 +-
 .../accumulo/core/volume/VolumeConfiguration.java  |  21 +-
 .../apache/accumulo/core/volume/VolumeImpl.java    |  12 +-
 .../apache/accumulo/core/zookeeper/ZooUtil.java    |  16 +-
 .../apache/accumulo/core/cli/TestClientOpts.java   |  34 +-
 .../core/client/BatchWriterConfigTest.java         |   6 +-
 .../core/client/ClientConfigurationTest.java       |   6 +-
 .../accumulo/core/client/IteratorSettingTest.java  |   6 +-
 .../accumulo/core/client/TestThrift1474.java       |   3 +-
 .../core/client/ZooKeeperInstanceTest.java         |  21 +-
 .../client/admin/DelegationTokenConfigTest.java    |   6 +-
 .../core/client/impl/ClientContextTest.java        |  15 +-
 .../core/client/impl/ScannerOptionsTest.java       |   3 +-
 .../client/impl/TableOperationsHelperTest.java     | 143 ++--
 .../core/client/impl/TableOperationsImplTest.java  |   3 +-
 .../core/client/impl/TabletLocatorImplTest.java    | 258 ++++---
 .../core/client/impl/ThriftScannerTest.java        |   6 +-
 .../core/client/impl/ThriftTransportKeyTest.java   |  89 +--
 .../client/lexicoder/BigIntegerLexicoderTest.java  |  19 +-
 .../core/client/lexicoder/DoubleLexicoderTest.java |  10 +-
 .../core/client/lexicoder/FloatLexicoderTest.java  |   9 +-
 .../client/lexicoder/IntegerLexicoderTest.java     |   4 +-
 .../core/client/lexicoder/LexicoderTest.java       |   3 +-
 .../core/client/lexicoder/LongLexicoderTest.java   |   8 +-
 .../core/client/lexicoder/PairLexicoderTest.java   |  21 +-
 .../client/lexicoder/ReverseLexicoderTest.java     |  11 +-
 .../core/client/lexicoder/ULongLexicoderTest.java  |  31 +-
 .../core/client/lexicoder/UUIDLexicoderTest.java   |   4 +-
 .../lexicoder/impl/AbstractLexicoderTest.java      |   5 +-
 .../mapred/AccumuloFileOutputFormatTest.java       |   9 +-
 .../client/mapred/AccumuloInputFormatTest.java     |  38 +-
 .../mapred/AccumuloMultiTableInputFormatTest.java  |   9 +-
 .../client/mapred/AccumuloOutputFormatTest.java    |   6 +-
 .../core/client/mapred/RangeInputSplitTest.java    |   9 +-
 .../mapreduce/AccumuloFileOutputFormatTest.java    |  12 +-
 .../client/mapreduce/AccumuloInputFormatTest.java  |  38 +-
 .../AccumuloMultiTableInputFormatTest.java         |   3 +-
 .../client/mapreduce/AccumuloOutputFormatTest.java |   6 +-
 .../core/client/mapreduce/RangeInputSplitTest.java |   9 +-
 .../client/mapreduce/impl/BatchInputSplitTest.java |   9 +-
 .../mapreduce/lib/impl/ConfiguratorBaseTest.java   |  43 +-
 .../lib/partition/RangePartitionerTest.java        |   9 +-
 .../core/client/mock/MockConnectorTest.java        |  26 +-
 .../core/client/mock/MockNamespacesTest.java       |  25 +-
 .../accumulo/core/client/mock/MockScannerTest.java |   6 +-
 .../core/client/mock/MockTableOperationsTest.java  |  34 +-
 .../core/client/mock/TestBatchScanner821.java      |   3 +-
 .../accumulo/core/client/rfile/RFileTest.java      |  58 +-
 .../client/security/SecurityErrorCodeTest.java     |   3 +-
 .../security/tokens/DelegationTokenImplTest.java   |  21 +-
 .../client/security/tokens/KerberosTokenTest.java  |   3 +-
 .../core/conf/AccumuloConfigurationTest.java       |   6 +-
 .../accumulo/core/conf/ConfigSanityCheckTest.java  |   3 +-
 .../conf/CredentialProviderFactoryShimTest.java    |  38 +-
 .../core/conf/DefaultConfigurationTest.java        |   3 +-
 .../apache/accumulo/core/conf/PropertyTest.java    |  23 +-
 .../accumulo/core/conf/PropertyTypeTest.java       |  51 +-
 .../accumulo/core/conf/SiteConfigurationTest.java  |  15 +-
 .../constraints/DefaultKeySizeConstraintTest.java  |  16 +-
 .../accumulo/core/data/ArrayByteSequenceTest.java  |   3 +-
 .../apache/accumulo/core/data/ConditionTest.java   |  12 +-
 .../core/data/ConstraintViolationSummaryTest.java  |  10 +-
 .../org/apache/accumulo/core/data/KeyTest.java     |  12 +-
 .../apache/accumulo/core/data/MutationTest.java    |  39 +-
 .../org/apache/accumulo/core/data/OldMutation.java |  84 ++-
 .../org/apache/accumulo/core/data/RangeTest.java   | 103 ++-
 .../core/file/BloomFilterLayerLookupTest.java      |  15 +-
 .../accumulo/core/file/FileOperationsTest.java     |   3 +-
 .../file/blockfile/cache/TestCachedBlockQueue.java |  10 +-
 .../file/blockfile/cache/TestLruBlockCache.java    |  43 +-
 .../accumulo/core/file/rfile/BlockIndexTest.java   |  15 +-
 .../core/file/rfile/CreateCompatTestFile.java      |  22 +-
 .../accumulo/core/file/rfile/KeyShortenerTest.java |  78 ++-
 .../core/file/rfile/MultiLevelIndexTest.java       |   6 +-
 .../core/file/rfile/MultiThreadedRFileTest.java    |  56 +-
 .../accumulo/core/file/rfile/RFileMetricsTest.java |   9 +-
 .../apache/accumulo/core/file/rfile/RFileTest.java | 299 +++++---
 .../accumulo/core/file/rfile/RelativeKeyTest.java  |  24 +-
 .../core/file/rfile/RolllingStatsTest.java         |   4 +-
 .../core/file/rfile/bcfile/CompressionTest.java    |  21 +-
 .../file/streams/RateLimitedInputStreamTest.java   |  12 +-
 .../file/streams/RateLimitedOutputStreamTest.java  |   3 +-
 .../core/iterators/AggregatingIteratorTest.java    |   9 +-
 .../core/iterators/DefaultIteratorEnvironment.java |   3 +-
 .../iterators/FirstEntryInRowIteratorTest.java     |   9 +-
 .../core/iterators/FirstEntryInRowTest.java        |   9 +-
 .../accumulo/core/iterators/IteratorUtilTest.java  |  74 +-
 .../conf/AggregatorConfigurationTest.java          |  16 +-
 .../system/ColumnFamilySkippingIteratorTest.java   |  16 +-
 .../core/iterators/system/ColumnFilterTest.java    |   6 +-
 .../iterators/system/DeletingIteratorTest.java     |   3 +-
 .../core/iterators/system/MultiIteratorTest.java   |  20 +-
 .../system/SourceSwitchingIteratorTest.java        |  31 +-
 .../iterators/system/TimeSettingIteratorTest.java  |  21 +-
 .../iterators/system/VisibilityFilterTest.java     |   6 +-
 .../core/iterators/user/ColumnSliceFilterTest.java |   3 +-
 .../accumulo/core/iterators/user/CombinerTest.java |  53 +-
 .../accumulo/core/iterators/user/FilterTest.java   |  27 +-
 .../core/iterators/user/GrepIteratorTest.java      |   3 +-
 .../iterators/user/IndexedDocIteratorTest.java     |  39 +-
 .../iterators/user/IntersectingIteratorTest.java   |  39 +-
 .../core/iterators/user/LargeRowFilterTest.java    |  27 +-
 .../iterators/user/RowDeletingIteratorTest.java    |  12 +-
 .../iterators/user/RowEncodingIteratorTest.java    |   9 +-
 .../core/iterators/user/RowFilterTest.java         |  12 +-
 .../core/iterators/user/TestCfCqSlice.java         |  81 ++-
 .../iterators/user/TransformingIteratorTest.java   | 102 ++-
 .../iterators/user/VersioningIteratorTest.java     |   3 +-
 .../core/iterators/user/VisibilityFilterTest.java  |  14 +-
 .../user/WholeColumnFamilyIteratorTest.java        |  53 +-
 .../core/iterators/user/WholeRowIteratorTest.java  |  44 +-
 .../core/metadata/MetadataServicerTest.java        |   3 +-
 .../ReplicationConfigurationUtilTest.java          |  20 +-
 .../rpc/SaslClientDigestCallbackHandlerTest.java   |   5 +-
 .../core/rpc/SaslConnectionParamsTest.java         | 121 ++--
 .../AuthenticationTokenIdentifierTest.java         |   6 +-
 .../core/security/AuthenticationTokenTest.java     |   6 +-
 .../accumulo/core/security/AuthorizationsTest.java |   3 +-
 .../core/security/ColumnVisibilityTest.java        |   6 +-
 .../accumulo/core/security/CredentialsTest.java    |  19 +-
 .../core/security/NamespacePermissionsTest.java    |   3 +-
 .../core/security/VisibilityConstraintTest.java    |   3 +-
 .../core/security/VisibilityEvaluatorTest.java     |  33 +-
 .../core/security/crypto/BlockedIOStreamTest.java  |   3 +-
 .../accumulo/core/security/crypto/CryptoTest.java  |  58 +-
 .../core/util/AsyncSocketAppenderTest.java         |   6 +-
 .../accumulo/core/util/ByteBufferUtilTest.java     |   6 +-
 .../accumulo/core/util/LocalityGroupUtilTest.java  |   3 +-
 .../org/apache/accumulo/core/util/MergeTest.java   |  12 +-
 .../org/apache/accumulo/core/util/OpTimerTest.java |  15 +-
 .../org/apache/accumulo/core/util/PairTest.java    |   3 +-
 .../apache/accumulo/core/util/PartitionerTest.java |   3 +-
 .../accumulo/core/util/PreAllocatedArrayTest.java  |   3 +-
 .../core/util/format/DateFormatSupplierTest.java   |   6 +-
 .../core/util/format/DefaultFormatterTest.java     |   9 +-
 .../core/util/format/FormatterFactoryTest.java     |   3 +-
 .../simple/client/CountingVerifyingReceiver.java   |   3 +-
 .../examples/simple/client/RandomBatchScanner.java |  26 +-
 .../examples/simple/client/RandomBatchWriter.java  |  30 +-
 .../examples/simple/client/ReadWriteExample.java   |  10 +-
 .../examples/simple/client/RowOperations.java      |  50 +-
 .../simple/client/SequentialBatchWriter.java       |  14 +-
 .../examples/simple/client/TraceDumpExample.java   |  12 +-
 .../examples/simple/client/TracingExample.java     |  21 +-
 .../examples/simple/combiner/StatsCombiner.java    |  17 +-
 .../simple/constraints/NumericValueConstraint.java |   6 +-
 .../examples/simple/dirlist/FileCount.java         |  25 +-
 .../accumulo/examples/simple/dirlist/Ingest.java   |  24 +-
 .../examples/simple/dirlist/QueryUtil.java         |  38 +-
 .../accumulo/examples/simple/dirlist/Viewer.java   |   9 +-
 .../simple/filedata/CharacterHistogram.java        |  11 +-
 .../examples/simple/filedata/ChunkCombiner.java    |  21 +-
 .../examples/simple/filedata/ChunkInputFormat.java |   8 +-
 .../examples/simple/filedata/ChunkInputStream.java |  21 +-
 .../examples/simple/filedata/FileDataIngest.java   |  27 +-
 .../examples/simple/filedata/FileDataQuery.java    |  10 +-
 .../simple/filedata/VisibilityCombiner.java        |   3 +-
 .../simple/helloworld/InsertWithBatchWriter.java   |  10 +-
 .../examples/simple/helloworld/ReadData.java       |   6 +-
 .../simple/isolation/InterferenceTest.java         |  14 +-
 .../examples/simple/mapreduce/NGramIngest.java     |   9 +-
 .../examples/simple/mapreduce/RegexExample.java    |   3 +-
 .../examples/simple/mapreduce/RowHash.java         |   3 +-
 .../examples/simple/mapreduce/TableToFile.java     |   3 +-
 .../examples/simple/mapreduce/TeraSortIngest.java  |  39 +-
 .../simple/mapreduce/TokenFileWordCount.java       |   9 +-
 .../examples/simple/mapreduce/UniqueColumns.java   |  18 +-
 .../examples/simple/mapreduce/WordCount.java       |   3 +-
 .../simple/mapreduce/bulk/BulkIngestExample.java   |  18 +-
 .../simple/mapreduce/bulk/GenerateTestData.java    |   3 +-
 .../simple/mapreduce/bulk/VerifyIngest.java        |   9 +-
 .../accumulo/examples/simple/reservations/ARS.java |  72 +-
 .../examples/simple/sample/SampleExample.java      |  32 +-
 .../examples/simple/shard/ContinuousQuery.java     |  11 +-
 .../simple/shard/CutoffIntersectingIterator.java   |  24 +-
 .../accumulo/examples/simple/shard/Index.java      |  15 +-
 .../accumulo/examples/simple/shard/Query.java      |  12 +-
 .../accumulo/examples/simple/shard/Reverse.java    |   5 +-
 .../constraints/AlphaNumKeyConstraintTest.java     |  13 +-
 .../constraints/NumericValueConstraintTest.java    |   6 +-
 .../simple/filedata/ChunkCombinerTest.java         |  21 +-
 .../simple/filedata/ChunkInputStreamTest.java      |  12 +-
 .../apache/accumulo/fate/AcceptableException.java  |  12 +-
 .../java/org/apache/accumulo/fate/AdminUtil.java   |  56 +-
 .../java/org/apache/accumulo/fate/AgeOffStore.java |   6 +-
 .../main/java/org/apache/accumulo/fate/Fate.java   |  21 +-
 .../org/apache/accumulo/fate/ReadOnlyRepo.java     |   4 +-
 .../org/apache/accumulo/fate/ReadOnlyStore.java    |   6 +-
 .../org/apache/accumulo/fate/ReadOnlyTStore.java   |  19 +-
 .../main/java/org/apache/accumulo/fate/TStore.java |   7 +-
 .../java/org/apache/accumulo/fate/ZooStore.java    |  27 +-
 .../org/apache/accumulo/fate/util/AddressUtil.java |  24 +-
 .../apache/accumulo/fate/util/LoggingRunnable.java |   9 +-
 .../java/org/apache/accumulo/fate/util/Retry.java  |  47 +-
 .../apache/accumulo/fate/util/UtilWaitThread.java  |   8 +-
 .../fate/zookeeper/DistributedReadWriteLock.java   |  20 +-
 .../apache/accumulo/fate/zookeeper/IZooReader.java |   9 +-
 .../accumulo/fate/zookeeper/IZooReaderWriter.java  |  24 +-
 .../apache/accumulo/fate/zookeeper/ZooCache.java   |  63 +-
 .../accumulo/fate/zookeeper/ZooCacheFactory.java   |   7 +-
 .../apache/accumulo/fate/zookeeper/ZooLock.java    |  52 +-
 .../accumulo/fate/zookeeper/ZooQueueLock.java      |   3 +-
 .../apache/accumulo/fate/zookeeper/ZooReader.java  |  42 +-
 .../accumulo/fate/zookeeper/ZooReaderWriter.java   |  46 +-
 .../accumulo/fate/zookeeper/ZooReservation.java    |  12 +-
 .../apache/accumulo/fate/zookeeper/ZooSession.java |  18 +-
 .../apache/accumulo/fate/zookeeper/ZooUtil.java    |  72 +-
 .../org/apache/accumulo/fate/AgeOffStoreTest.java  |  12 +-
 .../apache/accumulo/fate/ReadOnlyStoreTest.java    |   6 +-
 .../java/org/apache/accumulo/fate/SimpleStore.java |   6 +-
 .../apache/accumulo/fate/util/AddressUtilTest.java |  15 +-
 .../org/apache/accumulo/fate/util/RetryTest.java   |  29 +-
 .../accumulo/fate/zookeeper/ZooCacheTest.java      |  24 +-
 .../zookeeper/ZooKeeperConnectionInfoTest.java     |   7 +-
 .../fate/zookeeper/ZooReaderWriterTest.java        |  17 +-
 .../iteratortest/IteratorTestCaseFinder.java       |   9 +-
 .../accumulo/iteratortest/IteratorTestInput.java   |  29 +-
 .../accumulo/iteratortest/IteratorTestOutput.java  |  17 +-
 .../accumulo/iteratortest/IteratorTestReport.java  |   6 +-
 .../accumulo/iteratortest/IteratorTestRunner.java  |  14 +-
 .../accumulo/iteratortest/IteratorTestUtil.java    |   3 +-
 .../iteratortest/SimpleKVReusingIterator.java      |   9 +-
 .../environments/SimpleIteratorEnvironment.java    |   3 +-
 .../junit4/BaseJUnit4IteratorTest.java             |  12 +-
 .../testcases/InstantiationTestCase.java           |   3 +-
 .../testcases/IsolatedDeepCopiesTestCase.java      |  24 +-
 .../iteratortest/testcases/IteratorTestCase.java   |   7 +-
 .../testcases/MultipleHasTopCalls.java             |  13 +-
 .../testcases/OutputVerifyingTestCase.java         |   3 +-
 .../iteratortest/testcases/ReSeekTestCase.java     |  20 +-
 .../iteratortest/testcases/YieldingTestCase.java   |  24 +-
 .../iteratortest/framework/JUnitFrameworkTest.java |   9 +-
 .../maven/plugin/AbstractAccumuloMojo.java         |   6 +-
 .../apache/accumulo/maven/plugin/StartMojo.java    |  24 +-
 .../org/apache/accumulo/maven/plugin/StopMojo.java |   6 +-
 .../apache/accumulo/cluster/AccumuloCluster.java   |   6 +-
 .../apache/accumulo/cluster/ClusterControl.java    |   9 +-
 .../org/apache/accumulo/cluster/ClusterUser.java   |   6 +-
 .../org/apache/accumulo/cluster/ClusterUsers.java  |   3 +-
 .../org/apache/accumulo/cluster/RemoteShell.java   |  12 +-
 .../accumulo/cluster/RemoteShellOptions.java       |   5 +-
 .../standalone/StandaloneAccumuloCluster.java      |  29 +-
 .../standalone/StandaloneClusterControl.java       |  60 +-
 .../apache/accumulo/minicluster/MemoryUnit.java    |   5 +-
 .../accumulo/minicluster/MiniAccumuloCluster.java  |  18 +-
 .../accumulo/minicluster/MiniAccumuloConfig.java   |  18 +-
 .../accumulo/minicluster/MiniAccumuloInstance.java |  10 +-
 .../accumulo/minicluster/MiniAccumuloRunner.java   |  64 +-
 .../apache/accumulo/minicluster/ServerType.java    |   7 +-
 .../impl/MiniAccumuloClusterControl.java           |  16 +-
 .../minicluster/impl/MiniAccumuloClusterImpl.java  | 123 ++--
 .../minicluster/impl/MiniAccumuloConfigImpl.java   |  76 +-
 .../minicluster/impl/ProcessReference.java         |   3 +-
 .../minicluster/impl/ZooKeeperBindException.java   |   3 +-
 .../standalone/StandaloneAccumuloClusterTest.java  |   6 +-
 .../standalone/StandaloneClusterControlTest.java   |  14 +-
 .../MiniAccumuloClusterExistingZooKeepersTest.java |  13 +-
 .../MiniAccumuloClusterStartStopTest.java          |   3 +-
 .../minicluster/MiniAccumuloClusterTest.java       |  20 +-
 .../minicluster/impl/CleanShutdownMacTest.java     |   6 +-
 .../impl/MiniAccumuloClusterImplTest.java          |  18 +-
 .../impl/MiniAccumuloConfigImplTest.java           |  15 +-
 .../main/java/org/apache/accumulo/proxy/Proxy.java |  56 +-
 .../org/apache/accumulo/proxy/ProxyServer.java     | 772 ++++++++++++++-------
 .../main/java/org/apache/accumulo/proxy/Util.java  |  15 +-
 .../org/apache/accumulo/proxy/ProxyServerTest.java |   6 +-
 .../java/org/apache/accumulo/server/Accumulo.java  |  83 ++-
 .../accumulo/server/AccumuloServerContext.java     |  30 +-
 .../accumulo/server/GarbageCollectionLogger.java   |   9 +-
 .../apache/accumulo/server/ServerConstants.java    |  44 +-
 .../accumulo/server/client/BulkImporter.java       | 172 +++--
 .../server/client/ClientServiceHandler.java        | 178 +++--
 .../accumulo/server/client/HdfsZooInstance.java    |  27 +-
 .../accumulo/server/conf/NamespaceConfWatcher.java |  13 +-
 .../server/conf/NamespaceConfiguration.java        |   9 +-
 .../server/conf/ServerConfigurationFactory.java    |  21 +-
 .../accumulo/server/conf/TableConfWatcher.java     |  10 +-
 .../accumulo/server/conf/TableConfiguration.java   |  15 +-
 .../server/conf/ZooCachePropertyAccessor.java      |  15 +-
 .../accumulo/server/conf/ZooConfiguration.java     |   6 +-
 .../server/conf/ZooConfigurationFactory.java       |  15 +-
 .../server/constraints/MetadataConstraints.java    |  60 +-
 .../accumulo/server/data/ServerColumnUpdate.java   |   3 +-
 .../accumulo/server/data/ServerMutation.java       |   6 +-
 .../org/apache/accumulo/server/fs/FileRef.java     |   8 +-
 .../accumulo/server/fs/PerTableVolumeChooser.java  |  20 +-
 .../accumulo/server/fs/PreferredVolumeChooser.java |  26 +-
 .../org/apache/accumulo/server/fs/ViewFSUtils.java |   6 +-
 .../apache/accumulo/server/fs/VolumeChooser.java   |   4 +-
 .../apache/accumulo/server/fs/VolumeManager.java   |  18 +-
 .../accumulo/server/fs/VolumeManagerImpl.java      |  60 +-
 .../org/apache/accumulo/server/fs/VolumeUtil.java  |  57 +-
 .../apache/accumulo/server/init/Initialize.java    | 327 ++++++---
 .../server/iterators/MetadataBulkLoadFilter.java   |   3 +-
 .../apache/accumulo/server/log/SortedLogState.java |   5 +-
 .../accumulo/server/log/WalStateManager.java       |   6 +-
 .../accumulo/server/master/LiveTServerSet.java     |  81 ++-
 .../master/balancer/ChaoticLoadBalancer.java       |  22 +-
 .../master/balancer/DefaultLoadBalancer.java       |  33 +-
 .../server/master/balancer/GroupBalancer.java      |  93 ++-
 .../balancer/HostRegexTableLoadBalancer.java       | 130 ++--
 .../server/master/balancer/RegexGroupBalancer.java |  35 +-
 .../server/master/balancer/TableLoadBalancer.java  |  16 +-
 .../server/master/balancer/TabletBalancer.java     |  75 +-
 .../server/master/recovery/HadoopLogCloser.java    |   3 +-
 .../accumulo/server/master/state/CurrentState.java |   3 +-
 .../accumulo/server/master/state/MergeInfo.java    |   3 +-
 .../accumulo/server/master/state/MergeState.java   |   6 +-
 .../server/master/state/MetaDataStateStore.java    |  21 +-
 .../server/master/state/MetaDataTableScanner.java  |  20 +-
 .../server/master/state/RootTabletStateStore.java  |   3 +-
 .../server/master/state/TServerInstance.java       |   6 +-
 .../server/master/state/TabletLocationState.java   |  26 +-
 .../master/state/TabletStateChangeIterator.java    |   9 +-
 .../server/master/state/TabletStateStore.java      |  46 +-
 .../server/master/state/ZooTabletStateStore.java   |  21 +-
 .../master/tableOps/UserCompactionConfig.java      |   3 +-
 .../server/metrics/AbstractMetricsImpl.java        |  16 +-
 .../server/metrics/MetricsConfiguration.java       |  15 +-
 .../server/metrics/MetricsSystemHelper.java        |   3 +-
 .../accumulo/server/metrics/ThriftMetrics.java     |   3 +-
 .../accumulo/server/monitor/DedupedLogEvent.java   |   6 +-
 .../apache/accumulo/server/monitor/LogService.java |   6 +-
 .../accumulo/server/problems/ProblemReport.java    |  27 +-
 .../server/problems/ProblemReportingIterator.java  |  19 +-
 .../accumulo/server/problems/ProblemReports.java   |  34 +-
 .../DistributedWorkQueueWorkAssignerHelper.java    |  21 +-
 .../replication/PrintReplicationRecords.java       |   6 +-
 .../accumulo/server/replication/ReplicaSystem.java |   6 +-
 .../server/replication/ReplicaSystemFactory.java   |  15 +-
 .../server/replication/ReplicaSystemHelper.java    |  10 +-
 .../server/replication/ReplicationUtil.java        |  33 +-
 .../server/replication/StatusCombiner.java         |  20 +-
 .../server/replication/StatusFormatter.java        |  10 +-
 .../accumulo/server/replication/StatusUtil.java    |  15 +-
 .../replication/ZooKeeperInitialization.java       |   6 +-
 .../server/rpc/ClientInfoProcessorFactory.java     |   3 +-
 .../server/rpc/CustomNonBlockingServer.java        |  25 +-
 .../org/apache/accumulo/server/rpc/RpcWrapper.java |  36 +-
 .../server/rpc/SaslServerConnectionParams.java     |   9 +-
 .../rpc/SaslServerDigestCallbackHandler.java       |  12 +-
 .../rpc/TCredentialsUpdatingInvocationHandler.java |  67 +-
 .../server/rpc/TCredentialsUpdatingWrapper.java    |  13 +-
 .../apache/accumulo/server/rpc/TServerUtils.java   | 275 +++++---
 .../accumulo/server/rpc/ThriftServerType.java      |  10 +-
 .../apache/accumulo/server/rpc/TimedProcessor.java |   6 +-
 .../accumulo/server/rpc/UGIAssumingProcessor.java  |   6 +-
 .../server/security/AuditedSecurityOperation.java  | 174 +++--
 .../server/security/SecurityOperation.java         | 383 ++++++----
 .../accumulo/server/security/SecurityUtil.java     |  36 +-
 .../server/security/SystemCredentials.java         |  18 +-
 .../server/security/UserImpersonation.java         |  27 +-
 .../security/delegation/AuthenticationKey.java     |  12 +-
 .../delegation/AuthenticationTokenKeyManager.java  |  21 +-
 .../AuthenticationTokenSecretManager.java          |  36 +-
 .../ZooAuthenticationKeyDistributor.java           |  36 +-
 .../delegation/ZooAuthenticationKeyWatcher.java    |  24 +-
 .../server/security/handler/Authenticator.java     |  11 +-
 .../server/security/handler/Authorizor.java        |  14 +-
 .../security/handler/InsecureAuthenticator.java    |  14 +-
 .../security/handler/InsecurePermHandler.java      |  54 +-
 .../security/handler/KerberosAuthenticator.java    |  31 +-
 .../security/handler/KerberosAuthorizor.java       |  24 +-
 .../handler/KerberosPermissionHandler.java         |  91 ++-
 .../server/security/handler/PermissionHandler.java |  59 +-
 .../server/security/handler/ZKAuthenticator.java   |  29 +-
 .../server/security/handler/ZKAuthorizor.java      |  19 +-
 .../server/security/handler/ZKPermHandler.java     | 132 ++--
 .../server/security/handler/ZKSecurityTool.java    |  16 +-
 .../accumulo/server/tables/TableManager.java       | 165 +++--
 .../server/tablets/UniqueNameAllocator.java        |  26 +-
 .../tabletserver/LargestFirstMemoryManager.java    |  37 +-
 .../server/tabletserver/MemoryManager.java         |  14 +-
 .../accumulo/server/util/AccumuloStatus.java       |   3 +-
 .../org/apache/accumulo/server/util/Admin.java     |  96 ++-
 .../apache/accumulo/server/util/ChangeSecret.java  |  28 +-
 .../server/util/CheckForMetadataProblems.java      |  18 +-
 .../accumulo/server/util/CleanZookeeper.java       |  10 +-
 .../apache/accumulo/server/util/DefaultMap.java    |   3 +-
 .../apache/accumulo/server/util/DumpZookeeper.java |  12 +-
 .../accumulo/server/util/FileSystemMonitor.java    |   6 +-
 .../org/apache/accumulo/server/util/FileUtil.java  | 148 ++--
 .../accumulo/server/util/FindOfflineTablets.java   |  18 +-
 .../apache/accumulo/server/util/ListInstances.java |  23 +-
 .../accumulo/server/util/ListVolumesUsed.java      |  18 +-
 .../apache/accumulo/server/util/LocalityCheck.java |   9 +-
 .../accumulo/server/util/LoginProperties.java      |  12 +-
 .../accumulo/server/util/MasterMetadataUtil.java   |  94 ++-
 .../accumulo/server/util/MetadataTableUtil.java    | 282 +++++---
 .../accumulo/server/util/NamespacePropUtil.java    |  21 +-
 .../apache/accumulo/server/util/RandomWriter.java  |   6 +-
 .../accumulo/server/util/RandomizeVolumes.java     |  17 +-
 .../server/util/RemoveEntriesForMissingFiles.java  |  17 +-
 .../accumulo/server/util/ReplicationTableUtil.java |  27 +-
 .../accumulo/server/util/RestoreZookeeper.java     |   6 +-
 .../accumulo/server/util/SendLogToChainsaw.java    |  31 +-
 .../accumulo/server/util/SystemPropUtil.java       |  27 +-
 .../accumulo/server/util/TableDiskUsage.java       |  18 +-
 .../apache/accumulo/server/util/TableInfoUtil.java |   3 +-
 .../apache/accumulo/server/util/TablePropUtil.java |  18 +-
 .../accumulo/server/util/TabletIterator.java       |  32 +-
 .../accumulo/server/util/TabletServerLocks.java    |   3 +-
 .../server/util/VerifyTabletAssignments.java       |  22 +-
 .../apache/accumulo/server/util/ZooKeeperMain.java |  12 +-
 .../org/apache/accumulo/server/util/ZooZap.java    |   6 +-
 .../server/util/time/BaseRelativeTime.java         |   3 +-
 .../accumulo/server/util/time/SimpleTimer.java     |  21 +-
 .../server/watcher/Log4jConfiguration.java         |   9 +-
 .../server/watcher/MonitorLog4jWatcher.java        |   3 +-
 .../server/zookeeper/DistributedWorkQueue.java     |  21 +-
 .../server/zookeeper/TransactionWatcher.java       |  21 +-
 .../apache/accumulo/server/zookeeper/ZooLock.java  |   3 +-
 .../accumulo/server/zookeeper/ZooQueueLock.java    |   3 +-
 .../accumulo/server/zookeeper/ZooReaderWriter.java |   3 +-
 .../server/zookeeper/ZooReaderWriterFactory.java   |   6 +-
 .../accumulo/server/AccumuloServerContextTest.java |  42 +-
 .../org/apache/accumulo/server/AccumuloTest.java   |  15 +-
 .../accumulo/server/ServerConstantsTest.java       |  51 +-
 .../accumulo/server/client/BulkImporterTest.java   |  52 +-
 .../server/conf/NamespaceConfigurationTest.java    |  29 +-
 .../conf/ServerConfigurationFactoryTest.java       |   3 +-
 .../server/conf/TableConfigurationTest.java        |  24 +-
 .../constraints/MetadataConstraintsTest.java       |  72 +-
 .../org/apache/accumulo/server/fs/FileRefTest.java |  72 +-
 .../apache/accumulo/server/fs/FileTypeTest.java    |  75 +-
 .../apache/accumulo/server/fs/ViewFSUtilsTest.java |  41 +-
 .../accumulo/server/fs/VolumeManagerImplTest.java  |   9 +-
 .../apache/accumulo/server/fs/VolumeUtilTest.java  | 153 ++--
 .../accumulo/server/init/InitializeTest.java       |  12 +-
 .../iterators/MetadataBulkLoadFilterTest.java      |  31 +-
 .../accumulo/server/master/LiveTServerSetTest.java |   6 +-
 .../BaseHostRegexTableLoadBalancerTest.java        |  90 ++-
 .../master/balancer/ChaoticLoadBalancerTest.java   |  18 +-
 .../master/balancer/DefaultLoadBalancerTest.java   |  29 +-
 .../server/master/balancer/GroupBalancerTest.java  |  56 +-
 ...tRegexTableLoadBalancerReconfigurationTest.java |  24 +-
 .../balancer/HostRegexTableLoadBalancerTest.java   |  74 +-
 .../master/balancer/TableLoadBalancerTest.java     |  26 +-
 .../server/master/state/MergeInfoTest.java         |   3 +-
 .../server/problems/ProblemReportTest.java         |  36 +-
 .../server/replication/ReplicationUtilTest.java    |   6 +-
 .../server/replication/StatusCombinerTest.java     | 114 +--
 .../server/replication/StatusUtilTest.java         |  15 +-
 .../replication/ZooKeeperInitializationTest.java   |  12 +-
 .../apache/accumulo/server/rpc/RpcWrapperTest.java |  21 +-
 .../server/rpc/SaslDigestCallbackHandlerTest.java  |  15 +-
 .../server/rpc/SaslServerConnectionParamsTest.java |   3 +-
 .../TCredentialsUpdatingInvocationHandlerTest.java |  63 +-
 .../accumulo/server/rpc/ThriftServerTypeTest.java  |   3 +-
 .../server/security/SystemCredentialsTest.java     |  27 +-
 .../server/security/UserImpersonationTest.java     |  18 +-
 .../security/delegation/AuthenticationKeyTest.java |   9 +-
 .../AuthenticationTokenKeyManagerTest.java         |  32 +-
 .../AuthenticationTokenSecretManagerTest.java      |  99 ++-
 .../ZooAuthenticationKeyDistributorTest.java       |  74 +-
 .../ZooAuthenticationKeyWatcherTest.java           |  68 +-
 .../security/handler/ZKAuthenticatorTest.java      |   6 +-
 .../IllegalTableTransitionExceptionTest.java       |   6 +-
 .../org/apache/accumulo/server/util/AdminTest.java |  23 +-
 .../accumulo/server/util/DefaultMapTest.java       |   3 +-
 .../server/util/FileSystemMonitorTest.java         |  33 +-
 .../apache/accumulo/server/util/FileUtilTest.java  |  15 +-
 .../server/util/ReplicationTableUtilTest.java      |  21 +-
 .../accumulo/server/util/TServerUtilsTest.java     |  41 +-
 .../server/util/time/BaseRelativeTimeTest.java     |   3 +-
 .../accumulo/gc/GarbageCollectWriteAheadLogs.java  |  43 +-
 .../accumulo/gc/GarbageCollectionAlgorithm.java    |  60 +-
 .../accumulo/gc/GarbageCollectionEnvironment.java  |  37 +-
 .../apache/accumulo/gc/SimpleGarbageCollector.java | 154 ++--
 .../replication/CloseWriteAheadLogReferences.java  |  30 +-
 .../gc/GarbageCollectWriteAheadLogsTest.java       |  60 +-
 .../apache/accumulo/gc/GarbageCollectionTest.java  |  47 +-
 .../accumulo/gc/SimpleGarbageCollectorTest.java    |  30 +-
 .../apache/accumulo/master/FateServiceHandler.java | 248 ++++---
 .../java/org/apache/accumulo/master/Master.java    | 313 ++++++---
 .../master/MasterClientServiceHandler.java         | 152 ++--
 .../org/apache/accumulo/master/MasterTime.java     |  21 +-
 .../apache/accumulo/master/TabletGroupWatcher.java | 150 ++--
 .../master/metrics/Metrics2ReplicationMetrics.java |  23 +-
 .../master/metrics/ReplicationMetrics.java         |   4 +-
 .../master/metrics/ReplicationMetricsMBean.java    |  14 +-
 .../accumulo/master/recovery/RecoveryManager.java  |  34 +-
 .../DistributedWorkQueueWorkAssigner.java          |  31 +-
 .../master/replication/FinishedWorkUpdater.java    |  32 +-
 .../replication/MasterReplicationCoordinator.java  |  23 +-
 .../RemoveCompleteReplicationRecords.java          |  30 +-
 .../master/replication/ReplicationDriver.java      |   6 +-
 .../master/replication/SequentialWorkAssigner.java |  30 +-
 .../accumulo/master/replication/StatusMaker.java   |  34 +-
 .../master/replication/UnorderedWorkAssigner.java  |  26 +-
 .../accumulo/master/replication/WorkMaker.java     |   9 +-
 .../apache/accumulo/master/state/MergeStats.java   |  55 +-
 .../apache/accumulo/master/state/SetGoalState.java |   8 +-
 .../accumulo/master/tableOps/BulkImport.java       |  31 +-
 .../master/tableOps/CancelCompactions.java         |  13 +-
 .../accumulo/master/tableOps/ChangeTableState.java |   9 +-
 .../apache/accumulo/master/tableOps/ChooseDir.java |   6 +-
 .../apache/accumulo/master/tableOps/CleanUp.java   |  27 +-
 .../master/tableOps/CleanUpBulkImport.java         |   3 +-
 .../accumulo/master/tableOps/CloneMetadata.java    |  14 +-
 .../accumulo/master/tableOps/ClonePermissions.java |   9 +-
 .../accumulo/master/tableOps/CloneTable.java       |   6 +-
 .../accumulo/master/tableOps/CloneZookeeper.java   |   9 +-
 .../accumulo/master/tableOps/CompactRange.java     |  39 +-
 .../accumulo/master/tableOps/CompactionDriver.java |  28 +-
 .../accumulo/master/tableOps/CopyFailed.java       |  16 +-
 .../accumulo/master/tableOps/CreateImportDir.java  |   3 +-
 .../accumulo/master/tableOps/CreateNamespace.java  |   3 +-
 .../accumulo/master/tableOps/CreateTable.java      |   3 +-
 .../accumulo/master/tableOps/DeleteTable.java      |   3 +-
 .../accumulo/master/tableOps/ExportTable.java      |   3 +-
 .../master/tableOps/FinishCancelCompaction.java    |   3 +-
 .../accumulo/master/tableOps/FinishCloneTable.java |   9 +-
 .../master/tableOps/FinishCreateNamespace.java     |   3 +-
 .../master/tableOps/FinishCreateTable.java         |   3 +-
 .../master/tableOps/FinishImportTable.java         |   3 +-
 .../master/tableOps/ImportPopulateZookeeper.java   |  12 +-
 .../master/tableOps/ImportSetupPermissions.java    |   6 +-
 .../accumulo/master/tableOps/ImportTable.java      |   9 +-
 .../apache/accumulo/master/tableOps/LoadFiles.java |  18 +-
 .../master/tableOps/MapImportFileNames.java        |   3 +-
 .../master/tableOps/MoveExportedFiles.java         |   6 +-
 .../accumulo/master/tableOps/PopulateMetadata.java |   6 +-
 .../master/tableOps/PopulateMetadataTable.java     |  46 +-
 .../master/tableOps/PopulateZookeeper.java         |   6 +-
 .../tableOps/PopulateZookeeperWithNamespace.java   |  12 +-
 .../accumulo/master/tableOps/RenameNamespace.java  |  10 +-
 .../accumulo/master/tableOps/RenameTable.java      |  21 +-
 .../master/tableOps/SetupNamespacePermissions.java |   3 +-
 .../accumulo/master/tableOps/SetupPermissions.java |   6 +-
 .../accumulo/master/tableOps/TableRangeOp.java     |  10 +-
 .../accumulo/master/tableOps/TableRangeOpWait.java |  22 +-
 .../org/apache/accumulo/master/tableOps/Utils.java |  75 +-
 .../accumulo/master/tableOps/WriteExportFiles.java |  59 +-
 .../master/tserverOps/ShutdownTServer.java         |   6 +-
 .../org/apache/accumulo/master/util/FateAdmin.java |   4 +-
 .../accumulo/master/util/TableValidators.java      |  10 +-
 .../metrics/Metrics2ReplicationMetricsTest.java    |   3 +-
 ...DistributedWorkQueueWorkAssignerHelperTest.java |   3 +-
 .../replication/SequentialWorkAssignerTest.java    |  24 +-
 .../replication/UnorderedWorkAssignerTest.java     |  20 +-
 .../accumulo/master/replication/WorkMakerTest.java |   6 +-
 .../master/state/RootTabletStateStoreTest.java     |   3 +-
 .../accumulo/master/tableOps/ImportTableTest.java  |   9 +-
 .../apache/accumulo/monitor/EmbeddedWebServer.java |   9 +-
 .../java/org/apache/accumulo/monitor/Monitor.java  |  85 ++-
 .../apache/accumulo/monitor/ZooKeeperStatus.java   |   6 +-
 .../accumulo/monitor/servlets/BasicServlet.java    |  77 +-
 .../monitor/servlets/BulkImportServlet.java        |  12 +-
 .../accumulo/monitor/servlets/DefaultServlet.java  |  47 +-
 .../accumulo/monitor/servlets/GcStatusServlet.java |  23 +-
 .../accumulo/monitor/servlets/JSONServlet.java     |  12 +-
 .../accumulo/monitor/servlets/LogServlet.java      |  13 +-
 .../accumulo/monitor/servlets/MasterServlet.java   |  77 +-
 .../monitor/servlets/OperationServlet.java         |  18 +-
 .../accumulo/monitor/servlets/ProblemServlet.java  |  34 +-
 .../monitor/servlets/ReplicationServlet.java       |  28 +-
 .../accumulo/monitor/servlets/ScanServlet.java     |   9 +-
 .../accumulo/monitor/servlets/ShellServlet.java    |  30 +-
 .../accumulo/monitor/servlets/TServersServlet.java | 146 ++--
 .../accumulo/monitor/servlets/TablesServlet.java   |  55 +-
 .../accumulo/monitor/servlets/VisServlet.java      |  53 +-
 .../accumulo/monitor/servlets/XMLServlet.java      |  32 +-
 .../accumulo/monitor/servlets/trace/Basic.java     |  21 +-
 .../accumulo/monitor/servlets/trace/ListType.java  |   6 +-
 .../accumulo/monitor/servlets/trace/ShowTrace.java |  25 +-
 .../monitor/servlets/trace/ShowTraceLinkType.java  |   3 +-
 .../accumulo/monitor/servlets/trace/Summary.java   |  13 +-
 .../org/apache/accumulo/monitor/util/Table.java    |  41 +-
 .../monitor/util/celltypes/CompactionsType.java    |   3 +-
 .../monitor/util/celltypes/DateTimeType.java       |   3 +-
 .../monitor/util/celltypes/NumberType.java         |  12 +-
 .../monitor/util/celltypes/TableLinkType.java      |   3 +-
 .../accumulo/monitor/ShowTraceLinkTypeTest.java    |   3 +-
 .../accumulo/monitor/ZooKeeperStatusTest.java      |   3 +-
 .../apache/accumulo/tracer/AsyncSpanReceiver.java  |   6 +-
 .../apache/accumulo/tracer/SendSpansViaThrift.java |   3 +-
 .../java/org/apache/accumulo/tracer/SpanTree.java  |   3 +-
 .../java/org/apache/accumulo/tracer/TraceDump.java |  19 +-
 .../org/apache/accumulo/tracer/TraceFormatter.java |   6 +-
 .../org/apache/accumulo/tracer/TraceServer.java    |  89 ++-
 .../apache/accumulo/tracer/TraceTableStats.java    |  17 +-
 .../org/apache/accumulo/tracer/ZooTraceClient.java |   6 +-
 .../accumulo/tracer/AsyncSpanReceiverTest.java     |   9 +-
 .../org/apache/accumulo/tracer/TracerTest.java     |  16 +-
 .../apache/accumulo/tracer/ZooTraceClientTest.java |  12 +-
 .../accumulo/tserver/ActiveAssignmentRunnable.java |   9 +-
 .../apache/accumulo/tserver/CompactionQueue.java   |   6 +-
 .../accumulo/tserver/ConditionCheckerContext.java  |  30 +-
 .../accumulo/tserver/ConditionalMutationSet.java   |  15 +-
 .../org/apache/accumulo/tserver/FileManager.java   |  59 +-
 .../org/apache/accumulo/tserver/InMemoryMap.java   |  79 ++-
 .../java/org/apache/accumulo/tserver/MemKey.java   |   3 +-
 .../accumulo/tserver/MemKeyConversionIterator.java |   3 +-
 .../java/org/apache/accumulo/tserver/MemValue.java |   3 +-
 .../org/apache/accumulo/tserver/NativeMap.java     |  93 ++-
 .../java/org/apache/accumulo/tserver/RowLocks.java |   6 +-
 .../tserver/TConstraintViolationException.java     |   3 +-
 .../tserver/TabletIteratorEnvironment.java         |  32 +-
 .../org/apache/accumulo/tserver/TabletServer.java  | 749 +++++++++++++-------
 .../tserver/TabletServerResourceManager.java       | 107 ++-
 .../accumulo/tserver/TservConstraintEnv.java       |   3 +-
 .../org/apache/accumulo/tserver/WriteTracker.java  |   7 +-
 .../tserver/compaction/CompactionPlan.java         |   7 +-
 .../tserver/compaction/CompactionStrategy.java     |  49 +-
 .../compaction/DefaultCompactionStrategy.java      |   3 +-
 .../compaction/EverythingCompactionStrategy.java   |   3 +-
 .../tserver/compaction/MajorCompactionReason.java  |   5 +-
 .../tserver/compaction/MajorCompactionRequest.java |   6 +-
 .../strategies/ConfigurableCompactionStrategy.java |  24 +-
 .../tserver/constraints/ConstraintChecker.java     |  15 +-
 .../tserver/data/ServerConditionalMutation.java    |   3 +-
 .../org/apache/accumulo/tserver/log/DfsLogger.java |  92 ++-
 .../org/apache/accumulo/tserver/log/LogSorter.java |  22 +-
 .../apache/accumulo/tserver/log/MultiReader.java   |   8 +-
 .../accumulo/tserver/log/SortedLogRecovery.java    |  41 +-
 .../accumulo/tserver/log/TabletServerLogger.java   |  69 +-
 .../apache/accumulo/tserver/logger/LogEvents.java  |   7 +-
 .../apache/accumulo/tserver/logger/LogFileKey.java |   6 +-
 .../accumulo/tserver/logger/LogFileValue.java      |   8 +-
 .../apache/accumulo/tserver/logger/LogReader.java  |   6 +-
 .../tserver/mastermessage/MasterMessage.java       |   3 +-
 .../tserver/mastermessage/SplitReportMessage.java  |   6 +-
 .../tserver/mastermessage/TabletStatusMessage.java |   3 +-
 .../metrics/Metrics2TabletServerMetrics.java       |  46 +-
 .../metrics/Metrics2TabletServerMinCMetrics.java   |   6 +-
 .../metrics/Metrics2TabletServerScanMetrics.java   |   6 +-
 .../metrics/Metrics2TabletServerUpdateMetrics.java |  30 +-
 .../tserver/metrics/TabletServerMBeanImpl.java     |   4 +-
 .../metrics/TabletServerMetricsFactory.java        |   3 +-
 .../tserver/metrics/TabletServerMinCMetrics.java   |  10 +-
 .../tserver/metrics/TabletServerScanMetrics.java   |  10 +-
 .../tserver/metrics/TabletServerUpdateMetrics.java |  11 +-
 .../tserver/replication/AccumuloReplicaSystem.java | 211 ++++--
 .../BatchWriterReplicationReplayer.java            |  41 +-
 .../tserver/replication/ReplicationProcessor.java  |  21 +-
 .../replication/ReplicationServicerHandler.java    |  23 +-
 .../tserver/replication/ReplicationWorker.java     |   9 +-
 .../apache/accumulo/tserver/scan/LookupTask.java   |  24 +-
 .../accumulo/tserver/scan/NextBatchTask.java       |  17 +-
 .../org/apache/accumulo/tserver/scan/ScanTask.java |   9 +-
 .../tserver/session/ConditionalSession.java        |   3 +-
 .../accumulo/tserver/session/MultiScanSession.java |   6 +-
 .../accumulo/tserver/session/ScanSession.java      |   5 +-
 .../accumulo/tserver/session/SessionManager.java   |  31 +-
 .../tserver/tablet/BulkImportCacheCleaner.java     |   3 +-
 .../accumulo/tserver/tablet/CompactionInfo.java    |   9 +-
 .../accumulo/tserver/tablet/CompactionRunner.java  |   3 +-
 .../accumulo/tserver/tablet/CompactionWatcher.java |  14 +-
 .../apache/accumulo/tserver/tablet/Compactor.java  |  50 +-
 .../accumulo/tserver/tablet/CountingIterator.java  |   3 +-
 .../accumulo/tserver/tablet/DatafileManager.java   | 117 ++--
 .../tserver/tablet/MinorCompactionTask.java        |  23 +-
 .../accumulo/tserver/tablet/MinorCompactor.java    |  68 +-
 .../apache/accumulo/tserver/tablet/RootFiles.java  |  30 +-
 .../accumulo/tserver/tablet/ScanDataSource.java    |  53 +-
 .../accumulo/tserver/tablet/ScanOptions.java       |   6 +-
 .../apache/accumulo/tserver/tablet/Scanner.java    |  22 +-
 .../org/apache/accumulo/tserver/tablet/Tablet.java | 552 +++++++++------
 .../apache/accumulo/tserver/tablet/TabletData.java |  13 +-
 .../accumulo/tserver/tablet/TabletMemory.java      |   3 +-
 .../accumulo/tserver/CheckTabletMetadataTest.java  |  24 +-
 .../apache/accumulo/tserver/InMemoryMapTest.java   |  55 +-
 .../tserver/LargestFirstMemoryManagerTest.java     |  82 ++-
 .../tserver/TabletServerSyncCheckTest.java         |  12 +-
 .../accumulo/tserver/TservConstraintEnvTest.java   |   9 +-
 .../compaction/DefaultCompactionStrategyTest.java  |  24 +-
 .../SizeLimitCompactionStrategyTest.java           |  12 +-
 .../ConfigurableCompactionStrategyTest.java        |  15 +-
 .../apache/accumulo/tserver/log/DfsLoggerTest.java |  21 +-
 .../accumulo/tserver/log/MultiReaderTest.java      |   8 +-
 .../tserver/log/SortedLogRecoveryTest.java         | 215 ++++--
 .../tserver/log/TestUpgradePathForWALogs.java      |  16 +-
 .../accumulo/tserver/logger/LogFileTest.java       |  11 +-
 .../replication/AccumuloReplicaSystemTest.java     |  66 +-
 .../BatchWriterReplicationReplayerTest.java        |   6 +-
 .../replication/ReplicationProcessorTest.java      |   6 +-
 .../tserver/tablet/DatafileManagerTest.java        |  27 +-
 .../accumulo/tserver/tablet/RootFilesTest.java     |  12 +-
 .../apache/accumulo/tserver/tablet/TabletTest.java |  12 +-
 .../main/java/org/apache/accumulo/shell/Shell.java | 239 ++++---
 .../org/apache/accumulo/shell/ShellCompletor.java  |   3 +-
 .../org/apache/accumulo/shell/ShellOptionsJC.java  |  60 +-
 .../java/org/apache/accumulo/shell/ShellUtil.java  |   6 +-
 .../accumulo/shell/commands/AboutCommand.java      |   3 +-
 .../shell/commands/ActiveCompactionIterator.java   |  15 +-
 .../shell/commands/ActiveScanIterator.java         |  15 +-
 .../accumulo/shell/commands/AddAuthsCommand.java   |  12 +-
 .../accumulo/shell/commands/AddSplitsCommand.java  |   9 +-
 .../shell/commands/AuthenticateCommand.java        |   9 +-
 .../shell/commands/BulkImportListIterator.java     |   3 +-
 .../accumulo/shell/commands/ClearCommand.java      |   3 +-
 .../accumulo/shell/commands/CloneTableCommand.java |  20 +-
 .../accumulo/shell/commands/CompactCommand.java    |  47 +-
 .../accumulo/shell/commands/ConfigCommand.java     |  76 +-
 .../accumulo/shell/commands/ConstraintCommand.java |  40 +-
 .../shell/commands/CreateNamespaceCommand.java     |  12 +-
 .../shell/commands/CreateTableCommand.java         |  48 +-
 .../accumulo/shell/commands/CreateUserCommand.java |  11 +-
 .../apache/accumulo/shell/commands/DUCommand.java  |  19 +-
 .../accumulo/shell/commands/DebugCommand.java      |  12 +-
 .../shell/commands/DeleteAuthsCommand.java         |   9 +-
 .../accumulo/shell/commands/DeleteCommand.java     |   8 +-
 .../accumulo/shell/commands/DeleteIterCommand.java |  27 +-
 .../accumulo/shell/commands/DeleteManyCommand.java |  14 +-
 .../shell/commands/DeleteNamespaceCommand.java     |  12 +-
 .../accumulo/shell/commands/DeleteRowsCommand.java |   9 +-
 .../shell/commands/DeleteScanIterCommand.java      |  15 +-
 .../shell/commands/DeleteShellIterCommand.java     |   6 +-
 .../shell/commands/DeleteTableCommand.java         |   3 +-
 .../accumulo/shell/commands/DropUserCommand.java   |  12 +-
 .../accumulo/shell/commands/EGrepCommand.java      |   9 +-
 .../accumulo/shell/commands/ExecfileCommand.java   |   6 +-
 .../shell/commands/ExportTableCommand.java         |   8 +-
 .../accumulo/shell/commands/FateCommand.java       |  28 +-
 .../accumulo/shell/commands/FlushCommand.java      |   6 +-
 .../accumulo/shell/commands/FormatterCommand.java  |  19 +-
 .../accumulo/shell/commands/GetAuthsCommand.java   |   6 +-
 .../accumulo/shell/commands/GetGroupsCommand.java  |   9 +-
 .../accumulo/shell/commands/GetSplitsCommand.java  |  33 +-
 .../accumulo/shell/commands/GrantCommand.java      |  37 +-
 .../accumulo/shell/commands/GrepCommand.java       |  12 +-
 .../accumulo/shell/commands/HelpCommand.java       |  21 +-
 .../accumulo/shell/commands/HiddenCommand.java     |  11 +-
 .../accumulo/shell/commands/HistoryCommand.java    |   3 +-
 .../shell/commands/ImportDirectoryCommand.java     |   7 +-
 .../shell/commands/ImportTableCommand.java         |   5 +-
 .../accumulo/shell/commands/InsertCommand.java     |  17 +-
 .../shell/commands/InterpreterCommand.java         |   6 +-
 .../accumulo/shell/commands/ListBulkCommand.java   |   6 +-
 .../shell/commands/ListCompactionsCommand.java     |   3 +-
 .../accumulo/shell/commands/ListIterCommand.java   |  39 +-
 .../accumulo/shell/commands/ListScansCommand.java  |   3 +-
 .../shell/commands/ListShellIterCommand.java       |  12 +-
 .../accumulo/shell/commands/MaxRowCommand.java     |   7 +-
 .../accumulo/shell/commands/MergeCommand.java      |  15 +-
 .../commands/NamespacePermissionsCommand.java      |   3 +-
 .../accumulo/shell/commands/NamespacesCommand.java |  36 +-
 .../accumulo/shell/commands/NoTableCommand.java    |   3 +-
 .../accumulo/shell/commands/OfflineCommand.java    |   6 +-
 .../accumulo/shell/commands/OnlineCommand.java     |   6 +-
 .../apache/accumulo/shell/commands/OptUtil.java    |  16 +-
 .../accumulo/shell/commands/PasswdCommand.java     |  15 +-
 .../accumulo/shell/commands/PingCommand.java       |   3 +-
 .../shell/commands/QuotedStringTokenizer.java      |  13 +-
 .../shell/commands/RenameNamespaceCommand.java     |   8 +-
 .../shell/commands/RenameTableCommand.java         |   8 +-
 .../accumulo/shell/commands/RevokeCommand.java     |  37 +-
 .../accumulo/shell/commands/ScanCommand.java       | 130 ++--
 .../accumulo/shell/commands/ScriptCommand.java     |   6 +-
 .../accumulo/shell/commands/SetAuthsCommand.java   |  12 +-
 .../accumulo/shell/commands/SetGroupsCommand.java  |   3 +-
 .../accumulo/shell/commands/SetIterCommand.java    |  98 ++-
 .../shell/commands/SetScanIterCommand.java         |  18 +-
 .../shell/commands/SetShellIterCommand.java        |  11 +-
 .../commands/ShellPluginConfigurationCommand.java  |  40 +-
 .../accumulo/shell/commands/SleepCommand.java      |   3 +-
 .../shell/commands/SystemPermissionsCommand.java   |   3 +-
 .../accumulo/shell/commands/TableCommand.java      |   7 +-
 .../accumulo/shell/commands/TableOperation.java    |  21 +-
 .../shell/commands/TablePermissionsCommand.java    |   3 +-
 .../accumulo/shell/commands/TablesCommand.java     |  38 +-
 .../accumulo/shell/commands/TraceCommand.java      |  15 +-
 .../accumulo/shell/commands/UserCommand.java       |   6 +-
 .../shell/commands/UserPermissionsCommand.java     |  12 +-
 .../accumulo/shell/commands/UsersCommand.java      |   3 +-
 .../accumulo/shell/commands/WhoAmICommand.java     |   3 +-
 .../accumulo/shell/format/DeleterFormatter.java    |   9 +-
 .../org/apache/accumulo/shell/mock/MockShell.java  |   8 +-
 .../org/apache/accumulo/shell/ShellConfigTest.java |  14 +-
 .../accumulo/shell/ShellSetInstanceTest.java       |  40 +-
 .../java/org/apache/accumulo/shell/ShellTest.java  |  43 +-
 .../org/apache/accumulo/shell/ShellUtilTest.java   |   6 +-
 .../shell/commands/CompactCommandTest.java         |   3 +-
 .../shell/commands/DeleteAuthsCommandTest.java     |   9 +-
 .../shell/commands/DeleteManyCommandTest.java      |   3 +-
 .../shell/commands/DeleteRowsCommandTest.java      |   3 +-
 .../shell/commands/DeleteTableCommandTest.java     |   3 +-
 .../accumulo/shell/commands/FlushCommandTest.java  |   3 +-
 .../shell/commands/HistoryCommandTest.java         |   6 +-
 .../accumulo/shell/commands/MergeCommandTest.java  |   3 +-
 .../accumulo/shell/commands/ScanCommandTest.java   |   3 +-
 .../shell/commands/SetIterCommandTest.java         |  24 +-
 .../shell/format/DeleterFormatterTest.java         |  18 +-
 .../main/java/org/apache/accumulo/start/Main.java  |  51 +-
 .../java/org/apache/accumulo/start/TestMain.java   |   5 +-
 .../start/classloader/AccumuloClassLoader.java     |  34 +-
 .../vfs/AccumuloReloadingVFSClassLoader.java       |  17 +-
 .../classloader/vfs/AccumuloVFSClassLoader.java    |  54 +-
 .../start/classloader/vfs/ContextManager.java      |   9 +-
 .../vfs/PostDelegatingVFSClassLoader.java          |   6 +-
 .../classloader/vfs/UniqueFileReplicator.java      |   3 +-
 .../accumulo/start/spi/KeywordExecutable.java      |  18 +-
 .../vfs/AccumuloReloadingVFSClassLoaderTest.java   |  76 +-
 .../vfs/AccumuloVFSClassLoaderTest.java            |  45 +-
 .../start/classloader/vfs/ContextManagerTest.java  |  12 +-
 .../accumulo/start/test/AccumuloDFSBase.java       |  10 +-
 .../accumulo/harness/AccumuloClusterHarness.java   |  74 +-
 .../apache/accumulo/harness/AccumuloITBase.java    |  28 +-
 .../harness/MiniClusterConfigurationCallback.java  |   3 +-
 .../accumulo/harness/MiniClusterHarness.java       | 108 ++-
 .../accumulo/harness/SharedMiniClusterBase.java    |  55 +-
 .../org/apache/accumulo/harness/TestingKdc.java    |   9 +-
 .../conf/AccumuloClusterPropertyConfiguration.java |  18 +-
 .../conf/AccumuloMiniClusterConfiguration.java     |   6 +-
 .../StandaloneAccumuloClusterConfiguration.java    |  51 +-
 .../accumulo/test/ArbitraryTablePropertiesIT.java  |  12 +-
 .../org/apache/accumulo/test/AuditMessageIT.java   | 256 ++++---
 .../accumulo/test/BadDeleteMarkersCreatedIT.java   |   6 +-
 .../accumulo/test/BatchWriterInTabletServerIT.java |  16 +-
 .../apache/accumulo/test/BatchWriterIterator.java  |  50 +-
 .../apache/accumulo/test/BulkImportDirectory.java  |  15 +-
 .../accumulo/test/BulkImportMonitoringIT.java      |   6 +-
 .../accumulo/test/BulkImportSequentialRowsIT.java  |  12 +-
 .../java/org/apache/accumulo/test/CleanWalIT.java  |   6 +-
 .../apache/accumulo/test/ClientSideIteratorIT.java |   6 +-
 .../java/org/apache/accumulo/test/CloneIT.java     |  30 +-
 .../accumulo/test/CompactionRateLimitingIT.java    |  10 +-
 .../apache/accumulo/test/ConditionalWriterIT.java  | 303 +++++---
 .../test/ConfigurableMajorCompactionIT.java        |   3 +-
 .../org/apache/accumulo/test/CreateRFiles.java     |  11 +-
 .../apache/accumulo/test/CreateRandomRFile.java    |   3 +-
 .../test/CreateTableWithNewTableConfigIT.java      |  25 +-
 .../accumulo/test/DetectDeadTabletServersIT.java   |   3 +-
 .../org/apache/accumulo/test/DumpConfigIT.java     |  10 +-
 .../accumulo/test/EstimateInMemMapOverhead.java    |   6 +-
 .../org/apache/accumulo/test/ExistingMacIT.java    |  19 +-
 .../accumulo/test/FaultyConditionalWriter.java     |   6 +-
 .../org/apache/accumulo/test/FileArchiveIT.java    |  33 +-
 .../java/org/apache/accumulo/test/FindMaxIT.java   |  30 +-
 .../apache/accumulo/test/GarbageCollectWALIT.java  |   3 +-
 .../accumulo/test/GenerateSequentialRFile.java     |   6 +-
 .../apache/accumulo/test/GetFileInfoBulkIT.java    |   3 +-
 .../org/apache/accumulo/test/GetMasterStats.java   |   3 +-
 .../org/apache/accumulo/test/HardListIterator.java |  30 +-
 .../org/apache/accumulo/test/IMMLGBenchmark.java   |  19 +-
 .../org/apache/accumulo/test/ImportExportIT.java   |  27 +-
 .../org/apache/accumulo/test/InMemoryMapIT.java    |  81 ++-
 .../accumulo/test/InMemoryMapMemoryUsageTest.java  |   3 +-
 .../accumulo/test/InterruptibleScannersIT.java     |   6 +-
 .../accumulo/test/IsolationAndDeepCopyIT.java      |   9 +-
 .../apache/accumulo/test/KeyValueEqualityIT.java   |  10 +-
 .../org/apache/accumulo/test/LargeSplitRowIT.java  |  48 +-
 .../java/org/apache/accumulo/test/LocatorIT.java   |  16 +-
 .../java/org/apache/accumulo/test/ManySplitIT.java |   3 +-
 .../test/MasterRepairsDualAssignmentIT.java        |   9 +-
 .../org/apache/accumulo/test/MemoryUsageTest.java  |   8 +-
 .../accumulo/test/MetaConstraintRetryIT.java       |   6 +-
 .../apache/accumulo/test/MetaGetsReadersIT.java    |   3 +-
 .../java/org/apache/accumulo/test/MetaSplitIT.java |   9 +-
 .../test/MissingWalHeaderCompletesRecoveryIT.java  |  33 +-
 .../accumulo/test/MultiTableBatchWriterIT.java     |  15 +-
 .../apache/accumulo/test/MultiTableRecoveryIT.java |   3 +-
 .../org/apache/accumulo/test/NamespacesIT.java     | 164 +++--
 .../accumulo/test/NativeMapConcurrencyTest.java    |   9 +-
 .../accumulo/test/NativeMapPerformanceTest.java    |  18 +-
 .../apache/accumulo/test/NativeMapStressTest.java  |  29 +-
 .../org/apache/accumulo/test/NullBatchWriter.java  |   3 +-
 .../org/apache/accumulo/test/OrIteratorIT.java     |  21 +-
 .../apache/accumulo/test/QueryMetadataTable.java   |   6 +-
 .../accumulo/test/RewriteTabletDirectoriesIT.java  |  24 +-
 .../java/org/apache/accumulo/test/SampleIT.java    |  53 +-
 .../org/apache/accumulo/test/ShellConfigIT.java    |  18 +-
 .../org/apache/accumulo/test/ShellServerIT.java    | 217 +++---
 .../org/apache/accumulo/test/SplitRecoveryIT.java  |   9 +-
 .../accumulo/test/TableConfigurationUpdateIT.java  |  10 +-
 .../apache/accumulo/test/TableOperationsIT.java    |  50 +-
 .../org/apache/accumulo/test/TestBinaryRows.java   |  37 +-
 .../java/org/apache/accumulo/test/TestIngest.java  |  49 +-
 .../apache/accumulo/test/TestMultiTableIngest.java |   9 +-
 .../apache/accumulo/test/TestRandomDeletes.java    |  19 +-
 .../apache/accumulo/test/TextMemoryUsageTest.java  |   4 +-
 .../org/apache/accumulo/test/TotalQueuedIT.java    |  17 +-
 .../test/TracerRecoversAfterOfflineTableIT.java    |   3 +-
 .../apache/accumulo/test/TransportCachingIT.java   |  12 +-
 .../java/org/apache/accumulo/test/UnusedWALIT.java |   6 +-
 .../accumulo/test/UserCompactionStrategyIT.java    |  57 +-
 .../java/org/apache/accumulo/test/UsersIT.java     |   9 +-
 .../org/apache/accumulo/test/VerifyIngest.java     |  39 +-
 .../accumulo/test/VerifySerialRecoveryIT.java      |   3 +-
 .../org/apache/accumulo/test/VolumeChooserIT.java  |  54 +-
 .../java/org/apache/accumulo/test/VolumeIT.java    |  77 +-
 .../org/apache/accumulo/test/WaitForBalanceIT.java |   9 +-
 .../org/apache/accumulo/test/WrongTabletTest.java  |   3 +-
 .../org/apache/accumulo/test/YieldScannersIT.java  |  30 +-
 .../test/categories/MiniClusterOnlyTests.java      |   3 +-
 .../accumulo/test/categories/PerformanceTests.java |   8 +-
 .../categories/StandaloneCapableClusterTests.java  |   4 +-
 .../accumulo/test/categories/SunnyDayTests.java    |   4 +-
 .../accumulo/test/categories/package-info.java     |   1 -
 .../test/continuous/ContinuousBatchWalker.java     |  12 +-
 .../accumulo/test/continuous/ContinuousIngest.java |  41 +-
 .../accumulo/test/continuous/ContinuousMoru.java   |  29 +-
 .../accumulo/test/continuous/ContinuousOpts.java   |  15 +-
 .../accumulo/test/continuous/ContinuousQuery.java  |   6 +-
 .../test/continuous/ContinuousScanner.java         |   9 +-
 .../test/continuous/ContinuousStatsCollector.java  |  31 +-
 .../accumulo/test/continuous/ContinuousUtil.java   |   6 +-
 .../accumulo/test/continuous/ContinuousVerify.java |  33 +-
 .../accumulo/test/continuous/ContinuousWalk.java   |   3 +-
 .../apache/accumulo/test/continuous/HistData.java  |   3 +-
 .../apache/accumulo/test/continuous/Histogram.java |   3 +-
 .../test/continuous/PrintScanTimeHistogram.java    |   3 +-
 .../accumulo/test/continuous/TimeBinner.java       |  26 +-
 .../test/continuous/UndefinedAnalyzer.java         |  39 +-
 .../test/examples/simple/dirlist/CountIT.java      |   6 +-
 .../simple/filedata/ChunkInputFormatIT.java        |  42 +-
 .../simple/filedata/ChunkInputStreamIT.java        |  18 +-
 .../accumulo/test/functional/AddSplitIT.java       |   3 +-
 .../accumulo/test/functional/AuthsIterator.java    |   3 +-
 .../accumulo/test/functional/BackupMasterIT.java   |   3 +-
 .../test/functional/BadIteratorMincIT.java         |   3 +-
 .../functional/BalanceAfterCommsFailureIT.java     |  16 +-
 .../BalanceInPresenceOfOfflineTableIT.java         |  21 +-
 .../accumulo/test/functional/BatchScanSplitIT.java |   6 +-
 .../test/functional/BatchWriterFlushIT.java        |  13 +-
 .../accumulo/test/functional/BigRootTabletIT.java  |   9 +-
 .../accumulo/test/functional/BloomFilterIT.java    |  30 +-
 .../accumulo/test/functional/BulkFileIT.java       |  18 +-
 .../apache/accumulo/test/functional/BulkIT.java    |  11 +-
 .../test/functional/BulkSplitOptimizationIT.java   |   9 +-
 .../accumulo/test/functional/ClassLoaderIT.java    |   9 +-
 .../apache/accumulo/test/functional/CleanUpIT.java |  14 +-
 .../accumulo/test/functional/CloneTestIT.java      |  25 +-
 .../accumulo/test/functional/CombinerIT.java       |   3 +-
 .../accumulo/test/functional/CompactionIT.java     |   3 +-
 .../accumulo/test/functional/ConcurrencyIT.java    |   8 +-
 .../test/functional/ConcurrentDeleteTableIT.java   |   3 +-
 .../test/functional/ConfigurableCompactionIT.java  |  21 +-
 .../test/functional/ConfigurableMacBase.java       |  32 +-
 .../accumulo/test/functional/ConstraintIT.java     |  66 +-
 .../accumulo/test/functional/CreateAndUseIT.java   |   3 +-
 .../accumulo/test/functional/CredentialsIT.java    |   6 +-
 .../test/functional/DeleteEverythingIT.java        |   6 +-
 .../apache/accumulo/test/functional/DeleteIT.java  |  15 +-
 .../accumulo/test/functional/DeleteRowsIT.java     |  10 +-
 .../accumulo/test/functional/DropModIter.java      |   6 +-
 .../accumulo/test/functional/DurabilityIT.java     |   3 +-
 .../test/functional/DynamicThreadPoolsIT.java      |   6 +-
 .../accumulo/test/functional/ExamplesIT.java       | 213 +++---
 .../test/functional/FunctionalTestUtils.java       |  33 +-
 .../test/functional/GarbageCollectorIT.java        |  18 +-
 .../test/functional/HalfDeadTServerIT.java         |  16 +-
 .../accumulo/test/functional/KerberosIT.java       | 222 +++---
 .../accumulo/test/functional/KerberosProxyIT.java  | 187 +++--
 .../test/functional/KerberosRenewalIT.java         |  44 +-
 .../accumulo/test/functional/LargeRowIT.java       |  18 +-
 .../test/functional/LateLastContactIT.java         |   3 +-
 .../accumulo/test/functional/LogicalTimeIT.java    |  62 +-
 .../accumulo/test/functional/MapReduceIT.java      |  13 +-
 .../test/functional/MasterAssignmentIT.java        |   9 +-
 .../apache/accumulo/test/functional/MaxOpenIT.java |   9 +-
 .../apache/accumulo/test/functional/MergeIT.java   |  64 +-
 .../test/functional/MetadataMaxFilesIT.java        |   3 +-
 .../accumulo/test/functional/MetadataSplitIT.java  |   3 +-
 .../accumulo/test/functional/MonitorLoggingIT.java |  15 +-
 .../accumulo/test/functional/MonitorSslIT.java     |  30 +-
 .../accumulo/test/functional/NativeMapIT.java      |  47 +-
 .../accumulo/test/functional/PermissionsIT.java    | 197 ++++--
 .../accumulo/test/functional/ReadWriteIT.java      | 136 ++--
 .../test/functional/RecoveryWithEmptyRFileIT.java  |  14 +-
 .../test/functional/RegexGroupBalanceIT.java       |  19 +-
 .../apache/accumulo/test/functional/RestartIT.java |  37 +-
 .../accumulo/test/functional/RestartStressIT.java  |   8 +-
 .../apache/accumulo/test/functional/ScanIdIT.java  |  59 +-
 .../accumulo/test/functional/ScanIteratorIT.java   |  28 +-
 .../accumulo/test/functional/ScanRangeIT.java      |  18 +-
 .../test/functional/ScanSessionTimeOutIT.java      |   3 +-
 .../accumulo/test/functional/ScannerContextIT.java |  24 +-
 .../apache/accumulo/test/functional/ScannerIT.java |   6 +-
 .../test/functional/SessionBlockVerifyIT.java      |  20 +-
 .../test/functional/SessionDurabilityIT.java       |   6 +-
 .../accumulo/test/functional/ShutdownIT.java       |  28 +-
 .../test/functional/SimpleBalancerFairnessIT.java  |  10 +-
 .../accumulo/test/functional/SlowIterator.java     |   6 +-
 .../test/functional/SparseColumnFamilyIT.java      |   3 +-
 .../apache/accumulo/test/functional/SplitIT.java   |  16 +-
 .../accumulo/test/functional/SplitRecoveryIT.java  |  75 +-
 .../org/apache/accumulo/test/functional/SslIT.java |  13 +-
 .../test/functional/TableChangeStateIT.java        |  93 ++-
 .../apache/accumulo/test/functional/TabletIT.java  |   6 +-
 .../functional/TabletStateChangeIteratorIT.java    |  64 +-
 .../apache/accumulo/test/functional/TimeoutIT.java |   3 +-
 .../accumulo/test/functional/VisibilityIT.java     |  27 +-
 .../accumulo/test/functional/WALSunnyDayIT.java    |  21 +-
 .../test/functional/WatchTheWatchCountIT.java      |   7 +-
 .../accumulo/test/functional/WriteLotsIT.java      |   3 +-
 .../accumulo/test/functional/YieldingIterator.java |  30 +-
 .../accumulo/test/functional/ZombieTServer.java    |  26 +-
 .../accumulo/test/functional/ZooCacheIT.java       |   6 +-
 .../CloseWriteAheadLogReferencesIT.java            |  45 +-
 .../test/mapred/AccumuloFileOutputFormatIT.java    |  21 +-
 .../test/mapred/AccumuloInputFormatIT.java         |  19 +-
 .../mapred/AccumuloMultiTableInputFormatIT.java    |   9 +-
 .../test/mapred/AccumuloOutputFormatIT.java        |  18 +-
 .../test/mapred/AccumuloRowInputFormatIT.java      |  18 +-
 .../apache/accumulo/test/mapred/TokenFileIT.java   |  12 +-
 .../test/mapreduce/AccumuloFileOutputFormatIT.java |  33 +-
 .../test/mapreduce/AccumuloInputFormatIT.java      |  78 ++-
 .../mapreduce/AccumuloMultiTableInputFormatIT.java |  12 +-
 .../test/mapreduce/AccumuloOutputFormatIT.java     |   9 +-
 .../test/mapreduce/AccumuloRowInputFormatIT.java   |  21 +-
 .../accumulo/test/mapreduce/TokenFileIT.java       |  12 +-
 .../apache/accumulo/test/master/MergeStateIT.java  |  32 +-
 .../accumulo/test/master/SuspendedTabletsIT.java   |  47 +-
 .../test/mrit/IntegrationTestMapReduce.java        |  19 +-
 .../accumulo/test/performance/NullTserver.java     | 101 ++-
 .../test/performance/RollWALPerformanceIT.java     |   5 +-
 .../performance/metadata/FastBulkImportIT.java     |   3 +-
 .../metadata/MetadataBatchScanTest.java            |  19 +-
 .../test/performance/scan/CollectTabletStats.java  |  84 ++-
 .../accumulo/test/proxy/ProxyDurabilityIT.java     |   9 +-
 .../accumulo/test/proxy/SimpleProxyBase.java       | 531 +++++++++-----
 .../accumulo/test/proxy/TestProxyClient.java       |  17 +-
 .../test/proxy/TestProxyInstanceOperations.java    |  10 +-
 .../test/proxy/TestProxyNamespaceOperations.java   |  40 +-
 .../accumulo/test/proxy/TestProxyReadWrite.java    |  54 +-
 .../test/proxy/TestProxySecurityOperations.java    |  26 +-
 .../test/proxy/TestProxyTableOperations.java       |  24 +-
 .../accumulo/test/randomwalk/Environment.java      |  24 +-
 .../apache/accumulo/test/randomwalk/Framework.java |   9 +-
 .../apache/accumulo/test/randomwalk/Module.java    |  27 +-
 .../org/apache/accumulo/test/randomwalk/Node.java  |   3 +-
 .../org/apache/accumulo/test/randomwalk/State.java |   3 +-
 .../test/randomwalk/bulk/BulkImportTest.java       |  20 +-
 .../accumulo/test/randomwalk/bulk/BulkPlusOne.java |  16 +-
 .../accumulo/test/randomwalk/bulk/Compact.java     |   3 +-
 .../test/randomwalk/bulk/ConsistencyCheck.java     |   6 +-
 .../accumulo/test/randomwalk/bulk/Merge.java       |   6 +-
 .../test/randomwalk/bulk/SelectiveBulkTest.java    |   6 +-
 .../test/randomwalk/bulk/SelectiveQueueing.java    |   3 +-
 .../accumulo/test/randomwalk/bulk/Split.java       |   3 +-
 .../accumulo/test/randomwalk/bulk/Verify.java      |   6 +-
 .../test/randomwalk/concurrent/Apocalypse.java     |   3 +-
 .../test/randomwalk/concurrent/BulkImport.java     |  15 +-
 .../concurrent/ChangeAuthorizations.java           |   3 +-
 .../randomwalk/concurrent/ChangePermissions.java   |   9 +-
 .../randomwalk/concurrent/CheckPermission.java     |   9 +-
 .../test/randomwalk/concurrent/CloneTable.java     |   6 +-
 .../test/randomwalk/concurrent/Compact.java        |   9 +-
 .../randomwalk/concurrent/ConcurrentFixture.java   |   6 +-
 .../test/randomwalk/concurrent/Config.java         |  39 +-
 .../test/randomwalk/concurrent/IsolatedScan.java   |   3 +-
 .../accumulo/test/randomwalk/concurrent/Merge.java |   6 +-
 .../test/randomwalk/concurrent/Replication.java    |   6 +-
 .../test/randomwalk/concurrent/Shutdown.java       |   3 +-
 .../test/randomwalk/concurrent/StartAll.java       |   9 +-
 .../randomwalk/concurrent/StopTabletServer.java    |   6 +-
 .../test/randomwalk/conditional/Setup.java         |   6 +-
 .../test/randomwalk/conditional/Transfer.java      |   6 +-
 .../test/randomwalk/conditional/Verify.java        |   6 +-
 .../accumulo/test/randomwalk/image/Commit.java     |   3 +-
 .../test/randomwalk/image/ImageFixture.java        |   6 +-
 .../accumulo/test/randomwalk/image/ScanMeta.java   |   6 +-
 .../accumulo/test/randomwalk/image/Verify.java     |   3 +-
 .../accumulo/test/randomwalk/image/Write.java      |   6 +-
 .../test/randomwalk/multitable/CopyTool.java       |  15 +-
 .../randomwalk/multitable/MultiTableFixture.java   |   3 +-
 .../test/randomwalk/security/AlterTable.java       |  19 +-
 .../test/randomwalk/security/AlterTablePerm.java   |  26 +-
 .../test/randomwalk/security/Authenticate.java     |  20 +-
 .../test/randomwalk/security/ChangePass.java       |  10 +-
 .../test/randomwalk/security/CreateTable.java      |  13 +-
 .../test/randomwalk/security/CreateUser.java       |  13 +-
 .../test/randomwalk/security/DropTable.java        |  10 +-
 .../test/randomwalk/security/DropUser.java         |  10 +-
 .../test/randomwalk/security/SecurityFixture.java  |   6 +-
 .../test/randomwalk/security/SecurityHelper.java   |   9 +-
 .../test/randomwalk/security/SetAuths.java         |  10 +-
 .../accumulo/test/randomwalk/security/TableOp.java |  73 +-
 .../test/randomwalk/security/Validate.java         |  39 +-
 .../test/randomwalk/security/WalkingSecurity.java  |  88 ++-
 .../test/randomwalk/sequential/BatchVerify.java    |  12 +-
 .../test/randomwalk/sequential/Commit.java         |   3 +-
 .../randomwalk/sequential/MapRedVerifyTool.java    |  21 +-
 .../randomwalk/sequential/SequentialFixture.java   |   6 +-
 .../accumulo/test/randomwalk/shard/BulkInsert.java |  28 +-
 .../accumulo/test/randomwalk/shard/CloneIndex.java |   6 +-
 .../test/randomwalk/shard/CompactFilter.java       |  12 +-
 .../accumulo/test/randomwalk/shard/Delete.java     |   3 +-
 .../test/randomwalk/shard/DeleteSomeDocs.java      |   6 +-
 .../accumulo/test/randomwalk/shard/DeleteWord.java |   6 +-
 .../test/randomwalk/shard/ExportIndex.java         |  31 +-
 .../accumulo/test/randomwalk/shard/Grep.java       |  14 +-
 .../accumulo/test/randomwalk/shard/Insert.java     |  17 +-
 .../accumulo/test/randomwalk/shard/Merge.java      |   3 +-
 .../accumulo/test/randomwalk/shard/Reindex.java    |   3 +-
 .../accumulo/test/randomwalk/shard/Search.java     |   9 +-
 .../test/randomwalk/shard/ShardFixture.java        |  12 +-
 .../accumulo/test/randomwalk/shard/Split.java      |   3 +-
 .../test/randomwalk/shard/VerifyIndex.java         |   9 +-
 .../test/replication/CyclicReplicationIT.java      |  88 ++-
 .../test/replication/FinishedWorkUpdaterIT.java    |  21 +-
 ...GarbageCollectorCommunicatesWithTServersIT.java |  85 ++-
 .../test/replication/KerberosReplicationIT.java    |  32 +-
 .../test/replication/MockReplicaSystem.java        |  19 +-
 .../replication/MultiInstanceReplicationIT.java    | 191 +++--
 .../replication/MultiTserverReplicationIT.java     |   9 +-
 .../RemoveCompleteReplicationRecordsIT.java        |  45 +-
 .../accumulo/test/replication/ReplicationIT.java   | 255 ++++---
 .../replication/ReplicationOperationsImplIT.java   |  48 +-
 .../test/replication/SequentialWorkAssignerIT.java |  75 +-
 .../test/replication/StatusCombinerMacIT.java      |  12 +-
 .../accumulo/test/replication/StatusMakerIT.java   |  47 +-
 .../test/replication/UnorderedWorkAssignerIT.java  |  36 +-
 .../UnorderedWorkAssignerReplicationIT.java        | 191 +++--
 .../UnusedWalDoesntCloseReplicationStatusIT.java   |  27 +-
 .../accumulo/test/replication/WorkMakerIT.java     |  36 +-
 .../test/replication/merkle/MerkleTree.java        |   7 +-
 .../test/replication/merkle/MerkleTreeNode.java    |  15 +-
 .../test/replication/merkle/cli/CompareTables.java |  36 +-
 .../replication/merkle/cli/ComputeRootHash.java    |  17 +-
 .../replication/merkle/cli/GenerateHashes.java     |  49 +-
 .../replication/merkle/cli/ManualComparison.java   |   7 +-
 .../replication/merkle/ingest/RandomWorkload.java  |  19 +-
 .../test/replication/merkle/package-info.java      |  33 +-
 .../replication/merkle/skvi/DigestIterator.java    |  15 +-
 .../apache/accumulo/test/scalability/Ingest.java   |   7 +-
 .../org/apache/accumulo/test/scalability/Run.java  |  10 +-
 .../accumulo/test/scalability/ScaleTest.java       |   8 +-
 .../test/server/security/SystemCredentialsIT.java  |  39 +-
 .../apache/accumulo/test/start/KeywordStartIT.java |  18 +-
 .../test/stress/random/RandomMutations.java        |   8 +-
 .../apache/accumulo/test/stress/random/Scan.java   |  15 +-
 .../accumulo/test/stress/random/ScanOpts.java      |   6 +-
 .../apache/accumulo/test/stress/random/Stream.java |   3 +-
 .../apache/accumulo/test/stress/random/Write.java  |  30 +-
 .../accumulo/test/stress/random/WriteOptions.java  |  43 +-
 .../accumulo/test/stress/random/package-info.java  |  30 +-
 .../org/apache/accumulo/test/util/CertUtils.java   |  99 ++-
 .../accumulo/test/util/SerializationUtil.java      |  17 +-
 .../test/TraceRepoDeserializationTest.java         |  18 +-
 .../accumulo/test/fate/zookeeper/ZooLockTest.java  |  36 +-
 .../test/functional/ValueReversingIterator.java    |   6 +-
 .../accumulo/test/iterator/AgeOffFilterTest.java   |  21 +-
 .../test/iterator/CfCqSliceFilterTest.java         |  23 +-
 .../apache/accumulo/test/iterator/RegExTest.java   |   9 +-
 .../test/iterator/SummingCombinerTest.java         |   6 +-
 .../test/iterator/WholeRowIteratorTest.java        |   6 +-
 .../accumulo/test/randomwalk/FrameworkTest.java    |   9 +-
 .../apache/accumulo/test/util/CertUtilsTest.java   |  24 +-
 .../accumulo/trace/instrument/CloudtraceSpan.java  |  10 +-
 .../accumulo/trace/instrument/CountSampler.java    |   3 +-
 .../apache/accumulo/trace/instrument/Tracer.java   |   8 +-
 1556 files changed, 30101 insertions(+), 16564 deletions(-)

diff --git a/core/src/main/java/org/apache/accumulo/core/Constants.java b/core/src/main/java/org/apache/accumulo/core/Constants.java
index eebd81d..ed1680b 100644
--- a/core/src/main/java/org/apache/accumulo/core/Constants.java
+++ b/core/src/main/java/org/apache/accumulo/core/Constants.java
@@ -126,7 +126,8 @@ public class Constants {
   public static final String EXPORT_INFO_FILE = "accumulo_export_info.txt";
 
   // Variables that will be substituted with environment vars in PropertyType.PATH values
-  public static final Collection<String> PATH_PROPERTY_ENV_VARS = Collections.unmodifiableCollection(Arrays.asList("ACCUMULO_HOME", "ACCUMULO_CONF_DIR"));
+  public static final Collection<String> PATH_PROPERTY_ENV_VARS = Collections
+      .unmodifiableCollection(Arrays.asList("ACCUMULO_HOME", "ACCUMULO_CONF_DIR"));
 
   public static final String HDFS_TABLES_DIR = "/tables";
 
diff --git a/core/src/main/java/org/apache/accumulo/core/bloomfilter/BloomFilter.java b/core/src/main/java/org/apache/accumulo/core/bloomfilter/BloomFilter.java
index f51f8f7..37e84d9 100644
--- a/core/src/main/java/org/apache/accumulo/core/bloomfilter/BloomFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/bloomfilter/BloomFilter.java
@@ -65,23 +65,29 @@ import org.slf4j.LoggerFactory;
 /**
  * Implements a <i>Bloom filter</i>, as defined by Bloom in 1970.
  * <p>
- * The Bloom filter is a data structure that was introduced in 1970 and that has been adopted by the networking research community in the past decade thanks to
- * the bandwidth efficiencies that it offers for the transmission of set membership information between networked hosts. A sender encodes the information into a
- * bit vector, the Bloom filter, that is more compact than a conventional representation. Computation and space costs for construction are linear in the number
- * of elements. The receiver uses the filter to test whether various elements are members of the set. Though the filter will occasionally return a false
- * positive, it will never return a false negative. When creating the filter, the sender can choose its desired point in a trade-off between the false positive
- * rate and the size.
+ * The Bloom filter is a data structure that was introduced in 1970 and that has been adopted by the
+ * networking research community in the past decade thanks to the bandwidth efficiencies that it
+ * offers for the transmission of set membership information between networked hosts. A sender
+ * encodes the information into a bit vector, the Bloom filter, that is more compact than a
+ * conventional representation. Computation and space costs for construction are linear in the
+ * number of elements. The receiver uses the filter to test whether various elements are members of
+ * the set. Though the filter will occasionally return a false positive, it will never return a
+ * false negative. When creating the filter, the sender can choose its desired point in a trade-off
+ * between the false positive rate and the size.
  *
  * <p>
- * Originally created by <a href="http://www.one-lab.org">European Commission One-Lab Project 034819</a>.
+ * Originally created by <a href="http://www.one-lab.org">European Commission One-Lab Project
+ * 034819</a>.
  *
  * @see Filter The general behavior of a filter
  *
- * @see <a href="http://portal.acm.org/citation.cfm?id=362692&dl=ACM&coll=portal">Space/Time Trade-Offs in Hash Coding with Allowable Errors</a>
+ * @see <a href="http://portal.acm.org/citation.cfm?id=362692&dl=ACM&coll=portal">Space/Time
+ *      Trade-Offs in Hash Coding with Allowable Errors</a>
  */
 public class BloomFilter extends Filter {
   private static final Logger log = LoggerFactory.getLogger(BloomFilter.class);
-  private static final byte[] bitvalues = new byte[] {(byte) 0x01, (byte) 0x02, (byte) 0x04, (byte) 0x08, (byte) 0x10, (byte) 0x20, (byte) 0x40, (byte) 0x80};
+  private static final byte[] bitvalues = new byte[] {(byte) 0x01, (byte) 0x02, (byte) 0x04,
+      (byte) 0x08, (byte) 0x10, (byte) 0x20, (byte) 0x40, (byte) 0x80};
 
   /** The bit vector. */
   BitSet bits;
@@ -128,7 +134,8 @@ public class BloomFilter extends Filter {
 
   @Override
   public void and(final Filter filter) {
-    if (filter == null || !(filter instanceof BloomFilter) || filter.vectorSize != this.vectorSize || filter.nbHash != this.nbHash) {
+    if (filter == null || !(filter instanceof BloomFilter) || filter.vectorSize != this.vectorSize
+        || filter.nbHash != this.nbHash) {
       throw new IllegalArgumentException("filters cannot be and-ed");
     }
 
@@ -158,7 +165,8 @@ public class BloomFilter extends Filter {
 
   @Override
   public void or(final Filter filter) {
-    if (filter == null || !(filter instanceof BloomFilter) || filter.vectorSize != this.vectorSize || filter.nbHash != this.nbHash) {
+    if (filter == null || !(filter instanceof BloomFilter) || filter.vectorSize != this.vectorSize
+        || filter.nbHash != this.nbHash) {
       throw new IllegalArgumentException("filters cannot be or-ed");
     }
     bits.or(((BloomFilter) filter).bits);
@@ -166,7 +174,8 @@ public class BloomFilter extends Filter {
 
   @Override
   public void xor(final Filter filter) {
-    if (filter == null || !(filter instanceof BloomFilter) || filter.vectorSize != this.vectorSize || filter.nbHash != this.nbHash) {
+    if (filter == null || !(filter instanceof BloomFilter) || filter.vectorSize != this.vectorSize
+        || filter.nbHash != this.nbHash) {
       throw new IllegalArgumentException("filters cannot be xor-ed");
     }
     bits.xor(((BloomFilter) filter).bits);
diff --git a/core/src/main/java/org/apache/accumulo/core/bloomfilter/DynamicBloomFilter.java b/core/src/main/java/org/apache/accumulo/core/bloomfilter/DynamicBloomFilter.java
index 11e765a..5f70105 100644
--- a/core/src/main/java/org/apache/accumulo/core/bloomfilter/DynamicBloomFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/bloomfilter/DynamicBloomFilter.java
@@ -58,25 +58,33 @@ import org.apache.hadoop.util.bloom.Key;
 /**
  * Implements a <i>dynamic Bloom filter</i>, as defined in the INFOCOM 2006 paper.
  * <p>
- * A dynamic Bloom filter (DBF) makes use of a <code>s * m</code> bit matrix but each of the <code>s</code> rows is a standard Bloom filter. The creation
- * process of a DBF is iterative. At the start, the DBF is a <code>1 * m</code> bit matrix, i.e., it is composed of a single standard Bloom filter. It assumes
- * that <code>n<sub>r</sub></code> elements are recorded in the initial bit vector, where <code>n<sub>r</sub> &lt;= n</code> (<code>n</code> is the cardinality
- * of the set <code>A</code> to record in the filter).
+ * A dynamic Bloom filter (DBF) makes use of a <code>s * m</code> bit matrix but each of the
+ * <code>s</code> rows is a standard Bloom filter. The creation process of a DBF is iterative. At
+ * the start, the DBF is a <code>1 * m</code> bit matrix, i.e., it is composed of a single standard
+ * Bloom filter. It assumes that <code>n<sub>r</sub></code> elements are recorded in the initial bit
+ * vector, where <code>n<sub>r</sub> &lt;= n</code> (<code>n</code> is the cardinality of the set
+ * <code>A</code> to record in the filter).
  * <p>
- * As the size of <code>A</code> grows during the execution of the application, several keys must be inserted in the DBF. When inserting a key into the DBF, one
- * must first get an active Bloom filter in the matrix. A Bloom filter is active when the number of recorded keys, <code>n<sub>r</sub></code>, is strictly less
- * than the current cardinality of <code>A</code>, <code>n</code>. If an active Bloom filter is found, the key is inserted and <code>n<sub>r</sub></code> is
- * incremented by one. On the other hand, if there is no active Bloom filter, a new one is created (i.e., a new row is added to the matrix) according to the
- * current size of <code>A</code> and the element is added in this new Bloom filter and the <code>n<sub>r</sub></code> value of this new Bloom filter is set to
- * one. A given key is said to belong to the DBF if the <code>k</code> positions are set to one in one of the matrix rows.
+ * As the size of <code>A</code> grows during the execution of the application, several keys must be
+ * inserted in the DBF. When inserting a key into the DBF, one must first get an active Bloom filter
+ * in the matrix. A Bloom filter is active when the number of recorded keys,
+ * <code>n<sub>r</sub></code>, is strictly less than the current cardinality of <code>A</code>,
+ * <code>n</code>. If an active Bloom filter is found, the key is inserted and
+ * <code>n<sub>r</sub></code> is incremented by one. On the other hand, if there is no active Bloom
+ * filter, a new one is created (i.e., a new row is added to the matrix) according to the current
+ * size of <code>A</code> and the element is added in this new Bloom filter and the
+ * <code>n<sub>r</sub></code> value of this new Bloom filter is set to one. A given key is said to
+ * belong to the DBF if the <code>k</code> positions are set to one in one of the matrix rows.
  * <p>
- * Originally created by <a href="http://www.one-lab.org">European Commission One-Lab Project 034819</a>.
+ * Originally created by <a href="http://www.one-lab.org">European Commission One-Lab Project
+ * 034819</a>.
  *
  * @see Filter The general behavior of a filter
  * @see BloomFilter A Bloom filter
  *
- * @see <a href="http://www.cse.fau.edu/~jie/research/publications/Publication_files/infocom2006.pdf">Theory and Network Applications of Dynamic Bloom
- *      Filters</a>
+ * @see <a href=
+ *      "http://www.cse.fau.edu/~jie/research/publications/Publication_files/infocom2006.pdf">Theory
+ *      and Network Applications of Dynamic Bloom Filters</a>
  */
 public class DynamicBloomFilter extends Filter {
   /**
@@ -113,7 +121,8 @@ public class DynamicBloomFilter extends Filter {
    * @param nr
    *          The threshold for the maximum number of keys to record in a dynamic Bloom filter row.
    */
-  public DynamicBloomFilter(final int vectorSize, final int nbHash, final int hashType, final int nr) {
+  public DynamicBloomFilter(final int vectorSize, final int nbHash, final int hashType,
+      final int nr) {
     super(vectorSize, nbHash, hashType);
 
     this.nr = nr;
@@ -147,7 +156,8 @@ public class DynamicBloomFilter extends Filter {
 
   @Override
   public void and(final Filter filter) {
-    if (filter == null || !(filter instanceof DynamicBloomFilter) || filter.vectorSize != this.vectorSize || filter.nbHash != this.nbHash) {
+    if (filter == null || !(filter instanceof DynamicBloomFilter)
+        || filter.vectorSize != this.vectorSize || filter.nbHash != this.nbHash) {
       throw new IllegalArgumentException("filters cannot be and-ed");
     }
 
@@ -186,7 +196,8 @@ public class DynamicBloomFilter extends Filter {
 
   @Override
   public void or(final Filter filter) {
-    if (filter == null || !(filter instanceof DynamicBloomFilter) || filter.vectorSize != this.vectorSize || filter.nbHash != this.nbHash) {
+    if (filter == null || !(filter instanceof DynamicBloomFilter)
+        || filter.vectorSize != this.vectorSize || filter.nbHash != this.nbHash) {
       throw new IllegalArgumentException("filters cannot be or-ed");
     }
 
@@ -202,7 +213,8 @@ public class DynamicBloomFilter extends Filter {
 
   @Override
   public void xor(final Filter filter) {
-    if (filter == null || !(filter instanceof DynamicBloomFilter) || filter.vectorSize != this.vectorSize || filter.nbHash != this.nbHash) {
+    if (filter == null || !(filter instanceof DynamicBloomFilter)
+        || filter.vectorSize != this.vectorSize || filter.nbHash != this.nbHash) {
       throw new IllegalArgumentException("filters cannot be xor-ed");
     }
     DynamicBloomFilter dbf = (DynamicBloomFilter) filter;
diff --git a/core/src/main/java/org/apache/accumulo/core/bloomfilter/Filter.java b/core/src/main/java/org/apache/accumulo/core/bloomfilter/Filter.java
index f6fb632..8d30a05 100644
--- a/core/src/main/java/org/apache/accumulo/core/bloomfilter/Filter.java
+++ b/core/src/main/java/org/apache/accumulo/core/bloomfilter/Filter.java
@@ -62,8 +62,9 @@ import org.apache.hadoop.util.hash.Hash;
 /**
  * Defines the general behavior of a filter.
  * <p>
- * A filter is a data structure which aims at offering a lossy summary of a set <code>A</code>. The key idea is to map entries of <code>A</code> (also called
- * <i>keys</i>) into several positions in a vector through the use of several hash functions.
+ * A filter is a data structure which aims at offering a lossy summary of a set <code>A</code>. The
+ * key idea is to map entries of <code>A</code> (also called <i>keys</i>) into several positions in
+ * a vector through the use of several hash functions.
  * <p>
  * Typically, a filter will be implemented as a Bloom filter (or a Bloom filter extension).
  * <p>
diff --git a/core/src/main/java/org/apache/accumulo/core/cli/BatchScannerOpts.java b/core/src/main/java/org/apache/accumulo/core/cli/BatchScannerOpts.java
index 2d5b51d..2706468 100644
--- a/core/src/main/java/org/apache/accumulo/core/cli/BatchScannerOpts.java
+++ b/core/src/main/java/org/apache/accumulo/core/cli/BatchScannerOpts.java
@@ -24,7 +24,8 @@ public class BatchScannerOpts {
   @Parameter(names = "--scanThreads", description = "Number of threads to use when batch scanning")
   public Integer scanThreads = 10;
 
-  @Parameter(names = "--scanTimeout", converter = TimeConverter.class, description = "timeout used to fail a batch scan")
+  @Parameter(names = "--scanTimeout", converter = TimeConverter.class,
+      description = "timeout used to fail a batch scan")
   public Long scanTimeout = Long.MAX_VALUE;
 
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/cli/BatchWriterOpts.java b/core/src/main/java/org/apache/accumulo/core/cli/BatchWriterOpts.java
index 02fb3da..96e4e85 100644
--- a/core/src/main/java/org/apache/accumulo/core/cli/BatchWriterOpts.java
+++ b/core/src/main/java/org/apache/accumulo/core/cli/BatchWriterOpts.java
@@ -27,16 +27,20 @@ import com.beust.jcommander.Parameter;
 public class BatchWriterOpts {
   private static final BatchWriterConfig BWDEFAULTS = new BatchWriterConfig();
 
-  @Parameter(names = "--batchThreads", description = "Number of threads to use when writing large batches")
+  @Parameter(names = "--batchThreads",
+      description = "Number of threads to use when writing large batches")
   public Integer batchThreads = BWDEFAULTS.getMaxWriteThreads();
 
-  @Parameter(names = "--batchLatency", converter = TimeConverter.class, description = "The maximum time to wait before flushing data to servers when writing")
+  @Parameter(names = "--batchLatency", converter = TimeConverter.class,
+      description = "The maximum time to wait before flushing data to servers when writing")
   public Long batchLatency = BWDEFAULTS.getMaxLatency(TimeUnit.MILLISECONDS);
 
-  @Parameter(names = "--batchMemory", converter = MemoryConverter.class, description = "memory used to batch data when writing")
+  @Parameter(names = "--batchMemory", converter = MemoryConverter.class,
+      description = "memory used to batch data when writing")
   public Long batchMemory = BWDEFAULTS.getMaxMemory();
 
-  @Parameter(names = "--batchTimeout", converter = TimeConverter.class, description = "timeout used to fail a batch write")
+  @Parameter(names = "--batchTimeout", converter = TimeConverter.class,
+      description = "timeout used to fail a batch write")
   public Long batchTimeout = BWDEFAULTS.getTimeout(TimeUnit.MILLISECONDS);
 
   public BatchWriterConfig getBatchWriterConfig() {
diff --git a/core/src/main/java/org/apache/accumulo/core/cli/ClientOpts.java b/core/src/main/java/org/apache/accumulo/core/cli/ClientOpts.java
index 4073455..b1d3150 100644
--- a/core/src/main/java/org/apache/accumulo/core/cli/ClientOpts.java
+++ b/core/src/main/java/org/apache/accumulo/core/cli/ClientOpts.java
@@ -130,7 +130,8 @@ public class ClientOpts extends Help {
   @Parameter(names = "-p", converter = PasswordConverter.class, description = "Connection password")
   private Password password = null;
 
-  @Parameter(names = "--password", converter = PasswordConverter.class, description = "Enter the connection password", password = true)
+  @Parameter(names = "--password", converter = PasswordConverter.class,
+      description = "Enter the connection password", password = true)
   private Password securePassword = null;
 
   @Parameter(names = {"-tc", "--tokenClass"}, description = "Token class")
@@ -148,9 +149,11 @@ public class ClientOpts extends Help {
           props.put(loginOption.getKey(), loginOption.getValue());
       }
 
-      // It's expected that the user is already logged in via UserGroupInformation or external to this program (kinit).
+      // It's expected that the user is already logged in via UserGroupInformation or external to
+      // this program (kinit).
       try {
-        AuthenticationToken token = Class.forName(tokenClassName).asSubclass(AuthenticationToken.class).newInstance();
+        AuthenticationToken token = Class.forName(tokenClassName)
+            .asSubclass(AuthenticationToken.class).newInstance();
         token.init(props);
         return token;
       } catch (Exception e) {
@@ -174,13 +177,15 @@ public class ClientOpts extends Help {
     return new PasswordToken(pass.value);
   }
 
-  @Parameter(names = {"-z", "--keepers"}, description = "Comma separated list of zookeeper hosts (host:port,host:port)")
+  @Parameter(names = {"-z", "--keepers"},
+      description = "Comma separated list of zookeeper hosts (host:port,host:port)")
   public String zookeepers = "localhost:2181";
 
   @Parameter(names = {"-i", "--instance"}, description = "The name of the accumulo instance")
   public String instance = null;
 
-  @Parameter(names = {"-auths", "--auths"}, converter = AuthConverter.class, description = "the authorizations to use when reading or writing")
+  @Parameter(names = {"-auths", "--auths"}, converter = AuthConverter.class,
+      description = "the authorizations to use when reading or writing")
   public Authorizations auths = Authorizations.EMPTY;
 
   @Parameter(names = "--debug", description = "turn on TRACE-level log messages")
@@ -189,7 +194,8 @@ public class ClientOpts extends Help {
   @Parameter(names = {"-fake", "--mock"}, description = "Use a mock Instance")
   public boolean mock = false;
 
-  @Parameter(names = "--site-file", description = "Read the given accumulo site file to find the accumulo instance")
+  @Parameter(names = "--site-file",
+      description = "Read the given accumulo site file to find the accumulo instance")
   public String siteFile = null;
 
   @Parameter(names = "--ssl", description = "Connect to accumulo over SSL")
@@ -225,8 +231,8 @@ public class ClientOpts extends Help {
   }
 
   /**
-   * Automatically update the options to use a KerberosToken when SASL is enabled for RPCs. Don't overwrite the options if the user has provided something
-   * specifically.
+   * Automatically update the options to use a KerberosToken when SASL is enabled for RPCs. Don't
+   * overwrite the options if the user has provided something specifically.
    */
   public void updateKerberosCredentials() {
     ClientConfiguration clientConfig;
@@ -242,14 +248,16 @@ public class ClientOpts extends Help {
   }
 
   /**
-   * Automatically update the options to use a KerberosToken when SASL is enabled for RPCs. Don't overwrite the options if the user has provided something
-   * specifically.
+   * Automatically update the options to use a KerberosToken when SASL is enabled for RPCs. Don't
+   * overwrite the options if the user has provided something specifically.
    */
   public void updateKerberosCredentials(ClientConfiguration clientConfig) {
-    final boolean clientConfSaslEnabled = Boolean.parseBoolean(clientConfig.get(ClientProperty.INSTANCE_RPC_SASL_ENABLED));
+    final boolean clientConfSaslEnabled = Boolean
+        .parseBoolean(clientConfig.get(ClientProperty.INSTANCE_RPC_SASL_ENABLED));
     if ((saslEnabled || clientConfSaslEnabled) && null == tokenClassName) {
       tokenClassName = KerberosToken.CLASS_NAME;
-      // ACCUMULO-3701 We need to ensure we're logged in before parseArgs returns as the MapReduce Job is going to make a copy of the current user (UGI)
+      // ACCUMULO-3701 We need to ensure we're logged in before parseArgs returns as the MapReduce
+      // Job is going to make a copy of the current user (UGI)
       // when it is instantiated.
       if (null != keytabPath) {
         File keytab = new File(keytabPath);
@@ -291,10 +299,12 @@ public class ClientOpts extends Help {
     if (null == principal) {
       AuthenticationToken token = getToken();
       if (null == token) {
-        throw new AccumuloSecurityException("No principal or authentication token was provided", SecurityErrorCode.BAD_CREDENTIALS);
+        throw new AccumuloSecurityException("No principal or authentication token was provided",
+            SecurityErrorCode.BAD_CREDENTIALS);
       }
 
-      // In MapReduce, if we create a DelegationToken, the principal is updated from the KerberosToken
+      // In MapReduce, if we create a DelegationToken, the principal is updated from the
+      // KerberosToken
       // used to obtain the DelegationToken.
       if (null != principal) {
         return principal;
@@ -389,7 +399,8 @@ public class ClientOpts extends Help {
       String instanceIDFromFile = ZooUtil.getInstanceIDFromHdfs(instanceDir, config);
       if (config.getBoolean(Property.INSTANCE_RPC_SSL_ENABLED))
         clientConfig.setProperty(ClientProperty.INSTANCE_RPC_SSL_ENABLED, "true");
-      return cachedClientConfig = clientConfig.withInstance(UUID.fromString(instanceIDFromFile)).withZkHosts(zookeepers);
+      return cachedClientConfig = clientConfig.withInstance(UUID.fromString(instanceIDFromFile))
+          .withZkHosts(zookeepers);
     }
     return cachedClientConfig = clientConfig.withInstance(instance).withZkHosts(zookeepers);
   }
diff --git a/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOnRequiredTable.java b/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOnRequiredTable.java
index caef02d..79b59e7 100644
--- a/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOnRequiredTable.java
+++ b/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOnRequiredTable.java
@@ -29,7 +29,8 @@ public class MapReduceClientOnRequiredTable extends MapReduceClientOpts {
   @Parameter(names = {"-t", "--table"}, required = true, description = "table to use")
   private String tableName;
 
-  @Parameter(names = {"-tf", "--tokenFile"}, description = "File in hdfs containing the user's authentication token create with \"bin/accumulo create-token\"")
+  @Parameter(names = {"-tf", "--tokenFile"},
+      description = "File in hdfs containing the user's authentication token create with \"bin/accumulo create-token\"")
   private String tokenFile = "";
 
   @Override
diff --git a/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOpts.java b/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOpts.java
index 2a5408b..71d8e1c 100644
--- a/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOpts.java
+++ b/core/src/main/java/org/apache/accumulo/core/cli/MapReduceClientOpts.java
@@ -62,11 +62,14 @@ public class MapReduceClientOpts extends ClientOpts {
         Connector conn = getInstance().getConnector(newPrincipal, krbToken);
 
         // Do the explicit check to see if the user has the permission to get a delegation token
-        if (!conn.securityOperations().hasSystemPermission(conn.whoami(), SystemPermission.OBTAIN_DELEGATION_TOKEN)) {
-          log.error("{} doesn't have the {} SystemPermission neccesary to obtain a delegation token. MapReduce tasks cannot automatically use the client's"
-              + " credentials on remote servers. Delegation tokens provide a means to run MapReduce without distributing the user's credentials.",
+        if (!conn.securityOperations().hasSystemPermission(conn.whoami(),
+            SystemPermission.OBTAIN_DELEGATION_TOKEN)) {
+          log.error(
+              "{} doesn't have the {} SystemPermission neccesary to obtain a delegation token. MapReduce tasks cannot automatically use the client's"
+                  + " credentials on remote servers. Delegation tokens provide a means to run MapReduce without distributing the user's credentials.",
               user.getUserName(), SystemPermission.OBTAIN_DELEGATION_TOKEN.name());
-          throw new IllegalStateException(conn.whoami() + " does not have permission to obtain a delegation token");
+          throw new IllegalStateException(
+              conn.whoami() + " does not have permission to obtain a delegation token");
         }
 
         // Get the delegation token from Accumulo
diff --git a/core/src/main/java/org/apache/accumulo/core/cli/ScannerOpts.java b/core/src/main/java/org/apache/accumulo/core/cli/ScannerOpts.java
index 439b374..37939fd 100644
--- a/core/src/main/java/org/apache/accumulo/core/cli/ScannerOpts.java
+++ b/core/src/main/java/org/apache/accumulo/core/cli/ScannerOpts.java
@@ -19,6 +19,7 @@ package org.apache.accumulo.core.cli;
 import com.beust.jcommander.Parameter;
 
 public class ScannerOpts {
-  @Parameter(names = "--scanBatchSize", description = "the number of key-values to pull during a scan")
+  @Parameter(names = "--scanBatchSize",
+      description = "the number of key-values to pull during a scan")
   public int scanBatchSize = 1000;
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/AccumuloSecurityException.java b/core/src/main/java/org/apache/accumulo/core/client/AccumuloSecurityException.java
index a614e8c..0881ac2 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/AccumuloSecurityException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/AccumuloSecurityException.java
@@ -21,7 +21,8 @@ import org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException;
 import org.apache.commons.lang.StringUtils;
 
 /**
- * An Accumulo Exception for security violations, authentication failures, authorization failures, etc.
+ * An Accumulo Exception for security violations, authentication failures, authorization failures,
+ * etc.
  *
  */
 public class AccumuloSecurityException extends Exception {
@@ -92,7 +93,8 @@ public class AccumuloSecurityException extends Exception {
    * @param cause
    *          the exception that caused this violation
    */
-  public AccumuloSecurityException(final String user, final SecurityErrorCode errorcode, final Throwable cause) {
+  public AccumuloSecurityException(final String user, final SecurityErrorCode errorcode,
+      final Throwable cause) {
     super(getDefaultErrorMessage(errorcode), cause);
     this.user = user;
     this.errorCode = errorcode == null ? SecurityErrorCode.DEFAULT_SECURITY_ERROR : errorcode;
@@ -108,7 +110,8 @@ public class AccumuloSecurityException extends Exception {
    * @param cause
    *          the exception that caused this violation
    */
-  public AccumuloSecurityException(final String user, final SecurityErrorCode errorcode, final String tableInfo, final Throwable cause) {
+  public AccumuloSecurityException(final String user, final SecurityErrorCode errorcode,
+      final String tableInfo, final Throwable cause) {
     super(getDefaultErrorMessage(errorcode), cause);
     this.user = user;
     this.errorCode = errorcode == null ? SecurityErrorCode.DEFAULT_SECURITY_ERROR : errorcode;
@@ -135,7 +138,8 @@ public class AccumuloSecurityException extends Exception {
    * @param tableInfo
    *          the relevant tableInfo for the security violation
    */
-  public AccumuloSecurityException(final String user, final SecurityErrorCode errorcode, final String tableInfo) {
+  public AccumuloSecurityException(final String user, final SecurityErrorCode errorcode,
+      final String tableInfo) {
     super(getDefaultErrorMessage(errorcode));
     this.user = user;
     this.errorCode = errorcode == null ? SecurityErrorCode.DEFAULT_SECURITY_ERROR : errorcode;
diff --git a/core/src/main/java/org/apache/accumulo/core/client/BatchScanner.java b/core/src/main/java/org/apache/accumulo/core/client/BatchScanner.java
index 402eb1a..8c33d09 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/BatchScanner.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/BatchScanner.java
@@ -22,10 +22,13 @@ import java.util.concurrent.TimeUnit;
 import org.apache.accumulo.core.data.Range;
 
 /**
- * In exchange for possibly <b>returning scanned entries out of order</b>, BatchScanner implementations may scan an Accumulo table more efficiently by
+ * In exchange for possibly <b>returning scanned entries out of order</b>, BatchScanner
+ * implementations may scan an Accumulo table more efficiently by
  * <ul>
- * <li>Looking up multiple ranges in parallel. Parallelism is constrained by the number of threads available to the BatchScanner, set in its constructor.</li>
- * <li>Breaking up large ranges into subranges. Often the number and boundaries of subranges are determined by a table's split points.</li>
+ * <li>Looking up multiple ranges in parallel. Parallelism is constrained by the number of threads
+ * available to the BatchScanner, set in its constructor.</li>
+ * <li>Breaking up large ranges into subranges. Often the number and boundaries of subranges are
+ * determined by a table's split points.</li>
  * <li>Combining multiple ranges into a single RPC call to a tablet server.</li>
  * </ul>
  *
@@ -33,15 +36,18 @@ import org.apache.accumulo.core.data.Range;
  * <ul>
  * <li>Retrieving many small ranges</li>
  * <li>Scanning a large range that returns many entries</li>
- * <li>Running server-side iterators that perform computation, even if few entries are returned from the scan itself</li>
+ * <li>Running server-side iterators that perform computation, even if few entries are returned from
+ * the scan itself</li>
  * </ul>
  *
- * To re-emphasize, only use a BatchScanner when you do not care whether returned data is in sorted order. Use a {@link Scanner} instead when sorted order is
- * important.
+ * To re-emphasize, only use a BatchScanner when you do not care whether returned data is in sorted
+ * order. Use a {@link Scanner} instead when sorted order is important.
  *
  * <p>
- * A BatchScanner instance will use no more threads than provided in the construction of the BatchScanner implementation. Multiple invocations of
- * <code>iterator()</code> will all share the same resources of the instance. A new BatchScanner instance should be created to use allocate additional threads.
+ * A BatchScanner instance will use no more threads than provided in the construction of the
+ * BatchScanner implementation. Multiple invocations of <code>iterator()</code> will all share the
+ * same resources of the instance. A new BatchScanner instance should be created to use allocate
+ * additional threads.
  */
 public interface BatchScanner extends ScannerBase {
 
@@ -60,8 +66,8 @@ public interface BatchScanner extends ScannerBase {
    * {@inheritDoc}
    *
    * <p>
-   * The batch scanner will accomplish as much work as possible before throwing an exception. BatchScanner iterators will throw a {@link TimedOutException} when
-   * all needed servers timeout.
+   * The batch scanner will accomplish as much work as possible before throwing an exception.
+   * BatchScanner iterators will throw a {@link TimedOutException} when all needed servers timeout.
    */
   @Override
   void setTimeout(long timeout, TimeUnit timeUnit);
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 95d87c5..da9601b 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
@@ -21,13 +21,16 @@ import org.apache.accumulo.core.data.Mutation;
 /**
  * Send Mutations to a single Table in Accumulo.
  * <p>
- * When the user uses a Connector to create a BatchWriter, they specify how much memory and how many threads it should use. As the user adds mutations to the
- * batch writer, it buffers them. Once the buffered mutations have used half of the user specified buffer, the mutations are dumped into the background to be
- * written by a thread pool. If the user specified memory completely fills up, then writes are held. When a user calls flush, it does not return until all
- * buffered mutations are written.
+ * When the user uses a Connector to create a BatchWriter, they specify how much memory and how many
+ * threads it should use. As the user adds mutations to the batch writer, it buffers them. Once the
+ * buffered mutations have used half of the user specified buffer, the mutations are dumped into the
+ * background to be written by a thread pool. If the user specified memory completely fills up, then
+ * writes are held. When a user calls flush, it does not return until all buffered mutations are
+ * written.
  * <p>
- * In the event that an MutationsRejectedException exception is thrown by one of the methods on a BatchWriter instance, the user should close the current
- * instance and create a new instance. This is a known limitation which will be addressed by ACCUMULO-2990 in the future.
+ * In the event that an MutationsRejectedException exception is thrown by one of the methods on a
+ * BatchWriter instance, the user should close the current instance and create a new instance. This
+ * is a known limitation which will be addressed by ACCUMULO-2990 in the future.
  */
 public interface BatchWriter extends AutoCloseable {
 
diff --git a/core/src/main/java/org/apache/accumulo/core/client/BatchWriterConfig.java b/core/src/main/java/org/apache/accumulo/core/client/BatchWriterConfig.java
index 521e0ce..f2ec775 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/BatchWriterConfig.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/BatchWriterConfig.java
@@ -52,8 +52,10 @@ public class BatchWriterConfig implements Writable {
   private Durability durability = Durability.DEFAULT;
 
   /**
-   * Sets the maximum memory to batch before writing. The smaller this value, the more frequently the {@link BatchWriter} will write.<br>
-   * If set to a value smaller than a single mutation, then it will {@link BatchWriter#flush()} after each added mutation. Must be non-negative.
+   * Sets the maximum memory to batch before writing. The smaller this value, the more frequently
+   * the {@link BatchWriter} will write.<br>
+   * If set to a value smaller than a single mutation, then it will {@link BatchWriter#flush()}
+   * after each added mutation. Must be non-negative.
    *
    * <p>
    * <b>Default:</b> 50M
@@ -76,9 +78,10 @@ public class BatchWriterConfig implements Writable {
    * For no maximum, set to zero, or {@link Long#MAX_VALUE} with {@link TimeUnit#MILLISECONDS}.
    *
    * <p>
-   * {@link TimeUnit#MICROSECONDS} or {@link TimeUnit#NANOSECONDS} will be truncated to the nearest {@link TimeUnit#MILLISECONDS}.<br>
-   * If this truncation would result in making the value zero when it was specified as non-zero, then a minimum value of one {@link TimeUnit#MILLISECONDS} will
-   * be used.
+   * {@link TimeUnit#MICROSECONDS} or {@link TimeUnit#NANOSECONDS} will be truncated to the nearest
+   * {@link TimeUnit#MILLISECONDS}.<br>
+   * If this truncation would result in making the value zero when it was specified as non-zero,
+   * then a minimum value of one {@link TimeUnit#MILLISECONDS} will be used.
    *
    * <p>
    * <b>Default:</b> 120 seconds
@@ -98,19 +101,22 @@ public class BatchWriterConfig implements Writable {
     if (maxLatency == 0)
       this.maxLatency = Long.MAX_VALUE;
     else
-      // make small, positive values that truncate to 0 when converted use the minimum millis instead
+      // make small, positive values that truncate to 0 when converted use the minimum millis
+      // instead
       this.maxLatency = Math.max(1, timeUnit.toMillis(maxLatency));
     return this;
   }
 
   /**
-   * Sets the maximum amount of time an unresponsive server will be re-tried. When this timeout is exceeded, the {@link BatchWriter} should throw an exception.<br>
+   * Sets the maximum amount of time an unresponsive server will be re-tried. When this timeout is
+   * exceeded, the {@link BatchWriter} should throw an exception.<br>
    * For no timeout, set to zero, or {@link Long#MAX_VALUE} with {@link TimeUnit#MILLISECONDS}.
    *
    * <p>
-   * {@link TimeUnit#MICROSECONDS} or {@link TimeUnit#NANOSECONDS} will be truncated to the nearest {@link TimeUnit#MILLISECONDS}.<br>
-   * If this truncation would result in making the value zero when it was specified as non-zero, then a minimum value of one {@link TimeUnit#MILLISECONDS} will
-   * be used.
+   * {@link TimeUnit#MICROSECONDS} or {@link TimeUnit#NANOSECONDS} will be truncated to the nearest
+   * {@link TimeUnit#MILLISECONDS}.<br>
+   * If this truncation would result in making the value zero when it was specified as non-zero,
+   * then a minimum value of one {@link TimeUnit#MILLISECONDS} will be used.
    *
    * <p>
    * <b>Default:</b> {@link Long#MAX_VALUE} (no timeout)
@@ -130,7 +136,8 @@ public class BatchWriterConfig implements Writable {
     if (timeout == 0)
       this.timeout = Long.MAX_VALUE;
     else
-      // make small, positive values that truncate to 0 when converted use the minimum millis instead
+      // make small, positive values that truncate to 0 when converted use the minimum millis
+      // instead
       this.timeout = Math.max(1, timeUnit.toMillis(timeout));
     return this;
   }
@@ -160,7 +167,8 @@ public class BatchWriterConfig implements Writable {
   }
 
   public long getMaxLatency(TimeUnit timeUnit) {
-    return timeUnit.convert(maxLatency != null ? maxLatency : DEFAULT_MAX_LATENCY, TimeUnit.MILLISECONDS);
+    return timeUnit.convert(maxLatency != null ? maxLatency : DEFAULT_MAX_LATENCY,
+        TimeUnit.MILLISECONDS);
   }
 
   public long getTimeout(TimeUnit timeUnit) {
@@ -180,8 +188,9 @@ public class BatchWriterConfig implements Writable {
   }
 
   /**
-   * Change the durability for the BatchWriter session. The default durability is "default" which is the table's durability setting. If the durability is set to
-   * something other than the default, it will override the durability setting of the table.
+   * Change the durability for the BatchWriter session. The default durability is "default" which is
+   * the table's durability setting. If the durability is set to something other than the default,
+   * it will override the durability setting of the table.
    *
    * @param durability
    *          the Durability to be used by the BatchWriter
@@ -230,7 +239,8 @@ public class BatchWriterConfig implements Writable {
     String strLen = new String(len, UTF_8);
     if (!strLen.endsWith("#"))
       throw new IllegalStateException("length was not encoded correctly");
-    byte[] bytes = new byte[Integer.parseInt(strLen.substring(strLen.lastIndexOf(' ') + 1, strLen.length() - 1), 36)];
+    byte[] bytes = new byte[Integer
+        .parseInt(strLen.substring(strLen.lastIndexOf(' ') + 1, strLen.length() - 1), 36)];
     in.readFully(bytes);
 
     String strFields = new String(bytes, UTF_8);
@@ -312,15 +322,18 @@ public class BatchWriterConfig implements Writable {
   @Override
   public int hashCode() {
     HashCodeBuilder hcb = new HashCodeBuilder();
-    hcb.append(maxMemory).append(maxLatency).append(maxWriteThreads).append(timeout).append(durability);
+    hcb.append(maxMemory).append(maxLatency).append(maxWriteThreads).append(timeout)
+        .append(durability);
     return hcb.toHashCode();
   }
 
   @Override
   public String toString() {
     StringBuilder sb = new StringBuilder(32);
-    sb.append("[maxMemory=").append(getMaxMemory()).append(", maxLatency=").append(getMaxLatency(TimeUnit.MILLISECONDS)).append(", maxWriteThreads=")
-        .append(getMaxWriteThreads()).append(", timeout=").append(getTimeout(TimeUnit.MILLISECONDS)).append(", durability=").append(durability).append("]");
+    sb.append("[maxMemory=").append(getMaxMemory()).append(", maxLatency=")
+        .append(getMaxLatency(TimeUnit.MILLISECONDS)).append(", maxWriteThreads=")
+        .append(getMaxWriteThreads()).append(", timeout=").append(getTimeout(TimeUnit.MILLISECONDS))
+        .append(", durability=").append(durability).append("]");
     return sb.toString();
   }
 }
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 a8622be..09c9e8b 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
@@ -53,7 +53,8 @@ import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 /**
- * Contains a list of property keys recognized by the Accumulo client and convenience methods for setting them.
+ * Contains a list of property keys recognized by the Accumulo client and convenience methods for
+ * setting them.
  *
  * @since 1.6.0
  */
@@ -82,8 +83,10 @@ public class ClientConfiguration extends CompositeConfiguration {
     INSTANCE_ZK_TIMEOUT(Property.INSTANCE_ZK_TIMEOUT),
 
     // Instance information
-    INSTANCE_NAME("instance.name", null, PropertyType.STRING, "Name of Accumulo instance to connect to"),
-    INSTANCE_ID("instance.id", null, PropertyType.STRING, "UUID of Accumulo instance to connect to"),
+    INSTANCE_NAME("instance.name", null, PropertyType.STRING,
+        "Name of Accumulo instance to connect to"),
+    INSTANCE_ID("instance.id", null, PropertyType.STRING,
+        "UUID of Accumulo instance to connect to"),
 
     // Tracing
     TRACE_SPAN_RECEIVERS(Property.TRACE_SPAN_RECEIVERS),
@@ -133,7 +136,8 @@ public class ClientConfiguration extends CompositeConfiguration {
     }
 
     /**
-     * @deprecated since 1.7.0 This method returns a type that is not part of the public API and not guaranteed to be stable.
+     * @deprecated since 1.7.0 This method returns a type that is not part of the public API and not
+     *             guaranteed to be stable.
      */
     @Deprecated
     public PropertyType getType() {
@@ -145,7 +149,8 @@ public class ClientConfiguration extends CompositeConfiguration {
     }
 
     /**
-     * @deprecated since 1.7.0 This method returns a type that is not part of the public API and not guaranteed to be stable.
+     * @deprecated since 1.7.0 This method returns a type that is not part of the public API and not
+     *             guaranteed to be stable.
      */
     @Deprecated
     public Property getAccumuloProperty() {
@@ -177,7 +182,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API; use {@link #fromFile(File)} instead.
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API; use {@link #fromFile(File)} instead.
    */
   @Deprecated
   public ClientConfiguration(String configFile) throws ConfigurationException {
@@ -189,7 +195,8 @@ public class ClientConfiguration extends CompositeConfiguration {
    *
    * @param configFile
    *          the path to the properties file
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API; use {@link #fromFile(File)} instead.
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API; use {@link #fromFile(File)} instead.
    */
   @Deprecated
   public ClientConfiguration(File configFile) throws ConfigurationException {
@@ -197,7 +204,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   public ClientConfiguration(List<? extends Configuration> configs) {
@@ -207,9 +215,11 @@ public class ClientConfiguration extends CompositeConfiguration {
     for (Configuration c : configs) {
       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");
+        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");
           abstractConfiguration.setListDelimiter('\0');
         }
       }
@@ -221,7 +231,8 @@ public class ClientConfiguration extends CompositeConfiguration {
    *
    * @see PropertiesConfiguration
    * @see #loadDefault()
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   public ClientConfiguration(Configuration... configs) {
@@ -229,8 +240,9 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * Attempts to load a configuration file from the system using the default search paths. Uses the <em>ACCUMULO_CLIENT_CONF_PATH</em> environment variable,
-   * split on <em>File.pathSeparator</em>, for a list of target files.
+   * Attempts to load a configuration file from the system using the default search paths. Uses the
+   * <em>ACCUMULO_CLIENT_CONF_PATH</em> environment variable, split on <em>File.pathSeparator</em>,
+   * for a list of target files.
    * <p>
    * If <em>ACCUMULO_CLIENT_CONF_PATH</em> is not set, uses the following in this order:
    * <ul>
@@ -240,8 +252,9 @@ public class ClientConfiguration extends CompositeConfiguration {
    * <li>/etc/accumulo/conf/client.conf
    * </ul>
    * <p>
-   * A client configuration will then be read from each location using <em>PropertiesConfiguration</em> to construct a configuration. That means the latest item
-   * will be the one in the configuration.
+   * A client configuration will then be read from each location using
+   * <em>PropertiesConfiguration</em> to construct a configuration. That means the latest item will
+   * be the one in the configuration.
    *
    * @see PropertiesConfiguration
    * @see File#pathSeparator
@@ -251,7 +264,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * Initializes an empty configuration object to be further configured with other methods on the class.
+   * Initializes an empty configuration object to be further configured with other methods on the
+   * class.
    *
    * @since 1.9.0
    */
@@ -260,8 +274,9 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * Initializes a configuration object from the contents of a configuration file. Currently supports Java "properties" files. The returned object can be
-   * further configured with subsequent calls to other methods on this class.
+   * Initializes a configuration object from the contents of a configuration file. Currently
+   * supports Java "properties" files. The returned object can be further configured with subsequent
+   * calls to other methods on this class.
    *
    * @param file
    *          the path to the configuration file
@@ -276,8 +291,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * Initializes a configuration object from the contents of a map. The returned object can be further configured with subsequent calls to other methods on this
-   * class.
+   * Initializes a configuration object from the contents of a map. The returned object can be
+   * further configured with subsequent calls to other methods on this class.
    *
    * @param properties
    *          a map containing the configuration properties to use
@@ -318,14 +333,16 @@ public class ClientConfiguration extends CompositeConfiguration {
     try {
       propConfig.load(new StringReader(serializedConfig));
     } catch (ConfigurationException e) {
-      throw new IllegalArgumentException("Error deserializing client configuration: " + serializedConfig, e);
+      throw new IllegalArgumentException(
+          "Error deserializing client configuration: " + serializedConfig, e);
     }
     return new ClientConfiguration(propConfig);
   }
 
   /**
-   * Muck the value of {@code clientConfPath} if it points to a directory by appending {@code client.conf} to the end of the file path. This is a no-op if the
-   * value is not a directory on the filesystem.
+   * Muck the value of {@code clientConfPath} if it points to a directory by appending
+   * {@code client.conf} to the end of the file path. This is a no-op if the value is not a
+   * directory on the filesystem.
    *
    * @param clientConfPath
    *          The value of ACCUMULO_CLIENT_CONF_PATH.
@@ -350,14 +367,18 @@ public class ClientConfiguration extends CompositeConfiguration {
     } else {
       // if $ACCUMULO_CLIENT_CONF_PATH env isn't set, priority from top to bottom is:
       // ~/.accumulo/config
-      // $ACCUMULO_CONF_DIR/client.conf -OR- $ACCUMULO_HOME/conf/client.conf (depending on whether $ACCUMULO_CONF_DIR is set)
+      // $ACCUMULO_CONF_DIR/client.conf -OR- $ACCUMULO_HOME/conf/client.conf (depending on whether
+      // $ACCUMULO_CONF_DIR is set)
       // /etc/accumulo/client.conf
       clientConfPaths = new LinkedList<>();
-      clientConfPaths.add(System.getProperty("user.home") + File.separator + USER_ACCUMULO_DIR_NAME + File.separator + USER_CONF_FILENAME);
+      clientConfPaths.add(System.getProperty("user.home") + File.separator + USER_ACCUMULO_DIR_NAME
+          + File.separator + USER_CONF_FILENAME);
       if (System.getenv("ACCUMULO_CONF_DIR") != null) {
-        clientConfPaths.add(System.getenv("ACCUMULO_CONF_DIR") + File.separator + GLOBAL_CONF_FILENAME);
+        clientConfPaths
+            .add(System.getenv("ACCUMULO_CONF_DIR") + File.separator + GLOBAL_CONF_FILENAME);
       } else if (System.getenv("ACCUMULO_HOME") != null) {
-        clientConfPaths.add(System.getenv("ACCUMULO_HOME") + File.separator + "conf" + File.separator + GLOBAL_CONF_FILENAME);
+        clientConfPaths.add(System.getenv("ACCUMULO_HOME") + File.separator + "conf"
+            + File.separator + GLOBAL_CONF_FILENAME);
       }
       clientConfPaths.add("/etc/accumulo/" + GLOBAL_CONF_FILENAME);
       clientConfPaths.add("/etc/accumulo/conf/" + GLOBAL_CONF_FILENAME);
@@ -391,7 +412,8 @@ public class ClientConfiguration extends CompositeConfiguration {
 
   private void checkType(ClientProperty property, PropertyType type) {
     if (!property.getType().equals(type)) {
-      String msg = "Configuration method intended for type " + type + " called with a " + property.getType() + " argument (" + property.getKey() + ")";
+      String msg = "Configuration method intended for type " + type + " called with a "
+          + property.getType() + " argument (" + property.getKey() + ")";
       throw new IllegalArgumentException(msg);
     }
   }
@@ -430,7 +452,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * Same as {@link #setProperty(ClientProperty, String)} but returns the ClientConfiguration for chaining purposes
+   * Same as {@link #setProperty(ClientProperty, String)} but returns the ClientConfiguration for
+   * chaining purposes
    */
   public ClientConfiguration with(ClientProperty prop, String value) {
     return with(prop.getKey(), value);
@@ -446,7 +469,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * Same as {@link #setProperty(String, String)} but returns the ClientConfiguration for chaining purposes
+   * Same as {@link #setProperty(String, String)} but returns the ClientConfiguration for chaining
+   * purposes
    *
    * @since 1.9.0
    */
@@ -499,11 +523,13 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * Same as {@link #with(ClientProperty, String)} for ClientProperty.INSTANCE_RPC_SSL_ENABLED and ClientProperty.RPC_USE_JSSE
+   * Same as {@link #with(ClientProperty, String)} for ClientProperty.INSTANCE_RPC_SSL_ENABLED and
+   * ClientProperty.RPC_USE_JSSE
    *
    */
   public ClientConfiguration withSsl(boolean sslEnabled, boolean useJsseConfig) {
-    return with(ClientProperty.INSTANCE_RPC_SSL_ENABLED, String.valueOf(sslEnabled)).with(ClientProperty.RPC_USE_JSSE, String.valueOf(useJsseConfig));
+    return with(ClientProperty.INSTANCE_RPC_SSL_ENABLED, String.valueOf(sslEnabled))
+        .with(ClientProperty.RPC_USE_JSSE, String.valueOf(useJsseConfig));
   }
 
   /**
@@ -515,8 +541,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * Same as {@link #with(ClientProperty, String)} for ClientProperty.RPC_SSL_TRUSTORE_PATH, ClientProperty.RPC_SSL_TRUSTORE_PASSWORD, and
-   * ClientProperty.RPC_SSL_TRUSTORE_TYPE
+   * Same as {@link #with(ClientProperty, String)} for ClientProperty.RPC_SSL_TRUSTORE_PATH,
+   * ClientProperty.RPC_SSL_TRUSTORE_PASSWORD, and ClientProperty.RPC_SSL_TRUSTORE_TYPE
    *
    */
   public ClientConfiguration withTruststore(String path, String password, String type) {
@@ -538,8 +564,9 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * Same as {@link #with(ClientProperty, String)} for ClientProperty.INSTANCE_RPC_SSL_CLIENT_AUTH, ClientProperty.RPC_SSL_KEYSTORE_PATH,
-   * ClientProperty.RPC_SSL_KEYSTORE_PASSWORD, and ClientProperty.RPC_SSL_KEYSTORE_TYPE
+   * Same as {@link #with(ClientProperty, String)} for ClientProperty.INSTANCE_RPC_SSL_CLIENT_AUTH,
+   * ClientProperty.RPC_SSL_KEYSTORE_PATH, ClientProperty.RPC_SSL_KEYSTORE_PASSWORD, and
+   * ClientProperty.RPC_SSL_KEYSTORE_TYPE
    *
    */
   public ClientConfiguration withKeystore(String path, String password, String type) {
@@ -568,24 +595,29 @@ public class ClientConfiguration extends CompositeConfiguration {
    * @since 1.9.0
    */
   public boolean hasSasl() {
-    return getBoolean(ClientProperty.INSTANCE_RPC_SASL_ENABLED.getKey(), Boolean.parseBoolean(ClientProperty.INSTANCE_RPC_SASL_ENABLED.getDefaultValue()));
+    return getBoolean(ClientProperty.INSTANCE_RPC_SASL_ENABLED.getKey(),
+        Boolean.parseBoolean(ClientProperty.INSTANCE_RPC_SASL_ENABLED.getDefaultValue()));
   }
 
   /**
-   * Same as {@link #with(ClientProperty, String)} for ClientProperty.INSTANCE_RPC_SASL_ENABLED and ClientProperty.GENERAL_KERBEROS_PRINCIPAL.
+   * Same as {@link #with(ClientProperty, String)} for ClientProperty.INSTANCE_RPC_SASL_ENABLED and
+   * ClientProperty.GENERAL_KERBEROS_PRINCIPAL.
    *
    * @param saslEnabled
    *          Should SASL(kerberos) be enabled
    * @param kerberosServerPrimary
-   *          The 'primary' component of the Kerberos principal Accumulo servers use to login (e.g. 'accumulo' in 'accumulo/_HOST@REALM')
+   *          The 'primary' component of the Kerberos principal Accumulo servers use to login (e.g.
+   *          'accumulo' in 'accumulo/_HOST@REALM')
    * @since 1.7.0
    */
   public ClientConfiguration withSasl(boolean saslEnabled, String kerberosServerPrimary) {
-    return withSasl(saslEnabled).with(ClientProperty.KERBEROS_SERVER_PRIMARY, kerberosServerPrimary);
+    return withSasl(saslEnabled).with(ClientProperty.KERBEROS_SERVER_PRIMARY,
+        kerberosServerPrimary);
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -594,7 +626,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -603,7 +636,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -612,7 +646,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -621,7 +656,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -630,7 +666,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -639,7 +676,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -648,7 +686,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -657,7 +696,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -666,7 +706,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -675,7 +716,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -684,7 +726,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -693,7 +736,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -702,7 +746,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -711,7 +756,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -720,7 +766,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -729,7 +776,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -738,7 +786,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -747,7 +796,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -756,7 +806,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -765,7 +816,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -774,7 +826,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -783,7 +836,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -792,7 +846,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -801,7 +856,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -815,25 +871,30 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
-  protected ConfigurationErrorEvent createErrorEvent(int type, String propName, Object propValue, Throwable ex) {
+  protected ConfigurationErrorEvent createErrorEvent(int type, String propName, Object propValue,
+      Throwable ex) {
     return super.createErrorEvent(type, propName, propValue, ex);
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
-  protected ConfigurationEvent createEvent(int type, String propName, Object propValue, boolean before) {
+  protected ConfigurationEvent createEvent(int type, String propName, Object propValue,
+      boolean before) {
     return super.createEvent(type, propName, propValue, before);
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -842,7 +903,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -851,7 +913,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -860,7 +923,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -869,7 +933,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -878,7 +943,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -887,7 +953,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -896,7 +963,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -905,7 +973,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -914,7 +983,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -923,7 +993,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -932,7 +1003,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -941,7 +1013,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -950,7 +1023,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @SuppressWarnings("rawtypes")
@@ -960,7 +1034,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -969,7 +1044,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -978,7 +1054,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -987,7 +1064,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @SuppressWarnings("rawtypes")
@@ -997,7 +1075,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1006,7 +1085,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1015,7 +1095,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1024,7 +1105,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1033,7 +1115,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1042,7 +1125,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1057,7 +1141,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @SuppressWarnings("unchecked")
@@ -1067,7 +1152,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @SuppressWarnings("rawtypes")
@@ -1077,7 +1163,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @SuppressWarnings("rawtypes")
@@ -1087,7 +1174,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1096,7 +1184,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1105,7 +1194,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1114,7 +1204,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1123,7 +1214,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1132,7 +1224,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1141,7 +1234,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1150,7 +1244,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1159,7 +1254,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1168,7 +1264,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1177,7 +1274,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1191,7 +1289,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1200,7 +1299,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1209,7 +1309,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1218,7 +1319,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1227,7 +1329,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @SuppressWarnings("rawtypes")
@@ -1237,7 +1340,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1246,7 +1350,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1255,7 +1360,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1264,7 +1370,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1273,7 +1380,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1282,7 +1390,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1291,7 +1400,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1300,7 +1410,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1309,7 +1420,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
@@ -1318,7 +1430,8 @@ public class ClientConfiguration extends CompositeConfiguration {
   }
 
   /**
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API
    */
   @Deprecated
   @Override
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 d4622c6..b940941 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
@@ -48,14 +48,16 @@ import org.apache.accumulo.core.security.Authorizations;
 import org.apache.hadoop.io.Text;
 
 /**
- * A scanner that instantiates iterators on the client side instead of on the tablet server. This can be useful for testing iterators or in cases where you
- * don't want iterators affecting the performance of tablet servers.<br>
+ * A scanner that instantiates iterators on the client side instead of on the tablet server. This
+ * can be useful for testing iterators or in cases where you don't want iterators affecting the
+ * performance of tablet servers.<br>
  * <br>
  * Suggested usage:<br>
  * <code>Scanner scanner = new ClientSideIteratorScanner(connector.createScanner(tableName, authorizations));</code><br>
  * <br>
- * Iterators added to this scanner will be run in the client JVM. Separate scan iterators can be run on the server side and client side by adding iterators to
- * the source scanner (which will execute server side) and to the client side scanner (which will execute client side).
+ * Iterators added to this scanner will be run in the client JVM. Separate scan iterators can be run
+ * on the server side and client side by adding iterators to the source scanner (which will execute
+ * server side) and to the client side scanner (which will execute client side).
  */
 public class ClientSideIteratorScanner extends ScannerOptions implements Scanner {
   private int size;
@@ -66,7 +68,8 @@ public class ClientSideIteratorScanner extends ScannerOptions implements Scanner
   private SamplerConfiguration iteratorSamplerConfig;
 
   /**
-   * @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 {
@@ -91,7 +94,8 @@ public class ClientSideIteratorScanner extends ScannerOptions implements Scanner
     }
 
     @Override
-    public SortedKeyValueIterator<Key,Value> reserveMapFileReader(String mapFileName) throws IOException {
+    public SortedKeyValueIterator<Key,Value> reserveMapFileReader(String mapFileName)
+        throws IOException {
       throw new UnsupportedOperationException();
     }
 
@@ -137,7 +141,8 @@ public class ClientSideIteratorScanner extends ScannerOptions implements Scanner
   }
 
   /**
-   * A class that wraps a Scanner in a SortedKeyValueIterator so that other accumulo iterators can use it as a source.
+   * A class that wraps a Scanner in a SortedKeyValueIterator so that other accumulo iterators can
+   * use it as a source.
    */
   private class ScannerTranslatorImpl implements SortedKeyValueIterator<Key,Value> {
     protected Scanner scanner;
@@ -157,7 +162,8 @@ public class ClientSideIteratorScanner extends ScannerOptions implements Scanner
     }
 
     @Override
-    public void init(final SortedKeyValueIterator<Key,Value> source, final Map<String,String> options, final IteratorEnvironment env) throws IOException {
+    public void init(final SortedKeyValueIterator<Key,Value> source,
+        final Map<String,String> options, final IteratorEnvironment env) throws IOException {
       throw new UnsupportedOperationException();
     }
 
@@ -175,7 +181,8 @@ public class ClientSideIteratorScanner extends ScannerOptions implements Scanner
     }
 
     @Override
-    public void seek(final Range range, final Collection<ByteSequence> columnFamilies, final boolean inclusive) throws IOException {
+    public void seek(final Range range, final Collection<ByteSequence> columnFamilies,
+        final boolean inclusive) throws IOException {
       if (!inclusive && columnFamilies.size() > 0) {
         throw new IllegalArgumentException();
       }
@@ -207,7 +214,8 @@ public class ClientSideIteratorScanner extends ScannerOptions implements Scanner
 
     @Override
     public SortedKeyValueIterator<Key,Value> deepCopy(final IteratorEnvironment env) {
-      return new ScannerTranslatorImpl(scanner, env.isSamplingEnabled() ? env.getSamplerConfiguration() : null);
+      return new ScannerTranslatorImpl(scanner,
+          env.isSamplingEnabled() ? env.getSamplerConfiguration() : null);
     }
   }
 
@@ -259,8 +267,10 @@ public class ClientSideIteratorScanner extends ScannerOptions implements Scanner
 
     SortedKeyValueIterator<Key,Value> skvi;
     try {
-      skvi = IteratorUtil.loadIterators(smi, tm.values(), serverSideIteratorOptions, new ClientSideIteratorEnvironment(getSamplerConfiguration() != null,
-          getIteratorSamplerConfigurationInternal()), false, null);
+      skvi = IteratorUtil.loadIterators(smi, tm.values(), serverSideIteratorOptions,
+          new ClientSideIteratorEnvironment(getSamplerConfiguration() != null,
+              getIteratorSamplerConfigurationInternal()),
+          false, null);
     } catch (IOException e) {
       throw new RuntimeException(e);
     }
@@ -340,7 +350,8 @@ public class ClientSideIteratorScanner extends ScannerOptions implements Scanner
   @Override
   public void setReadaheadThreshold(long batches) {
     if (0 > batches) {
-      throw new IllegalArgumentException("Number of batches before read-ahead must be non-negative");
+      throw new IllegalArgumentException(
+          "Number of batches before read-ahead must be non-negative");
     }
     this.readaheadThreshold = batches;
   }
@@ -359,8 +370,10 @@ public class ClientSideIteratorScanner extends ScannerOptions implements Scanner
   }
 
   /**
-   * This is provided for the case where no sampler configuration is set on the scanner, but there is a need to create iterator deep copies that have sampling
-   * enabled. If sampler configuration is set on the scanner, then this method does not need to be called inorder to create deep copies with sampling.
+   * This is provided for the case where no sampler configuration is set on the scanner, but there
+   * is a need to create iterator deep copies that have sampling enabled. If sampler configuration
+   * is set on the scanner, then this method does not need to be called inorder to create deep
+   * copies with sampling.
    *
    * <p>
    * Setting this differently than the scanners sampler configuration may cause exceptions.
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 d13dc09..667e5a0 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
@@ -23,8 +23,8 @@ import org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode;
 import org.apache.accumulo.core.data.ConditionalMutation;
 
 /**
- * ConditionalWriter provides the ability to do efficient, atomic read-modify-write operations on rows. These operations are performed on the tablet server
- * while a row lock is held.
+ * ConditionalWriter provides the ability to do efficient, atomic read-modify-write operations on
+ * rows. These operations are performed on the tablet server while a row lock is held.
  *
  * @since 1.6.0
  */
@@ -49,8 +49,9 @@ public interface ConditionalWriter extends AutoCloseable {
     }
 
     /**
-     * If this method throws an exception, then its possible the mutation is still being actively processed. Therefore if code chooses to continue after seeing
-     * an exception it should take this into consideration.
+     * If this method throws an exception, then its possible the mutation is still being actively
+     * processed. Therefore if code chooses to continue after seeing an exception it should take
+     * this into consideration.
      *
      * @return status of a conditional mutation
      */
@@ -61,7 +62,9 @@ public interface ConditionalWriter extends AutoCloseable {
           throw new AccumuloException(exception);
         if (exception instanceof AccumuloSecurityException) {
           AccumuloSecurityException ase = (AccumuloSecurityException) exception;
-          throw new AccumuloSecurityException(ase.getUser(), SecurityErrorCode.valueOf(ase.getSecurityErrorCode().name()), ase.getTableInfo(), ase);
+          throw new AccumuloSecurityException(ase.getUser(),
+              SecurityErrorCode.valueOf(ase.getSecurityErrorCode().name()), ase.getTableInfo(),
+              ase);
         } else
           throw new AccumuloException(exception);
       }
@@ -71,7 +74,8 @@ public interface ConditionalWriter extends AutoCloseable {
 
     /**
      *
-     * @return A copy of the mutation previously submitted by a user. The mutation will reference the same data, but the object may be different.
+     * @return A copy of the mutation previously submitted by a user. The mutation will reference
+     *         the same data, but the object may be different.
      */
     public ConditionalMutation getMutation() {
       return mutation;
@@ -100,8 +104,9 @@ public interface ConditionalWriter extends AutoCloseable {
      */
     VIOLATED,
     /**
-     * error occurred after mutation was sent to server, its unknown if the mutation was written. Although the status of the mutation is unknown, Accumulo
-     * guarantees the mutation will not be written at a later point in time.
+     * error occurred after mutation was sent to server, its unknown if the mutation was written.
+     * Although the status of the mutation is unknown, Accumulo guarantees the mutation will not be
+     * written at a later point in time.
      */
     UNKNOWN,
     /**
@@ -112,11 +117,12 @@ public interface ConditionalWriter extends AutoCloseable {
   }
 
   /**
-   * This method returns one result for each mutation passed to it. This method is thread safe. Multiple threads can safely use a single conditional writer.
-   * Sharing a conditional writer between multiple threads may result in batching of request to tablet servers.
+   * This method returns one result for each mutation passed to it. This method is thread safe.
+   * Multiple threads can safely use a single conditional writer. Sharing a conditional writer
+   * between multiple threads may result in batching of request to tablet servers.
    *
-   * @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.
+   * @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.
    */
   Iterator<Result> write(Iterator<ConditionalMutation> mutations);
 
diff --git a/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriterConfig.java b/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriterConfig.java
index ae4577d..e6099dd 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriterConfig.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriterConfig.java
@@ -42,9 +42,10 @@ public class ConditionalWriterConfig {
   private String classLoaderContext = null;
 
   /**
-   * A set of authorization labels that will be checked against the column visibility of each key in order to filter data. The authorizations passed in must be
-   * a subset of the accumulo user's set of authorizations. If the accumulo user has authorizations (A1, A2) and authorizations (A2, A3) are passed, then an
-   * exception will be thrown.
+   * A set of authorization labels that will be checked against the column visibility of each key in
+   * order to filter data. The authorizations passed in must be a subset of the accumulo user's set
+   * of authorizations. If the accumulo user has authorizations (A1, A2) and authorizations (A2, A3)
+   * are passed, then an exception will be thrown.
    *
    * <p>
    * Any condition that is not visible with this set of authorizations will fail.
@@ -56,14 +57,15 @@ public class ConditionalWriterConfig {
   }
 
   /**
-   * Sets the maximum amount of time an unresponsive server will be re-tried. When this timeout is exceeded, the {@link ConditionalWriter} should return the
-   * mutation with an exception.<br>
+   * Sets the maximum amount of time an unresponsive server will be re-tried. When this timeout is
+   * exceeded, the {@link ConditionalWriter} should return the mutation with an exception.<br>
    * For no timeout, set to zero, or {@link Long#MAX_VALUE} with {@link TimeUnit#MILLISECONDS}.
    *
    * <p>
-   * {@link TimeUnit#MICROSECONDS} or {@link TimeUnit#NANOSECONDS} will be truncated to the nearest {@link TimeUnit#MILLISECONDS}.<br>
-   * If this truncation would result in making the value zero when it was specified as non-zero, then a minimum value of one {@link TimeUnit#MILLISECONDS} will
-   * be used.
+   * {@link TimeUnit#MICROSECONDS} or {@link TimeUnit#NANOSECONDS} will be truncated to the nearest
+   * {@link TimeUnit#MILLISECONDS}.<br>
+   * If this truncation would result in making the value zero when it was specified as non-zero,
+   * then a minimum value of one {@link TimeUnit#MILLISECONDS} will be used.
    *
    * <p>
    * <b>Default:</b> {@link Long#MAX_VALUE} (no timeout)
@@ -83,7 +85,8 @@ public class ConditionalWriterConfig {
     if (timeout == 0)
       this.timeout = Long.MAX_VALUE;
     else
-      // make small, positive values that truncate to 0 when converted use the minimum millis instead
+      // make small, positive values that truncate to 0 when converted use the minimum millis
+      // instead
       this.timeout = Math.max(1, timeUnit.toMillis(timeout));
     return this;
   }
@@ -138,8 +141,8 @@ public class ConditionalWriterConfig {
   }
 
   /**
-   * Sets the name of the classloader context on this scanner. See the administration chapter of the user manual for details on how to configure and use
-   * classloader contexts.
+   * Sets the name of the classloader context on this scanner. See the administration chapter of the
+   * user manual for details on how to configure and use classloader contexts.
    *
    * @param classLoaderContext
    *          name of the classloader context
diff --git a/core/src/main/java/org/apache/accumulo/core/client/Connector.java b/core/src/main/java/org/apache/accumulo/core/client/Connector.java
index e36cc82..585ba37 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/Connector.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/Connector.java
@@ -24,10 +24,11 @@ import org.apache.accumulo.core.client.admin.TableOperations;
 import org.apache.accumulo.core.security.Authorizations;
 
 /**
- * Connector connects to an Accumulo instance and allows the user to request readers and writers for the instance as well as various objects that permit
- * administrative operations.
+ * Connector connects to an Accumulo instance and allows the user to request readers and writers for
+ * the instance as well as various objects that permit administrative operations.
  *
- * The Connector enforces security on the client side by forcing all API calls to be accompanied by user credentials.
+ * The Connector enforces security on the client side by forcing all API calls to be accompanied by
+ * user credentials.
  */
 public abstract class Connector {
 
@@ -37,9 +38,10 @@ public abstract class Connector {
    * @param tableName
    *          the name of the table to query
    * @param authorizations
-   *          A set of authorization labels that will be checked against the column visibility of each key in order to filter data. The authorizations passed in
-   *          must be a subset of the accumulo user's set of authorizations. If the accumulo user has authorizations (A1, A2) and authorizations (A2, A3) are
-   *          passed, then an exception will be thrown.
+   *          A set of authorization labels that will be checked against the column visibility of
+   *          each key in order to filter data. The authorizations passed in must be a subset of the
+   *          accumulo user's set of authorizations. If the accumulo user has authorizations (A1,
+   *          A2) and authorizations (A2, A3) are passed, then an exception will be thrown.
    * @param numQueryThreads
    *          the number of concurrent threads to spawn for querying
    *
@@ -47,7 +49,8 @@ public abstract class Connector {
    * @throws TableNotFoundException
    *           when the specified table doesn't exist
    */
-  public abstract BatchScanner createBatchScanner(String tableName, Authorizations authorizations, int numQueryThreads) throws TableNotFoundException;
+  public abstract BatchScanner createBatchScanner(String tableName, Authorizations authorizations,
+      int numQueryThreads) throws TableNotFoundException;
 
   /**
    * Factory method to create a BatchDeleter connected to Accumulo.
@@ -55,35 +58,41 @@ public abstract class Connector {
    * @param tableName
    *          the name of the table to query and delete from
    * @param authorizations
-   *          A set of authorization labels that will be checked against the column visibility of each key in order to filter data. The authorizations passed in
-   *          must be a subset of the accumulo user's set of authorizations. If the accumulo user has authorizations (A1, A2) and authorizations (A2, A3) are
-   *          passed, then an exception will be thrown.
+   *          A set of authorization labels that will be checked against the column visibility of
+   *          each key in order to filter data. The authorizations passed in must be a subset of the
+   *          accumulo user's set of authorizations. If the accumulo user has authorizations (A1,
+   *          A2) and authorizations (A2, A3) are passed, then an exception will be thrown.
    * @param numQueryThreads
    *          the number of concurrent threads to spawn for querying
    * @param maxMemory
    *          size in bytes of the maximum memory to batch before writing
    * @param maxLatency
-   *          size in milliseconds; set to 0 or Long.MAX_VALUE to allow the maximum time to hold a batch before writing
+   *          size in milliseconds; set to 0 or Long.MAX_VALUE to allow the maximum time to hold a
+   *          batch before writing
    * @param maxWriteThreads
    *          the maximum number of threads to use for writing data to the tablet servers
    *
    * @return BatchDeleter object for configuring and deleting
    * @throws TableNotFoundException
    *           when the specified table doesn't exist
-   * @deprecated since 1.5.0; Use {@link #createBatchDeleter(String, Authorizations, int, BatchWriterConfig)} instead.
+   * @deprecated since 1.5.0; Use
+   *             {@link #createBatchDeleter(String, Authorizations, int, BatchWriterConfig)}
+   *             instead.
    */
   @Deprecated
-  public abstract BatchDeleter createBatchDeleter(String tableName, Authorizations authorizations, int numQueryThreads, long maxMemory, long maxLatency,
-      int maxWriteThreads) throws TableNotFoundException;
+  public abstract BatchDeleter createBatchDeleter(String tableName, Authorizations authorizations,
+      int numQueryThreads, long maxMemory, long maxLatency, int maxWriteThreads)
+      throws TableNotFoundException;
 
   /**
    *
    * @param tableName
    *          the name of the table to query and delete from
    * @param authorizations
-   *          A set of authorization labels that will be checked against the column visibility of each key in order to filter data. The authorizations passed in
-   *          must be a subset of the accumulo user's set of authorizations. If the accumulo user has authorizations (A1, A2) and authorizations (A2, A3) are
-   *          passed, then an exception will be thrown.
+   *          A set of authorization labels that will be checked against the column visibility of
+   *          each key in order to filter data. The authorizations passed in must be a subset of the
+   *          accumulo user's set of authorizations. If the accumulo user has authorizations (A1,
+   *          A2) and authorizations (A2, A3) are passed, then an exception will be thrown.
    * @param numQueryThreads
    *          the number of concurrent threads to spawn for querying
    * @param config
@@ -92,8 +101,8 @@ public abstract class Connector {
    * @since 1.5.0
    */
 
-  public abstract BatchDeleter createBatchDeleter(String tableName, Authorizations authorizations, int numQueryThreads, BatchWriterConfig config)
-      throws TableNotFoundException;
+  public abstract BatchDeleter createBatchDeleter(String tableName, Authorizations authorizations,
+      int numQueryThreads, BatchWriterConfig config) throws TableNotFoundException;
 
   /**
    * Factory method to create a BatchWriter connected to Accumulo.
@@ -103,7 +112,8 @@ public abstract class Connector {
    * @param maxMemory
    *          size in bytes of the maximum memory to batch before writing
    * @param maxLatency
-   *          time in milliseconds; set to 0 or Long.MAX_VALUE to allow the maximum time to hold a batch before writing
+   *          time in milliseconds; set to 0 or Long.MAX_VALUE to allow the maximum time to hold a
+   *          batch before writing
    * @param maxWriteThreads
    *          the maximum number of threads to use for writing data to the tablet servers
    *
@@ -113,7 +123,8 @@ public abstract class Connector {
    * @deprecated since 1.5.0; Use {@link #createBatchWriter(String, BatchWriterConfig)} instead.
    */
   @Deprecated
-  public abstract BatchWriter createBatchWriter(String tableName, long maxMemory, long maxLatency, int maxWriteThreads) throws TableNotFoundException;
+  public abstract BatchWriter createBatchWriter(String tableName, long maxMemory, long maxLatency,
+      int maxWriteThreads) throws TableNotFoundException;
 
   /**
    * Factory method to create a BatchWriter connected to Accumulo.
@@ -126,16 +137,19 @@ public abstract class Connector {
    * @since 1.5.0
    */
 
-  public abstract BatchWriter createBatchWriter(String tableName, BatchWriterConfig config) throws TableNotFoundException;
+  public abstract BatchWriter createBatchWriter(String tableName, BatchWriterConfig config)
+      throws TableNotFoundException;
 
   /**
-   * Factory method to create a Multi-Table BatchWriter connected to Accumulo. Multi-table batch writers can queue data for multiple tables, which is good for
-   * ingesting data into multiple tables from the same source
+   * Factory method to create a Multi-Table BatchWriter connected to Accumulo. Multi-table batch
+   * writers can queue data for multiple tables, which is good for ingesting data into multiple
+   * tables from the same source
    *
    * @param maxMemory
    *          size in bytes of the maximum memory to batch before writing
    * @param maxLatency
-   *          size in milliseconds; set to 0 or Long.MAX_VALUE to allow the maximum time to hold a batch before writing
+   *          size in milliseconds; set to 0 or Long.MAX_VALUE to allow the maximum time to hold a
+   *          batch before writing
    * @param maxWriteThreads
    *          the maximum number of threads to use for writing data to the tablet servers
    *
@@ -143,11 +157,14 @@ public abstract class Connector {
    * @deprecated since 1.5.0; Use {@link #createMultiTableBatchWriter(BatchWriterConfig)} instead.
    */
   @Deprecated
-  public abstract MultiTableBatchWriter createMultiTableBatchWriter(long maxMemory, long maxLatency, int maxWriteThreads);
+  public abstract MultiTableBatchWriter createMultiTableBatchWriter(long maxMemory, long maxLatency,
+      int maxWriteThreads);
 
   /**
-   * Factory method to create a Multi-Table BatchWriter connected to Accumulo. Multi-table batch writers can queue data for multiple tables. Also data for
-   * multiple tables can be sent to a server in a single batch. Its an efficient way to ingest data into multiple tables from a single process.
+   * Factory method to create a Multi-Table BatchWriter connected to Accumulo. Multi-table batch
+   * writers can queue data for multiple tables. Also data for multiple tables can be sent to a
+   * server in a single batch. Its an efficient way to ingest data into multiple tables from a
+   * single process.
    *
    * @param config
    *          configuration used to create multi-table batch writer
@@ -163,15 +180,17 @@ public abstract class Connector {
    * @param tableName
    *          the name of the table to query data from
    * @param authorizations
-   *          A set of authorization labels that will be checked against the column visibility of each key in order to filter data. The authorizations passed in
-   *          must be a subset of the accumulo user's set of authorizations. If the accumulo user has authorizations (A1, A2) and authorizations (A2, A3) are
-   *          passed, then an exception will be thrown.
+   *          A set of authorization labels that will be checked against the column visibility of
+   *          each key in order to filter data. The authorizations passed in must be a subset of the
+   *          accumulo user's set of authorizations. If the accumulo user has authorizations (A1,
+   *          A2) and authorizations (A2, A3) are passed, then an exception will be thrown.
    *
    * @return Scanner object for configuring and querying data with
    * @throws TableNotFoundException
    *           when the specified table doesn't exist
    */
-  public abstract Scanner createScanner(String tableName, Authorizations authorizations) throws TableNotFoundException;
+  public abstract Scanner createScanner(String tableName, Authorizations authorizations)
+      throws TableNotFoundException;
 
   /**
    * Factory method to create a ConditionalWriter connected to Accumulo.
@@ -186,7 +205,8 @@ public abstract class Connector {
    *           when the specified table doesn't exist
    * @since 1.6.0
    */
-  public abstract ConditionalWriter createConditionalWriter(String tableName, ConditionalWriterConfig config) throws TableNotFoundException;
+  public abstract ConditionalWriter createConditionalWriter(String tableName,
+      ConditionalWriterConfig config) throws TableNotFoundException;
 
   /**
    * Accessor method for internal instance object.
@@ -210,14 +230,16 @@ public abstract class Connector {
   public abstract TableOperations tableOperations();
 
   /**
-   * Retrieves a NamespaceOperations object to perform namespace functions, such as create and delete.
+   * Retrieves a NamespaceOperations object to perform namespace functions, such as create and
+   * delete.
    *
    * @return an object to manipulate namespaces
    */
   public abstract NamespaceOperations namespaceOperations();
 
   /**
-   * Retrieves a SecurityOperations object to perform user security operations, such as creating users.
+   * Retrieves a SecurityOperations object to perform user security operations, such as creating
+   * users.
    *
    * @return an object to modify users and permissions
    */
diff --git a/core/src/main/java/org/apache/accumulo/core/client/Durability.java b/core/src/main/java/org/apache/accumulo/core/client/Durability.java
index 08b2092..ff42b54 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/Durability.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/Durability.java
@@ -32,11 +32,13 @@ public enum Durability {
    */
   NONE,
   /**
-   * Write mutations the the write-ahead log. Data may be sitting the the servers output buffers, and not replicated anywhere.
+   * Write mutations the the write-ahead log. Data may be sitting the the servers output buffers,
+   * and not replicated anywhere.
    */
   LOG,
   /**
-   * Write mutations to the write-ahead log, and ensure the data is stored on remote servers, but perhaps not on persistent storage.
+   * Write mutations to the write-ahead log, and ensure the data is stored on remote servers, but
+   * perhaps not on persistent storage.
    */
   FLUSH,
   /**
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 8a70d4c..bbc06e7 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
@@ -25,7 +25,8 @@ import org.apache.accumulo.core.client.security.tokens.PasswordToken;
 import org.apache.accumulo.core.conf.AccumuloConfiguration;
 
 /**
- * This class represents the information a client needs to know to connect to an instance of accumulo.
+ * This class represents the information a client needs to know to connect to an instance of
+ * accumulo.
  *
  */
 public interface Instance {
@@ -83,10 +84,12 @@ public interface Instance {
    *           when a generic exception occurs
    * @throws AccumuloSecurityException
    *           when a user's credentials are invalid
-   * @deprecated since 1.5, use {@link #getConnector(String, AuthenticationToken)} with {@link PasswordToken}
+   * @deprecated since 1.5, use {@link #getConnector(String, AuthenticationToken)} with
+   *             {@link PasswordToken}
    */
   @Deprecated
-  Connector getConnector(String user, byte[] pass) throws AccumuloException, AccumuloSecurityException;
+  Connector getConnector(String user, byte[] pass)
+      throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Returns a connection to accumulo.
@@ -100,10 +103,12 @@ public interface Instance {
    *           when a generic exception occurs
    * @throws AccumuloSecurityException
    *           when a user's credentials are invalid
-   * @deprecated since 1.5, use {@link #getConnector(String, AuthenticationToken)} with {@link PasswordToken}
+   * @deprecated since 1.5, use {@link #getConnector(String, AuthenticationToken)} with
+   *             {@link PasswordToken}
    */
   @Deprecated
-  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.
@@ -117,17 +122,22 @@ public interface Instance {
    *           when a generic exception occurs
    * @throws AccumuloSecurityException
    *           when a user's credentials are invalid
-   * @deprecated since 1.5, use {@link #getConnector(String, AuthenticationToken)} with {@link PasswordToken}
+   * @deprecated since 1.5, use {@link #getConnector(String, AuthenticationToken)} with
+   *             {@link PasswordToken}
    */
   @Deprecated
-  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.
    *
-   * @return the AccumuloConfiguration that specifies properties related to interacting with this instance
-   * @deprecated since 1.6.0. This method makes very little sense in the context of the client API and never should have been exposed.
-   * @see InstanceOperations#getSystemConfiguration() for client-side reading of the server-side configuration.
+   * @return the AccumuloConfiguration that specifies properties related to interacting with this
+   *         instance
+   * @deprecated since 1.6.0. This method makes very little sense in the context of the client API
+   *             and never should have been exposed.
+   * @see InstanceOperations#getSystemConfiguration() for client-side reading of the server-side
+   *      configuration.
    */
   @Deprecated
   AccumuloConfiguration getConfiguration();
@@ -137,7 +147,8 @@ public interface Instance {
    *
    * @param conf
    *          accumulo configuration
-   * @deprecated since 1.6.0. This method makes very little sense in the context of the client API and never should have been exposed.
+   * @deprecated since 1.6.0. This method makes very little sense in the context of the client API
+   *             and never should have been exposed.
    * @see InstanceOperations#setProperty(String, String)
    */
   @Deprecated
@@ -149,9 +160,10 @@ public interface Instance {
    * @param principal
    *          a valid accumulo user
    * @param token
-   *          Use the token type configured for the Accumulo instance you are connecting to. An Accumulo instance with default configurations will use
-   *          {@link PasswordToken}
+   *          Use the token type configured for the Accumulo instance you are connecting to. An
+   *          Accumulo instance with default configurations will use {@link PasswordToken}
    * @since 1.5.0
    */
-  Connector getConnector(String principal, AuthenticationToken token) throws AccumuloException, AccumuloSecurityException;
+  Connector getConnector(String principal, AuthenticationToken token)
+      throws AccumuloException, AccumuloSecurityException;
 }
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 f1065f8..d4120ee 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
@@ -33,8 +33,10 @@ import org.apache.accumulo.core.data.Value;
 import org.apache.hadoop.io.Text;
 
 /**
- * A scanner that presents a row isolated view of an accumulo table. Rows are buffered in memory on the client side. If you think your rows may not fit into
- * memory, then you can provide an alternative row buffer factory to the constructor. This would allow rows to be buffered to disk for example.
+ * A scanner that presents a row isolated view of an accumulo table. Rows are buffered in memory on
+ * the client side. If you think your rows may not fit into memory, then you can provide an
+ * alternative row buffer factory to the constructor. This would allow rows to be buffered to disk
+ * for example.
  *
  */
 
@@ -133,8 +135,8 @@ public class IsolatedScanner extends ScannerOptions implements Scanner {
       }
     }
 
-    public RowBufferingIterator(Scanner scanner, ScannerOptions opts, Range range, long timeout, int batchSize, long readaheadThreshold,
-        RowBufferFactory bufferFactory) {
+    public RowBufferingIterator(Scanner scanner, ScannerOptions opts, Range range, long timeout,
+        int batchSize, long readaheadThreshold, RowBufferFactory bufferFactory) {
       this.scanner = scanner;
       this.opts = new ScannerOptions(opts);
       this.range = range;
@@ -235,7 +237,8 @@ public class IsolatedScanner extends ScannerOptions implements Scanner {
 
   @Override
   public Iterator<Entry<Key,Value>> iterator() {
-    return new RowBufferingIterator(scanner, this, range, timeOut, batchSize, readaheadThreshold, bufferFactory);
+    return new RowBufferingIterator(scanner, this, range, timeOut, batchSize, readaheadThreshold,
+        bufferFactory);
   }
 
   @Deprecated
@@ -294,7 +297,8 @@ public class IsolatedScanner extends ScannerOptions implements Scanner {
   @Override
   public void setReadaheadThreshold(long batches) {
     if (0 > batches) {
-      throw new IllegalArgumentException("Number of batches before read-ahead must be non-negative");
+      throw new IllegalArgumentException(
+          "Number of batches before read-ahead must be non-negative");
     }
 
     this.readaheadThreshold = batches;
diff --git a/core/src/main/java/org/apache/accumulo/core/client/IteratorSetting.java b/core/src/main/java/org/apache/accumulo/core/client/IteratorSetting.java
index fdaacd7..e2a0b62 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/IteratorSetting.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/IteratorSetting.java
@@ -36,7 +36,8 @@ import org.apache.hadoop.io.Writable;
 import org.apache.hadoop.io.WritableUtils;
 
 /**
- * Configure an iterator for minc, majc, and/or scan. By default, IteratorSetting will be configured for scan.
+ * Configure an iterator for minc, majc, and/or scan. By default, IteratorSetting will be configured
+ * for scan.
  *
  * Every iterator has a priority, a name, a class, a set of scopes, and configuration parameters.
  *
@@ -55,7 +56,8 @@ public class IteratorSetting implements Writable {
   private Map<String,String> properties;
 
   /**
-   * Get layer at which this iterator applies. See {@link #setPriority(int)} for how the priority is used.
+   * Get layer at which this iterator applies. See {@link #setPriority(int)} for how the priority is
+   * used.
    *
    * @return the priority of this Iterator
    */
@@ -67,8 +69,8 @@ public class IteratorSetting implements Writable {
    * Set layer at which this iterator applies.
    *
    * @param priority
-   *          determines the order in which iterators are applied (system iterators are always applied first, then user-configured iterators, lowest priority
-   *          first)
+   *          determines the order in which iterators are applied (system iterators are always
+   *          applied first, then user-configured iterators, lowest priority first)
    */
   public void setPriority(int priority) {
     checkArgument(priority > 0, "property must be strictly positive");
@@ -85,7 +87,8 @@ public class IteratorSetting implements Writable {
   }
 
   /**
-   * Set the iterator's name. Must be a simple alphanumeric identifier. The iterator name also may not contain a dot/period.
+   * Set the iterator's name. Must be a simple alphanumeric identifier. The iterator name also may
+   * not contain a dot/period.
    */
   public void setName(String name) {
     checkArgument(name != null, "name is null");
@@ -103,8 +106,8 @@ public class IteratorSetting implements Writable {
   }
 
   /**
-   * Set the name of the class that implements the iterator. The class does not have to be present on the client, but it must be available to all tablet
-   * servers.
+   * Set the name of the class that implements the iterator. The class does not have to be present
+   * on the client, but it must be available to all tablet servers.
    */
   public void setIteratorClass(String iteratorClass) {
     checkArgument(iteratorClass != null, "iteratorClass is null");
@@ -112,7 +115,8 @@ public class IteratorSetting implements Writable {
   }
 
   /**
-   * Constructs an iterator setting configured for the scan scope with no parameters. (Parameters can be added later.)
+   * Constructs an iterator setting configured for the scan scope with no parameters. (Parameters
+   * can be added later.)
    *
    * @param priority
    *          the priority for the iterator (see {@link #setPriority(int)})
@@ -126,7 +130,8 @@ public class IteratorSetting implements Writable {
   }
 
   /**
-   * Constructs an iterator setting configured for the specified scopes with the specified parameters.
+   * Constructs an iterator setting configured for the specified scopes with the specified
+   * parameters.
    *
    * @param priority
    *          the priority for the iterator (see {@link #setPriority(int)})
@@ -137,7 +142,8 @@ public class IteratorSetting implements Writable {
    * @param properties
    *          any properties for the iterator
    */
-  public IteratorSetting(int priority, String name, String iteratorClass, Map<String,String> properties) {
+  public IteratorSetting(int priority, String name, String iteratorClass,
+      Map<String,String> properties) {
     setPriority(priority);
     setName(name);
     setIteratorClass(iteratorClass);
@@ -146,22 +152,23 @@ public class IteratorSetting implements Writable {
   }
 
   /**
-   * Constructs an iterator setting using the given class's SimpleName for the iterator name. The iterator setting will be configured for the scan scope with no
-   * parameters.
+   * Constructs an iterator setting using the given class's SimpleName for the iterator name. The
+   * iterator setting will be configured for the scan scope with no parameters.
    *
    * @param priority
    *          the priority for the iterator (see {@link #setPriority(int)})
    * @param iteratorClass
    *          the class for the iterator
    */
-  public IteratorSetting(int priority, Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass) {
+  public IteratorSetting(int priority,
+      Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass) {
     this(priority, iteratorClass.getSimpleName(), iteratorClass.getName());
   }
 
   /**
    *
-   * Constructs an iterator setting using the given class's SimpleName for the iterator name and configured for the specified scopes with the specified
-   * parameters.
+   * Constructs an iterator setting using the given class's SimpleName for the iterator name and
+   * configured for the specified scopes with the specified parameters.
    *
    * @param priority
    *          the priority for the iterator (see {@link #setPriority(int)})
@@ -170,7 +177,9 @@ public class IteratorSetting implements Writable {
    * @param properties
    *          any properties for the iterator
    */
-  public IteratorSetting(int priority, Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass, Map<String,String> properties) {
+  public IteratorSetting(int priority,
+      Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass,
+      Map<String,String> properties) {
     this(priority, iteratorClass.getSimpleName(), iteratorClass.getName(), properties);
   }
 
@@ -184,12 +193,14 @@ public class IteratorSetting implements Writable {
    * @param iteratorClass
    *          the class for the iterator
    */
-  public IteratorSetting(int priority, String name, Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass) {
+  public IteratorSetting(int priority, String name,
+      Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass) {
     this(priority, name, iteratorClass.getName());
   }
 
   /**
-   * Constructs an iterator setting using the provided name and the provided class's name for the scan scope with the provided parameters.
+   * Constructs an iterator setting using the provided name and the provided class's name for the
+   * scan scope with the provided parameters.
    *
    * @param priority
    *          The priority for the iterator (see {@link #setPriority(int)})
@@ -202,7 +213,9 @@ public class IteratorSetting implements Writable {
    *
    * @since 1.6.0
    */
-  public IteratorSetting(int priority, String name, Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass, Map<String,String> properties) {
+  public IteratorSetting(int priority, String name,
+      Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass,
+      Map<String,String> properties) {
     this(priority, name, iteratorClass.getName(), properties);
   }
 
@@ -335,7 +348,8 @@ public class IteratorSetting implements Writable {
   }
 
   /**
-   * A convenience class for passing column family and column qualifiers to iterator configuration methods.
+   * A convenience class for passing column family and column qualifiers to iterator configuration
+   * methods.
    */
   public static class Column extends Pair<Text,Text> {
 
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 5495598..399eda8 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
@@ -17,8 +17,9 @@
 package org.apache.accumulo.core.client;
 
 /**
- * This class enables efficient batch writing to multiple tables. When creating a batch writer for each table, each has its own memory and network resources.
- * Using this class these resources may be shared among multiple tables.
+ * This class enables efficient batch writing to multiple tables. When creating a batch writer for
+ * each table, each has its own memory and network resources. Using this class these resources may
+ * be shared among multiple tables.
  *
  */
 public interface MultiTableBatchWriter {
@@ -36,7 +37,8 @@ public interface MultiTableBatchWriter {
    * @throws TableNotFoundException
    *           when the table does not exist
    */
-  BatchWriter getBatchWriter(String table) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
+  BatchWriter getBatchWriter(String table)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 
   /**
    * Send mutations for all tables to accumulo.
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 676957a..8bade1c 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
@@ -65,13 +65,17 @@ public class MutationsRejectedException extends AccumuloException {
    * @param unknownErrors
    *          number of unknown errors
    *
-   * @deprecated since 1.6.0, see {@link #MutationsRejectedException(Instance, List, Map, Collection, int, Throwable)}
+   * @deprecated since 1.6.0, see
+   *             {@link #MutationsRejectedException(Instance, List, Map, Collection, int, Throwable)}
    */
   @Deprecated
-  public MutationsRejectedException(List<ConstraintViolationSummary> cvsList, HashMap<org.apache.accumulo.core.data.KeyExtent,Set<SecurityErrorCode>> hashMap,
+  public MutationsRejectedException(List<ConstraintViolationSummary> cvsList,
+      HashMap<org.apache.accumulo.core.data.KeyExtent,Set<SecurityErrorCode>> hashMap,
       Collection<String> serverSideErrors, int unknownErrors, Throwable cause) {
-    super("# constraint violations : " + cvsList.size() + "  security codes: " + hashMap.values() + "  # server errors " + serverSideErrors.size()
-        + " # exceptions " + unknownErrors, cause);
+    super(
+        "# constraint violations : " + cvsList.size() + "  security codes: " + hashMap.values()
+            + "  # server errors " + serverSideErrors.size() + " # exceptions " + unknownErrors,
+        cause);
     this.cvsl = cvsList;
     this.af = transformKeys(hashMap, TabletIdImpl.KE_2_TID_OLD);
     this.es = serverSideErrors;
@@ -88,13 +92,18 @@ public class MutationsRejectedException extends AccumuloException {
    * @param unknownErrors
    *          number of unknown errors
    *
-   * @deprecated since 1.7.0 see {@link #MutationsRejectedException(Instance, List, Map, Collection, int, Throwable)}
+   * @deprecated since 1.7.0 see
+   *             {@link #MutationsRejectedException(Instance, List, Map, Collection, int, Throwable)}
    */
   @Deprecated
   public MutationsRejectedException(Instance instance, List<ConstraintViolationSummary> cvsList,
-      HashMap<org.apache.accumulo.core.data.KeyExtent,Set<SecurityErrorCode>> hashMap, Collection<String> serverSideErrors, int unknownErrors, Throwable cause) {
-    super("# constraint violations : " + cvsList.size() + "  security codes: " + format(transformKeys(hashMap, TabletIdImpl.KE_2_TID_OLD), instance)
-        + "  # server errors " + serverSideErrors.size() + " # exceptions " + unknownErrors, cause);
+      HashMap<org.apache.accumulo.core.data.KeyExtent,Set<SecurityErrorCode>> hashMap,
+      Collection<String> serverSideErrors, int unknownErrors, Throwable cause) {
+    super(
+        "# constraint violations : " + cvsList.size() + "  security codes: "
+            + format(transformKeys(hashMap, TabletIdImpl.KE_2_TID_OLD), instance)
+            + "  # server errors " + serverSideErrors.size() + " # exceptions " + unknownErrors,
+        cause);
     this.cvsl = cvsList;
     this.af = transformKeys(hashMap, TabletIdImpl.KE_2_TID_OLD);
     this.es = serverSideErrors;
@@ -114,9 +123,11 @@ public class MutationsRejectedException extends AccumuloException {
    *
    * @since 1.7.0
    */
-  public MutationsRejectedException(Instance instance, List<ConstraintViolationSummary> cvsList, Map<TabletId,Set<SecurityErrorCode>> hashMap,
-      Collection<String> serverSideErrors, int unknownErrors, Throwable cause) {
-    super("# constraint violations : " + cvsList.size() + "  security codes: " + format(hashMap, instance) + "  # server errors " + serverSideErrors.size()
+  public MutationsRejectedException(Instance instance, List<ConstraintViolationSummary> cvsList,
+      Map<TabletId,Set<SecurityErrorCode>> hashMap, Collection<String> serverSideErrors,
+      int unknownErrors, Throwable cause) {
+    super("# constraint violations : " + cvsList.size() + "  security codes: "
+        + format(hashMap, instance) + "  # server errors " + serverSideErrors.size()
         + " # exceptions " + unknownErrors, cause);
     this.cvsl = cvsList;
     this.af = hashMap;
@@ -128,7 +139,8 @@ public class MutationsRejectedException extends AccumuloException {
     Map<String,Set<SecurityErrorCode>> result = new HashMap<>();
 
     for (Entry<TabletId,Set<SecurityErrorCode>> entry : hashMap.entrySet()) {
-      String tableInfo = Tables.getPrintableTableInfoFromId(instance, entry.getKey().getTableId().toString());
+      String tableInfo = Tables.getPrintableTableInfoFromId(instance,
+          entry.getKey().getTableId().toString());
 
       if (!result.containsKey(tableInfo)) {
         result.put(tableInfo, new HashSet<SecurityErrorCode>());
diff --git a/core/src/main/java/org/apache/accumulo/core/client/NamespaceExistsException.java b/core/src/main/java/org/apache/accumulo/core/client/NamespaceExistsException.java
index 223ab3f..aa31717 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/NamespaceExistsException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/NamespaceExistsException.java
@@ -37,9 +37,11 @@ public class NamespaceExistsException extends Exception {
    *          the specific reason why it failed
    */
   public NamespaceExistsException(String namespaceId, String namespaceName, String description) {
-    super("Namespace" + (namespaceName != null && !namespaceName.isEmpty() ? " " + namespaceName : "")
-        + (namespaceId != null && !namespaceId.isEmpty() ? " (Id=" + namespaceId + ")" : "") + " exists"
-        + (description != null && !description.isEmpty() ? " (" + description + ")" : ""));
+    super(
+        "Namespace" + (namespaceName != null && !namespaceName.isEmpty() ? " " + namespaceName : "")
+            + (namespaceId != null && !namespaceId.isEmpty() ? " (Id=" + namespaceId + ")" : "")
+            + " exists"
+            + (description != null && !description.isEmpty() ? " (" + description + ")" : ""));
   }
 
   /**
@@ -52,7 +54,8 @@ public class NamespaceExistsException extends Exception {
    * @param cause
    *          the exception that caused this failure
    */
-  public NamespaceExistsException(String namespaceId, String namespaceName, String description, Throwable cause) {
+  public NamespaceExistsException(String namespaceId, String namespaceName, String description,
+      Throwable cause) {
     this(namespaceId, namespaceName, description);
     super.initCause(cause);
   }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/NamespaceNotEmptyException.java b/core/src/main/java/org/apache/accumulo/core/client/NamespaceNotEmptyException.java
index d5542bf..854be60 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/NamespaceNotEmptyException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/NamespaceNotEmptyException.java
@@ -36,9 +36,11 @@ public class NamespaceNotEmptyException extends Exception {
    *          the specific reason why it failed
    */
   public NamespaceNotEmptyException(String namespaceId, String namespaceName, String description) {
-    super("Namespace" + (namespaceName != null && !namespaceName.isEmpty() ? " " + namespaceName : "")
-        + (namespaceId != null && !namespaceId.isEmpty() ? " (Id=" + namespaceId + ")" : "") + " it not empty, contains at least one table"
-        + (description != null && !description.isEmpty() ? " (" + description + ")" : ""));
+    super(
+        "Namespace" + (namespaceName != null && !namespaceName.isEmpty() ? " " + namespaceName : "")
+            + (namespaceId != null && !namespaceId.isEmpty() ? " (Id=" + namespaceId + ")" : "")
+            + " it not empty, contains at least one table"
+            + (description != null && !description.isEmpty() ? " (" + description + ")" : ""));
     this.namespace = namespaceName;
   }
 
@@ -52,7 +54,8 @@ public class NamespaceNotEmptyException extends Exception {
    * @param cause
    *          the exception that caused this failure
    */
-  public NamespaceNotEmptyException(String namespaceId, String namespaceName, String description, Throwable cause) {
+  public NamespaceNotEmptyException(String namespaceId, String namespaceName, String description,
+      Throwable cause) {
     this(namespaceId, namespaceName, description);
     super.initCause(cause);
   }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/NamespaceNotFoundException.java b/core/src/main/java/org/apache/accumulo/core/client/NamespaceNotFoundException.java
index e330d69..a12ba45 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/NamespaceNotFoundException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/NamespaceNotFoundException.java
@@ -39,9 +39,11 @@ public class NamespaceNotFoundException extends Exception {
    *          the specific reason why it failed
    */
   public NamespaceNotFoundException(String namespaceId, String namespaceName, String description) {
-    super("Namespace" + (namespaceName != null && !namespaceName.isEmpty() ? " " + namespaceName : "")
-        + (namespaceId != null && !namespaceId.isEmpty() ? " (Id=" + namespaceId + ")" : "") + " does not exist"
-        + (description != null && !description.isEmpty() ? " (" + description + ")" : ""));
+    super(
+        "Namespace" + (namespaceName != null && !namespaceName.isEmpty() ? " " + namespaceName : "")
+            + (namespaceId != null && !namespaceId.isEmpty() ? " (Id=" + namespaceId + ")" : "")
+            + " does not exist"
+            + (description != null && !description.isEmpty() ? " (" + description + ")" : ""));
     this.namespace = namespaceName;
   }
 
@@ -55,7 +57,8 @@ public class NamespaceNotFoundException extends Exception {
    * @param cause
    *          the exception that caused this failure
    */
-  public NamespaceNotFoundException(String namespaceId, String namespaceName, String description, Throwable cause) {
+  public NamespaceNotFoundException(String namespaceId, String namespaceName, String description,
+      Throwable cause) {
     this(namespaceId, namespaceName, description);
     super.initCause(cause);
   }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/RowIterator.java b/core/src/main/java/org/apache/accumulo/core/client/RowIterator.java
index c8dab71..6fc1455 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/RowIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/RowIterator.java
@@ -44,7 +44,8 @@ public class RowIterator implements Iterator<Iterator<Entry<Key,Value>>> {
     private boolean disabled = false;
 
     /**
-     * SingleRowIter must be passed a PeekingIterator so that it can peek at the next entry to see if it belongs in the current row or not.
+     * SingleRowIter must be passed a PeekingIterator so that it can peek at the next entry to see
+     * if it belongs in the current row or not.
      */
     public SingleRowIter(PeekingIterator<Entry<Key,Value>> source) {
       this.source = source;
@@ -83,7 +84,8 @@ public class RowIterator implements Iterator<Iterator<Entry<Key,Value>>> {
     }
 
     /**
-     * Get a count of entries read from the row (only equals the number of entries in the row when the row has been read fully).
+     * Get a count of entries read from the row (only equals the number of entries in the row when
+     * the row has been read fully).
      */
     public long getCount() {
       return count;
@@ -120,8 +122,9 @@ public class RowIterator implements Iterator<Iterator<Entry<Key,Value>>> {
   /**
    * Returns true if there is at least one more row to get.
    *
-   * If the last row hasn't been fully read, this method will read through the end of the last row so it can determine if the underlying iterator has a next
-   * row. The last row is disabled from future use.
+   * If the last row hasn't been fully read, this method will read through the end of the last row
+   * so it can determine if the underlying iterator has a next row. The last row is disabled from
+   * future use.
    */
   @Override
   public boolean hasNext() {
diff --git a/core/src/main/java/org/apache/accumulo/core/client/SampleNotPresentException.java b/core/src/main/java/org/apache/accumulo/core/client/SampleNotPresentException.java
index c70a898..187cfc0 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/SampleNotPresentException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/SampleNotPresentException.java
@@ -18,7 +18,8 @@
 package org.apache.accumulo.core.client;
 
 /**
- * Exception thrown when a table does not have sampling configured or when sampling is configured but it differs from what was requested.
+ * Exception thrown when a table does not have sampling configured or when sampling is configured
+ * but it differs from what was requested.
  *
  * @since 1.8.0
  */
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 372ee42..03139e4 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
@@ -21,14 +21,16 @@ import org.apache.accumulo.core.data.Range;
 /**
  * Scans a table over a given range.
  *
- * "Clients can iterate over multiple column families, and there are several mechanisms for limiting the rows, columns, and timestamps traversed by a scan. For
- * example, we could restrict [a] scan ... to only produce anchors whose columns match [a] regular expression ..., or to only produce anchors whose timestamps
- * fall within ten days of the current time."
+ * "Clients can iterate over multiple column families, and there are several mechanisms for limiting
+ * the rows, columns, and timestamps traversed by a scan. For example, we could restrict [a] scan
+ * ... to only produce anchors whose columns match [a] regular expression ..., or to only produce
+ * anchors whose timestamps fall within ten days of the current time."
  */
 public interface Scanner extends ScannerBase {
 
   /**
-   * This setting determines how long a scanner will automatically retry when a failure occurs. By default a scanner will retry forever.
+   * This setting determines how long a scanner will automatically retry when a failure occurs. By
+   * default a scanner will retry forever.
    *
    * @param timeOut
    *          in seconds
@@ -70,24 +72,28 @@ public interface Scanner extends ScannerBase {
   void setBatchSize(int size);
 
   /**
-   * Returns the batch size (number of Key/Value pairs) that will be fetched at a time from a tablet server.
+   * 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
    */
   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.
+   * 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.
    */
   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.
+   * 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.
    */
   void disableIsolation();
 
   /**
-   * The number of batches of Key/Value pairs returned before the {@link Scanner} will begin to prefetch the next batch
+   * The number of batches of Key/Value pairs returned before the {@link Scanner} will begin to
+   * prefetch the next batch
    *
    * @return Number of batches before read-ahead begins
    * @since 1.6.0
@@ -95,7 +101,8 @@ public interface Scanner extends ScannerBase {
   long getReadaheadThreshold();
 
   /**
-   * Sets the number of batches of Key/Value pairs returned before the {@link Scanner} will begin to prefetch the next batch
+   * 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
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 2110050..6ec3618 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
@@ -37,8 +37,9 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>>, AutoCloseable {
    * Add a server-side scan iterator.
    *
    * @param cfg
-   *          fully specified scan-time iterator, including all options for the iterator. Any changes to the iterator setting after this call are not propagated
-   *          to the stored iterator.
+   *          fully specified scan-time iterator, including all options for the iterator. Any
+   *          changes to the iterator setting after this call are not propagated to the stored
+   *          iterator.
    * @throws IllegalArgumentException
    *           if the setting conflicts with existing iterators
    */
@@ -53,8 +54,9 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>>, AutoCloseable {
   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
-   * configured iterator before a scan is started.
+   * 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 configured iterator before a scan is
+   * started.
    *
    * @param iteratorName
    *          the name of the iterator to change
@@ -66,15 +68,17 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>>, AutoCloseable {
   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
-   * columns. To fetch multiple column families call this function multiple times.
+   * 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 columns. To fetch multiple column
+   * families call this function multiple times.
    *
    * <p>
    * This can help limit which locality groups are read on the server side.
    *
    * <p>
-   * When used in conjunction with custom iterators, the set of column families fetched is passed to the top iterator's seek method. Custom iterators may change
-   * this set of column families when calling seek on their source.
+   * When used in conjunction with custom iterators, the set of column families fetched is passed to
+   * the top iterator's seek method. Custom iterators may change this set of column families when
+   * calling seek on their source.
    *
    * @param col
    *          the column family to be fetched
@@ -82,22 +86,28 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>>, AutoCloseable {
   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
-   * have been added the scanner fetches all columns.
+   * 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 have been added the scanner
+   * fetches all columns.
    *
    * <p>
-   * <b>WARNING</b>. Using this method with custom iterators may have unexpected results. Iterators have control over which column families are fetched. However
-   * iterators have no control over which column qualifiers are fetched. When this method is called it activates a system iterator that only allows the
-   * requested family/qualifier pairs through. This low level filtering prevents custom iterators from requesting additional column families when calling seek.
+   * <b>WARNING</b>. Using this method with custom iterators may have unexpected results. Iterators
+   * have control over which column families are fetched. However iterators have no control over
+   * which column qualifiers are fetched. When this method is called it activates a system iterator
+   * that only allows the requested family/qualifier pairs through. This low level filtering
+   * prevents custom iterators from requesting additional column families when calling seek.
    *
    * <p>
-   * For an example, assume fetchColumns(A, Q1) and fetchColumns(B,Q1) is called on a scanner and a custom iterator is configured. The families (A,B) will be
-   * passed to the seek method of the custom iterator. If the custom iterator seeks its source iterator using the families (A,B,C), it will never see any data
-   * from C because the system iterator filtering A:Q1 and B:Q1 will prevent the C family from getting through. ACCUMULO-3905 also has an example of the type of
+   * For an example, assume fetchColumns(A, Q1) and fetchColumns(B,Q1) is called on a scanner and a
+   * custom iterator is configured. The families (A,B) will be passed to the seek method of the
+   * custom iterator. If the custom iterator seeks its source iterator using the families (A,B,C),
+   * it will never see any data from C because the system iterator filtering A:Q1 and B:Q1 will
+   * prevent the C family from getting through. ACCUMULO-3905 also has an example of the type of
    * problem this method can cause.
    *
    * <p>
-   * tl;dr If using a custom iterator with a seek method that adds column families, then may want to avoid using this method.
+   * tl;dr If using a custom iterator with a seek method that adds column families, then may want to
+   * avoid using this method.
    *
    * @param colFam
    *          the column family of the column to be fetched
@@ -116,7 +126,8 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>>, AutoCloseable {
   void fetchColumn(Column column);
 
   /**
-   * Clears the columns to be fetched (useful for resetting the scanner for reuse). Once cleared, the scanner will fetch all columns.
+   * Clears the columns to be fetched (useful for resetting the scanner for reuse). Once cleared,
+   * the scanner will fetch all columns.
    */
   void clearColumns();
 
@@ -126,8 +137,8 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>>, AutoCloseable {
   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
-   * on existing iterators.
+   * 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 on existing iterators.
    *
    * <p>
    * Keys returned by the iterator are not guaranteed to be in sorted order.
@@ -138,10 +149,12 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>>, AutoCloseable {
   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.
+   * This setting determines how long a scanner will automatically retry when a failure occurs. By
+   * default, a scanner will retry forever.
    *
    * <p>
-   * Setting the timeout to zero (with any time unit) or {@link Long#MAX_VALUE} (with {@link TimeUnit#MILLISECONDS}) means no timeout.
+   * Setting the timeout to zero (with any time unit) or {@link Long#MAX_VALUE} (with
+   * {@link TimeUnit#MILLISECONDS}) means no timeout.
    *
    * @param timeOut
    *          the length of the timeout
@@ -160,7 +173,8 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>>, AutoCloseable {
   long getTimeout(TimeUnit timeUnit);
 
   /**
-   * Closes any underlying connections on the scanner. This may invalidate any iterators derived from the Scanner, causing them to throw exceptions.
+   * Closes any underlying connections on the scanner. This may invalidate any iterators derived
+   * from the Scanner, causing them to throw exceptions.
    *
    * @since 1.5.0
    */
@@ -176,12 +190,13 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>>, AutoCloseable {
   Authorizations getAuthorizations();
 
   /**
-   * Setting this will cause the scanner to read sample data, as long as that sample data was generated with the given configuration. By default this is not set
-   * and all data is read.
+   * Setting this will cause the scanner to read sample data, as long as that sample data was
+   * generated with the given configuration. By default this is not set and all data is read.
    *
    * <p>
-   * One way to use this method is as follows, where the sampler configuration is obtained from the table configuration. Sample data can be generated in many
-   * different ways, so its important to verify the sample data configuration meets expectations.
+   * One way to use this method is as follows, where the sampler configuration is obtained from the
+   * table configuration. Sample data can be generated in many different ways, so its important to
+   * verify the sample data configuration meets expectations.
    *
    * <pre>
    * <code>
@@ -194,11 +209,13 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>>, AutoCloseable {
    * </pre>
    *
    * <p>
-   * Of course this is not the only way to obtain a {@link SamplerConfiguration}, it could be a constant, configuration, etc.
+   * Of course this is not the only way to obtain a {@link SamplerConfiguration}, it could be a
+   * constant, configuration, etc.
    *
    * <p>
-   * If sample data is not present or sample data was generated with a different configuration, then the scanner iterator will throw a
-   * {@link SampleNotPresentException}. Also if a table's sampler configuration is changed while a scanner is iterating over a table, a
+   * If sample data is not present or sample data was generated with a different configuration, then
+   * the scanner iterator will throw a {@link SampleNotPresentException}. Also if a table's sampler
+   * configuration is changed while a scanner is iterating over a table, a
    * {@link SampleNotPresentException} may be thrown.
    *
    * @since 1.8.0
@@ -212,17 +229,20 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>>, AutoCloseable {
   SamplerConfiguration getSamplerConfiguration();
 
   /**
-   * Clears sampler configuration making a scanner read all data. After calling this, {@link #getSamplerConfiguration()} should return null.
+   * Clears sampler configuration making a scanner read all data. After calling this,
+   * {@link #getSamplerConfiguration()} should return null.
    *
    * @since 1.8.0
    */
   void clearSamplerConfiguration();
 
   /**
-   * This setting determines how long a scanner will wait to fill the returned batch. By default, a scanner wait until the batch is full.
+   * This setting determines how long a scanner will wait to fill the returned batch. By default, a
+   * scanner wait until the batch is full.
    *
    * <p>
-   * Setting the timeout to zero (with any time unit) or {@link Long#MAX_VALUE} (with {@link TimeUnit#MILLISECONDS}) means no timeout.
+   * Setting the timeout to zero (with any time unit) or {@link Long#MAX_VALUE} (with
+   * {@link TimeUnit#MILLISECONDS}) means no timeout.
    *
    * @param timeOut
    *          the length of the timeout
@@ -241,8 +261,8 @@ public interface ScannerBase extends Iterable<Entry<Key,Value>>, AutoCloseable {
   long getBatchTimeout(TimeUnit timeUnit);
 
   /**
-   * Sets the name of the classloader context on this scanner. See the administration chapter of the user manual for details on how to configure and use
-   * classloader contexts.
+   * Sets the name of the classloader context on this scanner. See the administration chapter of the
+   * user manual for details on how to configure and use classloader contexts.
    *
    * @param classLoaderContext
    *          name of the classloader context
diff --git a/core/src/main/java/org/apache/accumulo/core/client/TableDeletedException.java b/core/src/main/java/org/apache/accumulo/core/client/TableDeletedException.java
index c1b1d6f..a506270 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/TableDeletedException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/TableDeletedException.java
@@ -19,7 +19,8 @@ package org.apache.accumulo.core.client;
 /**
  * This exception is thrown if a table is deleted after an operation starts.
  *
- * For example if table A exist when a scan is started, but is deleted during the scan then this exception is thrown.
+ * For example if table A exist when a scan is started, but is deleted during the scan then this
+ * exception is thrown.
  *
  */
 
diff --git a/core/src/main/java/org/apache/accumulo/core/client/TableExistsException.java b/core/src/main/java/org/apache/accumulo/core/client/TableExistsException.java
index 72c633c..cd9f7b6 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/TableExistsException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/TableExistsException.java
@@ -37,8 +37,9 @@ public class TableExistsException extends Exception {
    *          the specific reason why it failed
    */
   public TableExistsException(String tableId, String tableName, String description) {
-    super("Table" + (tableName != null && !tableName.isEmpty() ? " " + tableName : "") + (tableId != null && !tableId.isEmpty() ? " (Id=" + tableId + ")" : "")
-        + " exists" + (description != null && !description.isEmpty() ? " (" + description + ")" : ""));
+    super("Table" + (tableName != null && !tableName.isEmpty() ? " " + tableName : "")
+        + (tableId != null && !tableId.isEmpty() ? " (Id=" + tableId + ")" : "") + " exists"
+        + (description != null && !description.isEmpty() ? " (" + description + ")" : ""));
   }
 
   /**
@@ -51,7 +52,8 @@ public class TableExistsException extends Exception {
    * @param cause
    *          the exception that caused this failure
    */
-  public TableExistsException(String tableId, String tableName, String description, Throwable cause) {
+  public TableExistsException(String tableId, String tableName, String description,
+      Throwable cause) {
     this(tableId, tableName, description);
     super.initCause(cause);
   }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/TableNotFoundException.java b/core/src/main/java/org/apache/accumulo/core/client/TableNotFoundException.java
index 1e53936..6eff0b2 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/TableNotFoundException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/TableNotFoundException.java
@@ -40,8 +40,9 @@ public class TableNotFoundException extends Exception {
    *          the specific reason why it failed
    */
   public TableNotFoundException(String tableId, String tableName, String description) {
-    super("Table" + (tableName != null && !tableName.isEmpty() ? " " + tableName : "") + (tableId != null && !tableId.isEmpty() ? " (Id=" + tableId + ")" : "")
-        + " does not exist" + (description != null && !description.isEmpty() ? " (" + description + ")" : ""));
+    super("Table" + (tableName != null && !tableName.isEmpty() ? " " + tableName : "")
+        + (tableId != null && !tableId.isEmpty() ? " (Id=" + tableId + ")" : "") + " does not exist"
+        + (description != null && !description.isEmpty() ? " (" + description + ")" : ""));
     this.tableName = tableName;
   }
 
@@ -55,7 +56,8 @@ public class TableNotFoundException extends Exception {
    * @param cause
    *          the exception that caused this failure
    */
-  public TableNotFoundException(String tableId, String tableName, String description, Throwable cause) {
+  public TableNotFoundException(String tableId, String tableName, String description,
+      Throwable cause) {
     this(tableId, tableName, description);
     super.initCause(cause);
   }
@@ -72,10 +74,12 @@ public class TableNotFoundException extends Exception {
    * @param tableName
    *          the original specified table
    * @param e
-   *          indicates that a table wasn't found because the namespace specified in the table name wasn't found
+   *          indicates that a table wasn't found because the namespace specified in the table name
+   *          wasn't found
    */
   public TableNotFoundException(String tableName, NamespaceNotFoundException e) {
-    this(null, tableName, "Namespace " + Tables.qualify(tableName).getFirst() + " does not exist.", e);
+    this(null, tableName, "Namespace " + Tables.qualify(tableName).getFirst() + " does not exist.",
+        e);
   }
 
   /**
diff --git a/core/src/main/java/org/apache/accumulo/core/client/TimedOutException.java b/core/src/main/java/org/apache/accumulo/core/client/TimedOutException.java
index e5bba3e..ff8fab3 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/TimedOutException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/TimedOutException.java
@@ -34,7 +34,8 @@ public class TimedOutException extends RuntimeException {
       return set.toString();
     }
 
-    return new ArrayList<>(set).subList(0, 10).toString() + " ... " + (set.size() - 10) + " servers not shown";
+    return new ArrayList<>(set).subList(0, 10).toString() + " ... " + (set.size() - 10)
+        + " servers not shown";
   }
 
   public TimedOutException(Set<String> timedoutServers) {
diff --git a/core/src/main/java/org/apache/accumulo/core/client/ZooKeeperInstance.java b/core/src/main/java/org/apache/accumulo/core/client/ZooKeeperInstance.java
index 32fb62d..201de62 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/ZooKeeperInstance.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/ZooKeeperInstance.java
@@ -48,15 +48,19 @@ import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 /**
- * An implementation of instance that looks in zookeeper to find information needed to connect to an instance of accumulo.
+ * An implementation of instance that looks in zookeeper to find information needed to connect to an
+ * instance of accumulo.
  *
  * <p>
- * The advantage of using zookeeper to obtain information about accumulo is that zookeeper is highly available, very responsive, and supports caching.
+ * The advantage of using zookeeper to obtain information about accumulo is that zookeeper is highly
+ * available, very responsive, and supports caching.
  *
  * <p>
- * Because it is possible for multiple instances of accumulo to share a single set of zookeeper servers, all constructors require an accumulo instance name.
+ * Because it is possible for multiple instances of accumulo to share a single set of zookeeper
+ * servers, all constructors require an accumulo instance name.
  *
- * If you do not know the instance names then run accumulo org.apache.accumulo.server.util.ListInstances on an accumulo server.
+ * If you do not know the instance names then run accumulo
+ * org.apache.accumulo.server.util.ListInstances on an accumulo server.
  *
  */
 
@@ -81,7 +85,8 @@ public class ZooKeeperInstance implements Instance {
    * @param instanceName
    *          The name of specific accumulo instance. This is set at initialization time.
    * @param zooKeepers
-   *          A comma separated list of zoo keeper server locations. Each location can contain an optional port, of the format host:port.
+   *          A comma separated list of zoo keeper server locations. Each location can contain an
+   *          optional port, of the format host:port.
    */
   public ZooKeeperInstance(String instanceName, String zooKeepers) {
     this(ClientConfiguration.loadDefault().withInstance(instanceName).withZkHosts(zooKeepers));
@@ -92,14 +97,16 @@ public class ZooKeeperInstance implements Instance {
    * @param instanceName
    *          The name of specific accumulo instance. This is set at initialization time.
    * @param zooKeepers
-   *          A comma separated list of zoo keeper server locations. Each location can contain an optional port, of the format host:port.
+   *          A comma separated list of zoo keeper server locations. Each location can contain an
+   *          optional port, of the format host:port.
    * @param sessionTimeout
    *          zoo keeper session time out in milliseconds.
    * @deprecated since 1.6.0; Use {@link #ZooKeeperInstance(ClientConfiguration)} instead.
    */
   @Deprecated
   public ZooKeeperInstance(String instanceName, String zooKeepers, int sessionTimeout) {
-    this(ClientConfiguration.loadDefault().withInstance(instanceName).withZkHosts(zooKeepers).withZkTimeout(sessionTimeout));
+    this(ClientConfiguration.loadDefault().withInstance(instanceName).withZkHosts(zooKeepers)
+        .withZkTimeout(sessionTimeout));
   }
 
   /**
@@ -107,7 +114,8 @@ public class ZooKeeperInstance implements Instance {
    * @param instanceId
    *          The UUID that identifies the accumulo instance you want to connect to.
    * @param zooKeepers
-   *          A comma separated list of zoo keeper server locations. Each location can contain an optional port, of the format host:port.
+   *          A comma separated list of zoo keeper server locations. Each location can contain an
+   *          optional port, of the format host:port.
    * @deprecated since 1.6.0; Use {@link #ZooKeeperInstance(ClientConfiguration)} instead.
    */
   @Deprecated
@@ -120,23 +128,26 @@ public class ZooKeeperInstance implements Instance {
    * @param instanceId
    *          The UUID that identifies the accumulo instance you want to connect to.
    * @param zooKeepers
-   *          A comma separated list of zoo keeper server locations. Each location can contain an optional port, of the format host:port.
+   *          A comma separated list of zoo keeper server locations. Each location can contain an
+   *          optional port, of the format host:port.
    * @param sessionTimeout
    *          zoo keeper session time out in milliseconds.
    * @deprecated since 1.6.0; Use {@link #ZooKeeperInstance(ClientConfiguration)} instead.
    */
   @Deprecated
   public ZooKeeperInstance(UUID instanceId, String zooKeepers, int sessionTimeout) {
-    this(ClientConfiguration.loadDefault().withInstance(instanceId).withZkHosts(zooKeepers).withZkTimeout(sessionTimeout));
+    this(ClientConfiguration.loadDefault().withInstance(instanceId).withZkHosts(zooKeepers)
+        .withZkTimeout(sessionTimeout));
   }
 
   /**
    * @param config
-   *          Client configuration for specifying connection options. See {@link ClientConfiguration} which extends Configuration with convenience methods
+   *          Client configuration for specifying connection options. See
+   *          {@link ClientConfiguration} which extends Configuration with convenience methods
    *          specific to Accumulo.
    * @since 1.6.0
-   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API; use
-   *             {@link #ZooKeeperInstance(ClientConfiguration)} instead.
+   * @deprecated since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into
+   *             Accumulo API; use {@link #ZooKeeperInstance(ClientConfiguration)} instead.
    */
   @Deprecated
   public ZooKeeperInstance(Configuration config) {
@@ -155,9 +166,11 @@ public class ZooKeeperInstance implements Instance {
     this.instanceId = clientConf.get(ClientProperty.INSTANCE_ID);
     this.instanceName = clientConf.get(ClientProperty.INSTANCE_NAME);
     if ((instanceId == null) == (instanceName == null))
-      throw new IllegalArgumentException("Expected exactly one of instanceName and instanceId to be set");
+      throw new IllegalArgumentException(
+          "Expected exactly one of instanceName and instanceId to be set");
     this.zooKeepers = clientConf.get(ClientProperty.INSTANCE_ZK_HOST);
-    this.zooKeepersSessionTimeOut = (int) AccumuloConfiguration.getTimeInMillis(clientConf.get(ClientProperty.INSTANCE_ZK_TIMEOUT));
+    this.zooKeepersSessionTimeOut = (int) AccumuloConfiguration
+        .getTimeInMillis(clientConf.get(ClientProperty.INSTANCE_ZK_TIMEOUT));
     zooCache = zcf.getZooCache(zooKeepers, zooKeepersSessionTimeOut);
     if (null != instanceName) {
       // Validates that the provided instanceName actually exists
@@ -167,7 +180,8 @@ public class ZooKeeperInstance implements Instance {
 
   /**
    * @param config
-   *          Client configuration for specifying connection options. See {@link ClientConfiguration} which extends Configuration with convenience methods
+   *          Client configuration for specifying connection options. See
+   *          {@link ClientConfiguration} which extends Configuration with convenience methods
    *          specific to Accumulo.
    * @since 1.9.0
    */
@@ -192,7 +206,8 @@ public class ZooKeeperInstance implements Instance {
     if (zooCache.get(Constants.ZROOT + "/" + instanceId) == null) {
       if (instanceName == null)
         throw new RuntimeException("Instance id " + instanceId + " does not exist in zookeeper");
-      throw new RuntimeException("Instance id " + instanceId + " pointed to by the name " + instanceName + " does not exist in zookeeper");
+      throw new RuntimeException("Instance id " + instanceId + " pointed to by the name "
+          + instanceName + " does not exist in zookeeper");
     }
 
     return instanceId;
@@ -213,7 +228,8 @@ public class ZooKeeperInstance implements Instance {
 
     if (timer != null) {
       timer.stop();
-      log.trace("tid={} Found master at {} in {}", Thread.currentThread().getId(), (loc == null ? "null" : new String(loc, UTF_8)),
+      log.trace("tid={} Found master at {} in {}", Thread.currentThread().getId(),
+          (loc == null ? "null" : new String(loc, UTF_8)),
           String.format("%.3f secs", timer.scale(TimeUnit.SECONDS)));
     }
 
@@ -231,7 +247,8 @@ public class ZooKeeperInstance implements Instance {
     OpTimer timer = null;
 
     if (log.isTraceEnabled()) {
-      log.trace("tid={} Looking up root tablet location in zookeeper.", Thread.currentThread().getId());
+      log.trace("tid={} Looking up root tablet location in zookeeper.",
+          Thread.currentThread().getId());
       timer = new OpTimer().start();
     }
 
@@ -239,7 +256,8 @@ public class ZooKeeperInstance implements Instance {
 
     if (timer != null) {
       timer.stop();
-      log.trace("tid={} Found root tablet at {} in {}", Thread.currentThread().getId(), (loc == null ? "null" : new String(loc, UTF_8)),
+      log.trace("tid={} Found root tablet at {} in {}", Thread.currentThread().getId(),
+          (loc == null ? "null" : new String(loc, UTF_8)),
           String.format("%.3f secs", timer.scale(TimeUnit.SECONDS)));
     }
 
@@ -253,7 +271,8 @@ public class ZooKeeperInstance implements Instance {
   @Override
   public String getInstanceName() {
     if (instanceName == null)
-      instanceName = InstanceOperationsImpl.lookupInstanceName(zooCache, UUID.fromString(getInstanceID()));
+      instanceName = InstanceOperationsImpl.lookupInstanceName(zooCache,
+          UUID.fromString(getInstanceID()));
 
     return instanceName;
   }
@@ -270,31 +289,37 @@ public class ZooKeeperInstance implements Instance {
 
   @Override
   @Deprecated
-  public Connector getConnector(String user, CharSequence pass) throws AccumuloException, AccumuloSecurityException {
+  public Connector getConnector(String user, CharSequence pass)
+      throws AccumuloException, AccumuloSecurityException {
     return getConnector(user, TextUtil.getBytes(new Text(pass.toString())));
   }
 
   @Override
   @Deprecated
-  public Connector getConnector(String user, ByteBuffer pass) throws AccumuloException, AccumuloSecurityException {
+  public Connector getConnector(String user, ByteBuffer pass)
+      throws AccumuloException, AccumuloSecurityException {
     return getConnector(user, ByteBufferUtil.toBytes(pass));
   }
 
   @Override
-  public Connector getConnector(String principal, AuthenticationToken token) throws AccumuloException, AccumuloSecurityException {
-    return new ConnectorImpl(new ClientContext(this, new Credentials(principal, token), clientConf));
+  public Connector getConnector(String principal, AuthenticationToken token)
+      throws AccumuloException, AccumuloSecurityException {
+    return new ConnectorImpl(
+        new ClientContext(this, new Credentials(principal, token), clientConf));
   }
 
   @Override
   @Deprecated
-  public Connector getConnector(String principal, byte[] pass) throws AccumuloException, AccumuloSecurityException {
+  public Connector getConnector(String principal, byte[] pass)
+      throws AccumuloException, AccumuloSecurityException {
     return getConnector(principal, new PasswordToken(pass));
   }
 
   @Override
   @Deprecated
   public AccumuloConfiguration getConfiguration() {
-    return conf = conf == null ? DefaultConfiguration.getInstance() : ClientContext.convertClientConfig(clientConf);
+    return conf = conf == null ? DefaultConfiguration.getInstance()
+        : ClientContext.convertClientConfig(clientConf);
   }
 
   @Override
@@ -306,8 +331,9 @@ public class ZooKeeperInstance implements Instance {
   /**
    * Given a zooCache and instanceId, look up the instance name.
    *
-   * @deprecated since 1.7.0 {@link ZooCache} is not part of the public API, but its a parameter to this method. Therefore code that uses this method is not
-   *             guaranteed to be stable. This method was deprecated to discourage its use.
+   * @deprecated since 1.7.0 {@link ZooCache} is not part of the public API, but its a parameter to
+   *             this method. Therefore code that uses this method is not guaranteed to be stable.
+   *             This method was deprecated to discourage its use.
    */
   @Deprecated
   public static String lookupInstanceName(ZooCache zooCache, UUID instanceId) {
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveCompaction.java b/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveCompaction.java
index 5228391..d438016 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveCompaction.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveCompaction.java
@@ -34,7 +34,8 @@ public abstract class ActiveCompaction {
      */
     MINOR,
     /**
-     * compaction to flush a tablets memory and merge it with the tablets smallest file. This type compaction is done when a tablet has too many files
+     * compaction to flush a tablets memory and merge it with the tablets smallest file. This type
+     * compaction is done when a tablet has too many files
      */
     MERGE,
     /**
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionConfig.java b/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionConfig.java
index 74e77eb..7a220a7 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionConfig.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionConfig.java
@@ -43,7 +43,8 @@ public class CompactionConfig {
 
   /**
    * @param start
-   *          First tablet to be compacted contains the row after this row, null means the first tablet in table. The default is null.
+   *          First tablet to be compacted contains the row after this row, null means the first
+   *          tablet in table. The default is null.
    * @return this
    */
 
@@ -62,7 +63,8 @@ public class CompactionConfig {
   /**
    *
    * @param end
-   *          Last tablet to be compacted contains this row, null means the last tablet in table. The default is null.
+   *          Last tablet to be compacted contains this row, null means the last tablet in table.
+   *          The default is null.
    * @return this
    */
   public CompactionConfig setEndRow(Text end) {
@@ -79,7 +81,8 @@ public class CompactionConfig {
 
   /**
    * @param flush
-   *          If set to true, will flush in memory data of all tablets in range before compacting. If not set, the default is true.
+   *          If set to true, will flush in memory data of all tablets in range before compacting.
+   *          If not set, the default is true.
    * @return this
    */
   public CompactionConfig setFlush(boolean flush) {
@@ -96,7 +99,8 @@ public class CompactionConfig {
 
   /**
    * @param wait
-   *          If set to true, will cause compact operation to wait for all tablets in range to compact. If not set, the default is true.
+   *          If set to true, will cause compact operation to wait for all tablets in range to
+   *          compact. If not set, the default is true.
    * @return this
    */
 
@@ -115,7 +119,8 @@ public class CompactionConfig {
 
   /**
    * @param iterators
-   *          configures the iterators that will be used when compacting tablets. These iterators are merged with current iterators configured for the table.
+   *          configures the iterators that will be used when compacting tablets. These iterators
+   *          are merged with current iterators configured for the table.
    * @return this
    */
   public CompactionConfig setIterators(List<IteratorSetting> iterators) {
@@ -124,7 +129,8 @@ public class CompactionConfig {
   }
 
   /**
-   * @return The previously set iterators. Returns an empty list if not set. The returned list is unmodifiable.
+   * @return The previously set iterators. Returns an empty list if not set. The returned list is
+   *         unmodifiable.
    */
   public List<IteratorSetting> getIterators() {
     return Collections.unmodifiableList(iterators);
@@ -132,7 +138,8 @@ public class CompactionConfig {
 
   /**
    * @param csConfig
-   *          configures the strategy that will be used by each tablet to select files. If no strategy is set, then all files will be compacted.
+   *          configures the strategy that will be used by each tablet to select files. If no
+   *          strategy is set, then all files will be compacted.
    * @return this
    */
   public CompactionConfig setCompactionStrategy(CompactionStrategyConfig csConfig) {
@@ -142,8 +149,9 @@ public class CompactionConfig {
   }
 
   /**
-   * @return The previously set compaction strategy. Defaults to a configuration of org.apache.accumulo.tserver.compaction.EverythingCompactionStrategy which
-   *         always compacts all files.
+   * @return The previously set compaction strategy. Defaults to a configuration of
+   *         org.apache.accumulo.tserver.compaction.EverythingCompactionStrategy which always
+   *         compacts all files.
    */
   public CompactionStrategyConfig getCompactionStrategy() {
     return compactionStrategy;
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionStrategyConfig.java b/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionStrategyConfig.java
index af3b537..e674e08 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionStrategyConfig.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionStrategyConfig.java
@@ -24,8 +24,9 @@ import java.util.HashMap;
 import java.util.Map;
 
 /**
- * Configuration object which describes how a Compaction is run. Configuration objects are dependent upon the CompactionStrategy running insider the server.
- * This class is used in conjunction with {@link CompactionConfig}.
+ * Configuration object which describes how a Compaction is run. Configuration objects are dependent
+ * upon the CompactionStrategy running insider the server. This class is used in conjunction with
+ * {@link CompactionConfig}.
  *
  * @since 1.7.0
  */
@@ -35,7 +36,9 @@ public class CompactionStrategyConfig {
 
   /**
    * @param className
-   *          The name of a class that implements org.apache.accumulo.tserver.compaction.CompactionStrategy. This class must be exist on tservers.
+   *          The name of a class that implements
+   *          org.apache.accumulo.tserver.compaction.CompactionStrategy. This class must be exist on
+   *          tservers.
    */
   public CompactionStrategyConfig(String className) {
     requireNonNull(className);
@@ -51,8 +54,9 @@ public class CompactionStrategyConfig {
 
   /**
    * @param opts
-   *          The options that will be passed to the init() method of the compaction strategy when its instantiated on a tserver. This method will copy the map.
-   *          The default is an empty map.
+   *          The options that will be passed to the init() method of the compaction strategy when
+   *          its instantiated on a tserver. This method will copy the map. The default is an empty
+   *          map.
    * @return this
    */
   public CompactionStrategyConfig setOptions(Map<String,String> opts) {
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/DelegationTokenConfig.java b/core/src/main/java/org/apache/accumulo/core/client/admin/DelegationTokenConfig.java
index b67a3e8..0f0f2f1 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/DelegationTokenConfig.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/DelegationTokenConfig.java
@@ -22,7 +22,8 @@ import static java.util.Objects.requireNonNull;
 import java.util.concurrent.TimeUnit;
 
 /**
- * Configuration options for obtaining a delegation token created by {@link SecurityOperations#getDelegationToken(DelegationTokenConfig)}
+ * Configuration options for obtaining a delegation token created by
+ * {@link SecurityOperations#getDelegationToken(DelegationTokenConfig)}
  *
  * @since 1.7.0
  */
@@ -31,8 +32,8 @@ public class DelegationTokenConfig {
   private long lifetime = 0;
 
   /**
-   * Requests a specific lifetime for the token that is different than the default system lifetime. The lifetime must not exceed the secret key lifetime
-   * configured on the servers.
+   * Requests a specific lifetime for the token that is different than the default system lifetime.
+   * The lifetime must not exceed the secret key lifetime configured on the servers.
    *
    * @param lifetime
    *          Token lifetime
@@ -48,7 +49,8 @@ public class DelegationTokenConfig {
   }
 
   /**
-   * The current token lifetime. A value of zero corresponds to using the system configured lifetime.
+   * The current token lifetime. A value of zero corresponds to using the system configured
+   * lifetime.
    *
    * @param unit
    *          The unit of time the lifetime should be returned in
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/FindMax.java b/core/src/main/java/org/apache/accumulo/core/client/admin/FindMax.java
index 00fe950..dea48fd 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/FindMax.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/FindMax.java
@@ -78,7 +78,8 @@ public class FindMax {
     }
 
     // remove trailing 0x0 bytes
-    while (ret.getLength() > 0 && ret.getBytes()[ret.getLength() - 1] == 0 && ret.compareTo(minBS) > 0) {
+    while (ret.getLength() > 0 && ret.getBytes()[ret.getLength() - 1] == 0
+        && ret.compareTo(minBS) > 0) {
       Text t = new Text();
       t.set(ret.getBytes(), 0, ret.getLength() - 1);
       ret = t;
@@ -87,9 +88,11 @@ public class FindMax {
     return ret;
   }
 
-  private static Text _findMax(Scanner scanner, Text start, boolean inclStart, Text end, boolean inclEnd) {
+  private static Text _findMax(Scanner scanner, Text start, boolean inclStart, Text end,
+      boolean inclEnd) {
 
-    // System.out.printf("findMax(%s, %s, %s, %s)%n", Key.toPrintableString(start.getBytes(), 0, start.getLength(), 1000), inclStart,
+    // System.out.printf("findMax(%s, %s, %s, %s)%n", Key.toPrintableString(start.getBytes(), 0,
+    // start.getLength(), 1000), inclStart,
     // Key.toPrintableString(end.getBytes(), 0, end.getLength(), 1000), inclEnd);
 
     int cmp = start.compareTo(end);
@@ -106,7 +109,8 @@ public class FindMax {
     }
 
     Text mid = findMidPoint(start, end);
-    // System.out.println("mid = :"+Key.toPrintableString(mid.getBytes(), 0, mid.getLength(), 1000)+":");
+    // System.out.println("mid = :"+Key.toPrintableString(mid.getBytes(), 0, mid.getLength(),
+    // 1000)+":");
 
     scanner.setRange(new Range(mid, mid.equals(start) ? inclStart : true, end, inclEnd));
 
@@ -151,7 +155,8 @@ public class FindMax {
     return end;
   }
 
-  public static Text findMax(Scanner scanner, Text start, boolean is, Text end, boolean ie) throws TableNotFoundException {
+  public static Text findMax(Scanner scanner, Text start, boolean is, Text end, boolean ie)
+      throws TableNotFoundException {
 
     scanner.setBatchSize(12);
     IteratorSetting cfg = new IteratorSetting(Integer.MAX_VALUE, SortedKeyIterator.class);
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 79b430c..c5331b2 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
@@ -28,10 +28,12 @@ import org.apache.accumulo.core.client.AccumuloSecurityException;
 public interface InstanceOperations {
 
   /**
-   * Sets an system property in zookeeper. Tablet servers will pull this setting and override the equivalent setting in accumulo-site.xml. Changes can be seen
-   * using {@link #getSystemConfiguration()}.
+   * Sets an system property in zookeeper. Tablet servers will pull this setting and override the
+   * equivalent setting in accumulo-site.xml. Changes can be seen using
+   * {@link #getSystemConfiguration()}.
    * <p>
-   * Only some properties can be changed by this method, an IllegalArgumentException will be thrown if a read-only property is set.
+   * Only some properties can be changed by this method, an IllegalArgumentException will be thrown
+   * if a read-only property is set.
    *
    * @param property
    *          the name of a per-table property
@@ -42,10 +44,12 @@ public interface InstanceOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission
    */
-  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()}
+   * Removes a system property from zookeeper. Changes can be seen using
+   * {@link #getSystemConfiguration()}
    *
    * @param property
    *          the name of a per-table property
@@ -58,16 +62,17 @@ public interface InstanceOperations {
 
   /**
    *
-   * @return A map of system properties set in zookeeper. If a property is not set in zookeeper, then it will return the value set in accumulo-site.xml on some
-   *         server. If nothing is set in an accumulo-site.xml file it will return the default value for each property.
+   * @return A map of system properties set in zookeeper. If a property is not set in zookeeper,
+   *         then it will return the value set in accumulo-site.xml on some server. If nothing is
+   *         set in an accumulo-site.xml file it will return the default value for each property.
    */
 
   Map<String,String> getSystemConfiguration() throws AccumuloException, AccumuloSecurityException;
 
   /**
    *
-   * @return A map of system properties set in accumulo-site.xml on some server. If nothing is set in an accumulo-site.xml file it will return the default value
-   *         for each property.
+   * @return A map of system properties set in accumulo-site.xml on some server. If nothing is set
+   *         in an accumulo-site.xml file it will return the default value for each property.
    */
 
   Map<String,String> getSiteConfiguration() throws AccumuloException, AccumuloSecurityException;
@@ -88,7 +93,8 @@ public interface InstanceOperations {
    * @return A list of active scans on tablet server.
    */
 
-  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
@@ -99,7 +105,8 @@ public interface InstanceOperations {
    * @since 1.5.0
    */
 
-  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.
@@ -111,12 +118,14 @@ public interface InstanceOperations {
   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
+   * Test to see if the instance can load the given class as the given type. This check does not
+   * consider per table classpaths, see
    * {@link TableOperations#testClassLoad(String, String, String)}
    *
    * @return true if the instance can load the given class as the given type, false otherwise
    */
-  boolean testClassLoad(final String className, final String asTypeName) throws AccumuloException, AccumuloSecurityException;
+  boolean testClassLoad(final String className, final String asTypeName)
+      throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Waits for the tablet balancer to run and return no migrations.
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/Locations.java b/core/src/main/java/org/apache/accumulo/core/client/admin/Locations.java
index aaecf33..d42d988 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/Locations.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/Locations.java
@@ -24,24 +24,28 @@ import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.TabletId;
 
 /**
- * A snapshot of metadata information about where a specified set of ranges are located returned by {@link TableOperations#locate(String, java.util.Collection)}
+ * A snapshot of metadata information about where a specified set of ranges are located returned by
+ * {@link TableOperations#locate(String, java.util.Collection)}
  *
  * @since 1.8.0
  */
 public interface Locations {
 
   /**
-   * For all of the ranges passed to {@link TableOperations#locate(String, java.util.Collection)}, return a map of the tablets each range overlaps.
+   * For all of the ranges passed to {@link TableOperations#locate(String, java.util.Collection)},
+   * return a map of the tablets each range overlaps.
    */
   public Map<Range,List<TabletId>> groupByRange();
 
   /**
-   * For all of the ranges passed to {@link TableOperations#locate(String, java.util.Collection)}, return a map of the ranges each tablet overlaps.
+   * For all of the ranges passed to {@link TableOperations#locate(String, java.util.Collection)},
+   * return a map of the ranges each tablet overlaps.
    */
   public Map<TabletId,List<Range>> groupByTablet();
 
   /**
-   * For any {@link TabletId} known to this object, the method will return the tablet server location for that tablet.
+   * For any {@link TabletId} known to this object, the method will return the tablet server
+   * location for that tablet.
    *
    * @return A tablet server location in the form of {@code <host>:<port>}
    */
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 b2e7198..f2d0c98 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
@@ -32,8 +32,9 @@ import org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope;
 /**
  * Provides an API for administering namespaces
  *
- * All tables exist in a namespace. The default namespace has no name, and is used if an explicit namespace is not specified. Fully qualified table names look
- * like "namespaceName.tableName". Tables in the default namespace are fully qualified simply as "tableName".
+ * All tables exist in a namespace. The default namespace has no name, and is used if an explicit
+ * namespace is not specified. Fully qualified table names look like "namespaceName.tableName".
+ * Tables in the default namespace are fully qualified simply as "tableName".
  *
  * @since 1.6.0
  */
@@ -82,7 +83,8 @@ public interface NamespaceOperations {
   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.
+   * Create an empty namespace with no initial configuration. Valid names for a namespace contain
+   * letters, numbers, and the underscore character.
    *
    * @param namespace
    *          the name of the namespace
@@ -94,7 +96,8 @@ public interface NamespaceOperations {
    *           if the specified namespace already exists
    * @since 1.6.0
    */
-  void create(String namespace) throws AccumuloException, AccumuloSecurityException, NamespaceExistsException;
+  void create(String namespace)
+      throws AccumuloException, AccumuloSecurityException, NamespaceExistsException;
 
   /**
    * Delete an empty namespace
@@ -111,7 +114,8 @@ public interface NamespaceOperations {
    *           if the namespaces still contains tables
    * @since 1.6.0
    */
-  void delete(String namespace) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException, NamespaceNotEmptyException;
+  void delete(String namespace) throws AccumuloException, AccumuloSecurityException,
+      NamespaceNotFoundException, NamespaceNotEmptyException;
 
   /**
    * Rename a namespace
@@ -130,11 +134,12 @@ public interface NamespaceOperations {
    *           if the new namespace already exists
    * @since 1.6.0
    */
-  void rename(String oldNamespaceName, String newNamespaceName) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException,
-      NamespaceExistsException;
+  void rename(String oldNamespaceName, String newNamespaceName) throws AccumuloException,
+      AccumuloSecurityException, NamespaceNotFoundException, NamespaceExistsException;
 
   /**
-   * Sets a property on a namespace which applies to all tables in the namespace. Note that it may take a few seconds to propagate the change everywhere.
+   * Sets a property on a namespace which applies to all tables in the namespace. Note that it may
+   * take a few seconds to propagate the change everywhere.
    *
    * @param namespace
    *          the name of the namespace
@@ -150,10 +155,12 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  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.
+   * Removes a property from a namespace. Note that it may take a few seconds to propagate the
+   * change everywhere.
    *
    * @param namespace
    *          the name of the namespace
@@ -167,14 +174,17 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  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.
+   * Gets properties of a namespace, which are inherited by tables in this namespace. Note that
+   * recently changed properties may not be available immediately.
    *
    * @param namespace
    *          the name of the namespace
-   * @return all properties visible by this namespace (system and per-table properties). Note that recently changed properties may not be visible immediately.
+   * @return all properties visible by this namespace (system and per-table properties). Note that
+   *         recently changed properties may not be visible immediately.
    * @throws AccumuloException
    *           if a general error occurs
    * @throws AccumuloSecurityException
@@ -183,7 +193,8 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  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.
@@ -212,7 +223,8 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  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.
@@ -231,8 +243,8 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  void attachIterator(String namespace, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloException, AccumuloSecurityException,
-      NamespaceNotFoundException;
+  void attachIterator(String namespace, IteratorSetting setting, EnumSet<IteratorScope> scopes)
+      throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
 
   /**
    * Remove an iterator from a namespace by name.
@@ -251,8 +263,8 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  void removeIterator(String namespace, String name, EnumSet<IteratorScope> scopes) throws AccumuloException, AccumuloSecurityException,
-      NamespaceNotFoundException;
+  void removeIterator(String namespace, String name, EnumSet<IteratorScope> scopes)
+      throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
 
   /**
    * Get the settings for an iterator.
@@ -272,8 +284,8 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  IteratorSetting getIteratorSetting(String namespace, String name, IteratorScope scope) throws AccumuloException, AccumuloSecurityException,
-      NamespaceNotFoundException;
+  IteratorSetting getIteratorSetting(String namespace, String name, IteratorScope scope)
+      throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
 
   /**
    * Get a list of iterators for this namespace.
@@ -289,11 +301,13 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  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
-   * the specified scopes. If so, an IllegalArgumentException is thrown, wrapped in an AccumuloException.
+   * Check whether a given iterator configuration conflicts with existing configuration; in
+   * particular, determine if the name or priority are already in use for the specified scopes. If
+   * so, an IllegalArgumentException is thrown, wrapped in an AccumuloException.
    *
    * @param namespace
    *          the name of the namespace
@@ -309,8 +323,9 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  void checkIteratorConflicts(String namespace, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloException, AccumuloSecurityException,
-      NamespaceNotFoundException;
+  void checkIteratorConflicts(String namespace, IteratorSetting setting,
+      EnumSet<IteratorScope> scopes)
+      throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
 
   /**
    * Add a new constraint to a namespace.
@@ -328,7 +343,8 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  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.
@@ -345,7 +361,8 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  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.
@@ -361,10 +378,12 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  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.
+   * 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.
    *
    * @param namespace
    *          the name of the namespace
@@ -381,5 +400,6 @@ public interface NamespaceOperations {
    *           if the specified namespace doesn't exist
    * @since 1.6.0
    */
-  boolean testClassLoad(String namespace, String className, String asTypeName) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
+  boolean testClassLoad(String namespace, String className, String asTypeName)
+      throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException;
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/NewTableConfiguration.java b/core/src/main/java/org/apache/accumulo/core/client/admin/NewTableConfiguration.java
index 4694e1e..7d25a25 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/NewTableConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/NewTableConfiguration.java
@@ -29,8 +29,8 @@ import org.apache.accumulo.core.iterators.user.VersioningIterator;
 import org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl;
 
 /**
- * This object stores table creation parameters. Currently includes: {@link TimeType}, whether to include default iterators, and user-specified initial
- * properties
+ * This object stores table creation parameters. Currently includes: {@link TimeType}, whether to
+ * include default iterators, and user-specified initial properties
  *
  * @since 1.7.0
  */
@@ -68,8 +68,9 @@ public class NewTableConfiguration {
   }
 
   /**
-   * Currently the only default iterator is the {@link VersioningIterator}. This method will cause the table to be created without that iterator, or any others
-   * which may become defaults in the future.
+   * Currently the only default iterator is the {@link VersioningIterator}. This method will cause
+   * the table to be created without that iterator, or any others which may become defaults in the
+   * future.
    *
    * @return this
    */
@@ -79,8 +80,8 @@ public class NewTableConfiguration {
   }
 
   /**
-   * Sets additional properties to be applied to tables created with this configuration. Additional calls to this method replaces properties set by previous
-   * calls.
+   * Sets additional properties to be applied to tables created with this configuration. Additional
+   * calls to this method replaces properties set by previous calls.
    *
    * @param prop
    *          additional properties to add to the table when it is created
@@ -95,7 +96,8 @@ public class NewTableConfiguration {
   }
 
   /**
-   * Retrieves the complete set of currently configured table properties to be applied to a table when this configuration object is used.
+   * Retrieves the complete set of currently configured table properties to be applied to a table
+   * when this configuration object is used.
    *
    * @return the current properties configured
    */
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/ReplicationOperations.java b/core/src/main/java/org/apache/accumulo/core/client/admin/ReplicationOperations.java
index dfb043c..7b47f8b 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/ReplicationOperations.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/ReplicationOperations.java
@@ -39,7 +39,8 @@ public interface ReplicationOperations {
    * @param replicaType
    *          Class name to use to replicate the data
    */
-  public void addPeer(String name, String replicaType) throws AccumuloException, AccumuloSecurityException, PeerExistsException;
+  public void addPeer(String name, String replicaType)
+      throws AccumuloException, AccumuloSecurityException, PeerExistsException;
 
   /**
    * Removes a cluster with the given name.
@@ -47,32 +48,39 @@ public interface ReplicationOperations {
    * @param name
    *          Name of the cluster to remove
    */
-  public void removePeer(String name) throws AccumuloException, AccumuloSecurityException, PeerNotFoundException;
+  public void removePeer(String name)
+      throws AccumuloException, AccumuloSecurityException, PeerNotFoundException;
 
   /**
-   * Waits for a table to be fully replicated, given the state of files pending replication for the provided table at the point in time which this method is
-   * invoked.
+   * Waits for a table to be fully replicated, given the state of files pending replication for the
+   * provided table at the point in time which this method is invoked.
    *
    * @param tableName
    *          The table to wait for
    */
-  public void drain(String tableName) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
+  public void drain(String tableName)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 
   /**
-   * Given the provided set of files that are pending replication for a table, wait for those files to be fully replicated to all configured peers. This allows
-   * for the accurate calculation when a table, at a given point in time, has been fully replicated.
+   * Given the provided set of files that are pending replication for a table, wait for those files
+   * to be fully replicated to all configured peers. This allows for the accurate calculation when a
+   * table, at a given point in time, has been fully replicated.
    *
    * @param tableName
    *          The table to wait for
    */
-  public void drain(String tableName, Set<String> files) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
+  public void drain(String tableName, Set<String> files)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 
   /**
-   * Gets all of the referenced files for a table from the metadata table. The result of this method is intended to be directly supplied to
-   * {@link #drain(String, Set)}. This helps determine when all data from a given point in time has been fully replicated.
+   * Gets all of the referenced files for a table from the metadata table. The result of this method
+   * is intended to be directly supplied to {@link #drain(String, Set)}. This helps determine when
+   * all data from a given point in time has been fully replicated.
    * <p>
-   * This also allows callers to get the {@link Set} of files for a table at some time, and later provide that {@link Set} to {@link #drain(String,Set)} to wait
-   * for all of those files to be replicated.
+   * This also allows callers to get the {@link Set} of files for a table at some time, and later
+   * provide that {@link Set} to {@link #drain(String,Set)} to wait for all of those files to be
+   * replicated.
    */
-  public Set<String> referencedFiles(String tableName) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
+  public Set<String> referencedFiles(String tableName)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 }
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 cb916ef..14a6a3c 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
@@ -46,10 +46,12 @@ public interface SecurityOperations {
    *           if a general error occurs
    * @throws AccumuloSecurityException
    *           if the user does not have permission to create a user
-   * @deprecated since 1.5.0; use {@link #createLocalUser(String, PasswordToken)} or the user management functions of your configured authenticator instead.
+   * @deprecated since 1.5.0; use {@link #createLocalUser(String, PasswordToken)} or the user
+   *             management functions of your configured authenticator instead.
    */
   @Deprecated
-  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
@@ -64,7 +66,8 @@ public interface SecurityOperations {
    *           if the user does not have permission to create a user
    * @since 1.5.0
    */
-  void createLocalUser(String principal, PasswordToken password) throws AccumuloException, AccumuloSecurityException;
+  void createLocalUser(String principal, PasswordToken password)
+      throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Delete a user
@@ -75,7 +78,8 @@ public interface SecurityOperations {
    *           if a general error occurs
    * @throws AccumuloSecurityException
    *           if the user does not have permission to delete a user
-   * @deprecated since 1.5.0; use {@link #dropUser(String)} or the user management functions of your configured authenticator instead.
+   * @deprecated since 1.5.0; use {@link #dropUser(String)} or the user management functions of your
+   *             configured authenticator instead.
    */
   @Deprecated
   void dropUser(String user) throws AccumuloException, AccumuloSecurityException;
@@ -100,7 +104,8 @@ public interface SecurityOperations {
    *          the name of the user to authenticate
    * @param password
    *          the plaintext password for the user
-   * @return true if the user asking is allowed to know and the specified user/password is valid, false otherwise
+   * @return true if the user asking is allowed to know and the specified user/password is valid,
+   *         false otherwise
    * @throws AccumuloException
    *           if a general error occurs
    * @throws AccumuloSecurityException
@@ -108,7 +113,8 @@ public interface SecurityOperations {
    * @deprecated since 1.5.0; use {@link #authenticateUser(String, AuthenticationToken)} instead.
    */
   @Deprecated
-  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
@@ -117,14 +123,16 @@ public interface SecurityOperations {
    *          the name of the user to authenticate
    * @param token
    *          the SecurityToken for the user
-   * @return true if the user asking is allowed to know and the specified principal/token is valid, false otherwise
+   * @return true if the user asking is allowed to know and the specified principal/token is valid,
+   *         false otherwise
    * @throws AccumuloException
    *           if a general error occurs
    * @throws AccumuloSecurityException
    *           if the user does not have permission to ask
    * @since 1.5.0
    */
-  boolean authenticateUser(String principal, AuthenticationToken token) throws AccumuloException, AccumuloSecurityException;
+  boolean authenticateUser(String principal, AuthenticationToken token)
+      throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Set the user's password
@@ -137,11 +145,12 @@ public interface SecurityOperations {
    *           if a general error occurs
    * @throws AccumuloSecurityException
    *           if the user does not have permission to modify a user
-   * @deprecated since 1.5.0; use {@link #changeLocalUserPassword(String, PasswordToken)} or the user management functions of your configured authenticator
-   *             instead.
+   * @deprecated since 1.5.0; use {@link #changeLocalUserPassword(String, PasswordToken)} or the
+   *             user management functions of your configured authenticator instead.
    */
   @Deprecated
-  void changeUserPassword(String user, byte[] password) throws AccumuloException, AccumuloSecurityException;
+  void changeUserPassword(String user, byte[] password)
+      throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Set the user's password
@@ -156,7 +165,8 @@ public interface SecurityOperations {
    *           if the user does not have permission to modify a user
    * @since 1.5.0
    */
-  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
@@ -170,7 +180,8 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to modify a user
    */
-  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
@@ -183,7 +194,8 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to query a user
    */
-  Authorizations getUserAuthorizations(String principal) throws AccumuloException, AccumuloSecurityException;
+  Authorizations getUserAuthorizations(String principal)
+      throws AccumuloException, AccumuloSecurityException;
 
   /**
    * Verify the user has a particular system permission
@@ -198,7 +210,8 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to query a user
    */
-  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
@@ -215,7 +228,8 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to query a user
    */
-  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
@@ -232,7 +246,8 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to query a user
    */
-  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
@@ -246,7 +261,8 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to grant a user permissions
    */
-  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
@@ -262,7 +278,8 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to grant a user permissions
    */
-  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
@@ -278,7 +295,8 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to grant a user permissions
    */
-  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
@@ -292,7 +310,8 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to revoke a user's permissions
    */
-  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
@@ -308,7 +327,8 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to revoke a user's permissions
    */
-  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
@@ -324,7 +344,8 @@ public interface SecurityOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission to revoke a user's permissions
    */
-  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
@@ -334,7 +355,8 @@ public interface SecurityOperations {
    *           if a general error occurs
    * @throws AccumuloSecurityException
    *           if the user does not have permission to query users
-   * @deprecated since 1.5.0; use {@link #listLocalUsers()} or the user management functions of your configured authenticator instead.
+   * @deprecated since 1.5.0; use {@link #listLocalUsers()} or the user management functions of your
+   *             configured authenticator instead.
    */
   @Deprecated
   Set<String> listUsers() throws AccumuloException, AccumuloSecurityException;
@@ -352,9 +374,11 @@ public interface SecurityOperations {
   Set<String> listLocalUsers() throws AccumuloException, AccumuloSecurityException;
 
   /**
-   * Obtain a {@link DelegationToken} for use when Kerberos credentials cannot be used (e.g. YARN Jobs)
+   * Obtain a {@link DelegationToken} for use when Kerberos credentials cannot be used (e.g. YARN
+   * Jobs)
    *
    * @since 1.7.0
    */
-  DelegationToken getDelegationToken(DelegationTokenConfig cfg) throws AccumuloException, AccumuloSecurityException;
+  DelegationToken getDelegationToken(DelegationTokenConfig cfg)
+      throws AccumuloException, AccumuloSecurityException;
 }
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 3e56736..7ff76c9 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
@@ -74,13 +74,15 @@ public interface TableOperations {
    * @throws TableExistsException
    *           if the table already exists
    */
-  void create(String tableName) throws AccumuloException, AccumuloSecurityException, TableExistsException;
+  void create(String tableName)
+      throws AccumuloException, AccumuloSecurityException, TableExistsException;
 
   /**
    * @param tableName
    *          the name of the table
    * @param limitVersion
-   *          Enables/disables the versioning iterator, which will limit the number of Key versions kept.
+   *          Enables/disables the versioning iterator, which will limit the number of Key versions
+   *          kept.
    * @throws AccumuloException
    *           if a general error occurs
    * @throws AccumuloSecurityException
@@ -90,13 +92,15 @@ public interface TableOperations {
    * @deprecated since 1.7.0; use {@link #create(String, NewTableConfiguration)} instead.
    */
   @Deprecated
-  void create(String tableName, boolean limitVersion) throws AccumuloException, AccumuloSecurityException, TableExistsException;
+  void create(String tableName, boolean limitVersion)
+      throws AccumuloException, AccumuloSecurityException, TableExistsException;
 
   /**
    * @param tableName
    *          the name of the table
    * @param versioningIter
-   *          Enables/disables the versioning iterator, which will limit the number of Key versions kept.
+   *          Enables/disables the versioning iterator, which will limit the number of Key versions
+   *          kept.
    * @param timeType
    *          specifies logical or real-time based time recording for entries in the table
    * @throws AccumuloException
@@ -108,15 +112,17 @@ public interface TableOperations {
    * @deprecated since 1.7.0; use {@link #create(String, NewTableConfiguration)} instead.
    */
   @Deprecated
-  void create(String tableName, boolean versioningIter, TimeType timeType) throws AccumuloException, AccumuloSecurityException, TableExistsException;
+  void create(String tableName, boolean versioningIter, TimeType timeType)
+      throws AccumuloException, AccumuloSecurityException, TableExistsException;
 
   /**
    * @param tableName
    *          the name of the table
    * @param ntc
-   *          specifies the new table's configuration variable, which are: 1. enable/disable the versioning iterator, which will limit the number of Key
-   *          versions kept; 2. specifies logical or real-time based time recording for entries in the table; 3. user defined properties to be merged into the
-   *          initial properties of the table
+   *          specifies the new table's configuration variable, which are: 1. enable/disable the
+   *          versioning iterator, which will limit the number of Key versions kept; 2. specifies
+   *          logical or real-time based time recording for entries in the table; 3. user defined
+   *          properties to be merged into the initial properties of the table
    * @throws AccumuloException
    *           if a general error occurs
    * @throws AccumuloSecurityException
@@ -125,7 +131,8 @@ public interface TableOperations {
    *           if the table already exists
    * @since 1.7.0
    */
-  void create(String tableName, NewTableConfiguration ntc) throws AccumuloSecurityException, AccumuloException, TableExistsException;
+  void create(String tableName, NewTableConfiguration ntc)
+      throws AccumuloSecurityException, AccumuloException, TableExistsException;
 
   /**
    * Imports a table exported via exportTable and copied via hadoop distcp.
@@ -136,11 +143,13 @@ public interface TableOperations {
    *          Directory that contains the files copied by distcp from exportTable
    * @since 1.5.0
    */
-  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
-   * offline for the duration of distcp. To avoid losing access to a table it can be cloned and the clone taken offline for export.
+   * 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 offline for the duration of distcp.
+   * To avoid losing access to a table it can be cloned and the clone taken offline for export.
    *
    * <p>
    * See docs/examples/README.export
@@ -148,18 +157,21 @@ public interface TableOperations {
    * @param tableName
    *          Name of the table to export.
    * @param exportDir
-   *          An empty directory in HDFS where files containing table metadata and list of files to distcp will be placed.
+   *          An empty directory in HDFS where files containing table metadata and list of files to
+   *          distcp will be placed.
    * @since 1.5.0
    */
-  void exportTable(String tableName, String exportDir) throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
+  void exportTable(String tableName, String exportDir)
+      throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
 
   /**
    * Ensures that tablets are split along a set of keys.
    * <p>
-   * Note that while the documentation for Text specifies that its bytestream should be UTF-8, the encoding is not enforced by operations that work with byte
-   * arrays.
+   * Note that while the documentation for Text specifies that its bytestream should be UTF-8, the
+   * encoding is not enforced by operations that work with byte arrays.
    * <p>
-   * For example, you can create 256 evenly-sliced splits via the following code sample even though the given byte sequences are not valid UTF-8.
+   * For example, you can create 256 evenly-sliced splits via the following code sample even though
+   * the given byte sequences are not valid UTF-8.
    *
    * <pre>
    * TableOperations tableOps = connector.tableOperations();
@@ -182,7 +194,8 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           if the table does not exist
    */
-  void addSplits(String tableName, SortedSet<Text> partitionKeys) throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
+  void addSplits(String tableName, SortedSet<Text> partitionKeys)
+      throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
 
   /**
    * @param tableName
@@ -207,14 +220,16 @@ public interface TableOperations {
    *           if the user does not have permission
    * @since 1.5.0
    */
-  Collection<Text> listSplits(String tableName) throws TableNotFoundException, AccumuloSecurityException, AccumuloException;
+  Collection<Text> listSplits(String tableName)
+      throws TableNotFoundException, AccumuloSecurityException, AccumuloException;
 
   /**
    * @param tableName
    *          the name of the table
    * @param maxSplits
    *          specifies the maximum number of splits to return
-   * @return the split points (end-row names) for the table's current split profile, grouped into fewer splits so as not to exceed maxSplits
+   * @return the split points (end-row names) for the table's current split profile, grouped into
+   *         fewer splits so as not to exceed maxSplits
    * @deprecated since 1.5.0; use {@link #listSplits(String, int)} instead.
    */
   @Deprecated
@@ -229,14 +244,16 @@ public interface TableOperations {
    *           if a general error occurs
    * @throws AccumuloSecurityException
    *           if the user does not have permission
-   * @return the split points (end-row names) for the table's current split profile, grouped into fewer splits so as not to exceed maxSplits
+   * @return the split points (end-row names) for the table's current split profile, grouped into
+   *         fewer splits so as not to exceed maxSplits
    * @since 1.5.0
    */
-  Collection<Text> listSplits(String tableName, int maxSplits) throws TableNotFoundException, AccumuloSecurityException, AccumuloException;
+  Collection<Text> listSplits(String tableName, int maxSplits)
+      throws TableNotFoundException, AccumuloSecurityException, AccumuloException;
 
   /**
-   * Locates the tablet servers and tablets that would service a collections of ranges. If a range covers multiple tablets, it will occur multiple times in the
-   * returned map.
+   * Locates the tablet servers and tablets that would service a collections of ranges. If a range
+   * covers multiple tablets, it will occur multiple times in the returned map.
    *
    * @param ranges
    *          The input ranges that should be mapped to tablet servers and tablets.
@@ -245,10 +262,12 @@ public interface TableOperations {
    *           if the table is offline or goes offline during the operation
    * @since 1.8.0
    */
-  Locations locate(String tableName, Collection<Range> ranges) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
+  Locations locate(String tableName, Collection<Range> ranges)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 
   /**
-   * Finds the max row within a given range. To find the max row in a table, pass null for start and end row.
+   * Finds the max row within a given range. To find the max row in a table, pass null for start and
+   * end row.
    *
    * @param auths
    *          find the max row that can seen with these auths
@@ -263,7 +282,8 @@ public interface TableOperations {
    *
    * @return The max row in the range, or null if there is no visible data in the range.
    */
-  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;
 
   /**
@@ -276,7 +296,8 @@ public interface TableOperations {
    * @param end
    *          last tablet to be merged contains this row, null means the last tablet
    */
-  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]
@@ -288,15 +309,18 @@ public interface TableOperations {
    * @param end
    *          last row to be deleted, inclusive, null means the last row of the table
    */
-  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.
+   * 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.
    *
    * @param tableName
    *          the table to compact
    * @param start
-   *          first tablet to be compacted contains the row after this row, null means the first tablet in table
+   *          first tablet to be compacted contains the row after this row, null means the first
+   *          tablet in table
    * @param end
    *          last tablet to be compacted contains this row, null means the last tablet in table
    * @param flush
@@ -304,36 +328,42 @@ public interface TableOperations {
    * @param wait
    *          when true, the call will not return until compactions are finished
    */
-  void compact(String tableName, Text start, Text end, boolean flush, boolean wait) throws AccumuloSecurityException, TableNotFoundException, AccumuloException;
+  void compact(String tableName, Text start, Text end, boolean flush, boolean wait)
+      throws AccumuloSecurityException, TableNotFoundException, AccumuloException;
 
   /**
-   * 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.
+   * 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.
    *
    * @param tableName
    *          the table to compact
    * @param start
-   *          first tablet to be compacted contains the row after this row, null means the first tablet in table
+   *          first tablet to be compacted contains the row after this row, null means the first
+   *          tablet in table
    * @param end
    *          last tablet to be compacted contains this row, null means the last tablet in table
    * @param iterators
-   *          A set of iterators that will be applied to each tablet compacted. If two or more concurrent calls to compact pass iterators, then only one will
-   *          succeed and the others will fail.
+   *          A set of iterators that will be applied to each tablet compacted. If two or more
+   *          concurrent calls to compact pass iterators, then only one will succeed and the others
+   *          will fail.
    * @param flush
    *          when true, table memory is flushed before compaction starts
    * @param wait
    *          when true, the call will not return until compactions are finished
    * @since 1.5.0
    */
-  void compact(String tableName, Text start, Text end, List<IteratorSetting> iterators, boolean flush, boolean wait) throws AccumuloSecurityException,
-      TableNotFoundException, AccumuloException;
+  void compact(String tableName, Text start, Text end, List<IteratorSetting> iterators,
+      boolean flush, boolean wait)
+      throws AccumuloSecurityException, TableNotFoundException, AccumuloException;
 
   /**
-   * Starts a full major compaction of the tablets in the range (start, end]. If the config does not specify a compaction strategy, then all files in a tablet
-   * are compacted. The compaction is performed even for tablets that have only one file.
+   * Starts a full major compaction of the tablets in the range (start, end]. If the config does not
+   * specify a compaction strategy, then all files in a tablet are compacted. The compaction is
+   * performed even for tablets that have only one file.
    *
    * <p>
-   * Only one compact call at a time can pass iterators and/or a compaction strategy. If two threads call compaction with iterators and/or a copmaction
-   * strategy, then one will fail.
+   * Only one compact call at a time can pass iterators and/or a compaction strategy. If two threads
+   * call compaction with iterators and/or a copmaction strategy, then one will fail.
    *
    * @param tableName
    *          the table to compact
@@ -342,12 +372,14 @@ public interface TableOperations {
    *
    * @since 1.7.0
    */
-  void compact(String tableName, CompactionConfig config) throws AccumuloSecurityException, TableNotFoundException, AccumuloException;
+  void compact(String tableName, CompactionConfig config)
+      throws AccumuloSecurityException, TableNotFoundException, AccumuloException;
 
   /**
-   * Cancels a user initiated major compaction of a table initiated with {@link #compact(String, Text, Text, boolean, boolean)} or
-   * {@link #compact(String, Text, Text, List, boolean, boolean)}. Compactions of tablets that are currently running may finish, but new compactions of tablets
-   * will not start.
+   * Cancels a user initiated major compaction of a table initiated with
+   * {@link #compact(String, Text, Text, boolean, boolean)} or
+   * {@link #compact(String, Text, Text, List, boolean, boolean)}. Compactions of tablets that are
+   * currently running may finish, but new compactions of tablets will not start.
    *
    * @param tableName
    *          the name of the table
@@ -359,7 +391,8 @@ public interface TableOperations {
    *           if the user does not have permission
    * @since 1.5.0
    */
-  void cancelCompaction(String tableName) throws AccumuloSecurityException, TableNotFoundException, AccumuloException;
+  void cancelCompaction(String tableName)
+      throws AccumuloSecurityException, TableNotFoundException, AccumuloException;
 
   /**
    * Delete a table
@@ -373,12 +406,14 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           if the table does not exist
    */
-  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
-   * mutate independently. Initially the cloned table should not use any extra space, however as the source table and cloned table major compact extra space
-   * will be used by the clone.
+   * 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 mutate independently. Initially
+   * the cloned table should not use any extra space, however as the source table and cloned table
+   * major compact extra space will be used by the clone.
    *
    * Initially the cloned table is only readable and writable by the user who created it.
    *
@@ -394,8 +429,9 @@ public interface TableOperations {
    *          do not copy these properties from the source table, just revert to system defaults
    */
 
-  void clone(String srcTableName, String newTableName, boolean flush, Map<String,String> propertiesToSet, Set<String> propertiesToExclude)
-      throws AccumuloException, AccumuloSecurityException, TableNotFoundException, TableExistsException;
+  void clone(String srcTableName, String newTableName, boolean flush,
+      Map<String,String> propertiesToSet, Set<String> propertiesToExclude) throws AccumuloException,
+      AccumuloSecurityException, TableNotFoundException, TableExistsException;
 
   /**
    * Rename a table
@@ -413,7 +449,8 @@ public interface TableOperations {
    * @throws TableExistsException
    *           if the new table name already exists
    */
-  void rename(String oldTableName, String newTableName) throws AccumuloSecurityException, TableNotFoundException, AccumuloException, TableExistsException;
+  void rename(String oldTableName, String newTableName) throws AccumuloSecurityException,
+      TableNotFoundException, AccumuloException, TableExistsException;
 
   /**
    * Initiate a flush of a table's data that is in memory
@@ -436,19 +473,22 @@ public interface TableOperations {
    * @param tableName
    *          the name of the table
    * @param wait
-   *          if true the call will not return until all data present in memory when the call was is flushed if false will initiate a flush of data in memory,
-   *          but will not wait for it to complete
+   *          if true the call will not return until all data present in memory when the call was is
+   *          flushed if false will initiate a flush of data in memory, but will not wait for it to
+   *          complete
    * @throws AccumuloException
    *           if a general error occurs
    * @throws AccumuloSecurityException
    *           if the user does not have permission
    */
-  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. This operation is asynchronous and eventually consistent. Not all tablets in a table will acknowledge this new value
-   * immediately nor at the same time. Within a few seconds without another change, all tablets in a table should see the updated value. The clone table feature
-   * can be used if consistency is required.
+   * Sets a property on a table. This operation is asynchronous and eventually consistent. Not all
+   * tablets in a table will acknowledge this new value immediately nor at the same time. Within a
+   * few seconds without another change, all tablets in a table should see the updated value. The
+   * clone table feature can be used if consistency is required.
    *
    * @param tableName
    *          the name of the table
@@ -461,12 +501,14 @@ public interface TableOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission
    */
-  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. This operation is asynchronous and eventually consistent. Not all tablets in a table will acknowledge this altered value
-   * immediately nor at the same time. Within a few seconds without another change, all tablets in a table should see the altered value. The clone table feature
-   * can be used if consistency is required.
+   * Removes a property from a table. This operation is asynchronous and eventually consistent. Not
+   * all tablets in a table will acknowledge this altered value immediately nor at the same time.
+   * Within a few seconds without another change, all tablets in a table should see the altered
+   * value. The clone table feature can be used if consistency is required.
    *
    * @param tableName
    *          the name of the table
@@ -477,20 +519,24 @@ public interface TableOperations {
    * @throws AccumuloSecurityException
    *           if the user does not have permission
    */
-  void removeProperty(String tableName, String property) throws AccumuloException, AccumuloSecurityException;
+  void removeProperty(String tableName, String property)
+      throws AccumuloException, AccumuloSecurityException;
 
   /**
-   * Gets properties of a table. This operation is asynchronous and eventually consistent. It is not guaranteed that all tablets in a table will return the same
-   * values. Within a few seconds without another change, all tablets in a table should be consistent. The clone table feature can be used if consistency is
-   * required.
+   * Gets properties of a table. This operation is asynchronous and eventually consistent. It is not
+   * guaranteed that all tablets in a table will return the same values. Within a few seconds
+   * without another change, all tablets in a table should be consistent. The clone table feature
+   * can be used if consistency is required.
    *
    * @param tableName
    *          the name of the table
-   * @return all properties visible by this table (system and per-table properties). Note that recently changed properties may not be visible immediately.
+   * @return all properties visible by this table (system and per-table properties). Note that
+   *         recently changed properties may not be visible immediately.
    * @throws TableNotFoundException
    *           if the table does not exist
    */
-  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.
@@ -506,7 +552,8 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           if the table does not exist
    */
-  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;
 
   /**
    *
@@ -520,7 +567,8 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           if the table does not exist
    */
-  Map<String,Set<Text>> getLocalityGroups(String tableName) throws AccumuloException, TableNotFoundException;
+  Map<String,Set<Text>> getLocalityGroups(String tableName)
+      throws AccumuloException, TableNotFoundException;
 
   /**
    * @param tableName
@@ -529,7 +577,8 @@ public interface TableOperations {
    *          a range to split
    * @param maxSplits
    *          the maximum number of splits
-   * @return the range, split into smaller ranges that fall on boundaries of the table's split points as evenly as possible
+   * @return the range, split into smaller ranges that fall on boundaries of the table's split
+   *         points as evenly as possible
    * @throws AccumuloException
    *           if a general error occurs
    * @throws AccumuloSecurityException
@@ -537,10 +586,12 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           if the table does not exist
    */
-  Set<Range> splitRangeByTablets(String tableName, Range range, int maxSplits) throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
+  Set<Range> splitRangeByTablets(String tableName, Range range, int maxSplits)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 
   /**
-   * Bulk import all the files in a directory into a table. Files can be created using {@link AccumuloFileOutputFormat} and {@link RFile#newWriter()}
+   * Bulk import all the files in a directory into a table. Files can be created using
+   * {@link AccumuloFileOutputFormat} and {@link RFile#newWriter()}
    *
    * @param tableName
    *          the name of the table
@@ -549,7 +600,8 @@ public interface TableOperations {
    * @param failureDir
    *          the HDFS directory to place files that failed to be imported, must exist and be empty
    * @param setTime
-   *          override the time values in the input files, and use the current time for all mutations
+   *          override the time values in the input files, and use the current time for all
+   *          mutations
    * @throws IOException
    *           when there is an error reading/writing to HDFS
    * @throws AccumuloException
@@ -560,8 +612,8 @@ public interface TableOperations {
    *           when the table no longer exists
    *
    */
-  void importDirectory(String tableName, String dir, String failureDir, boolean setTime) throws TableNotFoundException, IOException, AccumuloException,
-      AccumuloSecurityException;
+  void importDirectory(String tableName, String dir, String failureDir, boolean setTime)
+      throws TableNotFoundException, IOException, AccumuloException, AccumuloSecurityException;
 
   /**
    * Initiates taking a table offline, but does not wait for action to complete
@@ -573,7 +625,8 @@ public interface TableOperations {
    * @throws AccumuloSecurityException
    *           when the user does not have the proper permissions
    */
-  void offline(String tableName) throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
+  void offline(String tableName)
+      throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
 
   /**
    *
@@ -587,7 +640,8 @@ public interface TableOperations {
    *           when the user does not have the proper permissions
    * @since 1.6.0
    */
-  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
@@ -599,7 +653,8 @@ public interface TableOperations {
    * @throws AccumuloSecurityException
    *           when the user does not have the proper permissions
    */
-  void online(String tableName) throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
+  void online(String tableName)
+      throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
 
   /**
    *
@@ -613,7 +668,8 @@ public interface TableOperations {
    *           when the user does not have the proper permissions
    * @since 1.6.0
    */
-  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
@@ -646,7 +702,8 @@ public interface TableOperations {
    * @throws IllegalArgumentException
    *           if the setting conflicts with any existing iterators
    */
-  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.
@@ -662,8 +719,8 @@ public interface TableOperations {
    * @throws IllegalArgumentException
    *           if the setting conflicts with any existing iterators
    */
-  void attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloSecurityException, AccumuloException,
-      TableNotFoundException;
+  void attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorScope> scopes)
+      throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
 
   /**
    * Remove an iterator from a table by name.
@@ -679,7 +736,8 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           throw if the table no longer exists
    */
-  void removeIterator(String tableName, String name, EnumSet<IteratorScope> scopes) throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
+  void removeIterator(String tableName, String name, EnumSet<IteratorScope> scopes)
+      throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
 
   /**
    * Get the settings for an iterator.
@@ -696,8 +754,8 @@ public interface TableOperations {
    * @throws TableNotFoundException
    *           throw if the table no longer exists
    */
-  IteratorSetting getIteratorSetting(String tableName, String name, IteratorScope scope) throws AccumuloSecurityException, AccumuloException,
-      TableNotFoundException;
+  IteratorSetting getIteratorSetting(String tableName, String name, IteratorScope scope)
+      throws AccumuloSecurityException, AccumuloException, TableNotFoundException;
 
   /**
    * Get a list of iterators for this table.
@@ -706,18 +764,20 @@ public interface TableOperations {
    *          the name of the table
    * @return a set of iterator names
    */
-  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
-   * the specified scopes.
+   * Check whether a given iterator configuration conflicts with existing configuration; in
+   * particular, determine if the name or priority are already in use for the specified scopes.
    *
    * @param tableName
    *          the name of the table
    * @param setting
    *          object specifying the properties of the iterator
    */
-  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.
@@ -728,12 +788,14 @@ public interface TableOperations {
    *          the full name of the constraint class
    * @return the unique number assigned to the constraint
    * @throws AccumuloException
-   *           thrown if the constraint has already been added to the table or if there are errors in the configuration of existing constraints
+   *           thrown if the constraint has already been added to the table or if there are errors
+   *           in the configuration of existing constraints
    * @throws AccumuloSecurityException
    *           thrown if the user doesn't have permission to add the constraint
    * @since 1.5.0
    */
-  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.
@@ -746,7 +808,8 @@ public interface TableOperations {
    *           thrown if the user doesn't have permission to remove the constraint
    * @since 1.5.0
    */
-  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.
@@ -758,7 +821,8 @@ public interface TableOperations {
    *           thrown if there are errors in the configuration of existing constraints
    * @since 1.5.0
    */
-  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
@@ -768,28 +832,30 @@ public interface TableOperations {
    * @return a list of disk usage objects containing linked table names and sizes
    * @since 1.6.0
    */
-  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.
+   * 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.
    *
    * @return true if the instance can load the given class as the given type, false otherwise
    *
    * @since 1.5.0
    */
-  boolean testClassLoad(String tableName, final String className, final String asTypeName) throws AccumuloException, AccumuloSecurityException,
-      TableNotFoundException;
+  boolean testClassLoad(String tableName, final String className, final String asTypeName)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 
   /**
-   * Set or update the sampler configuration for a table. If the table has existing sampler configuration, those properties will be cleared before setting the
-   * new table properties.
+   * Set or update the sampler configuration for a table. If the table has existing sampler
+   * configuration, those properties will be cleared before setting the new table properties.
    *
    * @param tableName
    *          the name of the table
    * @since 1.8.0
    */
-  void setSamplerConfiguration(String tableName, SamplerConfiguration samplerConfiguration) throws TableNotFoundException, AccumuloException,
-      AccumuloSecurityException;
+  void setSamplerConfiguration(String tableName, SamplerConfiguration samplerConfiguration)
+      throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
 
   /**
    * Clear all sampling configuration properties on the table.
@@ -798,7 +864,8 @@ public interface TableOperations {
    *          the name of the table
    * @since 1.8.0
    */
-  void clearSamplerConfiguration(String tableName) throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
+  void clearSamplerConfiguration(String tableName)
+      throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
 
   /**
    * Reads the sampling configuration properties for a table.
@@ -807,5 +874,6 @@ public interface TableOperations {
    *          the name of the table
    * @since 1.8.0
    */
-  SamplerConfiguration getSamplerConfiguration(String tableName) throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
+  SamplerConfiguration getSamplerConfiguration(String tableName)
+      throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/TimeType.java b/core/src/main/java/org/apache/accumulo/core/client/admin/TimeType.java
index 426d384..0c966f4 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/TimeType.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/TimeType.java
@@ -26,9 +26,10 @@ public enum TimeType {
   LOGICAL,
 
   /**
-   * This is the default. Tries to ensure that inserted data is stored with the timestamp closest to the machine's time to the nearest millisecond, without
-   * going backwards to guarantee insertion sequence. Note that using this time type can cause time to "skip" forward if a machine has a time that is too far
-   * off. NTP is recommended when using this type.
+   * This is the default. Tries to ensure that inserted data is stored with the timestamp closest to
+   * the machine's time to the nearest millisecond, without going backwards to guarantee insertion
+   * sequence. Note that using this time type can cause time to "skip" forward if a machine has a
+   * time that is too far off. NTP is recommended when using this type.
    */
   MILLIS
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/AcceptableThriftTableOperationException.java b/core/src/main/java/org/apache/accumulo/core/client/impl/AcceptableThriftTableOperationException.java
index 98c1bf5..6613117 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/AcceptableThriftTableOperationException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/AcceptableThriftTableOperationException.java
@@ -24,11 +24,13 @@ import org.apache.accumulo.fate.AcceptableException;
 /**
  * Concrete implementation of {@link AcceptableException} for table operations.
  */
-public class AcceptableThriftTableOperationException extends ThriftTableOperationException implements AcceptableException {
+public class AcceptableThriftTableOperationException extends ThriftTableOperationException
+    implements AcceptableException {
 
   private static final long serialVersionUID = 1L;
 
-  public AcceptableThriftTableOperationException(String tableId, String tableName, TableOperation op, TableOperationExceptionType type, String description) {
+  public AcceptableThriftTableOperationException(String tableId, String tableName,
+      TableOperation op, TableOperationExceptionType type, String description) {
     super(tableId, tableName, op, type, description);
   }
 }
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 bdd5d51..aa27c50 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
@@ -39,7 +39,8 @@ public class ActiveCompactionImpl extends ActiveCompaction {
   private org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction tac;
   private Instance instance;
 
-  ActiveCompactionImpl(Instance instance, org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction tac) {
+  ActiveCompactionImpl(Instance instance,
+      org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction tac) {
     this.tac = tac;
     this.instance = instance;
   }
@@ -53,7 +54,8 @@ public class ActiveCompactionImpl extends ActiveCompaction {
   @Deprecated
   public org.apache.accumulo.core.data.KeyExtent getExtent() {
     KeyExtent ke = new KeyExtent(tac.getExtent());
-    org.apache.accumulo.core.data.KeyExtent oke = new org.apache.accumulo.core.data.KeyExtent(new Text(ke.getTableId()), ke.getEndRow(), ke.getPrevEndRow());
+    org.apache.accumulo.core.data.KeyExtent oke = new org.apache.accumulo.core.data.KeyExtent(
+        new Text(ke.getTableId()), ke.getEndRow(), ke.getPrevEndRow());
     return oke;
   }
 
@@ -107,7 +109,8 @@ public class ActiveCompactionImpl extends ActiveCompaction {
     ArrayList<IteratorSetting> ret = new ArrayList<>();
 
     for (IterInfo ii : tac.getSsiList()) {
-      IteratorSetting settings = new IteratorSetting(ii.getPriority(), ii.getIterName(), ii.getClassName());
+      IteratorSetting settings = new IteratorSetting(ii.getPriority(), ii.getIterName(),
+          ii.getClassName());
       Map<String,String> options = tac.getSsio().get(ii.getIterName());
       settings.addOptions(options);
 
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveScanImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveScanImpl.java
index 9021190..2e22ed7 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveScanImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveScanImpl.java
@@ -55,7 +55,9 @@ public class ActiveScanImpl extends ActiveScan {
   private String user;
   private Authorizations authorizations;
 
-  ActiveScanImpl(Instance instance, org.apache.accumulo.core.tabletserver.thrift.ActiveScan activeScan) throws TableNotFoundException {
+  ActiveScanImpl(Instance instance,
+      org.apache.accumulo.core.tabletserver.thrift.ActiveScan activeScan)
+      throws TableNotFoundException {
     this.scanId = activeScan.scanId;
     this.client = activeScan.client;
     this.user = activeScan.user;
@@ -122,7 +124,8 @@ public class ActiveScanImpl extends ActiveScan {
   @Override
   @Deprecated
   public org.apache.accumulo.core.data.KeyExtent getExtent() {
-    return new org.apache.accumulo.core.data.KeyExtent(new Text(extent.getTableId()), extent.getEndRow(), extent.getPrevEndRow());
+    return new org.apache.accumulo.core.data.KeyExtent(new Text(extent.getTableId()),
+        extent.getEndRow(), extent.getPrevEndRow());
   }
 
   @Override
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/AuthenticationTokenIdentifier.java b/core/src/main/java/org/apache/accumulo/core/client/impl/AuthenticationTokenIdentifier.java
index 41c9120..56b83b7 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/AuthenticationTokenIdentifier.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/AuthenticationTokenIdentifier.java
@@ -56,7 +56,8 @@ public class AuthenticationTokenIdentifier extends TokenIdentifier {
     this.cfg = cfg;
   }
 
-  public AuthenticationTokenIdentifier(String principal, int keyId, long issueDate, long expirationDate, String instanceId) {
+  public AuthenticationTokenIdentifier(String principal, int keyId, long issueDate,
+      long expirationDate, String instanceId) {
     requireNonNull(principal);
     impl = new TAuthenticationTokenIdentifier(principal);
     impl.setKeyId(keyId);
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/BaseIteratorEnvironment.java b/core/src/main/java/org/apache/accumulo/core/client/impl/BaseIteratorEnvironment.java
index 7b1c441..b0f390b 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/BaseIteratorEnvironment.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/BaseIteratorEnvironment.java
@@ -29,14 +29,16 @@ import org.apache.accumulo.core.iterators.SortedKeyValueIterator;
 import org.apache.accumulo.core.security.Authorizations;
 
 /**
- * An implementation of {@link IteratorEnvironment} that throws {@link UnsupportedOperationException} for each operation. This is useful for situations that
- * need to extend {@link IteratorEnvironment} and implement a subset of the methods.
+ * An implementation of {@link IteratorEnvironment} that throws
+ * {@link UnsupportedOperationException} for each operation. This is useful for situations that need
+ * to extend {@link IteratorEnvironment} and implement a subset of the methods.
  */
 
 public class BaseIteratorEnvironment implements IteratorEnvironment {
 
   @Override
-  public SortedKeyValueIterator<Key,Value> reserveMapFileReader(String mapFileName) throws IOException {
+  public SortedKeyValueIterator<Key,Value> reserveMapFileReader(String mapFileName)
+      throws IOException {
     throw new UnsupportedOperationException();
   }
 
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ClientContext.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ClientContext.java
index f54a7a9..0f53992 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ClientContext.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ClientContext.java
@@ -47,10 +47,13 @@ import com.google.common.base.Supplier;
 import com.google.common.base.Suppliers;
 
 /**
- * This class represents any essential configuration and credentials needed to initiate RPC operations throughout the code. It is intended to represent a shared
- * object that contains these things from when the client was first constructed. It is not public API, and is only an internal representation of the context in
- * which a client is executing RPCs. If additional parameters are added to the public API that need to be used in the internals of Accumulo, they should be
- * added to this object for later retrieval, rather than as a separate parameter. Any state in this object should be available at the time of its construction.
+ * This class represents any essential configuration and credentials needed to initiate RPC
+ * operations throughout the code. It is intended to represent a shared object that contains these
+ * things from when the client was first constructed. It is not public API, and is only an internal
+ * representation of the context in which a client is executing RPCs. If additional parameters are
+ * added to the public API that need to be used in the internals of Accumulo, they should be added
+ * to this object for later retrieval, rather than as a separate parameter. Any state in this object
+ * should be available at the time of its construction.
  */
 public class ClientContext {
 
@@ -62,7 +65,8 @@ public class ClientContext {
   private final AccumuloConfiguration rpcConf;
   protected Connector conn;
 
-  // These fields are very frequently accessed (each time a connection is created) and expensive to compute, so cache them.
+  // These fields are very frequently accessed (each time a connection is created) and expensive to
+  // compute, so cache them.
   private Supplier<Long> timeoutSupplier;
   private Supplier<SaslConnectionParams> saslSupplier;
   private Supplier<SslConnectionParams> sslSupplier;
@@ -72,14 +76,17 @@ public class ClientContext {
    * Instantiate a client context
    */
   public ClientContext(Instance instance, Credentials credentials, ClientConfiguration clientConf) {
-    this(instance, credentials, convertClientConfig(requireNonNull(clientConf, "clientConf is null")));
+    this(instance, credentials,
+        convertClientConfig(requireNonNull(clientConf, "clientConf is null")));
     this.clientConf = clientConf;
   }
 
   /**
-   * Instantiate a client context from an existing {@link AccumuloConfiguration}. This is primarily intended for subclasses and testing.
+   * Instantiate a client context from an existing {@link AccumuloConfiguration}. This is primarily
+   * intended for subclasses and testing.
    */
-  public ClientContext(Instance instance, Credentials credentials, AccumuloConfiguration serverConf) {
+  public ClientContext(Instance instance, Credentials credentials,
+      AccumuloConfiguration serverConf) {
     inst = requireNonNull(instance, "instance is null");
     creds = requireNonNull(credentials, "credentials is null");
     rpcConf = requireNonNull(serverConf, "serverConf is null");
@@ -138,7 +145,8 @@ public class ClientContext {
   }
 
   /**
-   * Update the credentials in the current context after changing the current user's password or other auth token
+   * Update the credentials in the current context after changing the current user's password or
+   * other auth token
    */
   public synchronized void setCredentials(Credentials newCredentials) {
     checkArgument(newCredentials != null, "newCredentials is null");
@@ -207,7 +215,8 @@ public class ClientContext {
   }
 
   /**
-   * A utility method for converting client configuration to a standard configuration object for use internally.
+   * A utility method for converting client configuration to a standard configuration object for use
+   * internally.
    *
    * @param config
    *          the original {@link ClientConfiguration}
@@ -228,15 +237,20 @@ public class ClientContext {
           org.apache.hadoop.conf.Configuration hadoopConf = getHadoopConfiguration();
           if (null != hadoopConf) {
             try {
-              char[] value = CredentialProviderFactoryShim.getValueFromCredentialProvider(hadoopConf, key);
+              char[] value = CredentialProviderFactoryShim
+                  .getValueFromCredentialProvider(hadoopConf, key);
               if (null != value) {
                 log.trace("Loaded sensitive value for {} from CredentialProvider", key);
                 return new String(value);
               } else {
-                log.trace("Tried to load sensitive value for {} from CredentialProvider, but none was found", key);
+                log.trace(
+                    "Tried to load sensitive value for {} from CredentialProvider, but none was found",
+                    key);
               }
             } catch (IOException e) {
-              log.warn("Failed to extract sensitive property ({}) from Hadoop CredentialProvider, falling back to base AccumuloConfiguration", key, e);
+              log.warn(
+                  "Failed to extract sensitive property ({}) from Hadoop CredentialProvider, falling back to base AccumuloConfiguration",
+                  key, e);
             }
           }
         }
@@ -248,7 +262,8 @@ public class ClientContext {
           if (Property.GENERAL_KERBEROS_PRINCIPAL == property) {
             if (config.containsKey(ClientProperty.KERBEROS_SERVER_PRIMARY.getKey())) {
               // Avoid providing a realm since we don't know what it is...
-              return config.getString(ClientProperty.KERBEROS_SERVER_PRIMARY.getKey()) + "/_HOST@" + SaslConnectionParams.getDefaultRealm();
+              return config.getString(ClientProperty.KERBEROS_SERVER_PRIMARY.getKey()) + "/_HOST@"
+                  + SaslConnectionParams.getDefaultRealm();
             }
           }
           return defaults.get(property);
@@ -266,13 +281,16 @@ public class ClientContext {
             props.put(key, config.getString(key));
         }
 
-        // Two client props that don't exist on the server config. Client doesn't need to know about the Kerberos instance from the principle, but servers do
+        // Two client props that don't exist on the server config. Client doesn't need to know about
+        // the Kerberos instance from the principle, but servers do
         // Automatically reconstruct the server property when converting a client config.
         if (props.containsKey(ClientProperty.KERBEROS_SERVER_PRIMARY.getKey())) {
-          final String serverPrimary = props.remove(ClientProperty.KERBEROS_SERVER_PRIMARY.getKey());
+          final String serverPrimary = props
+              .remove(ClientProperty.KERBEROS_SERVER_PRIMARY.getKey());
           if (filter.apply(Property.GENERAL_KERBEROS_PRINCIPAL.getKey())) {
             // Use the _HOST expansion. It should be unnecessary in "client land".
-            props.put(Property.GENERAL_KERBEROS_PRINCIPAL.getKey(), serverPrimary + "/_HOST@" + SaslConnectionParams.getDefaultRealm());
+            props.put(Property.GENERAL_KERBEROS_PRINCIPAL.getKey(),
+                serverPrimary + "/_HOST@" + SaslConnectionParams.getDefaultRealm());
           }
         }
 
@@ -286,20 +304,24 @@ public class ClientContext {
               }
 
               if (filter.apply(key)) {
-                char[] value = CredentialProviderFactoryShim.getValueFromCredentialProvider(hadoopConf, key);
+                char[] value = CredentialProviderFactoryShim
+                    .getValueFromCredentialProvider(hadoopConf, key);
                 if (null != value) {
                   props.put(key, new String(value));
                 }
               }
             }
           } catch (IOException e) {
-            log.warn("Failed to extract sensitive properties from Hadoop CredentialProvider, falling back to accumulo-site.xml", e);
+            log.warn(
+                "Failed to extract sensitive properties from Hadoop CredentialProvider, falling back to accumulo-site.xml",
+                e);
           }
         }
       }
 
       private org.apache.hadoop.conf.Configuration getHadoopConfiguration() {
-        String credProviderPaths = config.getString(Property.GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS.getKey());
+        String credProviderPaths = config
+            .getString(Property.GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS.getKey());
         if (null != credProviderPaths && !credProviderPaths.isEmpty()) {
           org.apache.hadoop.conf.Configuration hadoopConf = new org.apache.hadoop.conf.Configuration();
           hadoopConf.set(CredentialProviderFactoryShim.CREDENTIAL_PROVIDER_PATH, credProviderPaths);
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 a8aecf6..6d1dc3d 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
@@ -107,8 +107,8 @@ class ConditionalWriterImpl implements ConditionalWriter {
     }
   }
 
-  private static ThreadPoolExecutor cleanupThreadPool = new ThreadPoolExecutor(1, 1, 3, TimeUnit.SECONDS, new LinkedBlockingQueue<Runnable>(),
-      new CleanupThreadFactory());
+  private static ThreadPoolExecutor cleanupThreadPool = new ThreadPoolExecutor(1, 1, 3,
+      TimeUnit.SECONDS, new LinkedBlockingQueue<Runnable>(), new CleanupThreadFactory());
 
   static {
     cleanupThreadPool.allowCoreThreadTimeOut(true);
@@ -348,10 +348,12 @@ class ConditionalWriterImpl implements ConditionalWriter {
 
   private void reschedule(SendTask task) {
     ServerQueue serverQueue = getServerQueue(task.location);
-    // just finished processing work for this server, could reschedule if it has more work or immediately process the work
+    // just finished processing work for this server, could reschedule if it has more work or
+    // immediately process the work
     // this code reschedules the the server for processing later... there may be other queues with
     // more data that need to be processed... also it will give the current server time to build
-    // up more data... the thinking is that rescheduling instead or processing immediately will result
+    // up more data... the thinking is that rescheduling instead or processing immediately will
+    // result
     // in bigger batches and less RPC overhead
 
     synchronized (serverQueue) {
@@ -398,7 +400,8 @@ class ConditionalWriterImpl implements ConditionalWriter {
     this.context = context;
     this.auths = config.getAuthorizations();
     this.ve = new VisibilityEvaluator(config.getAuthorizations());
-    this.threadPool = new ScheduledThreadPoolExecutor(config.getMaxWriteThreads(), new NamingThreadFactory(this.getClass().getSimpleName()));
+    this.threadPool = new ScheduledThreadPoolExecutor(config.getMaxWriteThreads(),
+        new NamingThreadFactory(this.getClass().getSimpleName()));
     this.locator = new SyncingTabletLocator(context, tableId);
     this.serverQueues = new HashMap<>();
     this.tableId = tableId;
@@ -438,7 +441,8 @@ class ConditionalWriterImpl implements ConditionalWriter {
       count++;
 
       if (mut.getConditions().size() == 0)
-        throw new IllegalArgumentException("ConditionalMutation had no conditions " + new String(mut.getRow(), UTF_8));
+        throw new IllegalArgumentException(
+            "ConditionalMutation had no conditions " + new String(mut.getRow(), UTF_8));
 
       for (Condition cond : mut.getConditions()) {
         if (!isVisible(cond.getVisibility())) {
@@ -504,7 +508,8 @@ class ConditionalWriterImpl implements ConditionalWriter {
 
   private HashMap<HostAndPort,SessionID> cachedSessionIDs = new HashMap<>();
 
-  private SessionID reserveSessionID(HostAndPort location, TabletClientService.Iface client, TInfo tinfo) throws ThriftSecurityException, TException {
+  private SessionID reserveSessionID(HostAndPort location, TabletClientService.Iface client,
+      TInfo tinfo) throws ThriftSecurityException, TException {
     // avoid cost of repeatedly making RPC to create sessions, reuse sessions
     synchronized (cachedSessionIDs) {
       SessionID sid = cachedSessionIDs.get(location);
@@ -521,7 +526,8 @@ class ConditionalWriterImpl implements ConditionalWriter {
       }
     }
 
-    TConditionalSession tcs = client.startConditionalUpdate(tinfo, context.rpcCreds(), ByteBufferUtil.toByteBuffers(auths.getAuthorizations()), tableId,
+    TConditionalSession tcs = client.startConditionalUpdate(tinfo, context.rpcCreds(),
+        ByteBufferUtil.toByteBuffers(auths.getAuthorizations()), tableId,
         DurabilityImpl.toThrift(durability), this.classLoaderContext);
 
     synchronized (cachedSessionIDs) {
@@ -598,7 +604,8 @@ class ConditionalWriterImpl implements ConditionalWriter {
       while (tresults == null) {
         try {
           sessionId = reserveSessionID(location, client, tinfo);
-          tresults = client.conditionalUpdate(tinfo, sessionId.sessionID, tmutations, compressedIters.getSymbolTable());
+          tresults = client.conditionalUpdate(tinfo, sessionId.sessionID, tmutations,
+              compressedIters.getSymbolTable());
         } catch (NoSuchScanIDException nssie) {
           sessionId = null;
           invalidateSessionID(location);
@@ -627,8 +634,9 @@ class ConditionalWriterImpl implements ConditionalWriter {
       queueRetry(ignored, location);
 
     } catch (ThriftSecurityException tse) {
-      AccumuloSecurityException ase = new AccumuloSecurityException(context.getCredentials().getPrincipal(), tse.getCode(), Tables.getPrintableTableInfoFromId(
-          context.getInstance(), tableId), tse);
+      AccumuloSecurityException ase = new AccumuloSecurityException(
+          context.getCredentials().getPrincipal(), tse.getCode(),
+          Tables.getPrintableTableInfoFromId(context.getInstance(), tableId), tse);
       queueException(location, cmidToCm, ase);
     } catch (TTransportException e) {
       locator.invalidateCache(context.getInstance(), location.toString());
@@ -659,7 +667,8 @@ class ConditionalWriterImpl implements ConditionalWriter {
       cmk.cm.queueResult(new Result(e, cmk.cm, location.toString()));
   }
 
-  private void invalidateSession(HostAndPort location, TabletServerMutations<QCMutation> mutations, Map<Long,CMK> cmidToCm, SessionID sessionId) {
+  private void invalidateSession(HostAndPort location, TabletServerMutations<QCMutation> mutations,
+      Map<Long,CMK> cmidToCm, SessionID sessionId) {
     if (sessionId == null) {
       queueRetry(cmidToCm, location);
     } else {
@@ -674,13 +683,16 @@ class ConditionalWriterImpl implements ConditionalWriter {
   }
 
   /**
-   * The purpose of this code is to ensure that a conditional mutation will not execute when its status is unknown. This allows a user to read the row when the
-   * status is unknown and not have to worry about the tserver applying the mutation after the scan.
+   * The purpose of this code is to ensure that a conditional mutation will not execute when its
+   * status is unknown. This allows a user to read the row when the status is unknown and not have
+   * to worry about the tserver applying the mutation after the scan.
    *
    * <p>
-   * If a conditional mutation is taking a long time to process, then this method will wait for it to finish... unless this exceeds timeout.
+   * If a conditional mutation is taking a long time to process, then this method will wait for it
+   * to finish... unless this exceeds timeout.
    */
-  private void invalidateSession(SessionID sessionId, HostAndPort location) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+  private void invalidateSession(SessionID sessionId, HostAndPort location)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
 
     long sleepTime = 50;
 
@@ -691,15 +703,18 @@ class ConditionalWriterImpl implements ConditionalWriter {
 
     ZooCacheFactory zcf = new ZooCacheFactory();
     while (true) {
-      if (!ZooLock.isLockHeld(zcf.getZooCache(instance.getZooKeepers(), instance.getZooKeepersSessionTimeOut()), lid)) {
-        // ACCUMULO-1152 added a tserver lock check to the tablet location cache, so this invalidation prevents future attempts to contact the
+      if (!ZooLock.isLockHeld(
+          zcf.getZooCache(instance.getZooKeepers(), instance.getZooKeepersSessionTimeOut()), lid)) {
+        // ACCUMULO-1152 added a tserver lock check to the tablet location cache, so this
+        // invalidation prevents future attempts to contact the
         // tserver even its gone zombie and is still running w/o a lock
         locator.invalidateCache(context.getInstance(), location.toString());
         return;
       }
 
       try {
-        // if the mutation is currently processing, this method will block until its done or times out
+        // if the mutation is currently processing, this method will block until its done or times
+        // out
         invalidateSession(sessionId.sessionID, location);
 
         return;
@@ -745,8 +760,9 @@ class ConditionalWriterImpl implements ConditionalWriter {
     }
   }
 
-  private void convertMutations(TabletServerMutations<QCMutation> mutations, Map<Long,CMK> cmidToCm, MutableLong cmid,
-      Map<TKeyExtent,List<TConditionalMutation>> tmutations, CompressedIterators compressedIters) {
+  private void convertMutations(TabletServerMutations<QCMutation> mutations, Map<Long,CMK> cmidToCm,
+      MutableLong cmid, Map<TKeyExtent,List<TConditionalMutation>> tmutations,
+      CompressedIterators compressedIters) {
 
     for (Entry<KeyExtent,List<QCMutation>> entry : mutations.getMutations().entrySet()) {
       TKeyExtent tke = entry.getKey().toThrift();
@@ -802,10 +818,12 @@ class ConditionalWriterImpl implements ConditionalWriter {
 
   private static final ConditionComparator CONDITION_COMPARATOR = new ConditionComparator();
 
-  private List<TCondition> convertConditions(ConditionalMutation cm, CompressedIterators compressedIters) {
+  private List<TCondition> convertConditions(ConditionalMutation cm,
+      CompressedIterators compressedIters) {
     List<TCondition> conditions = new ArrayList<>(cm.getConditions().size());
 
-    // sort conditions inorder to get better lookup performance. Sort on client side so tserver does not have to do it.
+    // sort conditions inorder to get better lookup performance. Sort on client side so tserver does
+    // not have to do it.
     Condition[] ca = cm.getConditions().toArray(new Condition[cm.getConditions().size()]);
     Arrays.sort(ca, CONDITION_COMPARATOR);
 
@@ -820,8 +838,10 @@ class ConditionalWriterImpl implements ConditionalWriter {
 
       ByteBuffer iters = compressedIters.compress(cond.getIterators());
 
-      TCondition tc = new TCondition(ByteBufferUtil.toByteBuffers(cond.getFamily()), ByteBufferUtil.toByteBuffers(cond.getQualifier()),
-          ByteBufferUtil.toByteBuffers(cond.getVisibility()), ts, hasTs, ByteBufferUtil.toByteBuffers(cond.getValue()), iters);
+      TCondition tc = new TCondition(ByteBufferUtil.toByteBuffers(cond.getFamily()),
+          ByteBufferUtil.toByteBuffers(cond.getQualifier()),
+          ByteBufferUtil.toByteBuffers(cond.getVisibility()), ts, hasTs,
+          ByteBufferUtil.toByteBuffers(cond.getValue()), iters);
 
       conditions.add(tc);
     }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ConnectorImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ConnectorImpl.java
index fc4affb..ebf4f30 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ConnectorImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ConnectorImpl.java
@@ -54,23 +54,27 @@ public class ConnectorImpl extends Connector {
   private InstanceOperations instanceops = null;
   private ReplicationOperations replicationops = null;
 
-  public ConnectorImpl(final ClientContext context) throws AccumuloException, AccumuloSecurityException {
+  public ConnectorImpl(final ClientContext context)
+      throws AccumuloException, AccumuloSecurityException {
     checkArgument(context != null, "Context is null");
     checkArgument(context.getCredentials() != null, "Credentials are null");
     checkArgument(context.getCredentials().getToken() != null, "Authentication token is null");
     if (context.getCredentials().getToken().isDestroyed())
-      throw new AccumuloSecurityException(context.getCredentials().getPrincipal(), SecurityErrorCode.TOKEN_EXPIRED);
+      throw new AccumuloSecurityException(context.getCredentials().getPrincipal(),
+          SecurityErrorCode.TOKEN_EXPIRED);
 
     this.context = context;
 
-    // Skip fail fast for system services; string literal for class name, to avoid dependency on server jar
+    // Skip fail fast for system services; string literal for class name, to avoid dependency on
+    // server jar
     final String tokenClassName = context.getCredentials().getToken().getClass().getName();
     if (!SYSTEM_TOKEN_NAME.equals(tokenClassName)) {
       ServerClient.execute(context, new ClientExec<ClientService.Client>() {
         @Override
         public void execute(ClientService.Client iface) throws Exception {
           if (!iface.authenticate(Tracer.traceInfo(), context.rpcCreds()))
-            throw new AccumuloSecurityException("Authentication failed, access denied", SecurityErrorCode.BAD_CREDENTIALS);
+            throw new AccumuloSecurityException("Authentication failed, access denied",
+                SecurityErrorCode.BAD_CREDENTIALS);
         }
       });
     }
@@ -92,49 +96,58 @@ public class ConnectorImpl extends Connector {
   }
 
   @Override
-  public BatchScanner createBatchScanner(String tableName, Authorizations authorizations, int numQueryThreads) throws TableNotFoundException {
+  public BatchScanner createBatchScanner(String tableName, Authorizations authorizations,
+      int numQueryThreads) throws TableNotFoundException {
     checkArgument(tableName != null, "tableName is null");
     checkArgument(authorizations != null, "authorizations is null");
-    return new TabletServerBatchReader(context, getTableId(tableName), authorizations, numQueryThreads);
+    return new TabletServerBatchReader(context, getTableId(tableName), authorizations,
+        numQueryThreads);
   }
 
   @Deprecated
   @Override
-  public BatchDeleter createBatchDeleter(String tableName, Authorizations authorizations, int numQueryThreads, long maxMemory, long maxLatency,
-      int maxWriteThreads) throws TableNotFoundException {
+  public BatchDeleter createBatchDeleter(String tableName, Authorizations authorizations,
+      int numQueryThreads, long maxMemory, long maxLatency, int maxWriteThreads)
+      throws TableNotFoundException {
     checkArgument(tableName != null, "tableName is null");
     checkArgument(authorizations != null, "authorizations is null");
-    return new TabletServerBatchDeleter(context, getTableId(tableName), authorizations, numQueryThreads, new BatchWriterConfig().setMaxMemory(maxMemory)
-        .setMaxLatency(maxLatency, TimeUnit.MILLISECONDS).setMaxWriteThreads(maxWriteThreads));
+    return new TabletServerBatchDeleter(context, getTableId(tableName), authorizations,
+        numQueryThreads, new BatchWriterConfig().setMaxMemory(maxMemory)
+            .setMaxLatency(maxLatency, TimeUnit.MILLISECONDS).setMaxWriteThreads(maxWriteThreads));
   }
 
   @Override
-  public BatchDeleter createBatchDeleter(String tableName, Authorizations authorizations, int numQueryThreads, BatchWriterConfig config)
-      throws TableNotFoundException {
+  public BatchDeleter createBatchDeleter(String tableName, Authorizations authorizations,
+      int numQueryThreads, BatchWriterConfig config) throws TableNotFoundException {
     checkArgument(tableName != null, "tableName is null");
     checkArgument(authorizations != null, "authorizations is null");
-    return new TabletServerBatchDeleter(context, getTableId(tableName), authorizations, numQueryThreads, config);
+    return new TabletServerBatchDeleter(context, getTableId(tableName), authorizations,
+        numQueryThreads, config);
   }
 
   @Deprecated
   @Override
-  public BatchWriter createBatchWriter(String tableName, long maxMemory, long maxLatency, int maxWriteThreads) throws TableNotFoundException {
+  public BatchWriter createBatchWriter(String tableName, long maxMemory, long maxLatency,
+      int maxWriteThreads) throws TableNotFoundException {
     checkArgument(tableName != null, "tableName is null");
-    return new BatchWriterImpl(context, getTableId(tableName), new BatchWriterConfig().setMaxMemory(maxMemory).setMaxLatency(maxLatency, TimeUnit.MILLISECONDS)
-        .setMaxWriteThreads(maxWriteThreads));
+    return new BatchWriterImpl(context, getTableId(tableName),
+        new BatchWriterConfig().setMaxMemory(maxMemory)
+            .setMaxLatency(maxLatency, TimeUnit.MILLISECONDS).setMaxWriteThreads(maxWriteThreads));
   }
 
   @Override
-  public BatchWriter createBatchWriter(String tableName, BatchWriterConfig config) throws TableNotFoundException {
+  public BatchWriter createBatchWriter(String tableName, BatchWriterConfig config)
+      throws TableNotFoundException {
     checkArgument(tableName != null, "tableName is null");
     return new BatchWriterImpl(context, getTableId(tableName), config);
   }
 
   @Deprecated
   @Override
-  public MultiTableBatchWriter createMultiTableBatchWriter(long maxMemory, long maxLatency, int maxWriteThreads) {
-    return new MultiTableBatchWriterImpl(context, new BatchWriterConfig().setMaxMemory(maxMemory).setMaxLatency(maxLatency, TimeUnit.MILLISECONDS)
-        .setMaxWriteThreads(maxWriteThreads));
+  public MultiTableBatchWriter createMultiTableBatchWriter(long maxMemory, long maxLatency,
+      int maxWriteThreads) {
+    return new MultiTableBatchWriterImpl(context, new BatchWriterConfig().setMaxMemory(maxMemory)
+        .setMaxLatency(maxLatency, TimeUnit.MILLISECONDS).setMaxWriteThreads(maxWriteThreads));
   }
 
   @Override
@@ -143,12 +156,14 @@ public class ConnectorImpl extends Connector {
   }
 
   @Override
-  public ConditionalWriter createConditionalWriter(String tableName, ConditionalWriterConfig config) throws TableNotFoundException {
+  public ConditionalWriter createConditionalWriter(String tableName, ConditionalWriterConfig config)
+      throws TableNotFoundException {
     return new ConditionalWriterImpl(context, getTableId(tableName), config);
   }
 
   @Override
-  public Scanner createScanner(String tableName, Authorizations authorizations) throws TableNotFoundException {
+  public Scanner createScanner(String tableName, Authorizations authorizations)
+      throws TableNotFoundException {
     checkArgument(tableName != null, "tableName is null");
     checkArgument(authorizations != null, "authorizations is null");
     return new ScannerImpl(context, getTableId(tableName), authorizations);
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/Credentials.java b/core/src/main/java/org/apache/accumulo/core/client/impl/Credentials.java
index 28a704a..a4522a6 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/Credentials.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/Credentials.java
@@ -30,8 +30,10 @@ import org.apache.accumulo.core.security.thrift.TCredentials;
 import org.apache.accumulo.core.util.Base64;
 
 /**
- * A wrapper for internal use. This class carries the instance, principal, and authentication token for use in the public API, in a non-serialized form. This is
- * important, so that the authentication token carried in a {@link Connector} can be destroyed, invalidating future RPC operations from that {@link Connector}.
+ * A wrapper for internal use. This class carries the instance, principal, and authentication token
+ * for use in the public API, in a non-serialized form. This is important, so that the
+ * authentication token carried in a {@link Connector} can be destroyed, invalidating future RPC
+ * operations from that {@link Connector}.
  * <p>
  * See ACCUMULO-1312
  *
@@ -46,9 +48,11 @@ public class Credentials {
    * Creates a new credentials object.
    *
    * @param principal
-   *          unique identifier for the entity (e.g. a user or service) authorized for these credentials
+   *          unique identifier for the entity (e.g. a user or service) authorized for these
+   *          credentials
    * @param token
-   *          authentication token used to prove that the principal for these credentials has been properly verified
+   *          authentication token used to prove that the principal for these credentials has been
+   *          properly verified
    */
   public Credentials(String principal, AuthenticationToken token) {
     this.principal = principal;
@@ -58,7 +62,8 @@ public class Credentials {
   /**
    * Gets the principal.
    *
-   * @return unique identifier for the entity (e.g. a user or service) authorized for these credentials
+   * @return unique identifier for the entity (e.g. a user or service) authorized for these
+   *         credentials
    */
   public String getPrincipal() {
     return principal;
@@ -67,15 +72,17 @@ public class Credentials {
   /**
    * Gets the authentication token.
    *
-   * @return authentication token used to prove that the principal for these credentials has been properly verified
+   * @return authentication token used to prove that the principal for these credentials has been
+   *         properly verified
    */
   public AuthenticationToken getToken() {
     return token;
   }
 
   /**
-   * Converts the current object to the relevant thrift type. The object returned from this contains a non-destroyable version of the
-   * {@link AuthenticationToken}, so this should be used just before placing on the wire, and references to it should be tightly controlled.
+   * Converts the current object to the relevant thrift type. The object returned from this contains
+   * a non-destroyable version of the {@link AuthenticationToken}, so this should be used just
+   * before placing on the wire, and references to it should be tightly controlled.
    *
    * @param instance
    *          client instance
@@ -85,9 +92,11 @@ public class Credentials {
    */
   public TCredentials toThrift(Instance instance) {
     TCredentials tCreds = new TCredentials(getPrincipal(), getToken().getClass().getName(),
-        ByteBuffer.wrap(AuthenticationTokenSerializer.serialize(getToken())), instance.getInstanceID());
+        ByteBuffer.wrap(AuthenticationTokenSerializer.serialize(getToken())),
+        instance.getInstanceID());
     if (getToken().isDestroyed())
-      throw new RuntimeException("Token has been destroyed", new AccumuloSecurityException(getPrincipal(), SecurityErrorCode.TOKEN_EXPIRED));
+      throw new RuntimeException("Token has been destroyed",
+          new AccumuloSecurityException(getPrincipal(), SecurityErrorCode.TOKEN_EXPIRED));
     return tCreds;
   }
 
@@ -99,23 +108,30 @@ public class Credentials {
    * @return a new Credentials instance; destroy the token when you're done.
    */
   public static Credentials fromThrift(TCredentials serialized) {
-    return new Credentials(serialized.getPrincipal(), AuthenticationTokenSerializer.deserialize(serialized.getTokenClassName(), serialized.getToken()));
+    return new Credentials(serialized.getPrincipal(), AuthenticationTokenSerializer
+        .deserialize(serialized.getTokenClassName(), serialized.getToken()));
   }
 
   /**
-   * Converts the current object to a serialized form. The object returned from this contains a non-destroyable version of the {@link AuthenticationToken}, so
-   * references to it should be tightly controlled.
+   * Converts the current object to a serialized form. The object returned from this contains a
+   * non-destroyable version of the {@link AuthenticationToken}, so references to it should be
+   * tightly controlled.
    *
    * @return serialized form of these credentials
    */
   public final String serialize() {
-    return (getPrincipal() == null ? "-" : Base64.encodeBase64String(getPrincipal().getBytes(UTF_8))) + ":"
-        + (getToken() == null ? "-" : Base64.encodeBase64String(getToken().getClass().getName().getBytes(UTF_8))) + ":"
-        + (getToken() == null ? "-" : Base64.encodeBase64String(AuthenticationTokenSerializer.serialize(getToken())));
+    return (getPrincipal() == null ? "-"
+        : Base64.encodeBase64String(getPrincipal().getBytes(UTF_8)))
+        + ":"
+        + (getToken() == null ? "-"
+            : Base64.encodeBase64String(getToken().getClass().getName().getBytes(UTF_8)))
+        + ":" + (getToken() == null ? "-"
+            : Base64.encodeBase64String(AuthenticationTokenSerializer.serialize(getToken())));
   }
 
   /**
-   * Converts the serialized form to an instance of {@link Credentials}. The original serialized form will not be affected.
+   * Converts the serialized form to an instance of {@link Credentials}. The original serialized
+   * form will not be affected.
    *
    * @param serializedForm
    *          serialized form of credentials
@@ -123,8 +139,10 @@ public class Credentials {
    */
   public static final Credentials deserialize(String serializedForm) {
     String[] split = serializedForm.split(":", 3);
-    String principal = split[0].equals("-") ? null : new String(Base64.decodeBase64(split[0]), UTF_8);
-    String tokenType = split[1].equals("-") ? null : new String(Base64.decodeBase64(split[1]), UTF_8);
+    String principal = split[0].equals("-") ? null
+        : new String(Base64.decodeBase64(split[0]), UTF_8);
+    String tokenType = split[1].equals("-") ? null
+        : new String(Base64.decodeBase64(split[1]), UTF_8);
     AuthenticationToken token = null;
     if (!split[2].equals("-")) {
       byte[] tokenBytes = Base64.decodeBase64(split[2]);
@@ -143,15 +161,18 @@ public class Credentials {
     if (obj == null || !(obj instanceof Credentials))
       return false;
     Credentials other = Credentials.class.cast(obj);
-    boolean pEq = getPrincipal() == null ? (other.getPrincipal() == null) : (getPrincipal().equals(other.getPrincipal()));
+    boolean pEq = getPrincipal() == null ? (other.getPrincipal() == null)
+        : (getPrincipal().equals(other.getPrincipal()));
     if (!pEq)
       return false;
-    boolean tEq = getToken() == null ? (other.getToken() == null) : (getToken().equals(other.getToken()));
+    boolean tEq = getToken() == null ? (other.getToken() == null)
+        : (getToken().equals(other.getToken()));
     return tEq;
   }
 
   @Override
   public String toString() {
-    return getClass().getName() + ":" + getPrincipal() + ":" + (getToken() == null ? null : getToken().getClass().getName()) + ":<hidden>";
+    return getClass().getName() + ":" + getPrincipal() + ":"
+        + (getToken() == null ? null : getToken().getClass().getName()) + ":<hidden>";
   }
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/DelegationTokenImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/DelegationTokenImpl.java
index 5e7a12d..f9d1111 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/DelegationTokenImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/DelegationTokenImpl.java
@@ -46,33 +46,39 @@ public class DelegationTokenImpl extends PasswordToken implements DelegationToke
     super();
   }
 
-  public DelegationTokenImpl(byte[] delegationTokenPassword, AuthenticationTokenIdentifier identifier) {
+  public DelegationTokenImpl(byte[] delegationTokenPassword,
+      AuthenticationTokenIdentifier identifier) {
     requireNonNull(delegationTokenPassword);
     requireNonNull(identifier);
     setPassword(delegationTokenPassword);
     this.identifier = identifier;
   }
 
-  public DelegationTokenImpl(Instance instance, UserGroupInformation user, AuthenticationTokenIdentifier identifier) {
+  public DelegationTokenImpl(Instance instance, UserGroupInformation user,
+      AuthenticationTokenIdentifier identifier) {
     requireNonNull(instance);
     requireNonNull(user);
     requireNonNull(identifier);
 
     Credentials creds = user.getCredentials();
-    Token<? extends TokenIdentifier> token = creds.getToken(new Text(SERVICE_NAME + "-" + instance.getInstanceID()));
+    Token<? extends TokenIdentifier> token = creds
+        .getToken(new Text(SERVICE_NAME + "-" + instance.getInstanceID()));
     if (null == token) {
-      throw new IllegalArgumentException("Did not find Accumulo delegation token in provided UserGroupInformation");
+      throw new IllegalArgumentException(
+          "Did not find Accumulo delegation token in provided UserGroupInformation");
     }
     setPasswordFromToken(token, identifier);
   }
 
-  public DelegationTokenImpl(Token<? extends TokenIdentifier> token, AuthenticationTokenIdentifier identifier) {
+  public DelegationTokenImpl(Token<? extends TokenIdentifier> token,
+      AuthenticationTokenIdentifier identifier) {
     requireNonNull(token);
     requireNonNull(identifier);
     setPasswordFromToken(token, identifier);
   }
 
-  private void setPasswordFromToken(Token<? extends TokenIdentifier> token, AuthenticationTokenIdentifier identifier) {
+  private void setPasswordFromToken(Token<? extends TokenIdentifier> token,
+      AuthenticationTokenIdentifier identifier) {
     if (!AuthenticationTokenIdentifier.TOKEN_KIND.equals(token.getKind())) {
       String msg = "Expected an AuthenticationTokenIdentifier but got a " + token.getKind();
       log.error(msg);
@@ -137,7 +143,8 @@ public class DelegationTokenImpl extends PasswordToken implements DelegationToke
 
   @Override
   public boolean equals(Object obj) {
-    // We assume we can cast obj to DelegationToken because the super.equals(obj) check ensures obj is of the same type as this
+    // We assume we can cast obj to DelegationToken because the super.equals(obj) check ensures obj
+    // is of the same type as this
     return super.equals(obj) && identifier.equals(((DelegationTokenImpl) obj).identifier);
   }
 
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/InstanceOperationsImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/InstanceOperationsImpl.java
index 64a23da..fab8b98 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/InstanceOperationsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/InstanceOperationsImpl.java
@@ -62,7 +62,8 @@ public class InstanceOperationsImpl implements InstanceOperations {
   }
 
   @Override
-  public void setProperty(final String property, final String value) throws AccumuloException, AccumuloSecurityException, IllegalArgumentException {
+  public void setProperty(final String property, final String value)
+      throws AccumuloException, AccumuloSecurityException, IllegalArgumentException {
     checkArgument(property != null, "property is null");
     checkArgument(value != null, "value is null");
     MasterClient.execute(context, new ClientExec<MasterClientService.Client>() {
@@ -74,7 +75,8 @@ public class InstanceOperationsImpl implements InstanceOperations {
   }
 
   @Override
-  public void removeProperty(final String property) throws AccumuloException, AccumuloSecurityException {
+  public void removeProperty(final String property)
+      throws AccumuloException, AccumuloSecurityException {
     checkArgument(property != null, "property is null");
     MasterClient.execute(context, new ClientExec<MasterClientService.Client>() {
       @Override
@@ -85,29 +87,36 @@ public class InstanceOperationsImpl implements InstanceOperations {
   }
 
   @Override
-  public Map<String,String> getSystemConfiguration() throws AccumuloException, AccumuloSecurityException {
-    return ServerClient.execute(context, new ClientExecReturn<Map<String,String>,ClientService.Client>() {
-      @Override
-      public Map<String,String> execute(ClientService.Client client) throws Exception {
-        return client.getConfiguration(Tracer.traceInfo(), context.rpcCreds(), ConfigurationType.CURRENT);
-      }
-    });
+  public Map<String,String> getSystemConfiguration()
+      throws AccumuloException, AccumuloSecurityException {
+    return ServerClient.execute(context,
+        new ClientExecReturn<Map<String,String>,ClientService.Client>() {
+          @Override
+          public Map<String,String> execute(ClientService.Client client) throws Exception {
+            return client.getConfiguration(Tracer.traceInfo(), context.rpcCreds(),
+                ConfigurationType.CURRENT);
+          }
+        });
   }
 
   @Override
-  public Map<String,String> getSiteConfiguration() throws AccumuloException, AccumuloSecurityException {
-    return ServerClient.execute(context, new ClientExecReturn<Map<String,String>,ClientService.Client>() {
-      @Override
-      public Map<String,String> execute(ClientService.Client client) throws Exception {
-        return client.getConfiguration(Tracer.traceInfo(), context.rpcCreds(), ConfigurationType.SITE);
-      }
-    });
+  public Map<String,String> getSiteConfiguration()
+      throws AccumuloException, AccumuloSecurityException {
+    return ServerClient.execute(context,
+        new ClientExecReturn<Map<String,String>,ClientService.Client>() {
+          @Override
+          public Map<String,String> execute(ClientService.Client client) throws Exception {
+            return client.getConfiguration(Tracer.traceInfo(), context.rpcCreds(),
+                ConfigurationType.SITE);
+          }
+        });
   }
 
   @Override
   public List<String> getTabletServers() {
     Instance instance = context.getInstance();
-    ZooCache cache = new ZooCacheFactory().getZooCache(instance.getZooKeepers(), instance.getZooKeepersSessionTimeOut());
+    ZooCache cache = new ZooCacheFactory().getZooCache(instance.getZooKeepers(),
+        instance.getZooKeepersSessionTimeOut());
     String path = ZooUtil.getRoot(instance) + Constants.ZTSERVERS;
     List<String> results = new ArrayList<>();
     for (String candidate : cache.getChildren(path)) {
@@ -125,14 +134,16 @@ public class InstanceOperationsImpl implements InstanceOperations {
   }
 
   @Override
-  public List<ActiveScan> getActiveScans(String tserver) throws AccumuloException, AccumuloSecurityException {
+  public List<ActiveScan> getActiveScans(String tserver)
+      throws AccumuloException, AccumuloSecurityException {
     final HostAndPort parsedTserver = HostAndPort.fromString(tserver);
     Client client = null;
     try {
       client = ThriftUtil.getTServerClient(parsedTserver, context);
 
       List<ActiveScan> as = new ArrayList<>();
-      for (org.apache.accumulo.core.tabletserver.thrift.ActiveScan activeScan : client.getActiveScans(Tracer.traceInfo(), context.rpcCreds())) {
+      for (org.apache.accumulo.core.tabletserver.thrift.ActiveScan activeScan : client
+          .getActiveScans(Tracer.traceInfo(), context.rpcCreds())) {
         try {
           as.add(new ActiveScanImpl(context.getInstance(), activeScan));
         } catch (TableNotFoundException e) {
@@ -153,7 +164,8 @@ public class InstanceOperationsImpl implements InstanceOperations {
   }
 
   @Override
-  public boolean testClassLoad(final String className, final String asTypeName) throws AccumuloException, AccumuloSecurityException {
+  public boolean testClassLoad(final String className, final String asTypeName)
+      throws AccumuloException, AccumuloSecurityException {
     return ServerClient.execute(context, new ClientExecReturn<Boolean,ClientService.Client>() {
       @Override
       public Boolean execute(ClientService.Client client) throws Exception {
@@ -163,14 +175,16 @@ public class InstanceOperationsImpl implements InstanceOperations {
   }
 
   @Override
-  public List<ActiveCompaction> getActiveCompactions(String tserver) throws AccumuloException, AccumuloSecurityException {
+  public List<ActiveCompaction> getActiveCompactions(String tserver)
+      throws AccumuloException, AccumuloSecurityException {
     final HostAndPort parsedTserver = HostAndPort.fromString(tserver);
     Client client = null;
     try {
       client = ThriftUtil.getTServerClient(parsedTserver, context);
 
       List<ActiveCompaction> as = new ArrayList<>();
-      for (org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction activeCompaction : client.getActiveCompactions(Tracer.traceInfo(), context.rpcCreds())) {
+      for (org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction activeCompaction : client
+          .getActiveCompactions(Tracer.traceInfo(), context.rpcCreds())) {
         as.add(new ActiveCompactionImpl(context.getInstance(), activeCompaction));
       }
       return as;
@@ -191,7 +205,8 @@ public class InstanceOperationsImpl implements InstanceOperations {
     TTransport transport = null;
     try {
       transport = ThriftUtil.createTransport(AddressUtil.parseAddress(tserver, false), context);
-      TabletClientService.Client client = ThriftUtil.createClient(new TabletClientService.Client.Factory(), transport);
+      TabletClientService.Client client = ThriftUtil
+          .createClient(new TabletClientService.Client.Factory(), transport);
       client.getTabletServerStatus(Tracer.traceInfo(), context.rpcCreds());
     } catch (TTransportException e) {
       throw new AccumuloException(e);
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/MasterClient.java b/core/src/main/java/org/apache/accumulo/core/client/impl/MasterClient.java
index 856536b..39e1f2d 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/MasterClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/MasterClient.java
@@ -66,7 +66,8 @@ public class MasterClient {
 
     try {
       // Master requests can take a long time: don't ever time out
-      MasterClientService.Client client = ThriftUtil.getClientNoTimeout(new MasterClientService.Client.Factory(), master, context);
+      MasterClientService.Client client = ThriftUtil
+          .getClientNoTimeout(new MasterClientService.Client.Factory(), master, context);
       return client;
     } catch (TTransportException tte) {
       Throwable cause = tte.getCause();
@@ -81,15 +82,17 @@ public class MasterClient {
 
   public static void close(MasterClientService.Iface iface) {
     TServiceClient client = (TServiceClient) iface;
-    if (client != null && client.getInputProtocol() != null && client.getInputProtocol().getTransport() != null) {
+    if (client != null && client.getInputProtocol() != null
+        && client.getInputProtocol().getTransport() != null) {
       ThriftTransportPool.getInstance().returnTransport(client.getInputProtocol().getTransport());
     } else {
       log.debug("Attempt to close null connection to the master", new Exception());
     }
   }
 
-  public static <T> T execute(ClientContext context, ClientExecReturn<T,MasterClientService.Client> exec) throws AccumuloException, AccumuloSecurityException,
-      TableNotFoundException {
+  public static <T> T execute(ClientContext context,
+      ClientExecReturn<T,MasterClientService.Client> exec)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     MasterClientService.Client client = null;
     while (true) {
       try {
@@ -120,8 +123,9 @@ public class MasterClient {
     }
   }
 
-  public static void executeGeneric(ClientContext context, ClientExec<MasterClientService.Client> exec) throws AccumuloException, AccumuloSecurityException,
-      TableNotFoundException {
+  public static void executeGeneric(ClientContext context,
+      ClientExec<MasterClientService.Client> exec)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     MasterClientService.Client client = null;
     while (true) {
       try {
@@ -153,13 +157,15 @@ public class MasterClient {
     }
   }
 
-  public static void executeTable(ClientContext context, ClientExec<MasterClientService.Client> exec) throws AccumuloException, AccumuloSecurityException,
-      TableNotFoundException {
+  public static void executeTable(ClientContext context,
+      ClientExec<MasterClientService.Client> exec)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     executeGeneric(context, exec);
   }
 
-  public static void executeNamespace(ClientContext context, ClientExec<MasterClientService.Client> exec) throws AccumuloException, AccumuloSecurityException,
-      NamespaceNotFoundException {
+  public static void executeNamespace(ClientContext context,
+      ClientExec<MasterClientService.Client> exec)
+      throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException {
     try {
       executeGeneric(context, exec);
     } catch (TableNotFoundException e) {
@@ -168,7 +174,8 @@ public class MasterClient {
     }
   }
 
-  public static void execute(ClientContext context, ClientExec<MasterClientService.Client> exec) throws AccumuloException, AccumuloSecurityException {
+  public static void execute(ClientContext context, ClientExec<MasterClientService.Client> exec)
+      throws AccumuloException, AccumuloSecurityException {
     try {
       executeGeneric(context, exec);
     } catch (TableNotFoundException e) {
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 a4a5b2f..e1b2306 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
@@ -61,12 +61,14 @@ public class MultiTableBatchWriterImpl implements MultiTableBatchWriter {
 
     @Override
     public void close() {
-      throw new UnsupportedOperationException("Must close all tables, can not close an individual table");
+      throw new UnsupportedOperationException(
+          "Must close all tables, can not close an individual table");
     }
 
     @Override
     public void flush() {
-      throw new UnsupportedOperationException("Must flush all tables, can not flush an individual table");
+      throw new UnsupportedOperationException(
+          "Must flush all tables, can not flush an individual table");
     }
 
   }
@@ -95,16 +97,19 @@ public class MultiTableBatchWriterImpl implements MultiTableBatchWriter {
     bw.close();
   }
 
-  // WARNING: do not rely upon finalize to close this class. Finalize is not guaranteed to be called.
+  // WARNING: do not rely upon finalize to close this class. Finalize is not guaranteed to be
+  // called.
   @Override
   protected void finalize() {
     if (!closed.get()) {
-      log.warn(MultiTableBatchWriterImpl.class.getSimpleName() + " not shutdown; did you forget to call close()?");
+      log.warn(MultiTableBatchWriterImpl.class.getSimpleName()
+          + " not shutdown; did you forget to call close()?");
       try {
         close();
       } catch (MutationsRejectedException mre) {
         log.error(MultiTableBatchWriterImpl.class.getSimpleName() + " internal error.", mre);
-        throw new RuntimeException("Exception when closing " + MultiTableBatchWriterImpl.class.getSimpleName(), mre);
+        throw new RuntimeException(
+            "Exception when closing " + MultiTableBatchWriterImpl.class.getSimpleName(), mre);
       }
     }
   }
@@ -137,7 +142,8 @@ public class MultiTableBatchWriterImpl implements MultiTableBatchWriter {
   }
 
   @Override
-  public BatchWriter getBatchWriter(String tableName) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+  public BatchWriter getBatchWriter(String tableName)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     checkArgument(tableName != null, "tableName is null");
 
     String tableId = getId(tableName);
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/NamespaceOperationsHelper.java b/core/src/main/java/org/apache/accumulo/core/client/impl/NamespaceOperationsHelper.java
index 9b3a358..e0e9d73 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/NamespaceOperationsHelper.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/NamespaceOperationsHelper.java
@@ -44,16 +44,19 @@ public abstract class NamespaceOperationsHelper implements NamespaceOperations {
   }
 
   @Override
-  public void attachIterator(String namespace, IteratorSetting setting) throws AccumuloSecurityException, AccumuloException, NamespaceNotFoundException {
+  public void attachIterator(String namespace, IteratorSetting setting)
+      throws AccumuloSecurityException, AccumuloException, NamespaceNotFoundException {
     attachIterator(namespace, setting, EnumSet.allOf(IteratorScope.class));
   }
 
   @Override
-  public void attachIterator(String namespace, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloSecurityException, AccumuloException,
-      NamespaceNotFoundException {
+  public void attachIterator(String namespace, IteratorSetting setting,
+      EnumSet<IteratorScope> scopes)
+      throws AccumuloSecurityException, AccumuloException, NamespaceNotFoundException {
     checkIteratorConflicts(namespace, setting, scopes);
     for (IteratorScope scope : scopes) {
-      String root = String.format("%s%s.%s", Property.TABLE_ITERATOR_PREFIX, scope.name().toLowerCase(), setting.getName());
+      String root = String.format("%s%s.%s", Property.TABLE_ITERATOR_PREFIX,
+          scope.name().toLowerCase(), setting.getName());
       for (Entry<String,String> prop : setting.getOptions().entrySet()) {
         this.setProperty(namespace, root + ".opt." + prop.getKey(), prop.getValue());
       }
@@ -62,8 +65,8 @@ public abstract class NamespaceOperationsHelper implements NamespaceOperations {
   }
 
   @Override
-  public void removeIterator(String namespace, String name, EnumSet<IteratorScope> scopes) throws AccumuloSecurityException, AccumuloException,
-      NamespaceNotFoundException {
+  public void removeIterator(String namespace, String name, EnumSet<IteratorScope> scopes)
+      throws AccumuloSecurityException, AccumuloException, NamespaceNotFoundException {
     if (!exists(namespace))
       throw new NamespaceNotFoundException(null, namespace, null);
     Map<String,String> copy = new TreeMap<>();
@@ -71,7 +74,8 @@ public abstract class NamespaceOperationsHelper implements NamespaceOperations {
       copy.put(property.getKey(), property.getValue());
     }
     for (IteratorScope scope : scopes) {
-      String root = String.format("%s%s.%s", Property.TABLE_ITERATOR_PREFIX, scope.name().toLowerCase(), name);
+      String root = String.format("%s%s.%s", Property.TABLE_ITERATOR_PREFIX,
+          scope.name().toLowerCase(), name);
       for (Entry<String,String> property : copy.entrySet()) {
         if (property.getKey().equals(root) || property.getKey().startsWith(root + ".opt."))
           this.removeProperty(namespace, property.getKey());
@@ -80,15 +84,16 @@ public abstract class NamespaceOperationsHelper implements NamespaceOperations {
   }
 
   @Override
-  public IteratorSetting getIteratorSetting(String namespace, String name, IteratorScope scope) throws AccumuloSecurityException, AccumuloException,
-      NamespaceNotFoundException {
+  public IteratorSetting getIteratorSetting(String namespace, String name, IteratorScope scope)
+      throws AccumuloSecurityException, AccumuloException, NamespaceNotFoundException {
     if (!exists(namespace))
       throw new NamespaceNotFoundException(null, namespace, null);
     int priority = -1;
     String classname = null;
     Map<String,String> settings = new HashMap<>();
 
-    String root = String.format("%s%s.%s", Property.TABLE_ITERATOR_PREFIX, scope.name().toLowerCase(), name);
+    String root = String.format("%s%s.%s", Property.TABLE_ITERATOR_PREFIX,
+        scope.name().toLowerCase(), name);
     String opt = root + ".opt.";
     for (Entry<String,String> property : this.getProperties(namespace)) {
       if (property.getKey().equals(root)) {
@@ -109,7 +114,8 @@ public abstract class NamespaceOperationsHelper implements NamespaceOperations {
   }
 
   @Override
-  public Map<String,EnumSet<IteratorScope>> listIterators(String namespace) throws AccumuloSecurityException, AccumuloException, NamespaceNotFoundException {
+  public Map<String,EnumSet<IteratorScope>> listIterators(String namespace)
+      throws AccumuloSecurityException, AccumuloException, NamespaceNotFoundException {
     if (!exists(namespace))
       throw new NamespaceNotFoundException(null, namespace, null);
     Map<String,EnumSet<IteratorScope>> result = new TreeMap<>();
@@ -129,49 +135,57 @@ public abstract class NamespaceOperationsHelper implements NamespaceOperations {
   }
 
   @Override
-  public void checkIteratorConflicts(String namespace, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloException,
-      NamespaceNotFoundException, AccumuloSecurityException {
+  public void checkIteratorConflicts(String namespace, IteratorSetting setting,
+      EnumSet<IteratorScope> scopes)
+      throws AccumuloException, NamespaceNotFoundException, AccumuloSecurityException {
     if (!exists(namespace))
       throw new NamespaceNotFoundException(null, namespace, null);
     for (IteratorScope scope : scopes) {
-      String scopeStr = String.format("%s%s", Property.TABLE_ITERATOR_PREFIX, scope.name().toLowerCase());
+      String scopeStr = String.format("%s%s", Property.TABLE_ITERATOR_PREFIX,
+          scope.name().toLowerCase());
       String nameStr = String.format("%s.%s", scopeStr, setting.getName());
       String optStr = String.format("%s.opt.", nameStr);
       Map<String,String> optionConflicts = new TreeMap<>();
       for (Entry<String,String> property : this.getProperties(namespace)) {
         if (property.getKey().startsWith(scopeStr)) {
           if (property.getKey().equals(nameStr))
-            throw new AccumuloException(new IllegalArgumentException("iterator name conflict for " + setting.getName() + ": " + property.getKey() + "="
-                + property.getValue()));
+            throw new AccumuloException(new IllegalArgumentException("iterator name conflict for "
+                + setting.getName() + ": " + property.getKey() + "=" + property.getValue()));
           if (property.getKey().startsWith(optStr))
             optionConflicts.put(property.getKey(), property.getValue());
           if (property.getKey().contains(".opt."))
             continue;
           String parts[] = property.getValue().split(",");
           if (parts.length != 2)
-            throw new AccumuloException("Bad value for existing iterator setting: " + property.getKey() + "=" + property.getValue());
+            throw new AccumuloException("Bad value for existing iterator setting: "
+                + property.getKey() + "=" + property.getValue());
           try {
             if (Integer.parseInt(parts[0]) == setting.getPriority())
-              throw new AccumuloException(new IllegalArgumentException("iterator priority conflict: " + property.getKey() + "=" + property.getValue()));
+              throw new AccumuloException(new IllegalArgumentException(
+                  "iterator priority conflict: " + property.getKey() + "=" + property.getValue()));
           } catch (NumberFormatException e) {
-            throw new AccumuloException("Bad value for existing iterator setting: " + property.getKey() + "=" + property.getValue());
+            throw new AccumuloException("Bad value for existing iterator setting: "
+                + property.getKey() + "=" + property.getValue());
           }
         }
       }
       if (optionConflicts.size() > 0)
-        throw new AccumuloException(new IllegalArgumentException("iterator options conflict for " + setting.getName() + ": " + optionConflicts));
+        throw new AccumuloException(new IllegalArgumentException(
+            "iterator options conflict for " + setting.getName() + ": " + optionConflicts));
     }
   }
 
   @Override
-  public int addConstraint(String namespace, String constraintClassName) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException {
+  public int addConstraint(String namespace, String constraintClassName)
+      throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException {
     TreeSet<Integer> constraintNumbers = new TreeSet<>();
     TreeMap<String,Integer> constraintClasses = new TreeMap<>();
     int i;
     for (Entry<String,String> property : this.getProperties(namespace)) {
       if (property.getKey().startsWith(Property.TABLE_CONSTRAINT_PREFIX.toString())) {
         try {
-          i = Integer.parseInt(property.getKey().substring(Property.TABLE_CONSTRAINT_PREFIX.toString().length()));
+          i = Integer.parseInt(
+              property.getKey().substring(Property.TABLE_CONSTRAINT_PREFIX.toString().length()));
         } catch (NumberFormatException e) {
           throw new AccumuloException("Bad key for existing constraint: " + property.toString());
         }
@@ -183,27 +197,33 @@ public abstract class NamespaceOperationsHelper implements NamespaceOperations {
     while (constraintNumbers.contains(i))
       i++;
     if (constraintClasses.containsKey(constraintClassName))
-      throw new AccumuloException("Constraint " + constraintClassName + " already exists for namespace " + namespace + " with number "
-          + constraintClasses.get(constraintClassName));
-    this.setProperty(namespace, Property.TABLE_CONSTRAINT_PREFIX.toString() + i, constraintClassName);
+      throw new AccumuloException(
+          "Constraint " + constraintClassName + " already exists for namespace " + namespace
+              + " with number " + constraintClasses.get(constraintClassName));
+    this.setProperty(namespace, Property.TABLE_CONSTRAINT_PREFIX.toString() + i,
+        constraintClassName);
     return i;
   }
 
   @Override
-  public void removeConstraint(String namespace, int number) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException {
+  public void removeConstraint(String namespace, int number)
+      throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException {
     this.removeProperty(namespace, Property.TABLE_CONSTRAINT_PREFIX.toString() + number);
   }
 
   @Override
-  public Map<String,Integer> listConstraints(String namespace) throws AccumuloException, NamespaceNotFoundException, AccumuloSecurityException {
+  public Map<String,Integer> listConstraints(String namespace)
+      throws AccumuloException, NamespaceNotFoundException, AccumuloSecurityException {
     Map<String,Integer> constraints = new TreeMap<>();
     for (Entry<String,String> property : this.getProperties(namespace)) {
       if (property.getKey().startsWith(Property.TABLE_CONSTRAINT_PREFIX.toString())) {
         if (constraints.containsKey(property.getValue()))
-          throw new AccumuloException("Same constraint configured twice: " + property.getKey() + "=" + Property.TABLE_CONSTRAINT_PREFIX
-              + constraints.get(property.getValue()) + "=" + property.getKey());
+          throw new AccumuloException("Same constraint configured twice: " + property.getKey() + "="
+              + Property.TABLE_CONSTRAINT_PREFIX + constraints.get(property.getValue()) + "="
+              + property.getKey());
         try {
-          constraints.put(property.getValue(), Integer.parseInt(property.getKey().substring(Property.TABLE_CONSTRAINT_PREFIX.toString().length())));
+          constraints.put(property.getValue(), Integer.parseInt(
+              property.getKey().substring(Property.TABLE_CONSTRAINT_PREFIX.toString().length())));
         } catch (NumberFormatException e) {
           throw new AccumuloException("Bad key for existing constraint: " + property.toString());
         }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/NamespaceOperationsImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/NamespaceOperationsImpl.java
index 7bd97a6..70c7f9d 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/NamespaceOperationsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/NamespaceOperationsImpl.java
@@ -76,12 +76,13 @@ public class NamespaceOperationsImpl extends NamespaceOperationsHelper {
       timer = new OpTimer().start();
     }
 
-    TreeSet<String> namespaces = new TreeSet<>(Namespaces.getNameToIdMap(context.getInstance()).keySet());
+    TreeSet<String> namespaces = new TreeSet<>(
+        Namespaces.getNameToIdMap(context.getInstance()).keySet());
 
     if (timer != null) {
       timer.stop();
-      log.trace("tid={} Fetched {} namespaces in {}", Thread.currentThread().getId(), namespaces.size(),
-          String.format("%.3f secs", timer.scale(TimeUnit.SECONDS)));
+      log.trace("tid={} Fetched {} namespaces in {}", Thread.currentThread().getId(),
+          namespaces.size(), String.format("%.3f secs", timer.scale(TimeUnit.SECONDS)));
     }
 
     return namespaces;
@@ -94,7 +95,8 @@ public class NamespaceOperationsImpl extends NamespaceOperationsHelper {
     OpTimer timer = null;
 
     if (log.isTraceEnabled()) {
-      log.trace("tid={} Checking if namespace {} exists", Thread.currentThread().getId(), namespace);
+      log.trace("tid={} Checking if namespace {} exists", Thread.currentThread().getId(),
+          namespace);
       timer = new OpTimer().start();
     }
 
@@ -102,18 +104,21 @@ public class NamespaceOperationsImpl extends NamespaceOperationsHelper {
 
     if (timer != null) {
       timer.stop();
-      log.trace("tid={} Checked existance of {} in {}", Thread.currentThread().getId(), exists, String.format("%.3f secs", timer.scale(TimeUnit.SECONDS)));
+      log.trace("tid={} Checked existance of {} in {}", Thread.currentThread().getId(), exists,
+          String.format("%.3f secs", timer.scale(TimeUnit.SECONDS)));
     }
 
     return exists;
   }
 
   @Override
-  public void create(String namespace) throws AccumuloException, AccumuloSecurityException, NamespaceExistsException {
+  public void create(String namespace)
+      throws AccumuloException, AccumuloSecurityException, NamespaceExistsException {
     checkArgument(namespace != null, "namespace is null");
 
     try {
-      doNamespaceFateOperation(FateOperation.NAMESPACE_CREATE, Arrays.asList(ByteBuffer.wrap(namespace.getBytes(UTF_8))),
+      doNamespaceFateOperation(FateOperation.NAMESPACE_CREATE,
+          Arrays.asList(ByteBuffer.wrap(namespace.getBytes(UTF_8))),
           Collections.<String,String> emptyMap(), namespace);
     } catch (NamespaceNotFoundException e) {
       // should not happen
@@ -122,14 +127,17 @@ public class NamespaceOperationsImpl extends NamespaceOperationsHelper {
   }
 
   @Override
-  public void delete(String namespace) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException, NamespaceNotEmptyException {
+  public void delete(String namespace) throws AccumuloException, AccumuloSecurityException,
+      NamespaceNotFoundException, NamespaceNotEmptyException {
     checkArgument(namespace != null, "namespace is null");
     String namespaceId = Namespaces.getNamespaceId(context.getInstance(), namespace);
 
-    if (namespaceId.equals(Namespaces.ACCUMULO_NAMESPACE_ID) || namespaceId.equals(Namespaces.DEFAULT_NAMESPACE_ID)) {
+    if (namespaceId.equals(Namespaces.ACCUMULO_NAMESPACE_ID)
+        || namespaceId.equals(Namespaces.DEFAULT_NAMESPACE_ID)) {
       Credentials credentials = context.getCredentials();
       log.debug("{} attempted to delete the {} namespace", credentials.getPrincipal(), namespaceId);
-      throw new AccumuloSecurityException(credentials.getPrincipal(), SecurityErrorCode.UNSUPPORTED_OPERATION);
+      throw new AccumuloSecurityException(credentials.getPrincipal(),
+          SecurityErrorCode.UNSUPPORTED_OPERATION);
     }
 
     if (Namespaces.getTableIds(context.getInstance(), namespaceId).size() > 0) {
@@ -149,17 +157,19 @@ public class NamespaceOperationsImpl extends NamespaceOperationsHelper {
   }
 
   @Override
-  public void rename(String oldNamespaceName, String newNamespaceName) throws AccumuloSecurityException, NamespaceNotFoundException, AccumuloException,
+  public void rename(String oldNamespaceName, String newNamespaceName)
+      throws AccumuloSecurityException, NamespaceNotFoundException, AccumuloException,
       NamespaceExistsException {
 
-    List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(oldNamespaceName.getBytes(UTF_8)), ByteBuffer.wrap(newNamespaceName.getBytes(UTF_8)));
+    List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(oldNamespaceName.getBytes(UTF_8)),
+        ByteBuffer.wrap(newNamespaceName.getBytes(UTF_8)));
     Map<String,String> opts = new HashMap<>();
     doNamespaceFateOperation(FateOperation.NAMESPACE_RENAME, args, opts, oldNamespaceName);
   }
 
   @Override
-  public void setProperty(final String namespace, final String property, final String value) throws AccumuloException, AccumuloSecurityException,
-      NamespaceNotFoundException {
+  public void setProperty(final String namespace, final String property, final String value)
+      throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException {
     checkArgument(namespace != null, "namespace is null");
     checkArgument(property != null, "property is null");
     checkArgument(value != null, "value is null");
@@ -167,13 +177,15 @@ public class NamespaceOperationsImpl extends NamespaceOperationsHelper {
     MasterClient.executeNamespace(context, new ClientExec<MasterClientService.Client>() {
       @Override
       public void execute(MasterClientService.Client client) throws Exception {
-        client.setNamespaceProperty(Tracer.traceInfo(), context.rpcCreds(), namespace, property, value);
+        client.setNamespaceProperty(Tracer.traceInfo(), context.rpcCreds(), namespace, property,
+            value);
       }
     });
   }
 
   @Override
-  public void removeProperty(final String namespace, final String property) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException {
+  public void removeProperty(final String namespace, final String property)
+      throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException {
     checkArgument(namespace != null, "namespace is null");
     checkArgument(property != null, "property is null");
 
@@ -186,15 +198,18 @@ public class NamespaceOperationsImpl extends NamespaceOperationsHelper {
   }
 
   @Override
-  public Iterable<Entry<String,String>> getProperties(final String namespace) throws AccumuloException, NamespaceNotFoundException {
+  public Iterable<Entry<String,String>> getProperties(final String namespace)
+      throws AccumuloException, NamespaceNotFoundException {
     checkArgument(namespace != null, "namespace is null");
     try {
-      return ServerClient.executeRaw(context, new ClientExecReturn<Map<String,String>,ClientService.Client>() {
-        @Override
-        public Map<String,String> execute(ClientService.Client client) throws Exception {
-          return client.getNamespaceConfiguration(Tracer.traceInfo(), context.rpcCreds(), namespace);
-        }
-      }).entrySet();
+      return ServerClient
+          .executeRaw(context, new ClientExecReturn<Map<String,String>,ClientService.Client>() {
+            @Override
+            public Map<String,String> execute(ClientService.Client client) throws Exception {
+              return client.getNamespaceConfiguration(Tracer.traceInfo(), context.rpcCreds(),
+                  namespace);
+            }
+          }).entrySet();
     } catch (ThriftTableOperationException e) {
       switch (e.getType()) {
         case NAMESPACE_NOTFOUND:
@@ -217,8 +232,9 @@ public class NamespaceOperationsImpl extends NamespaceOperationsHelper {
   }
 
   @Override
-  public boolean testClassLoad(final String namespace, final String className, final String asTypeName) throws NamespaceNotFoundException, AccumuloException,
-      AccumuloSecurityException {
+  public boolean testClassLoad(final String namespace, final String className,
+      final String asTypeName)
+      throws NamespaceNotFoundException, AccumuloException, AccumuloSecurityException {
     checkArgument(namespace != null, "namespace is null");
     checkArgument(className != null, "className is null");
     checkArgument(asTypeName != null, "asTypeName is null");
@@ -227,7 +243,8 @@ public class NamespaceOperationsImpl extends NamespaceOperationsHelper {
       return ServerClient.executeRaw(context, new ClientExecReturn<Boolean,ClientService.Client>() {
         @Override
         public Boolean execute(ClientService.Client client) throws Exception {
-          return client.checkNamespaceClass(Tracer.traceInfo(), context.rpcCreds(), namespace, className, asTypeName);
+          return client.checkNamespaceClass(Tracer.traceInfo(), context.rpcCreds(), namespace,
+              className, asTypeName);
         }
       });
     } catch (ThriftTableOperationException e) {
@@ -247,19 +264,22 @@ public class NamespaceOperationsImpl extends NamespaceOperationsHelper {
   }
 
   @Override
-  public void attachIterator(String namespace, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloSecurityException, AccumuloException,
-      NamespaceNotFoundException {
+  public void attachIterator(String namespace, IteratorSetting setting,
+      EnumSet<IteratorScope> scopes)
+      throws AccumuloSecurityException, AccumuloException, NamespaceNotFoundException {
     testClassLoad(namespace, setting.getIteratorClass(), SortedKeyValueIterator.class.getName());
     super.attachIterator(namespace, setting, scopes);
   }
 
   @Override
-  public int addConstraint(String namespace, String constraintClassName) throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException {
+  public int addConstraint(String namespace, String constraintClassName)
+      throws AccumuloException, AccumuloSecurityException, NamespaceNotFoundException {
     testClassLoad(namespace, constraintClassName, Constraint.class.getName());
     return super.addConstraint(namespace, constraintClassName);
   }
 
-  private String doNamespaceFateOperation(FateOperation op, List<ByteBuffer> args, Map<String,String> opts, String namespace) throws AccumuloSecurityException,
+  private String doNamespaceFateOperation(FateOperation op, List<ByteBuffer> args,
+      Map<String,String> opts, String namespace) throws AccumuloSecurityException,
       AccumuloException, NamespaceExistsException, NamespaceNotFoundException {
     try {
       return tableOps.doFateOperation(op, args, opts, namespace);
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/Namespaces.java b/core/src/main/java/org/apache/accumulo/core/client/impl/Namespaces.java
index 39d5822..9f8ff0d 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/Namespaces.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/Namespaces.java
@@ -45,7 +45,8 @@ public class Namespaces {
     public String invalidMessage(String namespace) {
       if (namespace == null)
         return "Namespace cannot be null";
-      return "Namespaces must only contain word characters (letters, digits, and underscores): " + namespace;
+      return "Namespaces must only contain word characters (letters, digits, and underscores): "
+          + namespace;
     }
   };
 
@@ -85,7 +86,8 @@ public class Namespaces {
     if (sm != null) {
       sm.checkPermission(TABLES_PERMISSION);
     }
-    return new ZooCacheFactory().getZooCache(instance.getZooKeepers(), instance.getZooKeepersSessionTimeOut());
+    return new ZooCacheFactory().getZooCache(instance.getZooKeepers(),
+        instance.getZooKeepersSessionTimeOut());
   }
 
   private static SortedMap<String,String> getMap(Instance instance, boolean nameAsKey) {
@@ -96,7 +98,8 @@ public class Namespaces {
     TreeMap<String,String> namespaceMap = new TreeMap<>();
 
     for (String id : namespaceIds) {
-      byte[] path = zc.get(ZooUtil.getRoot(instance) + Constants.ZNAMESPACES + "/" + id + Constants.ZNAMESPACE_NAME);
+      byte[] path = zc.get(
+          ZooUtil.getRoot(instance) + Constants.ZNAMESPACES + "/" + id + Constants.ZNAMESPACE_NAME);
       if (path != null) {
         if (nameAsKey)
           namespaceMap.put(new String(path, UTF_8), id);
@@ -113,17 +116,21 @@ public class Namespaces {
     return namespaceIds.contains(namespaceId);
   }
 
-  public static String getNamespaceId(Instance instance, String namespace) throws NamespaceNotFoundException {
+  public static String getNamespaceId(Instance instance, String namespace)
+      throws NamespaceNotFoundException {
     String id = getNameToIdMap(instance).get(namespace);
     if (id == null)
-      throw new NamespaceNotFoundException(null, namespace, "getNamespaceId() failed to find namespace");
+      throw new NamespaceNotFoundException(null, namespace,
+          "getNamespaceId() failed to find namespace");
     return id;
   }
 
-  public static String getNamespaceName(Instance instance, String namespaceId) throws NamespaceNotFoundException {
+  public static String getNamespaceName(Instance instance, String namespaceId)
+      throws NamespaceNotFoundException {
     String namespaceName = getIdToNameMap(instance).get(namespaceId);
     if (namespaceName == null)
-      throw new NamespaceNotFoundException(namespaceId, null, "getNamespaceName() failed to find namespace");
+      throw new NamespaceNotFoundException(namespaceId, null,
+          "getNamespaceName() failed to find namespace");
     return namespaceName;
   }
 
@@ -135,7 +142,8 @@ public class Namespaces {
     return getMap(instance, false);
   }
 
-  public static List<String> getTableIds(Instance instance, String namespaceId) throws NamespaceNotFoundException {
+  public static List<String> getTableIds(Instance instance, String namespaceId)
+      throws NamespaceNotFoundException {
     String namespace = getNamespaceName(instance, namespaceId);
     List<String> names = new LinkedList<>();
     for (Entry<String,String> nameToId : Tables.getNameToIdMap(instance).entrySet())
@@ -144,7 +152,8 @@ public class Namespaces {
     return names;
   }
 
-  public static List<String> getTableNames(Instance instance, String namespaceId) throws NamespaceNotFoundException {
+  public static List<String> getTableNames(Instance instance, String namespaceId)
+      throws NamespaceNotFoundException {
     String namespace = getNamespaceName(instance, namespaceId);
     List<String> names = new LinkedList<>();
     for (String name : Tables.getNameToIdMap(instance).keySet())
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 aba89a4..783ea77 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
@@ -77,7 +77,8 @@ class OfflineIterator implements Iterator<Entry<Key,Value>> {
     private boolean useSample;
     private SamplerConfiguration sampleConf;
 
-    public OfflineIteratorEnvironment(Authorizations auths, AccumuloConfiguration acuTableConf, boolean useSample, SamplerConfiguration samplerConf) {
+    public OfflineIteratorEnvironment(Authorizations auths, AccumuloConfiguration acuTableConf,
+        boolean useSample, SamplerConfiguration samplerConf) {
       this.authorizations = auths;
       this.conf = acuTableConf;
       this.useSample = useSample;
@@ -85,7 +86,8 @@ class OfflineIterator implements Iterator<Entry<Key,Value>> {
     }
 
     @Override
-    public SortedKeyValueIterator<Key,Value> reserveMapFileReader(String mapFileName) throws IOException {
+    public SortedKeyValueIterator<Key,Value> reserveMapFileReader(String mapFileName)
+        throws IOException {
       throw new NotImplementedException();
     }
 
@@ -153,13 +155,15 @@ class OfflineIterator implements Iterator<Entry<Key,Value>> {
   private ArrayList<SortedKeyValueIterator<Key,Value>> readers;
   private AccumuloConfiguration config;
 
-  public OfflineIterator(ScannerOptions options, Instance instance, Credentials credentials, Authorizations authorizations, Text table, Range range) {
+  public OfflineIterator(ScannerOptions options, Instance instance, Credentials credentials,
+      Authorizations authorizations, Text table, Range range) {
     this.options = new ScannerOptions(options);
     this.instance = instance;
     this.range = range;
 
     if (this.options.fetchedColumns.size() > 0) {
-      this.range = range.bound(this.options.fetchedColumns.first(), this.options.fetchedColumns.last());
+      this.range = range.bound(this.options.fetchedColumns.first(),
+          this.options.fetchedColumns.last());
     }
 
     this.tableId = table.toString();
@@ -216,7 +220,8 @@ class OfflineIterator implements Iterator<Entry<Key,Value>> {
       else
         startRow = new Text();
 
-      nextRange = new Range(new KeyExtent(tableId, startRow, null).getMetadataEntry(), true, null, false);
+      nextRange = new Range(new KeyExtent(tableId, startRow, null).getMetadataEntry(), true, null,
+          false);
     } else {
 
       if (currentExtent.getEndRow() == null) {
@@ -240,7 +245,8 @@ class OfflineIterator implements Iterator<Entry<Key,Value>> {
       if (Tables.getTableState(instance, tableId) != TableState.OFFLINE) {
         Tables.clearCache(instance);
         if (Tables.getTableState(instance, tableId) != TableState.OFFLINE) {
-          throw new AccumuloException("Table is online " + tableId + " cannot scan tablet in offline mode " + eloc.getFirst());
+          throw new AccumuloException("Table is online " + tableId
+              + " cannot scan tablet in offline mode " + eloc.getFirst());
         }
       }
 
@@ -259,7 +265,8 @@ class OfflineIterator implements Iterator<Entry<Key,Value>> {
       throw new AccumuloException(" " + currentExtent + " is not previous extent " + extent);
 
     // Old property is only used to resolve relative paths into absolute paths. For systems upgraded
-    // with relative paths, it's assumed that correct instance.dfs.{uri,dir} is still correct in the configuration
+    // with relative paths, it's assumed that correct instance.dfs.{uri,dir} is still correct in the
+    // configuration
     @SuppressWarnings("deprecation")
     String tablesDir = config.get(Property.INSTANCE_DFS_DIR) + Constants.HDFS_TABLES_DIR;
 
@@ -278,12 +285,14 @@ class OfflineIterator implements Iterator<Entry<Key,Value>> {
     }
 
     iter = createIterator(extent, absFiles);
-    iter.seek(range, LocalityGroupUtil.families(options.fetchedColumns), options.fetchedColumns.size() == 0 ? false : true);
+    iter.seek(range, LocalityGroupUtil.families(options.fetchedColumns),
+        options.fetchedColumns.size() == 0 ? false : true);
     currentExtent = extent;
 
   }
 
-  private Pair<KeyExtent,String> getTabletFiles(Range nextRange, List<String> relFiles) throws TableNotFoundException {
+  private Pair<KeyExtent,String> getTabletFiles(Range nextRange, List<String> relFiles)
+      throws TableNotFoundException {
     Scanner scanner = conn.createScanner(MetadataTable.NAME, Authorizations.EMPTY);
     scanner.setBatchSize(100);
     scanner.setRange(nextRange);
@@ -315,8 +324,8 @@ class OfflineIterator implements Iterator<Entry<Key,Value>> {
     return new Pair<>(extent, location);
   }
 
-  private SortedKeyValueIterator<Key,Value> createIterator(KeyExtent extent, List<String> absFiles) throws TableNotFoundException, AccumuloException,
-      IOException {
+  private SortedKeyValueIterator<Key,Value> createIterator(KeyExtent extent, List<String> absFiles)
+      throws TableNotFoundException, AccumuloException, IOException {
 
     // TODO share code w/ tablet - ACCUMULO-1303
     AccumuloConfiguration acuTableConf = AccumuloConfiguration.getTableConfiguration(conn, tableId);
@@ -330,17 +339,22 @@ class OfflineIterator implements Iterator<Entry<Key,Value>> {
     readers.clear();
 
     SamplerConfiguration scannerSamplerConfig = options.getSamplerConfiguration();
-    SamplerConfigurationImpl scannerSamplerConfigImpl = scannerSamplerConfig == null ? null : new SamplerConfigurationImpl(scannerSamplerConfig);
-    SamplerConfigurationImpl samplerConfImpl = SamplerConfigurationImpl.newSamplerConfig(acuTableConf);
-
-    if (scannerSamplerConfigImpl != null && ((samplerConfImpl != null && !scannerSamplerConfigImpl.equals(samplerConfImpl)) || samplerConfImpl == null)) {
+    SamplerConfigurationImpl scannerSamplerConfigImpl = scannerSamplerConfig == null ? null
+        : new SamplerConfigurationImpl(scannerSamplerConfig);
+    SamplerConfigurationImpl samplerConfImpl = SamplerConfigurationImpl
+        .newSamplerConfig(acuTableConf);
+
+    if (scannerSamplerConfigImpl != null
+        && ((samplerConfImpl != null && !scannerSamplerConfigImpl.equals(samplerConfImpl))
+            || samplerConfImpl == null)) {
       throw new SampleNotPresentException();
     }
 
     // TODO need to close files - ACCUMULO-1303
     for (String file : absFiles) {
       FileSystem fs = VolumeConfiguration.getVolume(file, conf, config).getFileSystem();
-      FileSKVIterator reader = FileOperations.getInstance().newReaderBuilder().forFile(file, fs, conf).withTableConfiguration(acuTableConf).build();
+      FileSKVIterator reader = FileOperations.getInstance().newReaderBuilder()
+          .forFile(file, fs, conf).withTableConfiguration(acuTableConf).build();
       if (scannerSamplerConfigImpl != null) {
         reader = reader.getSample(scannerSamplerConfigImpl);
         if (reader == null)
@@ -351,18 +365,21 @@ class OfflineIterator implements Iterator<Entry<Key,Value>> {
 
     MultiIterator multiIter = new MultiIterator(readers, extent);
 
-    OfflineIteratorEnvironment iterEnv = new OfflineIteratorEnvironment(authorizations, acuTableConf, false, samplerConfImpl == null ? null
-        : samplerConfImpl.toSamplerConfiguration());
+    OfflineIteratorEnvironment iterEnv = new OfflineIteratorEnvironment(authorizations,
+        acuTableConf, false,
+        samplerConfImpl == null ? null : samplerConfImpl.toSamplerConfiguration());
 
     byte[] defaultSecurityLabel;
-    ColumnVisibility cv = new ColumnVisibility(acuTableConf.get(Property.TABLE_DEFAULT_SCANTIME_VISIBILITY));
+    ColumnVisibility cv = new ColumnVisibility(
+        acuTableConf.get(Property.TABLE_DEFAULT_SCANTIME_VISIBILITY));
     defaultSecurityLabel = cv.getExpression();
 
-    SortedKeyValueIterator<Key,Value> visFilter = IteratorUtil.setupSystemScanIterators(multiIter, new HashSet<>(options.fetchedColumns), authorizations,
-        defaultSecurityLabel);
+    SortedKeyValueIterator<Key,Value> visFilter = IteratorUtil.setupSystemScanIterators(multiIter,
+        new HashSet<>(options.fetchedColumns), authorizations, defaultSecurityLabel);
 
-    return iterEnv.getTopLevelIterator(IteratorUtil.loadIterators(IteratorScope.scan, visFilter, extent, acuTableConf, options.serverSideIteratorList,
-        options.serverSideIteratorOptions, iterEnv, false));
+    return iterEnv.getTopLevelIterator(
+        IteratorUtil.loadIterators(IteratorScope.scan, visFilter, extent, acuTableConf,
+            options.serverSideIteratorList, options.serverSideIteratorOptions, iterEnv, false));
   }
 
   @Override
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/OfflineScanner.java b/core/src/main/java/org/apache/accumulo/core/client/impl/OfflineScanner.java
index 427a7cc..955a8da 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/OfflineScanner.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/OfflineScanner.java
@@ -41,7 +41,8 @@ public class OfflineScanner extends ScannerOptions implements Scanner {
   private Authorizations authorizations;
   private Text tableId;
 
-  public OfflineScanner(Instance instance, Credentials credentials, String tableId, Authorizations authorizations) {
+  public OfflineScanner(Instance instance, Credentials credentials, String tableId,
+      Authorizations authorizations) {
     checkArgument(instance != null, "instance is null");
     checkArgument(credentials != null, "credentials is null");
     checkArgument(tableId != null, "tableId is null");
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ReplicationClient.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ReplicationClient.java
index 1656d15..6eb1fd0 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ReplicationClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ReplicationClient.java
@@ -46,7 +46,8 @@ public class ReplicationClient {
    *          the client session for the peer replicant
    * @return Client to the ReplicationCoordinator service
    */
-  public static ReplicationCoordinator.Client getCoordinatorConnectionWithRetry(ClientContext context) throws AccumuloException {
+  public static ReplicationCoordinator.Client getCoordinatorConnectionWithRetry(
+      ClientContext context) throws AccumuloException {
     requireNonNull(context);
     Instance instance = context.getInstance();
 
@@ -55,7 +56,8 @@ public class ReplicationClient {
       ReplicationCoordinator.Client result = getCoordinatorConnection(context);
       if (result != null)
         return result;
-      log.debug("Could not get ReplicationCoordinator connection to {}, will retry", instance.getInstanceName());
+      log.debug("Could not get ReplicationCoordinator connection to {}, will retry",
+          instance.getInstanceName());
       try {
         Thread.sleep(attempts * 250);
       } catch (InterruptedException e) {
@@ -63,7 +65,8 @@ public class ReplicationClient {
       }
     }
 
-    throw new AccumuloException("Timed out trying to communicate with master from " + instance.getInstanceName());
+    throw new AccumuloException(
+        "Timed out trying to communicate with master from " + instance.getInstanceName());
   }
 
   public static ReplicationCoordinator.Client getCoordinatorConnection(ClientContext context) {
@@ -78,18 +81,21 @@ public class ReplicationClient {
     // This is the master thrift service, we just want the hostname, not the port
     String masterThriftService = locations.get(0);
     if (masterThriftService.endsWith(":0")) {
-      log.warn("Master found for {} did not have real location {}", instance.getInstanceName(), masterThriftService);
+      log.warn("Master found for {} did not have real location {}", instance.getInstanceName(),
+          masterThriftService);
       return null;
     }
 
     String zkPath = ZooUtil.getRoot(instance) + Constants.ZMASTER_REPLICATION_COORDINATOR_ADDR;
     String replCoordinatorAddr;
 
-    log.debug("Using ZooKeeper quorum at {} with path {} to find peer Master information", instance.getZooKeepers(), zkPath);
+    log.debug("Using ZooKeeper quorum at {} with path {} to find peer Master information",
+        instance.getZooKeepers(), zkPath);
 
     // Get the coordinator port for the master we're trying to connect to
     try {
-      ZooReader reader = new ZooReader(instance.getZooKeepers(), instance.getZooKeepersSessionTimeOut());
+      ZooReader reader = new ZooReader(instance.getZooKeepers(),
+          instance.getZooKeepersSessionTimeOut());
       replCoordinatorAddr = new String(reader.getData(zkPath, null), UTF_8);
     } catch (KeeperException | InterruptedException e) {
       log.error("Could not fetch remote coordinator port", e);
@@ -103,7 +109,8 @@ public class ReplicationClient {
 
     try {
       // Master requests can take a long time: don't ever time out
-      ReplicationCoordinator.Client client = ThriftUtil.getClientNoTimeout(new ReplicationCoordinator.Client.Factory(), coordinatorAddr, context);
+      ReplicationCoordinator.Client client = ThriftUtil.getClientNoTimeout(
+          new ReplicationCoordinator.Client.Factory(), coordinatorAddr, context);
       return client;
     } catch (TTransportException tte) {
       log.debug("Failed to connect to master coordinator service ({})", coordinatorAddr, tte);
@@ -122,12 +129,14 @@ public class ReplicationClient {
    *          RPC timeout in milliseconds
    * @return A ReplicationServicer client to the given host in the given instance
    */
-  public static ReplicationServicer.Client getServicerConnection(ClientContext context, HostAndPort server, long timeout) throws TTransportException {
+  public static ReplicationServicer.Client getServicerConnection(ClientContext context,
+      HostAndPort server, long timeout) throws TTransportException {
     requireNonNull(context);
     requireNonNull(server);
 
     try {
-      return ThriftUtil.getClient(new ReplicationServicer.Client.Factory(), server, context, timeout);
+      return ThriftUtil.getClient(new ReplicationServicer.Client.Factory(), server, context,
+          timeout);
     } catch (TTransportException tte) {
       log.debug("Failed to connect to servicer ({}), will retry...", server, tte);
       throw tte;
@@ -136,7 +145,8 @@ public class ReplicationClient {
 
   public static void close(ReplicationCoordinator.Iface iface) {
     TServiceClient client = (TServiceClient) iface;
-    if (client != null && client.getInputProtocol() != null && client.getInputProtocol().getTransport() != null) {
+    if (client != null && client.getInputProtocol() != null
+        && client.getInputProtocol().getTransport() != null) {
       ThriftTransportPool.getInstance().returnTransport(client.getInputProtocol().getTransport());
     } else {
       log.debug("Attempt to close null connection to the remote system", new Exception());
@@ -145,15 +155,17 @@ public class ReplicationClient {
 
   public static void close(ReplicationServicer.Iface iface) {
     TServiceClient client = (TServiceClient) iface;
-    if (client != null && client.getInputProtocol() != null && client.getInputProtocol().getTransport() != null) {
+    if (client != null && client.getInputProtocol() != null
+        && client.getInputProtocol().getTransport() != null) {
       ThriftTransportPool.getInstance().returnTransport(client.getInputProtocol().getTransport());
     } else {
       log.debug("Attempt to close null connection to the remote system", new Exception());
     }
   }
 
-  public static <T> T executeCoordinatorWithReturn(ClientContext context, ClientExecReturn<T,ReplicationCoordinator.Client> exec) throws AccumuloException,
-      AccumuloSecurityException {
+  public static <T> T executeCoordinatorWithReturn(ClientContext context,
+      ClientExecReturn<T,ReplicationCoordinator.Client> exec)
+      throws AccumuloException, AccumuloSecurityException {
     ReplicationCoordinator.Client client = null;
     for (int i = 0; i < 10; i++) {
       try {
@@ -178,10 +190,12 @@ public class ReplicationClient {
       }
     }
 
-    throw new AccumuloException("Could not connect to ReplicationCoordinator at " + context.getInstance().getInstanceName());
+    throw new AccumuloException("Could not connect to ReplicationCoordinator at "
+        + context.getInstance().getInstanceName());
   }
 
-  public static <T> T executeServicerWithReturn(ClientContext context, HostAndPort tserver, ClientExecReturn<T,ReplicationServicer.Client> exec, long timeout)
+  public static <T> T executeServicerWithReturn(ClientContext context, HostAndPort tserver,
+      ClientExecReturn<T,ReplicationServicer.Client> exec, long timeout)
       throws AccumuloException, AccumuloSecurityException, TTransportException {
     ReplicationServicer.Client client = null;
     while (true) {
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ReplicationOperationsImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ReplicationOperationsImpl.java
index da8cc37..527c02a 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ReplicationOperationsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ReplicationOperationsImpl.java
@@ -63,20 +63,25 @@ public class ReplicationOperationsImpl implements ReplicationOperations {
   }
 
   @Override
-  public void addPeer(final String name, final String replicaType) throws AccumuloException, AccumuloSecurityException, PeerExistsException {
+  public void addPeer(final String name, final String replicaType)
+      throws AccumuloException, AccumuloSecurityException, PeerExistsException {
     requireNonNull(name);
     requireNonNull(replicaType);
-    context.getConnector().instanceOperations().setProperty(Property.REPLICATION_PEERS.getKey() + name, replicaType);
+    context.getConnector().instanceOperations()
+        .setProperty(Property.REPLICATION_PEERS.getKey() + name, replicaType);
   }
 
   @Override
-  public void removePeer(final String name) throws AccumuloException, AccumuloSecurityException, PeerNotFoundException {
+  public void removePeer(final String name)
+      throws AccumuloException, AccumuloSecurityException, PeerNotFoundException {
     requireNonNull(name);
-    context.getConnector().instanceOperations().removeProperty(Property.REPLICATION_PEERS.getKey() + name);
+    context.getConnector().instanceOperations()
+        .removeProperty(Property.REPLICATION_PEERS.getKey() + name);
   }
 
   @Override
-  public void drain(String tableName) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+  public void drain(String tableName)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     requireNonNull(tableName);
 
     Set<String> wals = referencedFiles(tableName);
@@ -85,13 +90,15 @@ public class ReplicationOperationsImpl implements ReplicationOperations {
   }
 
   @Override
-  public void drain(final String tableName, final Set<String> wals) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+  public void drain(final String tableName, final Set<String> wals)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     requireNonNull(tableName);
 
     final TInfo tinfo = Tracer.traceInfo();
     final TCredentials rpcCreds = context.rpcCreds();
 
-    // Ask the master if the table is fully replicated given these WALs, but don't poll inside the master
+    // Ask the master if the table is fully replicated given these WALs, but don't poll inside the
+    // master
     boolean drained = false;
     while (!drained) {
       drained = getMasterDrain(tinfo, rpcCreds, tableName, wals);
@@ -107,8 +114,9 @@ public class ReplicationOperationsImpl implements ReplicationOperations {
     }
   }
 
-  protected boolean getMasterDrain(final TInfo tinfo, final TCredentials rpcCreds, final String tableName, final Set<String> wals) throws AccumuloException,
-      AccumuloSecurityException, TableNotFoundException {
+  protected boolean getMasterDrain(final TInfo tinfo, final TCredentials rpcCreds,
+      final String tableName, final Set<String> wals)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     return MasterClient.execute(context, new ClientExecReturn<Boolean,Client>() {
       @Override
       public Boolean execute(Client client) throws Exception {
@@ -117,7 +125,8 @@ public class ReplicationOperationsImpl implements ReplicationOperations {
     });
   }
 
-  protected String getTableId(Connector conn, String tableName) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+  protected String getTableId(Connector conn, String tableName)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     TableOperations tops = conn.tableOperations();
 
     if (!conn.tableOperations().exists(tableName)) {
@@ -136,7 +145,8 @@ public class ReplicationOperationsImpl implements ReplicationOperations {
   }
 
   @Override
-  public Set<String> referencedFiles(String tableName) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+  public Set<String> referencedFiles(String tableName)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     requireNonNull(tableName);
 
     log.debug("Collecting referenced files for replication of table {}", tableName);
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/RootTabletLocator.java b/core/src/main/java/org/apache/accumulo/core/client/impl/RootTabletLocator.java
index fb002e3..ecd6b78 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/RootTabletLocator.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/RootTabletLocator.java
@@ -57,7 +57,8 @@ public class RootTabletLocator extends TabletLocator {
   }
 
   @Override
-  public <T extends Mutation> void binMutations(ClientContext context, List<T> mutations, Map<String,TabletServerMutations<T>> binnedMutations, List<T> failures)
+  public <T extends Mutation> void binMutations(ClientContext context, List<T> mutations,
+      Map<String,TabletServerMutations<T>> binnedMutations, List<T> failures)
       throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     TabletLocation rootTabletLocation = getRootTabletLocation(context);
     if (rootTabletLocation != null) {
@@ -72,13 +73,15 @@ public class RootTabletLocator extends TabletLocator {
   }
 
   @Override
-  public List<Range> binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges) throws AccumuloException,
-      AccumuloSecurityException, TableNotFoundException {
+  public List<Range> binRanges(ClientContext context, List<Range> ranges,
+      Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
 
     TabletLocation rootTabletLocation = getRootTabletLocation(context);
     if (rootTabletLocation != null) {
       for (Range range : ranges) {
-        TabletLocatorImpl.addRange(binnedRanges, rootTabletLocation.tablet_location, RootTable.EXTENT, range);
+        TabletLocatorImpl.addRange(binnedRanges, rootTabletLocation.tablet_location,
+            RootTable.EXTENT, range);
       }
       return Collections.emptyList();
     }
@@ -93,7 +96,8 @@ public class RootTabletLocator extends TabletLocator {
 
   @Override
   public void invalidateCache(Instance instance, String server) {
-    ZooCache zooCache = zcf.getZooCache(instance.getZooKeepers(), instance.getZooKeepersSessionTimeOut());
+    ZooCache zooCache = zcf.getZooCache(instance.getZooKeepers(),
+        instance.getZooKeepersSessionTimeOut());
     String root = ZooUtil.getRoot(instance) + Constants.ZTSERVERS;
     zooCache.clear(root + "/" + server);
   }
@@ -104,14 +108,16 @@ public class RootTabletLocator extends TabletLocator {
   protected TabletLocation getRootTabletLocation(ClientContext context) {
     Instance instance = context.getInstance();
     String zRootLocPath = ZooUtil.getRoot(instance) + RootTable.ZROOT_TABLET_LOCATION;
-    ZooCache zooCache = zcf.getZooCache(instance.getZooKeepers(), instance.getZooKeepersSessionTimeOut());
+    ZooCache zooCache = zcf.getZooCache(instance.getZooKeepers(),
+        instance.getZooKeepersSessionTimeOut());
 
     Logger log = LoggerFactory.getLogger(this.getClass());
 
     OpTimer timer = null;
 
     if (log.isTraceEnabled()) {
-      log.trace("tid={} Looking up root tablet location in zookeeper.", Thread.currentThread().getId());
+      log.trace("tid={} Looking up root tablet location in zookeeper.",
+          Thread.currentThread().getId());
       timer = new OpTimer().start();
     }
 
@@ -119,7 +125,8 @@ public class RootTabletLocator extends TabletLocator {
 
     if (timer != null) {
       timer.stop();
-      log.trace("tid={} Found root tablet at {} in {}", Thread.currentThread().getId(), (loc == null ? "null" : new String(loc)),
+      log.trace("tid={} Found root tablet at {} in {}", Thread.currentThread().getId(),
+          (loc == null ? "null" : new String(loc)),
           String.format("%.3f secs", timer.scale(TimeUnit.SECONDS)));
     }
 
@@ -136,8 +143,8 @@ public class RootTabletLocator extends TabletLocator {
   }
 
   @Override
-  public TabletLocation locateTablet(ClientContext context, Text row, boolean skipRow, boolean retry) throws AccumuloException, AccumuloSecurityException,
-      TableNotFoundException {
+  public TabletLocation locateTablet(ClientContext context, Text row, boolean skipRow,
+      boolean retry) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     TabletLocation location = getRootTabletLocation(context);
     // Always retry when finding the root tablet
     while (retry && location == null) {
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerImpl.java
index 89406f4..07c62eb 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerImpl.java
@@ -32,9 +32,10 @@ import org.apache.accumulo.core.security.Authorizations;
 /**
  * provides scanner functionality
  *
- * "Clients can iterate over multiple column families, and there are several mechanisms for limiting the rows, columns, and timestamps traversed by a scan. For
- * example, we could restrict [a] scan ... to only produce anchors whose columns match [a] regular expression ..., or to only produce anchors whose timestamps
- * fall within ten days of the current time."
+ * "Clients can iterate over multiple column families, and there are several mechanisms for limiting
+ * the rows, columns, and timestamps traversed by a scan. For example, we could restrict [a] scan
+ * ... to only produce anchors whose columns match [a] regular expression ..., or to only produce
+ * anchors whose timestamps fall within ten days of the current time."
  *
  */
 public class ScannerImpl extends ScannerOptions implements Scanner {
@@ -92,7 +93,8 @@ public class ScannerImpl extends ScannerOptions implements Scanner {
 
   @Override
   public synchronized Iterator<Entry<Key,Value>> iterator() {
-    return new ScannerIterator(context, tableId, authorizations, range, size, getTimeOut(), this, isolated, readaheadThreshold);
+    return new ScannerIterator(context, tableId, authorizations, range, size, getTimeOut(), this,
+        isolated, readaheadThreshold);
   }
 
   @Override
@@ -131,7 +133,8 @@ public class ScannerImpl extends ScannerOptions implements Scanner {
   @Override
   public synchronized void setReadaheadThreshold(long batches) {
     if (0 > batches) {
-      throw new IllegalArgumentException("Number of batches before read-ahead must be non-negative");
+      throw new IllegalArgumentException(
+          "Number of batches before read-ahead must be non-negative");
     }
 
     readaheadThreshold = batches;
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerIterator.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerIterator.java
index ae55cc0..bc80f55 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerIterator.java
@@ -66,7 +66,8 @@ public class ScannerIterator implements Iterator<Entry<Key,Value>> {
 
   private static final List<KeyValue> EMPTY_LIST = Collections.emptyList();
 
-  private static ThreadPoolExecutor readaheadPool = new ThreadPoolExecutor(0, Integer.MAX_VALUE, 3l, TimeUnit.SECONDS, new SynchronousQueue<Runnable>(),
+  private static ThreadPoolExecutor readaheadPool = new ThreadPoolExecutor(0, Integer.MAX_VALUE, 3l,
+      TimeUnit.SECONDS, new SynchronousQueue<Runnable>(),
       new NamingThreadFactory("Accumulo scanner read ahead thread"));
 
   private class Reader implements Runnable {
@@ -89,7 +90,8 @@ public class ScannerIterator implements Iterator<Entry<Key,Value>> {
           synchQ.add(currentBatch);
           return;
         }
-      } catch (IsolationException | ScanTimedOutException | AccumuloException | AccumuloSecurityException | TableDeletedException | TableOfflineException
+      } catch (IsolationException | ScanTimedOutException | AccumuloException
+          | AccumuloSecurityException | TableDeletedException | TableOfflineException
           | SampleNotPresentException e) {
         log.trace("{}", e.getMessage(), e);
         synchQ.add(e);
@@ -104,8 +106,8 @@ public class ScannerIterator implements Iterator<Entry<Key,Value>> {
 
   }
 
-  ScannerIterator(ClientContext context, String tableId, Authorizations authorizations, Range range, int size, int timeOut, ScannerOptions options,
-      boolean isolated, long readaheadThreshold) {
+  ScannerIterator(ClientContext context, String tableId, Authorizations authorizations, Range range,
+      int size, int timeOut, ScannerOptions options, boolean isolated, long readaheadThreshold) {
     this.timeOut = timeOut;
     this.readaheadThreshold = readaheadThreshold;
 
@@ -117,8 +119,10 @@ public class ScannerIterator implements Iterator<Entry<Key,Value>> {
       range = range.bound(this.options.fetchedColumns.first(), this.options.fetchedColumns.last());
     }
 
-    scanState = new ScanState(context, tableId, authorizations, new Range(range), options.fetchedColumns, size, options.serverSideIteratorList,
-        options.serverSideIteratorOptions, isolated, readaheadThreshold, options.getSamplerConfiguration(), options.batchTimeOut, options.classLoaderContext);
+    scanState = new ScanState(context, tableId, authorizations, new Range(range),
+        options.fetchedColumns, size, options.serverSideIteratorList,
+        options.serverSideIteratorOptions, isolated, readaheadThreshold,
+        options.getSamplerConfiguration(), options.batchTimeOut, options.classLoaderContext);
 
     // If we want to start readahead immediately, don't wait for hasNext to be called
     if (0l == readaheadThreshold) {
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerOptions.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerOptions.java
index a986d87..838d003 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerOptions.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerOptions.java
@@ -75,7 +75,8 @@ public class ScannerOptions implements ScannerBase {
       if (ii.iterName.equals(si.getName()))
         throw new IllegalArgumentException("Iterator name is already in use " + si.getName());
       if (ii.getPriority() == si.getPriority())
-        throw new IllegalArgumentException("Iterator priority is already in use " + si.getPriority());
+        throw new IllegalArgumentException(
+            "Iterator priority is already in use " + si.getPriority());
     }
 
     serverSideIteratorList.add(new IterInfo(si.getPriority(), si.getIteratorClass(), si.getName()));
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/SecurityOperationsImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/SecurityOperationsImpl.java
index 73f17a7..71059b1 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/SecurityOperationsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/SecurityOperationsImpl.java
@@ -48,7 +48,8 @@ public class SecurityOperationsImpl implements SecurityOperations {
 
   private final ClientContext context;
 
-  private void execute(ClientExec<ClientService.Client> exec) throws AccumuloException, AccumuloSecurityException {
+  private void execute(ClientExec<ClientService.Client> exec)
+      throws AccumuloException, AccumuloSecurityException {
     try {
       ServerClient.executeRaw(context, exec);
     } catch (ThriftTableOperationException ttoe) {
@@ -68,7 +69,8 @@ public class SecurityOperationsImpl implements SecurityOperations {
     }
   }
 
-  private <T> T execute(ClientExecReturn<T,ClientService.Client> exec) throws AccumuloException, AccumuloSecurityException {
+  private <T> T execute(ClientExecReturn<T,ClientService.Client> exec)
+      throws AccumuloException, AccumuloSecurityException {
     try {
       return ServerClient.executeRaw(context, exec);
     } catch (ThriftTableOperationException ttoe) {
@@ -95,13 +97,15 @@ public class SecurityOperationsImpl implements SecurityOperations {
 
   @Deprecated
   @Override
-  public void createUser(String user, byte[] password, final Authorizations authorizations) throws AccumuloException, AccumuloSecurityException {
+  public void createUser(String user, byte[] password, final Authorizations authorizations)
+      throws AccumuloException, AccumuloSecurityException {
     createLocalUser(user, new PasswordToken(password));
     changeUserAuthorizations(user, authorizations);
   }
 
   @Override
-  public void createLocalUser(final String principal, final PasswordToken password) throws AccumuloException, AccumuloSecurityException {
+  public void createLocalUser(final String principal, final PasswordToken password)
+      throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
     if (null == context.getSaslParams()) {
       checkArgument(password != null, "password is null");
@@ -110,9 +114,11 @@ public class SecurityOperationsImpl implements SecurityOperations {
       @Override
       public void execute(ClientService.Client client) throws Exception {
         if (null == context.getSaslParams()) {
-          client.createLocalUser(Tracer.traceInfo(), context.rpcCreds(), principal, ByteBuffer.wrap(password.getPassword()));
+          client.createLocalUser(Tracer.traceInfo(), context.rpcCreds(), principal,
+              ByteBuffer.wrap(password.getPassword()));
         } else {
-          client.createLocalUser(Tracer.traceInfo(), context.rpcCreds(), principal, ByteBuffer.wrap(new byte[0]));
+          client.createLocalUser(Tracer.traceInfo(), context.rpcCreds(), principal,
+              ByteBuffer.wrap(new byte[0]));
         }
       }
     });
@@ -125,7 +131,8 @@ public class SecurityOperationsImpl implements SecurityOperations {
   }
 
   @Override
-  public void dropLocalUser(final String principal) throws AccumuloException, AccumuloSecurityException {
+  public void dropLocalUser(final String principal)
+      throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
     execute(new ClientExec<ClientService.Client>() {
       @Override
@@ -137,38 +144,44 @@ public class SecurityOperationsImpl implements SecurityOperations {
 
   @Deprecated
   @Override
-  public boolean authenticateUser(String user, byte[] password) throws AccumuloException, AccumuloSecurityException {
+  public boolean authenticateUser(String user, byte[] password)
+      throws AccumuloException, AccumuloSecurityException {
     return authenticateUser(user, new PasswordToken(password));
   }
 
   @Override
-  public boolean authenticateUser(final String principal, final AuthenticationToken token) throws AccumuloException, AccumuloSecurityException {
+  public boolean authenticateUser(final String principal, final AuthenticationToken token)
+      throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
     checkArgument(token != null, "token is null");
     final Credentials toAuth = new Credentials(principal, token);
     return execute(new ClientExecReturn<Boolean,ClientService.Client>() {
       @Override
       public Boolean execute(ClientService.Client client) throws Exception {
-        return client.authenticateUser(Tracer.traceInfo(), context.rpcCreds(), toAuth.toThrift(context.getInstance()));
+        return client.authenticateUser(Tracer.traceInfo(), context.rpcCreds(),
+            toAuth.toThrift(context.getInstance()));
       }
     });
   }
 
   @Override
   @Deprecated
-  public void changeUserPassword(String user, byte[] password) throws AccumuloException, AccumuloSecurityException {
+  public void changeUserPassword(String user, byte[] password)
+      throws AccumuloException, AccumuloSecurityException {
     changeLocalUserPassword(user, new PasswordToken(password));
   }
 
   @Override
-  public void changeLocalUserPassword(final String principal, final PasswordToken token) throws AccumuloException, AccumuloSecurityException {
+  public void changeLocalUserPassword(final String principal, final PasswordToken token)
+      throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
     checkArgument(token != null, "token is null");
     final Credentials toChange = new Credentials(principal, token);
     execute(new ClientExec<ClientService.Client>() {
       @Override
       public void execute(ClientService.Client client) throws Exception {
-        client.changeLocalUserPassword(Tracer.traceInfo(), context.rpcCreds(), principal, ByteBuffer.wrap(token.getPassword()));
+        client.changeLocalUserPassword(Tracer.traceInfo(), context.rpcCreds(), principal,
+            ByteBuffer.wrap(token.getPassword()));
       }
     });
     if (context.getCredentials().getPrincipal().equals(principal)) {
@@ -177,42 +190,49 @@ public class SecurityOperationsImpl implements SecurityOperations {
   }
 
   @Override
-  public void changeUserAuthorizations(final String principal, final Authorizations authorizations) throws AccumuloException, AccumuloSecurityException {
+  public void changeUserAuthorizations(final String principal, final Authorizations authorizations)
+      throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
     checkArgument(authorizations != null, "authorizations is null");
     execute(new ClientExec<ClientService.Client>() {
       @Override
       public void execute(ClientService.Client client) throws Exception {
-        client.changeAuthorizations(Tracer.traceInfo(), context.rpcCreds(), principal, ByteBufferUtil.toByteBuffers(authorizations.getAuthorizations()));
+        client.changeAuthorizations(Tracer.traceInfo(), context.rpcCreds(), principal,
+            ByteBufferUtil.toByteBuffers(authorizations.getAuthorizations()));
       }
     });
   }
 
   @Override
-  public Authorizations getUserAuthorizations(final String principal) throws AccumuloException, AccumuloSecurityException {
+  public Authorizations getUserAuthorizations(final String principal)
+      throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
     return execute(new ClientExecReturn<Authorizations,ClientService.Client>() {
       @Override
       public Authorizations execute(ClientService.Client client) throws Exception {
-        return new Authorizations(client.getUserAuthorizations(Tracer.traceInfo(), context.rpcCreds(), principal));
+        return new Authorizations(
+            client.getUserAuthorizations(Tracer.traceInfo(), context.rpcCreds(), principal));
       }
     });
   }
 
   @Override
-  public boolean hasSystemPermission(final String principal, final SystemPermission perm) throws AccumuloException, AccumuloSecurityException {
+  public boolean hasSystemPermission(final String principal, final SystemPermission perm)
+      throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
     checkArgument(perm != null, "perm is null");
     return execute(new ClientExecReturn<Boolean,ClientService.Client>() {
       @Override
       public Boolean execute(ClientService.Client client) throws Exception {
-        return client.hasSystemPermission(Tracer.traceInfo(), context.rpcCreds(), principal, perm.getId());
+        return client.hasSystemPermission(Tracer.traceInfo(), context.rpcCreds(), principal,
+            perm.getId());
       }
     });
   }
 
   @Override
-  public boolean hasTablePermission(final String principal, final String table, final TablePermission perm) throws AccumuloException, AccumuloSecurityException {
+  public boolean hasTablePermission(final String principal, final String table,
+      final TablePermission perm) throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
     checkArgument(table != null, "table is null");
     checkArgument(perm != null, "perm is null");
@@ -220,11 +240,13 @@ public class SecurityOperationsImpl implements SecurityOperations {
       return execute(new ClientExecReturn<Boolean,ClientService.Client>() {
         @Override
         public Boolean execute(ClientService.Client client) throws Exception {
-          return client.hasTablePermission(Tracer.traceInfo(), context.rpcCreds(), principal, table, perm.getId());
+          return client.hasTablePermission(Tracer.traceInfo(), context.rpcCreds(), principal, table,
+              perm.getId());
         }
       });
     } catch (AccumuloSecurityException e) {
-      if (e.getSecurityErrorCode() == org.apache.accumulo.core.client.security.SecurityErrorCode.NAMESPACE_DOESNT_EXIST)
+      if (e
+          .getSecurityErrorCode() == org.apache.accumulo.core.client.security.SecurityErrorCode.NAMESPACE_DOESNT_EXIST)
         throw new AccumuloSecurityException(null, SecurityErrorCode.TABLE_DOESNT_EXIST, e);
       else
         throw e;
@@ -232,34 +254,37 @@ public class SecurityOperationsImpl implements SecurityOperations {
   }
 
   @Override
-  public boolean hasNamespacePermission(final String principal, final String namespace, final NamespacePermission permission) throws AccumuloException,
-      AccumuloSecurityException {
+  public boolean hasNamespacePermission(final String principal, final String namespace,
+      final NamespacePermission permission) throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
     checkArgument(namespace != null, "namespace is null");
     checkArgument(permission != null, "permission is null");
     return execute(new ClientExecReturn<Boolean,ClientService.Client>() {
       @Override
       public Boolean execute(ClientService.Client client) throws Exception {
-        return client.hasNamespacePermission(Tracer.traceInfo(), context.rpcCreds(), principal, namespace, permission.getId());
+        return client.hasNamespacePermission(Tracer.traceInfo(), context.rpcCreds(), principal,
+            namespace, permission.getId());
       }
     });
   }
 
   @Override
-  public void grantSystemPermission(final String principal, final SystemPermission permission) throws AccumuloException, AccumuloSecurityException {
+  public void grantSystemPermission(final String principal, final SystemPermission permission)
+      throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
     checkArgument(permission != null, "permission is null");
     execute(new ClientExec<ClientService.Client>() {
       @Override
       public void execute(ClientService.Client client) throws Exception {
-        client.grantSystemPermission(Tracer.traceInfo(), context.rpcCreds(), principal, permission.getId());
+        client.grantSystemPermission(Tracer.traceInfo(), context.rpcCreds(), principal,
+            permission.getId());
       }
     });
   }
 
   @Override
-  public void grantTablePermission(final String principal, final String table, final TablePermission permission) throws AccumuloException,
-      AccumuloSecurityException {
+  public void grantTablePermission(final String principal, final String table,
+      final TablePermission permission) throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
     checkArgument(table != null, "table is null");
     checkArgument(permission != null, "permission is null");
@@ -267,11 +292,13 @@ public class SecurityOperationsImpl implements SecurityOperations {
       execute(new ClientExec<ClientService.Client>() {
         @Override
         public void execute(ClientService.Client client) throws Exception {
-          client.grantTablePermission(Tracer.traceInfo(), context.rpcCreds(), principal, table, permission.getId());
+          client.grantTablePermission(Tracer.traceInfo(), context.rpcCreds(), principal, table,
+              permission.getId());
         }
       });
     } catch (AccumuloSecurityException e) {
-      if (e.getSecurityErrorCode() == org.apache.accumulo.core.client.security.SecurityErrorCode.NAMESPACE_DOESNT_EXIST)
+      if (e
+          .getSecurityErrorCode() == org.apache.accumulo.core.client.security.SecurityErrorCode.NAMESPACE_DOESNT_EXIST)
         throw new AccumuloSecurityException(null, SecurityErrorCode.TABLE_DOESNT_EXIST, e);
       else
         throw e;
@@ -279,34 +306,37 @@ public class SecurityOperationsImpl implements SecurityOperations {
   }
 
   @Override
-  public void grantNamespacePermission(final String principal, final String namespace, final NamespacePermission permission) throws AccumuloException,
-      AccumuloSecurityException {
+  public void grantNamespacePermission(final String principal, final String namespace,
+      final NamespacePermission permission) throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
     checkArgument(namespace != null, "namespace is null");
     checkArgument(permission != null, "permission is null");
     execute(new ClientExec<ClientService.Client>() {
       @Override
       public void execute(ClientService.Client client) throws Exception {
-        client.grantNamespacePermission(Tracer.traceInfo(), context.rpcCreds(), principal, namespace, permission.getId());
+        client.grantNamespacePermission(Tracer.traceInfo(), context.rpcCreds(), principal,
+            namespace, permission.getId());
       }
     });
   }
 
   @Override
-  public void revokeSystemPermission(final String principal, final SystemPermission permission) throws AccumuloException, AccumuloSecurityException {
+  public void revokeSystemPermission(final String principal, final SystemPermission permission)
+      throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
     checkArgument(permission != null, "permission is null");
     execute(new ClientExec<ClientService.Client>() {
       @Override
       public void execute(ClientService.Client client) throws Exception {
-        client.revokeSystemPermission(Tracer.traceInfo(), context.rpcCreds(), principal, permission.getId());
+        client.revokeSystemPermission(Tracer.traceInfo(), context.rpcCreds(), principal,
+            permission.getId());
       }
     });
   }
 
   @Override
-  public void revokeTablePermission(final String principal, final String table, final TablePermission permission) throws AccumuloException,
-      AccumuloSecurityException {
+  public void revokeTablePermission(final String principal, final String table,
+      final TablePermission permission) throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
     checkArgument(table != null, "table is null");
     checkArgument(permission != null, "permission is null");
@@ -314,11 +344,13 @@ public class SecurityOperationsImpl implements SecurityOperations {
       execute(new ClientExec<ClientService.Client>() {
         @Override
         public void execute(ClientService.Client client) throws Exception {
-          client.revokeTablePermission(Tracer.traceInfo(), context.rpcCreds(), principal, table, permission.getId());
+          client.revokeTablePermission(Tracer.traceInfo(), context.rpcCreds(), principal, table,
+              permission.getId());
         }
       });
     } catch (AccumuloSecurityException e) {
-      if (e.getSecurityErrorCode() == org.apache.accumulo.core.client.security.SecurityErrorCode.NAMESPACE_DOESNT_EXIST)
+      if (e
+          .getSecurityErrorCode() == org.apache.accumulo.core.client.security.SecurityErrorCode.NAMESPACE_DOESNT_EXIST)
         throw new AccumuloSecurityException(null, SecurityErrorCode.TABLE_DOESNT_EXIST, e);
       else
         throw e;
@@ -326,15 +358,16 @@ public class SecurityOperationsImpl implements SecurityOperations {
   }
 
   @Override
-  public void revokeNamespacePermission(final String principal, final String namespace, final NamespacePermission permission) throws AccumuloException,
-      AccumuloSecurityException {
+  public void revokeNamespacePermission(final String principal, final String namespace,
+      final NamespacePermission permission) throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
     checkArgument(namespace != null, "namespace is null");
     checkArgument(permission != null, "permission is null");
     execute(new ClientExec<ClientService.Client>() {
       @Override
       public void execute(ClientService.Client client) throws Exception {
-        client.revokeNamespacePermission(Tracer.traceInfo(), context.rpcCreds(), principal, namespace, permission.getId());
+        client.revokeNamespacePermission(Tracer.traceInfo(), context.rpcCreds(), principal,
+            namespace, permission.getId());
       }
     });
   }
@@ -356,7 +389,8 @@ public class SecurityOperationsImpl implements SecurityOperations {
   }
 
   @Override
-  public DelegationToken getDelegationToken(DelegationTokenConfig cfg) throws AccumuloException, AccumuloSecurityException {
+  public DelegationToken getDelegationToken(DelegationTokenConfig cfg)
+      throws AccumuloException, AccumuloSecurityException {
     final TDelegationTokenConfig tConfig;
     if (null != cfg) {
       tConfig = DelegationTokenConfigSerializer.serialize(cfg);
@@ -374,10 +408,12 @@ public class SecurityOperationsImpl implements SecurityOperations {
       });
     } catch (TableNotFoundException e) {
       // should never happen
-      throw new AssertionError("Received TableNotFoundException on method which should not throw that exception", e);
+      throw new AssertionError(
+          "Received TableNotFoundException on method which should not throw that exception", e);
     }
 
-    AuthenticationTokenIdentifier identifier = new AuthenticationTokenIdentifier(thriftToken.getIdentifier());
+    AuthenticationTokenIdentifier identifier = new AuthenticationTokenIdentifier(
+        thriftToken.getIdentifier());
 
     // Get the password out of the thrift delegation token
     return new DelegationTokenImpl(thriftToken.getPassword(), identifier);
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ServerClient.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ServerClient.java
index 373d704..6e49585 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ServerClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ServerClient.java
@@ -45,7 +45,8 @@ import org.slf4j.LoggerFactory;
 public class ServerClient {
   private static final Logger log = LoggerFactory.getLogger(ServerClient.class);
 
-  public static <T> T execute(ClientContext context, ClientExecReturn<T,ClientService.Client> exec) throws AccumuloException, AccumuloSecurityException {
+  public static <T> T execute(ClientContext context, ClientExecReturn<T,ClientService.Client> exec)
+      throws AccumuloException, AccumuloSecurityException {
     try {
       return executeRaw(context, exec);
     } catch (ThriftSecurityException e) {
@@ -57,7 +58,8 @@ public class ServerClient {
     }
   }
 
-  public static void execute(ClientContext context, ClientExec<ClientService.Client> exec) throws AccumuloException, AccumuloSecurityException {
+  public static void execute(ClientContext context, ClientExec<ClientService.Client> exec)
+      throws AccumuloException, AccumuloSecurityException {
     try {
       executeRaw(context, exec);
     } catch (ThriftSecurityException e) {
@@ -69,7 +71,8 @@ public class ServerClient {
     }
   }
 
-  public static <T> T executeRaw(ClientContext context, ClientExecReturn<T,ClientService.Client> exec) throws Exception {
+  public static <T> T executeRaw(ClientContext context,
+      ClientExecReturn<T,ClientService.Client> exec) throws Exception {
     while (true) {
       ClientService.Client client = null;
       String server = null;
@@ -88,7 +91,8 @@ public class ServerClient {
     }
   }
 
-  public static void executeRaw(ClientContext context, ClientExec<ClientService.Client> exec) throws Exception {
+  public static void executeRaw(ClientContext context, ClientExec<ClientService.Client> exec)
+      throws Exception {
     while (true) {
       ClientService.Client client = null;
       String server = null;
@@ -110,37 +114,43 @@ public class ServerClient {
 
   static volatile boolean warnedAboutTServersBeingDown = false;
 
-  public static Pair<String,ClientService.Client> getConnection(ClientContext context) throws TTransportException {
+  public static Pair<String,ClientService.Client> getConnection(ClientContext context)
+      throws TTransportException {
     return getConnection(context, true);
   }
 
-  public static Pair<String,ClientService.Client> getConnection(ClientContext context, boolean preferCachedConnections) throws TTransportException {
+  public static Pair<String,ClientService.Client> getConnection(ClientContext context,
+      boolean preferCachedConnections) throws TTransportException {
     return getConnection(context, preferCachedConnections, context.getClientTimeoutInMillis());
   }
 
-  public static Pair<String,ClientService.Client> getConnection(ClientContext context, boolean preferCachedConnections, long rpcTimeout)
-      throws TTransportException {
+  public static Pair<String,ClientService.Client> getConnection(ClientContext context,
+      boolean preferCachedConnections, long rpcTimeout) throws TTransportException {
     checkArgument(context != null, "context is null");
     // create list of servers
     ArrayList<ThriftTransportKey> servers = new ArrayList<>();
 
     // add tservers
     Instance instance = context.getInstance();
-    ZooCache zc = new ZooCacheFactory().getZooCache(instance.getZooKeepers(), instance.getZooKeepersSessionTimeOut());
+    ZooCache zc = new ZooCacheFactory().getZooCache(instance.getZooKeepers(),
+        instance.getZooKeepersSessionTimeOut());
     for (String tserver : zc.getChildren(ZooUtil.getRoot(instance) + Constants.ZTSERVERS)) {
       String path = ZooUtil.getRoot(instance) + Constants.ZTSERVERS + "/" + tserver;
       byte[] data = ZooUtil.getLockData(zc, path);
       if (data != null) {
         String strData = new String(data, UTF_8);
         if (!strData.equals("master"))
-          servers.add(new ThriftTransportKey(new ServerServices(strData).getAddress(Service.TSERV_CLIENT), rpcTimeout, context));
+          servers.add(new ThriftTransportKey(
+              new ServerServices(strData).getAddress(Service.TSERV_CLIENT), rpcTimeout, context));
       }
     }
 
     boolean opened = false;
     try {
-      Pair<String,TTransport> pair = ThriftTransportPool.getInstance().getAnyTransport(servers, preferCachedConnections);
-      ClientService.Client client = ThriftUtil.createClient(new ClientService.Client.Factory(), pair.getSecond());
+      Pair<String,TTransport> pair = ThriftTransportPool.getInstance().getAnyTransport(servers,
+          preferCachedConnections);
+      ClientService.Client client = ThriftUtil.createClient(new ClientService.Client.Factory(),
+          pair.getSecond());
       opened = true;
       warnedAboutTServersBeingDown = false;
       return new Pair<>(pair.getFirst(), client);
@@ -159,7 +169,8 @@ public class ServerClient {
   }
 
   public static void close(ClientService.Client client) {
-    if (client != null && client.getInputProtocol() != null && client.getInputProtocol().getTransport() != null) {
+    if (client != null && client.getInputProtocol() != null
+        && client.getInputProtocol().getTransport() != null) {
       ThriftTransportPool.getInstance().returnTransport(client.getInputProtocol().getTransport());
     } else {
       log.debug("Attempt to close null connection to a server", new Exception());
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/SyncingTabletLocator.java b/core/src/main/java/org/apache/accumulo/core/client/impl/SyncingTabletLocator.java
index 9275a1e..271afc3 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/SyncingTabletLocator.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/SyncingTabletLocator.java
@@ -32,8 +32,9 @@ import org.apache.hadoop.io.Text;
 import org.apache.log4j.Logger;
 
 /**
- * Syncs itself with the static collection of TabletLocators, so that when the server clears it, it will automatically get the most up-to-date version. Caching
- * TabletLocators locally is safe when using SyncingTabletLocator.
+ * Syncs itself with the static collection of TabletLocators, so that when the server clears it, it
+ * will automatically get the most up-to-date version. Caching TabletLocators locally is safe when
+ * using SyncingTabletLocator.
  */
 public class SyncingTabletLocator extends TabletLocator {
   private static final Logger log = Logger.getLogger(SyncingTabletLocator.class);
@@ -76,20 +77,22 @@ public class SyncingTabletLocator extends TabletLocator {
   }
 
   @Override
-  public TabletLocation locateTablet(ClientContext context, Text row, boolean skipRow, boolean retry) throws AccumuloException, AccumuloSecurityException,
-      TableNotFoundException {
+  public TabletLocation locateTablet(ClientContext context, Text row, boolean skipRow,
+      boolean retry) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     return syncLocator().locateTablet(context, row, skipRow, retry);
   }
 
   @Override
-  public <T extends Mutation> void binMutations(ClientContext context, List<T> mutations, Map<String,TabletServerMutations<T>> binnedMutations, List<T> failures)
+  public <T extends Mutation> void binMutations(ClientContext context, List<T> mutations,
+      Map<String,TabletServerMutations<T>> binnedMutations, List<T> failures)
       throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     syncLocator().binMutations(context, mutations, binnedMutations, failures);
   }
 
   @Override
-  public List<Range> binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges) throws AccumuloException,
-      AccumuloSecurityException, TableNotFoundException {
+  public List<Range> binRanges(ClientContext context, List<Range> ranges,
+      Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     return syncLocator().binRanges(context, ranges, binnedRanges);
   }
 
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/TableMap.java b/core/src/main/java/org/apache/accumulo/core/client/impl/TableMap.java
index 3f3d90c..8bd2db3 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/TableMap.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/TableMap.java
@@ -75,7 +75,8 @@ public class TableMap {
               namespaceIdToNameMap.put(namespaceId, namespaceName);
             }
           } catch (NamespaceNotFoundException e) {
-            log.error("Table (" + tableId + ") contains reference to namespace (" + namespaceId + ") that doesn't exist", e);
+            log.error("Table (" + tableId + ") contains reference to namespace (" + namespaceId
+                + ") that doesn't exist", e);
             continue;
           }
         }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/TableOperationsHelper.java b/core/src/main/java/org/apache/accumulo/core/client/impl/TableOperationsHelper.java
index a81241a..baf53ef 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/TableOperationsHelper.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/TableOperationsHelper.java
@@ -36,19 +36,22 @@ import org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope;
 public abstract class TableOperationsHelper implements TableOperations {
 
   @Override
-  public void attachIterator(String tableName, IteratorSetting setting) throws AccumuloSecurityException, AccumuloException, TableNotFoundException {
+  public void attachIterator(String tableName, IteratorSetting setting)
+      throws AccumuloSecurityException, AccumuloException, TableNotFoundException {
     attachIterator(tableName, setting, EnumSet.allOf(IteratorScope.class));
   }
 
   @Override
-  public void attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloSecurityException, AccumuloException,
-      TableNotFoundException {
+  public void attachIterator(String tableName, IteratorSetting setting,
+      EnumSet<IteratorScope> scopes)
+      throws AccumuloSecurityException, AccumuloException, TableNotFoundException {
     checkArgument(tableName != null, "tableName is null");
     checkArgument(setting != null, "setting is null");
     checkArgument(scopes != null, "scopes is null");
     checkIteratorConflicts(tableName, setting, scopes);
     for (IteratorScope scope : scopes) {
-      String root = String.format("%s%s.%s", Property.TABLE_ITERATOR_PREFIX, scope.name().toLowerCase(), setting.getName());
+      String root = String.format("%s%s.%s", Property.TABLE_ITERATOR_PREFIX,
+          scope.name().toLowerCase(), setting.getName());
       for (Entry<String,String> prop : setting.getOptions().entrySet()) {
         this.setProperty(tableName, root + ".opt." + prop.getKey(), prop.getValue());
       }
@@ -57,14 +60,15 @@ public abstract class TableOperationsHelper implements TableOperations {
   }
 
   @Override
-  public void removeIterator(String tableName, String name, EnumSet<IteratorScope> scopes) throws AccumuloSecurityException, AccumuloException,
-      TableNotFoundException {
+  public void removeIterator(String tableName, String name, EnumSet<IteratorScope> scopes)
+      throws AccumuloSecurityException, AccumuloException, TableNotFoundException {
     Map<String,String> copy = new TreeMap<>();
     for (Entry<String,String> property : this.getProperties(tableName)) {
       copy.put(property.getKey(), property.getValue());
     }
     for (IteratorScope scope : scopes) {
-      String root = String.format("%s%s.%s", Property.TABLE_ITERATOR_PREFIX, scope.name().toLowerCase(), name);
+      String root = String.format("%s%s.%s", Property.TABLE_ITERATOR_PREFIX,
+          scope.name().toLowerCase(), name);
       for (Entry<String,String> property : copy.entrySet()) {
         if (property.getKey().equals(root) || property.getKey().startsWith(root + ".opt."))
           this.removeProperty(tableName, property.getKey());
@@ -73,8 +77,8 @@ public abstract class TableOperationsHelper implements TableOperations {
   }
 
   @Override
-  public IteratorSetting getIteratorSetting(String tableName, String name, IteratorScope scope) throws AccumuloSecurityException, AccumuloException,
-      TableNotFoundException {
+  public IteratorSetting getIteratorSetting(String tableName, String name, IteratorScope scope)
+      throws AccumuloSecurityException, AccumuloException, TableNotFoundException {
     checkArgument(tableName != null, "tableName is null");
     checkArgument(name != null, "name is null");
     checkArgument(scope != null, "scope is null");
@@ -82,7 +86,8 @@ public abstract class TableOperationsHelper implements TableOperations {
     String classname = null;
     Map<String,String> settings = new HashMap<>();
 
-    String root = String.format("%s%s.%s", Property.TABLE_ITERATOR_PREFIX, scope.name().toLowerCase(), name);
+    String root = String.format("%s%s.%s", Property.TABLE_ITERATOR_PREFIX,
+        scope.name().toLowerCase(), name);
     String opt = root + ".opt.";
     for (Entry<String,String> property : this.getProperties(tableName)) {
       if (property.getKey().equals(root)) {
@@ -103,7 +108,8 @@ public abstract class TableOperationsHelper implements TableOperations {
   }
 
   @Override
-  public Map<String,EnumSet<IteratorScope>> listIterators(String tableName) throws AccumuloSecurityException, AccumuloException, TableNotFoundException {
+  public Map<String,EnumSet<IteratorScope>> listIterators(String tableName)
+      throws AccumuloSecurityException, AccumuloException, TableNotFoundException {
     Map<String,EnumSet<IteratorScope>> result = new TreeMap<>();
     for (Entry<String,String> property : this.getProperties(tableName)) {
       String name = property.getKey();
@@ -121,49 +127,57 @@ public abstract class TableOperationsHelper implements TableOperations {
   }
 
   @Override
-  public void checkIteratorConflicts(String tableName, IteratorSetting setting, EnumSet<IteratorScope> scopes) throws AccumuloException, TableNotFoundException {
+  public void checkIteratorConflicts(String tableName, IteratorSetting setting,
+      EnumSet<IteratorScope> scopes) throws AccumuloException, TableNotFoundException {
     checkArgument(tableName != null, "tableName is null");
     checkArgument(setting != null, "setting is null");
     checkArgument(scopes != null, "scopes is null");
     for (IteratorScope scope : scopes) {
-      String scopeStr = String.format("%s%s", Property.TABLE_ITERATOR_PREFIX, scope.name().toLowerCase());
+      String scopeStr = String.format("%s%s", Property.TABLE_ITERATOR_PREFIX,
+          scope.name().toLowerCase());
       String nameStr = String.format("%s.%s", scopeStr, setting.getName());
       String optStr = String.format("%s.opt.", nameStr);
       Map<String,String> optionConflicts = new TreeMap<>();
       for (Entry<String,String> property : this.getProperties(tableName)) {
         if (property.getKey().startsWith(scopeStr)) {
           if (property.getKey().equals(nameStr))
-            throw new AccumuloException(new IllegalArgumentException("iterator name conflict for " + setting.getName() + ": " + property.getKey() + "="
-                + property.getValue()));
+            throw new AccumuloException(new IllegalArgumentException("iterator name conflict for "
+                + setting.getName() + ": " + property.getKey() + "=" + property.getValue()));
           if (property.getKey().startsWith(optStr))
             optionConflicts.put(property.getKey(), property.getValue());
           if (property.getKey().contains(".opt."))
             continue;
           String parts[] = property.getValue().split(",");
           if (parts.length != 2)
-            throw new AccumuloException("Bad value for existing iterator setting: " + property.getKey() + "=" + property.getValue());
+            throw new AccumuloException("Bad value for existing iterator setting: "
+                + property.getKey() + "=" + property.getValue());
           try {
             if (Integer.parseInt(parts[0]) == setting.getPriority())
-              throw new AccumuloException(new IllegalArgumentException("iterator priority conflict: " + property.getKey() + "=" + property.getValue()));
+              throw new AccumuloException(new IllegalArgumentException(
+                  "iterator priority conflict: " + property.getKey() + "=" + property.getValue()));
           } catch (NumberFormatException e) {
-            throw new AccumuloException("Bad value for existing iterator setting: " + property.getKey() + "=" + property.getValue());
+            throw new AccumuloException("Bad value for existing iterator setting: "
+                + property.getKey() + "=" + property.getValue());
           }
         }
       }
       if (optionConflicts.size() > 0)
-        throw new AccumuloException(new IllegalArgumentException("iterator options conflict for " + setting.getName() + ": " + optionConflicts));
+        throw new AccumuloException(new IllegalArgumentException(
+            "iterator options conflict for " + setting.getName() + ": " + optionConflicts));
     }
   }
 
   @Override
-  public int addConstraint(String tableName, String constraintClassName) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+  public int addConstraint(String tableName, String constraintClassName)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     TreeSet<Integer> constraintNumbers = new TreeSet<>();
     TreeMap<String,Integer> constraintClasses = new TreeMap<>();
     int i;
     for (Entry<String,String> property : this.getProperties(tableName)) {
       if (property.getKey().startsWith(Property.TABLE_CONSTRAINT_PREFIX.toString())) {
         try {
-          i = Integer.parseInt(property.getKey().substring(Property.TABLE_CONSTRAINT_PREFIX.toString().length()));
+          i = Integer.parseInt(
+              property.getKey().substring(Property.TABLE_CONSTRAINT_PREFIX.toString().length()));
         } catch (NumberFormatException e) {
           throw new AccumuloException("Bad key for existing constraint: " + property.toString());
         }
@@ -175,27 +189,32 @@ public abstract class TableOperationsHelper implements TableOperations {
     while (constraintNumbers.contains(i))
       i++;
     if (constraintClasses.containsKey(constraintClassName))
-      throw new AccumuloException("Constraint " + constraintClassName + " already exists for table " + tableName + " with number "
-          + constraintClasses.get(constraintClassName));
-    this.setProperty(tableName, Property.TABLE_CONSTRAINT_PREFIX.toString() + i, constraintClassName);
+      throw new AccumuloException("Constraint " + constraintClassName + " already exists for table "
+          + tableName + " with number " + constraintClasses.get(constraintClassName));
+    this.setProperty(tableName, Property.TABLE_CONSTRAINT_PREFIX.toString() + i,
+        constraintClassName);
     return i;
   }
 
   @Override
-  public void removeConstraint(String tableName, int number) throws AccumuloException, AccumuloSecurityException {
+  public void removeConstraint(String tableName, int number)
+      throws AccumuloException, AccumuloSecurityException {
     this.removeProperty(tableName, Property.TABLE_CONSTRAINT_PREFIX.toString() + number);
   }
 
   @Override
-  public Map<String,Integer> listConstraints(String tableName) throws AccumuloException, TableNotFoundException {
+  public Map<String,Integer> listConstraints(String tableName)
+      throws AccumuloException, TableNotFoundException {
     Map<String,Integer> constraints = new TreeMap<>();
     for (Entry<String,String> property : this.getProperties(tableName)) {
       if (property.getKey().startsWith(Property.TABLE_CONSTRAINT_PREFIX.toString())) {
         if (constraints.containsKey(property.getValue()))
-          throw new AccumuloException("Same constraint configured twice: " + property.getKey() + "=" + Property.TABLE_CONSTRAINT_PREFIX
-              + constraints.get(property.getValue()) + "=" + property.getKey());
+          throw new AccumuloException("Same constraint configured twice: " + property.getKey() + "="
+              + Property.TABLE_CONSTRAINT_PREFIX + constraints.get(property.getValue()) + "="
+              + property.getKey());
         try {
-          constraints.put(property.getValue(), Integer.parseInt(property.getKey().substring(Property.TABLE_CONSTRAINT_PREFIX.toString().length())));
+          constraints.put(property.getValue(), Integer.parseInt(
+              property.getKey().substring(Property.TABLE_CONSTRAINT_PREFIX.toString().length())));
         } catch (NumberFormatException e) {
           throw new AccumuloException("Bad key for existing constraint: " + property.toString());
         }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/TableOperationsImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/TableOperationsImpl.java
index cc43b1d..9632cc0 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/TableOperationsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/TableOperationsImpl.java
@@ -150,12 +150,13 @@ public class TableOperationsImpl extends TableOperationsHelper {
       timer = new OpTimer().start();
     }
 
-    TreeSet<String> tableNames = new TreeSet<>(Tables.getNameToIdMap(context.getInstance()).keySet());
+    TreeSet<String> tableNames = new TreeSet<>(
+        Tables.getNameToIdMap(context.getInstance()).keySet());
 
     if (timer != null) {
       timer.stop();
-      log.trace("tid={} Fetched {} table names in {}", Thread.currentThread().getId(), tableNames.size(),
-          String.format("%.3f secs", timer.scale(TimeUnit.SECONDS)));
+      log.trace("tid={} Fetched {} table names in {}", Thread.currentThread().getId(),
+          tableNames.size(), String.format("%.3f secs", timer.scale(TimeUnit.SECONDS)));
     }
 
     return tableNames;
@@ -178,26 +179,30 @@ public class TableOperationsImpl extends TableOperationsHelper {
 
     if (timer != null) {
       timer.stop();
-      log.trace("tid={} Checked existance of {} in {}", Thread.currentThread().getId(), exists, String.format("%.3f secs", timer.scale(TimeUnit.SECONDS)));
+      log.trace("tid={} Checked existance of {} in {}", Thread.currentThread().getId(), exists,
+          String.format("%.3f secs", timer.scale(TimeUnit.SECONDS)));
     }
 
     return exists;
   }
 
   @Override
-  public void create(String tableName) throws AccumuloException, AccumuloSecurityException, TableExistsException {
+  public void create(String tableName)
+      throws AccumuloException, AccumuloSecurityException, TableExistsException {
     create(tableName, new NewTableConfiguration());
   }
 
   @Override
   @Deprecated
-  public void create(String tableName, boolean limitVersion) throws AccumuloException, AccumuloSecurityException, TableExistsException {
+  public void create(String tableName, boolean limitVersion)
+      throws AccumuloException, AccumuloSecurityException, TableExistsException {
     create(tableName, limitVersion, TimeType.MILLIS);
   }
 
   @Override
   @Deprecated
-  public void create(String tableName, boolean limitVersion, TimeType timeType) throws AccumuloException, AccumuloSecurityException, TableExistsException {
+  public void create(String tableName, boolean limitVersion, TimeType timeType)
+      throws AccumuloException, AccumuloSecurityException, TableExistsException {
     checkArgument(tableName != null, "tableName is null");
     checkArgument(timeType != null, "timeType is null");
 
@@ -210,16 +215,19 @@ public class TableOperationsImpl extends TableOperationsHelper {
   }
 
   @Override
-  public void create(String tableName, NewTableConfiguration ntc) throws AccumuloException, AccumuloSecurityException, TableExistsException {
+  public void create(String tableName, NewTableConfiguration ntc)
+      throws AccumuloException, AccumuloSecurityException, TableExistsException {
     checkArgument(tableName != null, "tableName is null");
     checkArgument(ntc != null, "ntc is null");
 
-    List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(tableName.getBytes(UTF_8)), ByteBuffer.wrap(ntc.getTimeType().name().getBytes(UTF_8)));
+    List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(tableName.getBytes(UTF_8)),
+        ByteBuffer.wrap(ntc.getTimeType().name().getBytes(UTF_8)));
 
     Map<String,String> opts = ntc.getProperties();
 
     try {
-      doTableFateOperation(tableName, AccumuloException.class, FateOperation.TABLE_CREATE, args, opts);
+      doTableFateOperation(tableName, AccumuloException.class, FateOperation.TABLE_CREATE, args,
+          opts);
     } catch (TableNotFoundException e) {
       // should not happen
       throw new AssertionError(e);
@@ -241,14 +249,17 @@ public class TableOperationsImpl extends TableOperationsHelper {
     }
   }
 
-  // This method is for retrying in the case of network failures; anything else it passes to the caller to deal with
-  private void executeFateOperation(long opid, FateOperation op, List<ByteBuffer> args, Map<String,String> opts, boolean autoCleanUp)
+  // This method is for retrying in the case of network failures; anything else it passes to the
+  // caller to deal with
+  private void executeFateOperation(long opid, FateOperation op, List<ByteBuffer> args,
+      Map<String,String> opts, boolean autoCleanUp)
       throws ThriftSecurityException, TException, ThriftTableOperationException {
     while (true) {
       MasterClientService.Iface client = null;
       try {
         client = MasterClient.getConnectionWithRetry(context);
-        client.executeFateOperation(Tracer.traceInfo(), context.rpcCreds(), opid, op, args, opts, autoCleanUp);
+        client.executeFateOperation(Tracer.traceInfo(), context.rpcCreds(), opid, op, args, opts,
+            autoCleanUp);
         break;
       } catch (TTransportException tte) {
         log.debug("Failed to call executeFateOperation(), retrying ... ", tte);
@@ -259,7 +270,8 @@ public class TableOperationsImpl extends TableOperationsHelper {
     }
   }
 
-  private String waitForFateOperation(long opid) throws ThriftSecurityException, TException, ThriftTableOperationException {
+  private String waitForFateOperation(long opid)
+      throws ThriftSecurityException, TException, ThriftTableOperationException {
     while (true) {
       MasterClientService.Iface client = null;
       try {
@@ -290,13 +302,17 @@ public class TableOperationsImpl extends TableOperationsHelper {
     }
   }
 
-  String doFateOperation(FateOperation op, List<ByteBuffer> args, Map<String,String> opts, String tableOrNamespaceName) throws AccumuloSecurityException,
-      TableExistsException, TableNotFoundException, AccumuloException, NamespaceExistsException, NamespaceNotFoundException {
+  String doFateOperation(FateOperation op, List<ByteBuffer> args, Map<String,String> opts,
+      String tableOrNamespaceName)
+      throws AccumuloSecurityException, TableExistsException, TableNotFoundException,
+      AccumuloException, NamespaceExistsException, NamespaceNotFoundException {
     return doFateOperation(op, args, opts, tableOrNamespaceName, true);
   }
 
-  String doFateOperation(FateOperation op, List<ByteBuffer> args, Map<String,String> opts, String tableOrNamespaceName, boolean wait)
-      throws AccumuloSecurityException, TableExistsException, TableNotFoundException, AccumuloException, NamespaceExistsException, NamespaceNotFoundException {
+  String doFateOperation(FateOperation op, List<ByteBuffer> args, Map<String,String> opts,
+      String tableOrNamespaceName, boolean wait)
+      throws AccumuloSecurityException, TableExistsException, TableNotFoundException,
+      AccumuloException, NamespaceExistsException, NamespaceNotFoundException {
     Long opid = null;
 
     try {
@@ -311,11 +327,14 @@ public class TableOperationsImpl extends TableOperationsHelper {
     } catch (ThriftSecurityException e) {
       switch (e.getCode()) {
         case TABLE_DOESNT_EXIST:
-          throw new TableNotFoundException(null, tableOrNamespaceName, "Target table does not exist");
+          throw new TableNotFoundException(null, tableOrNamespaceName,
+              "Target table does not exist");
         case NAMESPACE_DOESNT_EXIST:
-          throw new NamespaceNotFoundException(null, tableOrNamespaceName, "Target namespace does not exist");
+          throw new NamespaceNotFoundException(null, tableOrNamespaceName,
+              "Target namespace does not exist");
         default:
-          String tableInfo = Tables.getPrintableTableInfoFromName(context.getInstance(), tableOrNamespaceName);
+          String tableInfo = Tables.getPrintableTableInfoFromName(context.getInstance(),
+              tableOrNamespaceName);
           throw new AccumuloSecurityException(e.user, e.code, tableInfo, e);
       }
     } catch (ThriftTableOperationException e) {
@@ -329,7 +348,8 @@ public class TableOperationsImpl extends TableOperationsHelper {
         case NAMESPACE_NOTFOUND:
           throw new NamespaceNotFoundException(e);
         case OFFLINE:
-          throw new TableOfflineException(context.getInstance(), Tables.getTableId(context.getInstance(), tableOrNamespaceName));
+          throw new TableOfflineException(context.getInstance(),
+              Tables.getTableId(context.getInstance(), tableOrNamespaceName));
         default:
           throw new AccumuloException(e.description, e);
       }
@@ -354,7 +374,8 @@ public class TableOperationsImpl extends TableOperationsHelper {
     private CountDownLatch latch;
     private AtomicReference<Throwable> exception;
 
-    SplitEnv(String tableName, String tableId, ExecutorService executor, CountDownLatch latch, AtomicReference<Throwable> exception) {
+    SplitEnv(String tableName, String tableId, ExecutorService executor, CountDownLatch latch,
+        AtomicReference<Throwable> exception) {
       this.tableName = tableName;
       this.tableId = tableId;
       this.executor = executor;
@@ -388,7 +409,8 @@ public class TableOperationsImpl extends TableOperationsHelper {
 
         int mid = splits.size() / 2;
 
-        // split the middle split point to ensure that child task split different tablets and can therefore
+        // split the middle split point to ensure that child task split different tablets and can
+        // therefore
         // run in parallel
         addSplits(env.tableName, new TreeSet<>(splits.subList(mid, mid + 1)), env.tableId);
         env.latch.countDown();
@@ -404,7 +426,8 @@ public class TableOperationsImpl extends TableOperationsHelper {
   }
 
   @Override
-  public void addSplits(String tableName, SortedSet<Text> partitionKeys) throws TableNotFoundException, AccumuloException, AccumuloSecurityException {
+  public void addSplits(String tableName, SortedSet<Text> partitionKeys)
+      throws TableNotFoundException, AccumuloException, AccumuloSecurityException {
     String tableId = Tables.getTableId(context.getInstance(), tableName);
 
     List<Text> splits = new ArrayList<>(partitionKeys);
@@ -415,26 +438,32 @@ public class TableOperationsImpl extends TableOperationsHelper {
     CountDownLatch latch = new CountDownLatch(splits.size());
     AtomicReference<Throwable> exception = new AtomicReference<>(null);
 
-    ExecutorService executor = Executors.newFixedThreadPool(16, new NamingThreadFactory("addSplits"));
+    ExecutorService executor = Executors.newFixedThreadPool(16,
+        new NamingThreadFactory("addSplits"));
     try {
-      executor.execute(new SplitTask(new SplitEnv(tableName, tableId, executor, latch, exception), splits));
+      executor.execute(
+          new SplitTask(new SplitEnv(tableName, tableId, executor, latch, exception), splits));
 
       while (!latch.await(100, TimeUnit.MILLISECONDS)) {
         if (exception.get() != null) {
           executor.shutdownNow();
           Throwable excep = exception.get();
-          // Below all exceptions are wrapped and rethrown. This is done so that the user knows what code path got them here. If the wrapping was not done, the
+          // Below all exceptions are wrapped and rethrown. This is done so that the user knows what
+          // code path got them here. If the wrapping was not done, the
           // user would only have the stack trace for the background thread.
           if (excep instanceof TableNotFoundException) {
             TableNotFoundException tnfe = (TableNotFoundException) excep;
-            throw new TableNotFoundException(tableId, tableName, "Table not found by background thread", tnfe);
+            throw new TableNotFoundException(tableId, tableName,
+                "Table not found by background thread", tnfe);
           } else if (excep instanceof TableOfflineException) {
-            log.debug("TableOfflineException occurred in background thread. Throwing new exception", excep);
+            log.debug("TableOfflineException occurred in background thread. Throwing new exception",
+                excep);
             throw new TableOfflineException(context.getInstance(), tableId);
           } else if (excep instanceof AccumuloSecurityException) {
             // base == background accumulo security exception
             AccumuloSecurityException base = (AccumuloSecurityException) excep;
-            throw new AccumuloSecurityException(base.getUser(), base.asThriftException().getCode(), base.getTableInfo(), excep);
+            throw new AccumuloSecurityException(base.getUser(), base.asThriftException().getCode(),
+                base.getTableInfo(), excep);
           } else if (excep instanceof AccumuloServerException) {
             throw new AccumuloServerException((AccumuloServerException) excep);
           } else if (excep instanceof Error) {
@@ -451,8 +480,9 @@ public class TableOperationsImpl extends TableOperationsHelper {
     }
   }
 
-  private void addSplits(String tableName, SortedSet<Text> partitionKeys, String tableId) throws AccumuloException, AccumuloSecurityException,
-      TableNotFoundException, AccumuloServerException {
+  private void addSplits(String tableName, SortedSet<Text> partitionKeys, String tableId)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException,
+      AccumuloServerException {
     TabletLocator tabLocator = TabletLocator.getLocator(context, tableId);
 
     for (Text split : partitionKeys) {
@@ -486,18 +516,21 @@ public class TableOperationsImpl extends TableOperationsHelper {
             OpTimer timer = null;
 
             if (log.isTraceEnabled()) {
-              log.trace("tid={} Splitting tablet {} on {} at {}", Thread.currentThread().getId(), tl.tablet_extent, address, split);
+              log.trace("tid={} Splitting tablet {} on {} at {}", Thread.currentThread().getId(),
+                  tl.tablet_extent, address, split);
               timer = new OpTimer().start();
             }
 
-            client.splitTablet(Tracer.traceInfo(), context.rpcCreds(), tl.tablet_extent.toThrift(), TextUtil.getByteBuffer(split));
+            client.splitTablet(Tracer.traceInfo(), context.rpcCreds(), tl.tablet_extent.toThrift(),
+                TextUtil.getByteBuffer(split));
 
             // just split it, might as well invalidate it in the cache
             tabLocator.invalidateCache(tl.tablet_extent);
 
             if (timer != null) {
               timer.stop();
-              log.trace("Split tablet in {}", String.format("%.3f secs", timer.scale(TimeUnit.SECONDS)));
+              log.trace("Split tablet in {}",
+                  String.format("%.3f secs", timer.scale(TimeUnit.SECONDS)));
             }
 
           } finally {
@@ -518,7 +551,9 @@ public class TableOperationsImpl extends TableOperationsHelper {
           // Do not silently spin when we repeatedly fail to get the location for a tablet
           locationFailures++;
           if (5 == locationFailures || 0 == locationFailures % 50) {
-            log.warn("Having difficulty locating hosting tabletserver for split {} on table {}. Seen {} failures.", split, tableName, locationFailures);
+            log.warn(
+                "Having difficulty locating hosting tabletserver for split {} on table {}. Seen {} failures.",
+                split, tableName, locationFailures);
           }
 
           tabLocator.invalidateCache(tl.tablet_extent);
@@ -534,15 +569,18 @@ public class TableOperationsImpl extends TableOperationsHelper {
   }
 
   @Override
-  public void merge(String tableName, Text start, Text end) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+  public void merge(String tableName, Text start, Text end)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
 
     checkArgument(tableName != null, "tableName is null");
     ByteBuffer EMPTY = ByteBuffer.allocate(0);
-    List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(tableName.getBytes(UTF_8)), start == null ? EMPTY : TextUtil.getByteBuffer(start),
+    List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(tableName.getBytes(UTF_8)),
+        start == null ? EMPTY : TextUtil.getByteBuffer(start),
         end == null ? EMPTY : TextUtil.getByteBuffer(end));
     Map<String,String> opts = new HashMap<>();
     try {
-      doTableFateOperation(tableName, TableNotFoundException.class, FateOperation.TABLE_MERGE, args, opts);
+      doTableFateOperation(tableName, TableNotFoundException.class, FateOperation.TABLE_MERGE, args,
+          opts);
     } catch (TableExistsException e) {
       // should not happen
       throw new AssertionError(e);
@@ -550,15 +588,18 @@ public class TableOperationsImpl extends TableOperationsHelper {
   }
 
   @Override
-  public void deleteRows(String tableName, Text start, Text end) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+  public void deleteRows(String tableName, Text start, Text end)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
 
     checkArgument(tableName != null, "tableName is null");
     ByteBuffer EMPTY = ByteBuffer.allocate(0);
-    List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(tableName.getBytes(UTF_8)), start == null ? EMPTY : TextUtil.getByteBuffer(start),
+    List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(tableName.getBytes(UTF_8)),
+        start == null ? EMPTY : TextUtil.getByteBuffer(start),
         end == null ? EMPTY : TextUtil.getByteBuffer(end));
     Map<String,String> opts = new HashMap<>();
     try {
-      doTableFateOperation(tableName, TableNotFoundException.class, FateOperation.TABLE_DELETE_RANGE, args, opts);
+      doTableFateOperation(tableName, TableNotFoundException.class,
+          FateOperation.TABLE_DELETE_RANGE, args, opts);
     } catch (TableExistsException e) {
       // should not happen
       throw new AssertionError(e);
@@ -566,7 +607,8 @@ public class TableOperationsImpl extends TableOperationsHelper {
   }
 
   @Override
-  public Collection<Text> listSplits(String tableName) throws TableNotFoundException, AccumuloSecurityException {
+  public Collection<Text> listSplits(String tableName)
+      throws TableNotFoundException, AccumuloSecurityException {
 
     checkArgument(tableName != null, "tableName is null");
 
@@ -616,7 +658,8 @@ public class TableOperationsImpl extends TableOperationsHelper {
   }
 
   @Override
-  public Collection<Text> listSplits(String tableName, int maxSplits) throws TableNotFoundException, AccumuloSecurityException {
+  public Collection<Text> listSplits(String tableName, int maxSplits)
+      throws TableNotFoundException, AccumuloSecurityException {
     Collection<Text> endRows = listSplits(tableName);
 
     if (endRows.size() <= maxSplits)
@@ -651,14 +694,16 @@ public class TableOperationsImpl extends TableOperationsHelper {
   }
 
   @Override
-  public void delete(String tableName) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+  public void delete(String tableName)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     checkArgument(tableName != null, "tableName is null");
 
     List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(tableName.getBytes(UTF_8)));
     Map<String,String> opts = new HashMap<>();
 
     try {
-      doTableFateOperation(tableName, TableNotFoundException.class, FateOperation.TABLE_DELETE, args, opts);
+      doTableFateOperation(tableName, TableNotFoundException.class, FateOperation.TABLE_DELETE,
+          args, opts);
     } catch (TableExistsException e) {
       // should not happen
       throw new AssertionError(e);
@@ -667,8 +712,10 @@ public class TableOperationsImpl extends TableOperationsHelper {
   }
 
   @Override
-  public void clone(String srcTableName, String newTableName, boolean flush, Map<String,String> propertiesToSet, Set<String> propertiesToExclude)
-      throws AccumuloSecurityException, TableNotFoundException, AccumuloException, TableExistsException {
+  public void clone(String srcTableName, String newTableName, boolean flush,
+      Map<String,String> propertiesToSet, Set<String> propertiesToExclude)
+      throws AccumuloSecurityException, TableNotFoundException, AccumuloException,
+      TableExistsException {
 
     checkArgument(srcTableName != null, "srcTableName is null");
     checkArgument(newTableName != null, "newTableName is null");
@@ -684,7 +731,8 @@ public class TableOperationsImpl extends TableOperationsHelper {
     if (propertiesToSet == null)
       propertiesToSet = Collections.emptyMap();
 
-    List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(srcTableId.getBytes(UTF_8)), ByteBuffer.wrap(newTableName.getBytes(UTF_8)));
+    List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(srcTableId.getBytes(UTF_8)),
+        ByteBuffer.wrap(newTableName.getBytes(UTF_8)));
     Map<String,String> opts = new HashMap<>();
     for (Entry<String,String> entry : propertiesToSet.entrySet()) {
       if (entry.getKey().startsWith(CLONE_EXCLUDE_PREFIX))
@@ -696,16 +744,19 @@ public class TableOperationsImpl extends TableOperationsHelper {
       opts.put(CLONE_EXCLUDE_PREFIX + prop, "");
     }
 
-    doTableFateOperation(newTableName, AccumuloException.class, FateOperation.TABLE_CLONE, args, opts);
+    doTableFateOperation(newTableName, AccumuloException.class, FateOperation.TABLE_CLONE, args,
+        opts);
   }
 
   @Override
-  public void rename(String oldTableName, String newTableName) throws AccumuloSecurityException, TableNotFoundException, AccumuloException,
-      TableExistsException {
+  public void rename(String oldTableName, String newTableName) throws AccumuloSecurityException,
+      TableNotFoundException, AccumuloException, TableExistsException {
 
-    List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(oldTableName.getBytes(UTF_8)), ByteBuffer.wrap(newTableName.getBytes(UTF_8)));
+    List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(oldTableName.getBytes(UTF_8)),
+        ByteBuffer.wrap(newTableName.getBytes(UTF_8)));
     Map<String,String> opts = new HashMap<>();
-    doTableFateOperation(oldTableName, TableNotFoundException.class, FateOperation.TABLE_RENAME, args, opts);
+    doTableFateOperation(oldTableName, TableNotFoundException.class, FateOperation.TABLE_RENAME,
+        args, opts);
   }
 
   @Override
@@ -719,7 +770,8 @@ public class TableOperationsImpl extends TableOperationsHelper {
   }
 
   @Override
-  public void flush(String tableName, Text start, Text end, boolean wait) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+  public void flush(String tableName, Text start, Text end, boolean wait)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     checkArgument(tableName != null, "tableName is null");
 
     String tableId = Tables.getTableId(context.getInstance(), tableName);
@@ -727,19 +779,22 @@ public class TableOperationsImpl extends TableOperationsHelper {
   }
 
   @Override
-  public void compact(String tableName, Text start, Text end, boolean flush, boolean wait) throws AccumuloSecurityException, TableNotFoundException,
-      AccumuloException {
+  public void compact(String tableName, Text start, Text end, boolean flush, boolean wait)
+      throws AccumuloSecurityException, TableNotFoundException, AccumuloException {
     compact(tableName, start, end, new ArrayList<IteratorSetting>(), flush, wait);
   }
 
   @Override
-  public void compact(String tableName, Text start, Text end, List<IteratorSetting> iterators, boolean flush, boolean wait) throws AccumuloSecurityException,
-      TableNotFoundException, AccumuloException {
-    compact(tableName, new CompactionConfig().setStartRow(start).setEndRow(end).setIterators(iterators).setFlush(flush).setWait(wait));
+  public void compact(String tableName, Text start, Text end, List<IteratorSetting> iterators,
+      boolean flush, boolean wait)
+      throws AccumuloSecurityException, TableNotFoundException, AccumuloException {
+    compact(tableName, new CompactionConfig().setStartRow(start).setEndRow(end)
+        .setIterators(iterators).setFlush(flush).setWait(wait));
   }
 
   @Override
-  public void compact(String tableName, CompactionConfig config) throws AccumuloSecurityException, TableNotFoundException, AccumuloException {
+  public void compact(String tableName, CompactionConfig config)
+      throws AccumuloSecurityException, TableNotFoundException, AccumuloException {
     checkArgument(tableName != null, "tableName is null");
     ByteBuffer EMPTY = ByteBuffer.allocate(0);
 
@@ -754,9 +809,12 @@ public class TableOperationsImpl extends TableOperationsHelper {
 
     // Make sure the specified compaction strategy exists on a tabletserver
     final String compactionStrategyName = config.getCompactionStrategy().getClassName();
-    if (!CompactionStrategyConfigUtil.DEFAULT_STRATEGY.getClassName().equals(compactionStrategyName)) {
-      if (!testClassLoad(tableName, compactionStrategyName, "org.apache.accumulo.tserver.compaction.CompactionStrategy")) {
-        throw new AccumuloException("TabletServer could not load CompactionStrategy class " + compactionStrategyName);
+    if (!CompactionStrategyConfigUtil.DEFAULT_STRATEGY.getClassName()
+        .equals(compactionStrategyName)) {
+      if (!testClassLoad(tableName, compactionStrategyName,
+          "org.apache.accumulo.tserver.compaction.CompactionStrategy")) {
+        throw new AccumuloException(
+            "TabletServer could not load CompactionStrategy class " + compactionStrategyName);
       }
     }
 
@@ -768,9 +826,11 @@ public class TableOperationsImpl extends TableOperationsHelper {
     if (config.getFlush())
       _flush(tableId, start, end, true);
 
-    List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(tableId.getBytes(UTF_8)), start == null ? EMPTY : TextUtil.getByteBuffer(start), end == null ? EMPTY
-        : TextUtil.getByteBuffer(end), ByteBuffer.wrap(IteratorUtil.encodeIteratorSettings(config.getIterators())), ByteBuffer
-        .wrap(CompactionStrategyConfigUtil.encode(config.getCompactionStrategy())));
+    List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(tableId.getBytes(UTF_8)),
+        start == null ? EMPTY : TextUtil.getByteBuffer(start),
+        end == null ? EMPTY : TextUtil.getByteBuffer(end),
+        ByteBuffer.wrap(IteratorUtil.encodeIteratorSettings(config.getIterators())),
+        ByteBuffer.wrap(CompactionStrategyConfigUtil.encode(config.getCompactionStrategy())));
 
     Map<String,String> opts = new HashMap<>();
     try {
@@ -787,14 +847,16 @@ public class TableOperationsImpl extends TableOperationsHelper {
   }
 
   @Override
-  public void cancelCompaction(String tableName) throws AccumuloSecurityException, TableNotFoundException, AccumuloException {
+  public void cancelCompaction(String tableName)
+      throws AccumuloSecurityException, TableNotFoundException, AccumuloException {
     String tableId = Tables.getTableId(context.getInstance(), tableName);
 
     List<ByteBuffer> args = Arrays.asList(ByteBuffer.wrap(tableId.getBytes(UTF_8)));
 
     Map<String,String> opts = new HashMap<>();
     try {
-      doTableFateOperation(tableName, TableNotFoundException.class, FateOperation.TABLE_CANCEL_COMPACT, args, opts);
+      doTableFateOperation(tableName, TableNotFoundException.class,
+          FateOperation.TABLE_CANCEL_COMPACT, args, opts);
     } catch (TableExistsException e) {
       // should not happen
       throw new AssertionError(e);
@@ -802,12 +864,14 @@ public class TableOperationsImpl extends TableOperationsHelper {
 
   }
 
-  private void _flush(String tableId, Text start, Text end, boolean wait) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+  private void _flush(String tableId, Text start, Text end, boolean wait)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
 
     try {
       long flushID;
 
-      // used to pass the table name. but the tableid associated with a table name could change between calls.
+      // used to pass the table name. but the tableid associated with a table name could change
+      // between calls.
       // so pass the tableid to both calls
 
       while (true) {
@@ -828,7 +892,8 @@ public class TableOperationsImpl extends TableOperationsHelper {
         MasterClientService.Iface client = null;
         try {
           client = MasterClient.getConnectionWithRetry(context);
-          client.waitForFlush(Tracer.traceInfo(), context.rpcCreds(), tableId, TextUtil.getByteBuffer(start), TextUtil.getByteBuffer(end), flushID,
+          client.waitForFlush(Tracer.traceInfo(), context.rpcCreds(), tableId,
+              TextUtil.getByteBuffer(start), TextUtil.getByteBuffer(end), flushID,
               wait ? Long.MAX_VALUE : 1);
           break;
         } catch (TTransportException tte) {
@@ -859,7 +924,8 @@ public class TableOperationsImpl extends TableOperationsHelper {
   }
 
   @Override
-  public void setProperty(final String tableName, final String property, final String value) throws AccumuloException, AccumuloSecurityException {
+  public void setProperty(final String tableName, final String property, final String value)
+      throws AccumuloException, AccumuloSecurityException {
     checkArgument(tableName != null, "tableName is null");
     checkArgument(property != null, "property is null");
     checkArgument(value != null, "value is null");
@@ -867,7 +933,8 @@ public class TableOperationsImpl extends TableOperationsHelper {
       MasterClient.executeTable(context, new ClientExec<MasterClientService.Client>() {
         @Override
         public void execute(MasterClientService.Client client) throws Exception {
-          client.setTableProperty(Tracer.traceInfo(), context.rpcCreds(), tableName, property, value);
+          client.setTableProperty(Tracer.traceInfo(), context.rpcCreds(), tableName, property,
+              value);
         }
       });
     } catch (TableNotFoundException e) {
@@ -876,7 +943,8 @@ public class TableOperationsImpl extends TableOperationsHelper {
   }
 
   @Override
-  public void removeProperty(final String tableName, final String property) throws AccumuloException, AccumuloSecurityException {
+  public void removeProperty(final String tableName, final String property)
+      throws AccumuloException, AccumuloSecurityException {
     checkArgument(tableName != null, "tableName is null");
     checkArgument(property != null, "property is null");
     try {
@@ -892,15 +960,18 @@ public class TableOperationsImpl extends TableOperationsHelper {
   }
 
   @Override
-  public Iterable<Entry<String,String>> getProperties(final String tableName) throws AccumuloException, TableNotFoundException {
+  public Iterable<Entry<String,String>> getProperties(final String tableName)
+      throws AccumuloException, TableNotFoundException {
     checkArgument(tableName != null, "tableName is null");
     try {
-      return ServerClient.executeRaw(context, new ClientExecReturn<Map<String,String>,ClientService.Client>() {
-        @Override
-        public Map<String,String> execute(ClientService.Client client) throws Exception {
-          return client.getTableConfiguration(Tracer.traceInfo(), context.rpcCreds(), tableName);
-        }
-      }).entrySet();
+      return ServerClient
+          .executeRaw(context, new ClientExecReturn<Map<String,String>,ClientService.Client>() {
+            @Override
+            public Map<String,String> execute(ClientService.Client client) throws Exception {
+              return client.getTableConfiguration(Tracer.traceInfo(), context.rpcCreds(),
+                  tableName);
+            }
+          }).entrySet();
     } catch (ThriftTableOperationException e) {
       switch (e.getType()) {
         case NOTFOUND:
@@ -919,13 +990,15 @@ public class TableOperationsImpl extends TableOperationsHelper {
   }
 
   @Override
-  public void setLocalityGroups(String tableName, Map<String,Set<Text>> groups) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+  public void setLocalityGroups(String tableName, Map<String,Set<Text>> groups)
+      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
     // ensure locality groups do not overlap
     HashSet<Text> all = new HashSet<>();
     for (Entry<String,Set<Text>> entry : groups.entrySet()) {
 
       if (!Collections.disjoint(all, entry.getValue())) {
-        throw new IllegalArgumentException("Group " + entry.getKey() + " overlaps with another group");
+        throw new IllegalArgumentException(
+            "Group " + entry.getKey() + " overlaps with another group");
       }
 
       all.addAll(entry.getValue());
@@ -938,7 +1011,8 @@ public class TableOperationsImpl extends TableOperationsHelper {
... 111203 lines suppressed ...

-- 
To stop receiving notification emails like this one, please contact
ctubbsii@apache.org.