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 2022/06/14 07:47:09 UTC

[accumulo] branch main updated: Trivial: Use https in more places (#2774)

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

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


The following commit(s) were added to refs/heads/main by this push:
     new cf57e343de Trivial: Use https in more places (#2774)
cf57e343de is described below

commit cf57e343de77f416de10c22e0ed05ef37f433b36
Author: Christopher Tubbs <ct...@apache.org>
AuthorDate: Tue Jun 14 03:47:04 2022 -0400

    Trivial: Use https in more places (#2774)
    
    * Update license header template to use https (this has been discussed
      at length on the legal mailing list and elsewhere, and is an
      acceptable URL to reference the license text that the rat plugin has
      been made to support)
    * Update to rat 0.14 to support https
    * Find other uses of http and replace with https unless it breaks a link
      or is a namespace identifier or other situation where http is required
    * Use the standardized format of the license header text for the
      markdown files and gitignore files
    * Update the gitignore files to sync with each other, so they all
      suppress the same IDE files
    * Remove unneeded CHECKSTYLE:ON comment in Accumulo.java
    * Remove redundant license header in WholeColumnFamilyIteratorTest
    
    * Apply automated changes from updating contrib/license-header.txt
---
 .asf.yaml                                          |  2 +-
 .github/CONTRIBUTING.md                            | 32 ++++++++++---------
 .github/ISSUE_TEMPLATE/post_vote_checklist.md      |  2 +-
 .github/workflows/maven-full-its.yaml              |  2 +-
 .github/workflows/maven-on-demand.yaml             |  2 +-
 .github/workflows/maven.yaml                       |  2 +-
 .github/workflows/scripts.yaml                     |  2 +-
 .gitignore                                         | 32 ++++++++++---------
 DEPENDENCIES                                       | 28 +++++++++--------
 NOTICE                                             |  2 +-
 README.md                                          | 32 ++++++++++---------
 TESTING.md                                         | 32 ++++++++++---------
 assemble/.gitignore                                | 32 +++++++++++--------
 assemble/bin/accumulo                              |  2 +-
 assemble/bin/accumulo-cluster                      |  2 +-
 assemble/bin/accumulo-service                      |  2 +-
 assemble/bin/accumulo-util                         |  2 +-
 assemble/build.sh                                  |  2 +-
 assemble/conf/accumulo-env.sh                      |  2 +-
 assemble/conf/accumulo.properties                  |  2 +-
 assemble/conf/log4j2-service.properties            |  2 +-
 assemble/conf/log4j2.properties                    |  2 +-
 assemble/pom.xml                                   |  2 +-
 assemble/src/main/assemblies/binary-release.xml    |  4 +--
 assemble/src/main/assemblies/component.xml         |  4 +--
 assemble/src/main/resources/NOTICE                 |  2 +-
 assemble/src/main/scripts/create-jshell.sh         |  2 +-
 contrib/Eclipse-Accumulo-Codestyle.xml             |  2 +-
 contrib/ci/find-unapproved-chars.sh                |  2 +-
 contrib/ci/find-unapproved-junit.sh                |  2 +-
 contrib/ci/install-shfmt.sh                        |  2 +-
 contrib/ci/it-matrix.sh                            |  2 +-
 contrib/ci/run-shellcheck.sh                       |  2 +-
 contrib/ci/run-shfmt.sh                            |  2 +-
 contrib/license-header.txt                         |  2 +-
 contrib/scripts/check-tservers.py                  |  2 +-
 core/.gitignore                                    | 32 +++++++++++--------
 core/pom.xml                                       |  2 +-
 .../apache/accumulo/core/FilteredConstants.java    |  2 +-
 .../java/org/apache/accumulo/core/Constants.java   |  2 +-
 .../accumulo/core/bloomfilter/BloomFilter.java     |  2 +-
 .../core/bloomfilter/DynamicBloomFilter.java       |  2 +-
 .../accumulo/core/classloader/ClassLoaderUtil.java |  2 +-
 .../DefaultContextClassLoaderFactory.java          |  2 +-
 .../org/apache/accumulo/core/cli/ClientOpts.java   |  2 +-
 .../org/apache/accumulo/core/cli/ConfigOpts.java   |  2 +-
 .../java/org/apache/accumulo/core/cli/Help.java    |  2 +-
 .../org/apache/accumulo/core/client/Accumulo.java  | 21 ++++++-------
 .../accumulo/core/client/AccumuloClient.java       |  2 +-
 .../accumulo/core/client/AccumuloException.java    |  2 +-
 .../core/client/AccumuloSecurityException.java     |  2 +-
 .../apache/accumulo/core/client/BatchDeleter.java  |  2 +-
 .../apache/accumulo/core/client/BatchScanner.java  |  2 +-
 .../apache/accumulo/core/client/BatchWriter.java   |  2 +-
 .../accumulo/core/client/BatchWriterConfig.java    |  2 +-
 .../accumulo/core/client/ClientConfiguration.java  |  2 +-
 .../core/client/ClientSideIteratorScanner.java     |  2 +-
 .../accumulo/core/client/ConditionalWriter.java    |  2 +-
 .../core/client/ConditionalWriterConfig.java       |  2 +-
 .../org/apache/accumulo/core/client/Connector.java |  2 +-
 .../apache/accumulo/core/client/Durability.java    |  2 +-
 .../org/apache/accumulo/core/client/Instance.java  |  2 +-
 .../accumulo/core/client/IsolatedScanner.java      |  2 +-
 .../accumulo/core/client/IteratorSetting.java      |  2 +-
 .../core/client/MultiTableBatchWriter.java         |  2 +-
 .../core/client/MutationsRejectedException.java    |  2 +-
 .../core/client/NamespaceExistsException.java      |  2 +-
 .../core/client/NamespaceNotEmptyException.java    |  2 +-
 .../core/client/NamespaceNotFoundException.java    |  2 +-
 .../accumulo/core/client/PluginEnvironment.java    |  2 +-
 .../apache/accumulo/core/client/RowIterator.java   |  2 +-
 .../core/client/SampleNotPresentException.java     |  2 +-
 .../org/apache/accumulo/core/client/Scanner.java   |  2 +-
 .../apache/accumulo/core/client/ScannerBase.java   |  2 +-
 .../core/client/TableDeletedException.java         |  2 +-
 .../accumulo/core/client/TableExistsException.java |  2 +-
 .../core/client/TableNotFoundException.java        |  2 +-
 .../core/client/TableOfflineException.java         |  2 +-
 .../accumulo/core/client/TimedOutException.java    |  2 +-
 .../accumulo/core/client/ZooKeeperInstance.java    |  2 +-
 .../core/client/admin/ActiveCompaction.java        |  2 +-
 .../accumulo/core/client/admin/ActiveScan.java     |  2 +-
 .../core/client/admin/CloneConfiguration.java      |  2 +-
 .../core/client/admin/CompactionConfig.java        |  2 +-
 .../client/admin/CompactionStrategyConfig.java     |  2 +-
 .../core/client/admin/DelegationTokenConfig.java   |  2 +-
 .../accumulo/core/client/admin/DiskUsage.java      |  2 +-
 .../apache/accumulo/core/client/admin/FindMax.java |  2 +-
 .../core/client/admin/InitialTableState.java       |  2 +-
 .../core/client/admin/InstanceOperations.java      |  2 +-
 .../accumulo/core/client/admin/Locations.java      |  2 +-
 .../core/client/admin/NamespaceOperations.java     |  2 +-
 .../core/client/admin/NewTableConfiguration.java   |  2 +-
 .../accumulo/core/client/admin/PluginConfig.java   |  2 +-
 .../core/client/admin/ReplicationOperations.java   |  2 +-
 .../accumulo/core/client/admin/ScanState.java      |  2 +-
 .../accumulo/core/client/admin/ScanType.java       |  2 +-
 .../core/client/admin/SecurityOperations.java      |  2 +-
 .../core/client/admin/SummaryRetriever.java        |  2 +-
 .../core/client/admin/TableOperations.java         |  2 +-
 .../accumulo/core/client/admin/TimeType.java       |  2 +-
 .../client/admin/compaction/CompactableFile.java   |  2 +-
 .../admin/compaction/CompactionConfigurer.java     |  2 +-
 .../admin/compaction/CompactionSelector.java       |  2 +-
 .../admin/compaction/CompressionConfigurer.java    |  2 +-
 .../admin/compaction/TooManyDeletesSelector.java   |  3 +-
 .../core/client/lexicoder/AbstractEncoder.java     |  2 +-
 .../core/client/lexicoder/AbstractLexicoder.java   |  2 +-
 .../core/client/lexicoder/BigIntegerLexicoder.java |  2 +-
 .../core/client/lexicoder/BytesLexicoder.java      |  2 +-
 .../core/client/lexicoder/DateLexicoder.java       |  2 +-
 .../core/client/lexicoder/DoubleLexicoder.java     |  2 +-
 .../accumulo/core/client/lexicoder/Encoder.java    |  2 +-
 .../core/client/lexicoder/FloatLexicoder.java      |  2 +-
 .../core/client/lexicoder/IntegerLexicoder.java    |  2 +-
 .../accumulo/core/client/lexicoder/Lexicoder.java  |  2 +-
 .../core/client/lexicoder/ListLexicoder.java       |  2 +-
 .../core/client/lexicoder/LongLexicoder.java       |  2 +-
 .../core/client/lexicoder/PairLexicoder.java       |  2 +-
 .../core/client/lexicoder/ReverseLexicoder.java    |  2 +-
 .../core/client/lexicoder/SequenceLexicoder.java   |  2 +-
 .../core/client/lexicoder/StringLexicoder.java     |  2 +-
 .../core/client/lexicoder/TextLexicoder.java       |  2 +-
 .../core/client/lexicoder/UIntegerLexicoder.java   |  2 +-
 .../core/client/lexicoder/ULongLexicoder.java      |  2 +-
 .../core/client/lexicoder/UUIDLexicoder.java       |  4 +--
 .../core/client/mapred/AbstractInputFormat.java    |  2 +-
 .../client/mapred/AccumuloFileOutputFormat.java    |  2 +-
 .../core/client/mapred/AccumuloInputFormat.java    |  2 +-
 .../mapred/AccumuloMultiTableInputFormat.java      |  2 +-
 .../core/client/mapred/AccumuloOutputFormat.java   |  2 +-
 .../core/client/mapred/AccumuloRowInputFormat.java |  2 +-
 .../core/client/mapred/InputFormatBase.java        |  2 +-
 .../core/client/mapred/RangeInputSplit.java        |  2 +-
 .../core/client/mapreduce/AbstractInputFormat.java |  2 +-
 .../client/mapreduce/AccumuloFileOutputFormat.java |  2 +-
 .../core/client/mapreduce/AccumuloInputFormat.java |  2 +-
 .../mapreduce/AccumuloMultiTableInputFormat.java   |  2 +-
 .../client/mapreduce/AccumuloOutputFormat.java     |  2 +-
 .../client/mapreduce/AccumuloRowInputFormat.java   |  2 +-
 .../core/client/mapreduce/InputFormatBase.java     |  2 +-
 .../core/client/mapreduce/InputTableConfig.java    |  2 +-
 .../core/client/mapreduce/RangeInputSplit.java     |  2 +-
 .../lib/partition/KeyRangePartitioner.java         |  2 +-
 .../mapreduce/lib/partition/RangePartitioner.java  |  2 +-
 .../client/replication/PeerExistsException.java    |  2 +-
 .../client/replication/PeerNotFoundException.java  |  2 +-
 .../accumulo/core/client/rfile/FSConfArgs.java     |  2 +-
 .../apache/accumulo/core/client/rfile/RFile.java   |  2 +-
 .../accumulo/core/client/rfile/RFileScanner.java   |  2 +-
 .../core/client/rfile/RFileScannerBuilder.java     |  2 +-
 .../accumulo/core/client/rfile/RFileSource.java    |  2 +-
 .../core/client/rfile/RFileSummariesRetriever.java |  2 +-
 .../accumulo/core/client/rfile/RFileWriter.java    |  2 +-
 .../core/client/rfile/RFileWriterBuilder.java      |  2 +-
 .../core/client/sample/AbstractHashSampler.java    |  2 +-
 .../core/client/sample/RowColumnSampler.java       |  2 +-
 .../accumulo/core/client/sample/RowSampler.java    |  2 +-
 .../accumulo/core/client/sample/Sampler.java       |  2 +-
 .../core/client/sample/SamplerConfiguration.java   |  2 +-
 .../core/client/security/SecurityErrorCode.java    |  2 +-
 .../security/tokens/AuthenticationToken.java       |  2 +-
 .../security/tokens/CredentialProviderToken.java   |  2 +-
 .../client/security/tokens/DelegationToken.java    |  2 +-
 .../core/client/security/tokens/KerberosToken.java |  2 +-
 .../core/client/security/tokens/NullToken.java     |  2 +-
 .../core/client/security/tokens/PasswordToken.java |  2 +-
 .../core/client/summary/CounterSummary.java        |  2 +-
 .../core/client/summary/CountingSummarizer.java    |  2 +-
 .../accumulo/core/client/summary/Summarizer.java   |  2 +-
 .../client/summary/SummarizerConfiguration.java    |  2 +-
 .../accumulo/core/client/summary/Summary.java      |  2 +-
 .../summarizers/AuthorizationSummarizer.java       |  2 +-
 .../summary/summarizers/DeletesSummarizer.java     |  2 +-
 .../summary/summarizers/EntryLengthSummarizer.java |  2 +-
 .../summary/summarizers/FamilySummarizer.java      |  2 +-
 .../summary/summarizers/VisibilitySummarizer.java  |  2 +-
 .../AcceptableThriftTableOperationException.java   |  2 +-
 .../clientImpl/AccumuloBulkMergeException.java     |  2 +-
 .../core/clientImpl/AccumuloServerException.java   |  2 +-
 .../core/clientImpl/ActiveCompactionImpl.java      |  2 +-
 .../accumulo/core/clientImpl/ActiveScanImpl.java   |  2 +-
 .../clientImpl/AuthenticationTokenIdentifier.java  |  2 +-
 .../accumulo/core/clientImpl/BatchWriterImpl.java  |  2 +-
 .../core/clientImpl/ClientConfConverter.java       |  2 +-
 .../accumulo/core/clientImpl/ClientContext.java    |  2 +-
 .../accumulo/core/clientImpl/ClientInfo.java       |  2 +-
 .../accumulo/core/clientImpl/ClientInfoImpl.java   |  2 +-
 .../core/clientImpl/CloneConfigurationImpl.java    |  2 +-
 .../clientImpl/CompactionStrategyConfigUtil.java   |  2 +-
 .../core/clientImpl/CompressedIterators.java       |  2 +-
 .../core/clientImpl/ConditionalWriterImpl.java     |  2 +-
 .../accumulo/core/clientImpl/ConnectorImpl.java    |  2 +-
 .../accumulo/core/clientImpl/Credentials.java      |  2 +-
 .../DelegationTokenConfigSerializer.java           |  2 +-
 .../core/clientImpl/DelegationTokenImpl.java       |  2 +-
 .../accumulo/core/clientImpl/DurabilityImpl.java   |  2 +-
 .../core/clientImpl/InstanceOperationsImpl.java    |  2 +-
 .../core/clientImpl/IsolationException.java        |  2 +-
 .../core/clientImpl/MultiTableBatchWriterImpl.java |  2 +-
 .../apache/accumulo/core/clientImpl/Namespace.java |  2 +-
 .../core/clientImpl/NamespaceOperationsHelper.java |  2 +-
 .../core/clientImpl/NamespaceOperationsImpl.java   |  2 +-
 .../accumulo/core/clientImpl/Namespaces.java       |  2 +-
 .../accumulo/core/clientImpl/OfflineIterator.java  |  2 +-
 .../accumulo/core/clientImpl/OfflineScanner.java   |  2 +-
 .../core/clientImpl/ReplicationOperationsImpl.java |  2 +-
 .../core/clientImpl/RootTabletLocator.java         |  2 +-
 .../accumulo/core/clientImpl/ScannerImpl.java      |  2 +-
 .../accumulo/core/clientImpl/ScannerIterator.java  |  2 +-
 .../accumulo/core/clientImpl/ScannerOptions.java   |  2 +-
 .../core/clientImpl/SecurityOperationsImpl.java    |  2 +-
 .../core/clientImpl/SyncingTabletLocator.java      |  2 +-
 .../core/clientImpl/TableOperationsHelper.java     |  2 +-
 .../core/clientImpl/TableOperationsImpl.java       |  2 +-
 .../accumulo/core/clientImpl/TabletLocator.java    |  2 +-
 .../core/clientImpl/TabletLocatorImpl.java         |  2 +-
 .../core/clientImpl/TabletServerBatchDeleter.java  |  2 +-
 .../core/clientImpl/TabletServerBatchReader.java   |  2 +-
 .../TabletServerBatchReaderIterator.java           |  2 +-
 .../core/clientImpl/TabletServerBatchWriter.java   |  2 +-
 .../accumulo/core/clientImpl/TabletType.java       |  2 +-
 .../accumulo/core/clientImpl/ThriftScanner.java    |  2 +-
 .../core/clientImpl/ThriftTransportKey.java        |  2 +-
 .../core/clientImpl/ThriftTransportPool.java       |  2 +-
 .../core/clientImpl/TimeoutTabletLocator.java      |  2 +-
 .../core/clientImpl/UserCompactionUtils.java       |  2 +-
 .../apache/accumulo/core/clientImpl/Writer.java    |  2 +-
 .../core/clientImpl/ZookeeperLockChecker.java      |  2 +-
 .../apache/accumulo/core/clientImpl/bulk/Bulk.java |  2 +-
 .../accumulo/core/clientImpl/bulk/BulkImport.java  |  2 +-
 .../core/clientImpl/bulk/BulkSerialize.java        |  2 +-
 .../clientImpl/bulk/ConcurrentKeyExtentCache.java  |  2 +-
 .../core/clientImpl/bulk/LoadMappingIterator.java  |  2 +-
 .../core/clientImpl/lexicoder/ByteUtils.java       |  2 +-
 .../lexicoder/FixedByteArrayOutputStream.java      |  2 +-
 .../core/clientImpl/mapred/BatchInputSplit.java    |  2 +-
 .../core/clientImpl/mapreduce/BatchInputSplit.java |  2 +-
 .../clientImpl/mapreduce/DelegationTokenStub.java  |  2 +-
 .../core/clientImpl/mapreduce/SplitUtils.java      |  2 +-
 .../clientImpl/mapreduce/lib/ConfiguratorBase.java |  2 +-
 .../mapreduce/lib/DistributedCacheHelper.java      |  2 +-
 .../mapreduce/lib/FileOutputConfigurator.java      |  2 +-
 .../mapreduce/lib/InputConfigurator.java           |  2 +-
 .../mapreduce/lib/OutputConfigurator.java          |  2 +-
 .../core/compaction/CompactionSettings.java        |  2 +-
 .../apache/accumulo/core/compaction/NullType.java  |  2 +-
 .../accumulo/core/compaction/PatternType.java      |  2 +-
 .../apache/accumulo/core/compaction/SizeType.java  |  2 +-
 .../accumulo/core/compaction/StringType.java       |  2 +-
 .../org/apache/accumulo/core/compaction/Type.java  |  2 +-
 .../apache/accumulo/core/compaction/UIntType.java  |  2 +-
 .../accumulo/core/conf/AccumuloConfiguration.java  |  2 +-
 .../accumulo/core/conf/ClientConfigGenerate.java   |  4 +--
 .../apache/accumulo/core/conf/ClientProperty.java  |  2 +-
 .../apache/accumulo/core/conf/ConfigCheckUtil.java |  2 +-
 .../accumulo/core/conf/ConfigurationCopy.java      |  2 +-
 .../accumulo/core/conf/ConfigurationDocGen.java    |  2 +-
 .../core/conf/ConfigurationTypeHelper.java         |  2 +-
 .../accumulo/core/conf/DefaultConfiguration.java   |  2 +-
 .../accumulo/core/conf/DeprecatedPropertyUtil.java |  2 +-
 .../apache/accumulo/core/conf/Experimental.java    |  2 +-
 .../core/conf/HadoopCredentialProvider.java        |  2 +-
 .../org/apache/accumulo/core/conf/Property.java    |  2 +-
 .../apache/accumulo/core/conf/PropertyType.java    |  2 +-
 .../org/apache/accumulo/core/conf/ReplacedBy.java  |  2 +-
 .../org/apache/accumulo/core/conf/Sensitive.java   |  2 +-
 .../accumulo/core/conf/SiteConfiguration.java      |  2 +-
 .../core/conf/cluster/ClusterConfigParser.java     |  2 +-
 .../accumulo/core/constraints/Constraint.java      |  2 +-
 .../core/constraints/DefaultKeySizeConstraint.java |  2 +-
 .../core/constraints/NoDeleteConstraint.java       |  2 +-
 .../accumulo/core/constraints/Violations.java      |  2 +-
 .../core/constraints/VisibilityConstraint.java     |  2 +-
 .../core/crypto/CryptoEnvironmentImpl.java         |  2 +-
 .../accumulo/core/crypto/CryptoServiceFactory.java |  2 +-
 .../apache/accumulo/core/crypto/CryptoUtils.java   |  2 +-
 .../core/crypto/streams/BlockedInputStream.java    |  2 +-
 .../core/crypto/streams/BlockedOutputStream.java   |  2 +-
 .../crypto/streams/DiscardCloseOutputStream.java   |  2 +-
 .../core/crypto/streams/NoFlushOutputStream.java   |  2 +-
 .../crypto/streams/RFileCipherOutputStream.java    |  2 +-
 .../org/apache/accumulo/core/data/AbstractId.java  |  2 +-
 .../accumulo/core/data/ArrayByteSequence.java      |  2 +-
 .../apache/accumulo/core/data/ByteSequence.java    |  2 +-
 .../java/org/apache/accumulo/core/data/Column.java |  2 +-
 .../apache/accumulo/core/data/ColumnUpdate.java    |  2 +-
 .../org/apache/accumulo/core/data/Condition.java   |  2 +-
 .../accumulo/core/data/ConditionalMutation.java    |  2 +-
 .../core/data/ConstraintViolationSummary.java      |  2 +-
 .../org/apache/accumulo/core/data/InstanceId.java  |  2 +-
 .../java/org/apache/accumulo/core/data/Key.java    |  2 +-
 .../org/apache/accumulo/core/data/KeyBuilder.java  |  2 +-
 .../org/apache/accumulo/core/data/KeyValue.java    |  2 +-
 .../org/apache/accumulo/core/data/LoadPlan.java    |  2 +-
 .../org/apache/accumulo/core/data/Mutation.java    |  2 +-
 .../org/apache/accumulo/core/data/NamespaceId.java |  2 +-
 .../org/apache/accumulo/core/data/PartialKey.java  |  2 +-
 .../java/org/apache/accumulo/core/data/Range.java  |  2 +-
 .../org/apache/accumulo/core/data/TableId.java     |  2 +-
 .../org/apache/accumulo/core/data/TabletId.java    |  2 +-
 .../java/org/apache/accumulo/core/data/Value.java  |  2 +-
 .../accumulo/core/data/constraints/Constraint.java |  2 +-
 .../data/constraints/DefaultKeySizeConstraint.java |  2 +-
 .../core/data/constraints/NoDeleteConstraint.java  |  2 +-
 .../data/constraints/VisibilityConstraint.java     |  2 +-
 .../data/doc-files/mutation-serialization.html     |  2 +-
 .../accumulo/core/dataImpl/ComparableBytes.java    |  2 +-
 .../apache/accumulo/core/dataImpl/KeyExtent.java   |  2 +-
 .../accumulo/core/dataImpl/TabletIdImpl.java       |  2 +-
 .../accumulo/core/file/BloomFilterLayer.java       |  2 +-
 .../accumulo/core/file/DispatchingFileFactory.java |  2 +-
 .../apache/accumulo/core/file/FileOperations.java  |  2 +-
 .../apache/accumulo/core/file/FileSKVIterator.java |  2 +-
 .../apache/accumulo/core/file/FileSKVWriter.java   |  2 +-
 .../core/file/NoSuchMetaStoreException.java        |  2 +-
 .../cache/impl/BlockCacheConfiguration.java        |  2 +-
 .../cache/impl/BlockCacheManagerFactory.java       |  2 +-
 .../core/file/blockfile/cache/impl/ClassSize.java  |  2 +-
 .../file/blockfile/cache/impl/SizeConstants.java   |  2 +-
 .../core/file/blockfile/cache/lru/CachedBlock.java |  2 +-
 .../file/blockfile/cache/lru/CachedBlockQueue.java |  2 +-
 .../core/file/blockfile/cache/lru/HeapSize.java    |  2 +-
 .../file/blockfile/cache/lru/LruBlockCache.java    |  2 +-
 .../cache/lru/LruBlockCacheConfiguration.java      |  2 +-
 .../blockfile/cache/lru/LruBlockCacheManager.java  |  2 +-
 .../cache/lru/SynchronousLoadingBlockCache.java    |  2 +-
 .../blockfile/cache/tinylfu/TinyLfuBlockCache.java |  6 ++--
 .../cache/tinylfu/TinyLfuBlockCacheManager.java    |  2 +-
 .../file/blockfile/impl/BasicCacheProvider.java    |  2 +-
 .../file/blockfile/impl/CachableBlockFile.java     |  2 +-
 .../core/file/blockfile/impl/CacheProvider.java    |  2 +-
 .../blockfile/impl/OpportunisticBlockCache.java    |  2 +-
 .../file/blockfile/impl/ScanCacheProvider.java     |  2 +-
 .../impl/SeekableByteArrayInputStream.java         |  2 +-
 .../core/file/keyfunctor/ColumnFamilyFunctor.java  |  2 +-
 .../file/keyfunctor/ColumnQualifierFunctor.java    |  2 +-
 .../accumulo/core/file/keyfunctor/KeyFunctor.java  |  2 +-
 .../accumulo/core/file/keyfunctor/RowFunctor.java  |  2 +-
 .../accumulo/core/file/map/MapFileOperations.java  |  2 +-
 .../apache/accumulo/core/file/map/MapFileUtil.java |  2 +-
 .../accumulo/core/file/rfile/BlockIndex.java       |  2 +-
 .../accumulo/core/file/rfile/CreateEmpty.java      |  2 +-
 .../accumulo/core/file/rfile/GenerateSplits.java   |  2 +-
 .../accumulo/core/file/rfile/IndexIterator.java    |  2 +-
 .../accumulo/core/file/rfile/KeyShortener.java     |  2 +-
 .../accumulo/core/file/rfile/MetricsGatherer.java  |  2 +-
 .../core/file/rfile/MultiIndexIterator.java        |  2 +-
 .../accumulo/core/file/rfile/MultiLevelIndex.java  |  2 +-
 .../apache/accumulo/core/file/rfile/PrintInfo.java |  2 +-
 .../org/apache/accumulo/core/file/rfile/RFile.java |  2 +-
 .../accumulo/core/file/rfile/RFileOperations.java  |  2 +-
 .../accumulo/core/file/rfile/RelativeKey.java      |  2 +-
 .../accumulo/core/file/rfile/RollingStats.java     |  4 +--
 .../accumulo/core/file/rfile/SplitLarge.java       |  2 +-
 .../core/file/rfile/VisMetricsGatherer.java        |  2 +-
 .../accumulo/core/file/rfile/VisibilityMetric.java |  2 +-
 .../accumulo/core/file/rfile/bcfile/BCFile.java    |  2 +-
 .../core/file/rfile/bcfile/Compression.java        |  2 +-
 .../file/rfile/bcfile/CompressionAlgorithm.java    |  2 +-
 .../core/file/rfile/bcfile/IdentityCodec.java      |  2 +-
 .../file/rfile/bcfile/MetaBlockAlreadyExists.java  |  2 +-
 .../file/rfile/bcfile/MetaBlockDoesNotExist.java   |  2 +-
 .../accumulo/core/file/rfile/bcfile/PrintInfo.java |  2 +-
 .../rfile/bcfile/SimpleBufferedOutputStream.java   |  2 +-
 .../accumulo/core/file/rfile/bcfile/Utils.java     |  2 +-
 .../file/streams/BoundedRangeFileInputStream.java  |  2 +-
 .../core/file/streams/RateLimitedInputStream.java  |  2 +-
 .../core/file/streams/RateLimitedOutputStream.java |  2 +-
 .../core/file/streams/SeekableDataInputStream.java |  2 +-
 .../org/apache/accumulo/core/gc/Reference.java     |  2 +-
 .../accumulo/core/gc/ReferenceDirectory.java       |  2 +-
 .../core/iterators/ColumnFamilyCounter.java        |  2 +-
 .../apache/accumulo/core/iterators/Combiner.java   |  2 +-
 .../accumulo/core/iterators/DebugIterator.java     |  2 +-
 .../apache/accumulo/core/iterators/DevNull.java    |  2 +-
 .../org/apache/accumulo/core/iterators/Filter.java |  2 +-
 .../core/iterators/FirstEntryInRowIterator.java    |  2 +-
 .../accumulo/core/iterators/IteratorAdapter.java   |  2 +-
 .../core/iterators/IteratorEnvironment.java        |  2 +-
 .../accumulo/core/iterators/IteratorUtil.java      |  2 +-
 .../accumulo/core/iterators/LongCombiner.java      |  2 +-
 .../accumulo/core/iterators/OptionDescriber.java   |  2 +-
 .../apache/accumulo/core/iterators/OrIterator.java |  2 +-
 .../accumulo/core/iterators/ServerFilter.java      |  2 +-
 .../core/iterators/ServerSkippingIterator.java     |  2 +-
 .../core/iterators/ServerWrappingIterator.java     |  2 +-
 .../accumulo/core/iterators/SkippingIterator.java  |  2 +-
 .../accumulo/core/iterators/SortedKeyIterator.java |  2 +-
 .../core/iterators/SortedKeyValueIterator.java     |  2 +-
 .../core/iterators/SynchronizedServerFilter.java   |  2 +-
 .../core/iterators/TypedValueCombiner.java         |  2 +-
 .../core/iterators/ValueFormatException.java       |  2 +-
 .../accumulo/core/iterators/WrappingIterator.java  |  2 +-
 .../accumulo/core/iterators/YieldCallback.java     |  2 +-
 .../core/iterators/YieldingKeyValueIterator.java   |  2 +-
 .../accumulo/core/iterators/user/AgeOffFilter.java |  2 +-
 .../core/iterators/user/BigDecimalCombiner.java    |  2 +-
 .../core/iterators/user/CfCqSliceFilter.java       |  2 +-
 .../core/iterators/user/CfCqSliceOpts.java         |  2 +-
 .../iterators/user/CfCqSliceSeekingFilter.java     |  2 +-
 .../core/iterators/user/ColumnAgeOffFilter.java    |  2 +-
 .../core/iterators/user/ColumnSliceFilter.java     |  2 +-
 .../accumulo/core/iterators/user/GrepIterator.java |  2 +-
 .../core/iterators/user/IndexedDocIterator.java    |  2 +-
 .../core/iterators/user/IntersectingIterator.java  |  2 +-
 .../core/iterators/user/LargeRowFilter.java        |  2 +-
 .../accumulo/core/iterators/user/MaxCombiner.java  |  2 +-
 .../accumulo/core/iterators/user/MinCombiner.java  |  2 +-
 .../accumulo/core/iterators/user/RegExFilter.java  |  2 +-
 .../accumulo/core/iterators/user/ReqVisFilter.java |  2 +-
 .../core/iterators/user/RowDeletingIterator.java   |  2 +-
 .../core/iterators/user/RowEncodingIterator.java   |  2 +-
 .../accumulo/core/iterators/user/RowFilter.java    |  2 +-
 .../core/iterators/user/SeekingFilter.java         |  2 +-
 .../core/iterators/user/SummingArrayCombiner.java  |  2 +-
 .../core/iterators/user/SummingCombiner.java       |  2 +-
 .../core/iterators/user/TimestampFilter.java       |  2 +-
 .../core/iterators/user/TransformingIterator.java  |  2 +-
 .../core/iterators/user/VersioningIterator.java    |  2 +-
 .../core/iterators/user/VisibilityFilter.java      |  2 +-
 .../iterators/user/WholeColumnFamilyIterator.java  |  2 +-
 .../core/iterators/user/WholeRowIterator.java      |  2 +-
 .../core/iteratorsImpl/IteratorBuilder.java        |  2 +-
 .../core/iteratorsImpl/IteratorBuilderImpl.java    |  2 +-
 .../core/iteratorsImpl/IteratorConfigUtil.java     |  2 +-
 .../core/iteratorsImpl/conf/ColumnSet.java         |  2 +-
 .../iteratorsImpl/conf/ColumnToClassMapping.java   |  2 +-
 .../core/iteratorsImpl/conf/ColumnUtil.java        |  2 +-
 .../system/ColumnFamilySkippingIterator.java       |  2 +-
 .../system/ColumnQualifierFilter.java              |  2 +-
 .../iteratorsImpl/system/CountingIterator.java     |  2 +-
 .../iteratorsImpl/system/DeletingIterator.java     |  2 +-
 .../core/iteratorsImpl/system/EmptyIterator.java   |  2 +-
 .../core/iteratorsImpl/system/HeapIterator.java    |  2 +-
 .../system/InterruptibleIterator.java              |  2 +-
 .../system/IterationInterruptedException.java      |  2 +-
 .../system/LocalityGroupIterator.java              |  2 +-
 .../core/iteratorsImpl/system/MapFileIterator.java |  2 +-
 .../core/iteratorsImpl/system/MultiIterator.java   |  2 +-
 .../core/iteratorsImpl/system/SampleIterator.java  |  2 +-
 .../iteratorsImpl/system/SequenceFileIterator.java |  2 +-
 .../iteratorsImpl/system/SortedMapIterator.java    |  2 +-
 .../system/SourceSwitchingIterator.java            |  2 +-
 .../core/iteratorsImpl/system/StatsIterator.java   |  2 +-
 .../iteratorsImpl/system/SynchronizedIterator.java |  2 +-
 .../iteratorsImpl/system/SystemIteratorUtil.java   |  2 +-
 .../iteratorsImpl/system/TimeSettingIterator.java  |  2 +-
 .../iteratorsImpl/system/VisibilityFilter.java     |  2 +-
 .../apache/accumulo/core/logging/FateLogger.java   |  3 +-
 .../org/apache/accumulo/core/logging/Logging.java  |  2 +-
 .../apache/accumulo/core/logging/TabletLogger.java |  2 +-
 .../apache/accumulo/core/logging/package-info.java |  2 +-
 .../manager/balancer/AssignmentParamsImpl.java     |  2 +-
 .../core/manager/balancer/BalanceParamsImpl.java   |  2 +-
 .../core/manager/balancer/TServerStatusImpl.java   |  2 +-
 .../core/manager/balancer/TableStatisticsImpl.java |  2 +-
 .../core/manager/balancer/TabletServerIdImpl.java  |  2 +-
 .../manager/balancer/TabletStatisticsImpl.java     |  2 +-
 .../core/manager/state/tables/TableState.java      |  2 +-
 .../core/metadata/CompactableFileImpl.java         |  2 +-
 .../core/metadata/MetadataLocationObtainer.java    |  2 +-
 .../accumulo/core/metadata/MetadataServicer.java   |  2 +-
 .../accumulo/core/metadata/MetadataTable.java      |  2 +-
 .../apache/accumulo/core/metadata/RootTable.java   |  2 +-
 .../core/metadata/ServicerForMetadataTable.java    |  2 +-
 .../core/metadata/ServicerForRootTable.java        |  2 +-
 .../core/metadata/ServicerForUserTables.java       |  2 +-
 .../accumulo/core/metadata/StoredTabletFile.java   |  2 +-
 .../accumulo/core/metadata/SuspendingTServer.java  |  2 +-
 .../accumulo/core/metadata/TServerInstance.java    |  2 +-
 .../core/metadata/TableMetadataServicer.java       |  2 +-
 .../accumulo/core/metadata/TabletDirectory.java    |  2 +-
 .../apache/accumulo/core/metadata/TabletFile.java  |  2 +-
 .../core/metadata/TabletLocationState.java         |  2 +-
 .../apache/accumulo/core/metadata/TabletState.java |  2 +-
 .../accumulo/core/metadata/ValidationUtil.java     |  2 +-
 .../accumulo/core/metadata/schema/Ample.java       |  2 +-
 .../accumulo/core/metadata/schema/AmpleImpl.java   |  2 +-
 .../core/metadata/schema/DataFileValue.java        |  2 +-
 .../schema/ExternalCompactionFinalState.java       |  2 +-
 .../core/metadata/schema/ExternalCompactionId.java |  2 +-
 .../schema/ExternalCompactionMetadata.java         |  2 +-
 .../core/metadata/schema/LinkingIterator.java      |  2 +-
 .../core/metadata/schema/MetadataSchema.java       |  2 +-
 .../core/metadata/schema/MetadataTime.java         |  2 +-
 .../core/metadata/schema/RootTabletMetadata.java   |  2 +-
 .../accumulo/core/metadata/schema/SortSkew.java    |  2 +-
 .../metadata/schema/TabletDeletedException.java    |  2 +-
 .../core/metadata/schema/TabletMetadata.java       |  2 +-
 .../core/metadata/schema/TabletsMetadata.java      |  2 +-
 .../core/metrics/MeterRegistryFactory.java         |  2 +-
 .../accumulo/core/metrics/MetricsProducer.java     |  2 +-
 .../apache/accumulo/core/metrics/MetricsUtil.java  |  2 +-
 .../accumulo/core/protobuf/ProtobufUtil.java       |  2 +-
 .../replication/AccumuloReplicationReplayer.java   |  2 +-
 .../replication/ReplicationConfigurationUtil.java  |  2 +-
 .../core/replication/ReplicationConstants.java     |  2 +-
 .../core/replication/ReplicationSchema.java        |  2 +-
 .../core/replication/ReplicationTable.java         |  2 +-
 .../ReplicationTableOfflineException.java          |  2 +-
 .../core/replication/ReplicationTarget.java        |  2 +-
 .../apache/accumulo/core/rpc/FilterTransport.java  |  2 +-
 .../rpc/ProtocolOverridingSSLSocketFactory.java    |  4 +--
 .../core/rpc/SaslClientDigestCallbackHandler.java  |  2 +-
 .../accumulo/core/rpc/SaslConnectionParams.java    |  2 +-
 .../core/rpc/SaslDigestCallbackHandler.java        |  2 +-
 .../accumulo/core/rpc/SslConnectionParams.java     |  2 +-
 .../apache/accumulo/core/rpc/TBufferedSocket.java  |  2 +-
 .../accumulo/core/rpc/TTimeoutTransport.java       |  2 +-
 .../org/apache/accumulo/core/rpc/ThriftUtil.java   |  2 +-
 .../accumulo/core/rpc/TraceProtocolFactory.java    |  2 +-
 .../accumulo/core/rpc/UGIAssumingTransport.java    |  2 +-
 .../core/rpc/UGIAssumingTransportFactory.java      |  2 +-
 .../rpc/clients/ClientServiceThriftClient.java     |  2 +-
 .../CompactionCoordinatorServiceThriftClient.java  |  2 +-
 .../rpc/clients/CompactorServiceThriftClient.java  |  2 +-
 .../core/rpc/clients/FateThriftClient.java         |  2 +-
 .../rpc/clients/GCMonitorServiceThriftClient.java  |  2 +-
 .../accumulo/core/rpc/clients/ManagerClient.java   |  2 +-
 .../core/rpc/clients/ManagerThriftClient.java      |  2 +-
 .../ReplicationCoordinatorThriftClient.java        |  2 +-
 .../clients/ReplicationServicerThriftClient.java   |  2 +-
 .../accumulo/core/rpc/clients/TServerClient.java   |  2 +-
 .../TabletScanClientServiceThriftClient.java       |  2 +-
 .../core/rpc/clients/TabletServerThriftClient.java |  2 +-
 .../core/rpc/clients/ThriftClientTypes.java        |  2 +-
 .../core/sample/impl/DataoutputHasher.java         |  2 +-
 .../core/sample/impl/SamplerConfigurationImpl.java |  2 +-
 .../accumulo/core/sample/impl/SamplerFactory.java  |  2 +-
 .../org/apache/accumulo/core/schema/Section.java   |  2 +-
 .../core/security/AuthorizationContainer.java      |  2 +-
 .../accumulo/core/security/Authorizations.java     |  2 +-
 .../accumulo/core/security/ColumnVisibility.java   |  2 +-
 .../core/security/NamespacePermission.java         |  2 +-
 .../accumulo/core/security/SystemPermission.java   |  2 +-
 .../accumulo/core/security/TablePermission.java    |  2 +-
 .../core/security/VisibilityEvaluator.java         |  2 +-
 .../core/security/VisibilityParseException.java    |  2 +-
 .../accumulo/core/singletons/SingletonManager.java |  2 +-
 .../core/singletons/SingletonReservation.java      |  2 +-
 .../accumulo/core/singletons/SingletonService.java |  2 +-
 .../core/spi/balancer/BalancerEnvironment.java     |  2 +-
 .../accumulo/core/spi/balancer/GroupBalancer.java  |  2 +-
 .../spi/balancer/HostRegexTableLoadBalancer.java   |  2 +-
 .../core/spi/balancer/RegexGroupBalancer.java      |  2 +-
 .../core/spi/balancer/SimpleLoadBalancer.java      |  2 +-
 .../core/spi/balancer/TableLoadBalancer.java       |  2 +-
 .../accumulo/core/spi/balancer/TabletBalancer.java |  2 +-
 .../core/spi/balancer/data/TServerStatus.java      |  2 +-
 .../core/spi/balancer/data/TableStatistics.java    |  2 +-
 .../core/spi/balancer/data/TabletMigration.java    |  2 +-
 .../core/spi/balancer/data/TabletServerId.java     |  2 +-
 .../core/spi/balancer/data/TabletStatistics.java   |  2 +-
 .../util/ThrottledBalancerProblemReporter.java     |  2 +-
 .../apache/accumulo/core/spi/cache/BlockCache.java |  2 +-
 .../accumulo/core/spi/cache/BlockCacheManager.java |  2 +-
 .../apache/accumulo/core/spi/cache/CacheEntry.java |  2 +-
 .../apache/accumulo/core/spi/cache/CacheType.java  |  2 +-
 .../core/spi/common/ContextClassLoaderFactory.java |  2 +-
 .../core/spi/common/IteratorConfiguration.java     |  2 +-
 .../core/spi/common/ServiceEnvironment.java        |  2 +-
 .../org/apache/accumulo/core/spi/common/Stats.java |  2 +-
 .../core/spi/compaction/CompactionDispatch.java    |  2 +-
 .../spi/compaction/CompactionDispatchBuilder.java  |  2 +-
 .../spi/compaction/CompactionDispatchImpl.java     |  2 +-
 .../core/spi/compaction/CompactionDispatcher.java  |  2 +-
 .../core/spi/compaction/CompactionExecutorId.java  |  2 +-
 .../core/spi/compaction/CompactionJob.java         |  2 +-
 .../core/spi/compaction/CompactionKind.java        |  2 +-
 .../core/spi/compaction/CompactionPlan.java        |  2 +-
 .../core/spi/compaction/CompactionPlanner.java     |  2 +-
 .../core/spi/compaction/CompactionServiceId.java   |  2 +-
 .../core/spi/compaction/CompactionServices.java    |  2 +-
 .../spi/compaction/DefaultCompactionPlanner.java   |  2 +-
 .../core/spi/compaction/ExecutorManager.java       |  2 +-
 .../spi/compaction/SimpleCompactionDispatcher.java |  2 +-
 .../accumulo/core/spi/compaction/package-info.java |  2 +-
 .../accumulo/core/spi/crypto/AESCryptoService.java |  2 +-
 .../core/spi/crypto/CryptoEnvironment.java         |  2 +-
 .../accumulo/core/spi/crypto/CryptoService.java    |  2 +-
 .../accumulo/core/spi/crypto/FileDecrypter.java    |  2 +-
 .../accumulo/core/spi/crypto/FileEncrypter.java    |  2 +-
 .../accumulo/core/spi/crypto/NoCryptoService.java  |  2 +-
 .../accumulo/core/spi/crypto/NoFileDecrypter.java  |  2 +-
 .../accumulo/core/spi/crypto/NoFileEncrypter.java  |  2 +-
 .../core/spi/file/rfile/compression/Bzip2.java     |  2 +-
 .../CompressionAlgorithmConfiguration.java         |  2 +-
 .../core/spi/file/rfile/compression/Gz.java        |  2 +-
 .../core/spi/file/rfile/compression/Lz4.java       |  2 +-
 .../core/spi/file/rfile/compression/Lzo.java       |  2 +-
 .../spi/file/rfile/compression/NoCompression.java  |  2 +-
 .../core/spi/file/rfile/compression/Snappy.java    |  2 +-
 .../core/spi/file/rfile/compression/ZStandard.java |  2 +-
 .../accumulo/core/spi/fs/DelegatingChooser.java    |  2 +-
 .../core/spi/fs/PreferredVolumeChooser.java        |  2 +-
 .../accumulo/core/spi/fs/RandomVolumeChooser.java  |  2 +-
 .../core/spi/fs/SpaceAwareVolumeChooser.java       |  2 +-
 .../apache/accumulo/core/spi/fs/VolumeChooser.java |  2 +-
 .../core/spi/fs/VolumeChooserEnvironment.java      |  2 +-
 .../org/apache/accumulo/core/spi/package-info.java |  2 +-
 .../core/spi/scan/DefaultScanDispatch.java         |  2 +-
 .../core/spi/scan/HintScanPrioritizer.java         |  2 +-
 .../core/spi/scan/IdleRatioScanPrioritizer.java    |  2 +-
 .../accumulo/core/spi/scan/ScanDispatch.java       |  2 +-
 .../accumulo/core/spi/scan/ScanDispatchImpl.java   |  2 +-
 .../accumulo/core/spi/scan/ScanDispatcher.java     |  2 +-
 .../accumulo/core/spi/scan/ScanExecutor.java       |  2 +-
 .../apache/accumulo/core/spi/scan/ScanInfo.java    |  2 +-
 .../accumulo/core/spi/scan/ScanPrioritizer.java    |  2 +-
 .../core/spi/scan/SimpleScanDispatcher.java        |  2 +-
 .../org/apache/accumulo/core/summary/Gatherer.java |  2 +-
 .../core/summary/SummarizerConfigurationUtil.java  |  2 +-
 .../accumulo/core/summary/SummarizerFactory.java   |  2 +-
 .../accumulo/core/summary/SummaryCollection.java   |  2 +-
 .../apache/accumulo/core/summary/SummaryInfo.java  |  2 +-
 .../accumulo/core/summary/SummaryReader.java       |  2 +-
 .../accumulo/core/summary/SummarySerializer.java   |  2 +-
 .../accumulo/core/summary/SummaryWriter.java       |  2 +-
 .../accumulo/core/tabletserver/log/LogEntry.java   |  2 +-
 .../org/apache/accumulo/core/trace/TraceUtil.java  |  2 +-
 .../accumulo/core/trace/TraceWrappedCallable.java  |  2 +-
 .../accumulo/core/trace/TraceWrappedRunnable.java  |  2 +-
 .../org/apache/accumulo/core/util/AddressUtil.java |  2 +-
 .../accumulo/core/util/BadArgumentException.java   |  2 +-
 .../accumulo/core/util/ByteArrayComparator.java    |  2 +-
 .../apache/accumulo/core/util/ByteArraySet.java    |  2 +-
 .../apache/accumulo/core/util/ByteBufferUtil.java  |  2 +-
 .../accumulo/core/util/CancelFlagFuture.java       |  2 +-
 .../org/apache/accumulo/core/util/CleanUp.java     |  2 +-
 .../org/apache/accumulo/core/util/ColumnFQ.java    |  2 +-
 .../apache/accumulo/core/util/ComparablePair.java  |  2 +-
 .../accumulo/core/util/CompletableFutureUtil.java  |  2 +-
 .../accumulo/core/util/ConfigurationImpl.java      |  2 +-
 .../org/apache/accumulo/core/util/CreateToken.java |  2 +-
 .../apache/accumulo/core/util/DurationFormat.java  |  2 +-
 .../org/apache/accumulo/core/util/Encoding.java    |  2 +-
 .../org/apache/accumulo/core/util/FastFormat.java  |  2 +-
 .../java/org/apache/accumulo/core/util/Halt.java   |  2 +-
 .../java/org/apache/accumulo/core/util/Help.java   |  2 +-
 .../org/apache/accumulo/core/util/HostAndPort.java |  2 +-
 .../org/apache/accumulo/core/util/Interner.java    |  2 +-
 .../accumulo/core/util/LocalityGroupUtil.java      |  2 +-
 .../org/apache/accumulo/core/util/MapCounter.java  |  2 +-
 .../java/org/apache/accumulo/core/util/Merge.java  |  2 +-
 .../org/apache/accumulo/core/util/MonitorUtil.java |  2 +-
 .../accumulo/core/util/MutableByteSequence.java    |  2 +-
 .../org/apache/accumulo/core/util/NumUtil.java     |  2 +-
 .../org/apache/accumulo/core/util/OpTimer.java     |  2 +-
 .../java/org/apache/accumulo/core/util/Pair.java   |  2 +-
 .../apache/accumulo/core/util/PeekingIterator.java |  2 +-
 .../accumulo/core/util/PreAllocatedArray.java      |  2 +-
 .../apache/accumulo/core/util/ServerServices.java  |  2 +-
 .../apache/accumulo/core/util/ShutdownUtil.java    |  2 +-
 .../java/org/apache/accumulo/core/util/Stat.java   |  2 +-
 .../org/apache/accumulo/core/util/StopWatch.java   |  2 +-
 .../org/apache/accumulo/core/util/TextUtil.java    |  2 +-
 .../accumulo/core/util/ThriftMessageUtil.java      |  2 +-
 .../accumulo/core/util/UnsynchronizedBuffer.java   |  4 +--
 .../org/apache/accumulo/core/util/Validator.java   |  2 +-
 .../org/apache/accumulo/core/util/Validators.java  |  2 +-
 .../org/apache/accumulo/core/util/Version.java     |  2 +-
 .../accumulo/core/util/cleaner/CleanerUtil.java    |  2 +-
 .../util/compaction/CompactionExecutorIdImpl.java  |  2 +-
 .../core/util/compaction/CompactionJobImpl.java    |  2 +-
 .../util/compaction/CompactionJobPrioritizer.java  |  3 +-
 .../core/util/compaction/CompactionPlanImpl.java   |  2 +-
 .../compaction/CompactionPlannerInitParams.java    |  2 +-
 .../util/compaction/CompactionServicesConfig.java  |  2 +-
 .../util/compaction/ExternalCompactionUtil.java    |  2 +-
 .../core/util/compaction/RunningCompaction.java    |  2 +-
 .../util/compaction/RunningCompactionInfo.java     |  2 +-
 .../core/util/format/AggregatingFormatter.java     |  2 +-
 .../accumulo/core/util/format/BinaryFormatter.java |  2 +-
 .../core/util/format/DateFormatSupplier.java       |  2 +-
 .../core/util/format/DateStringFormatter.java      |  2 +-
 .../core/util/format/DefaultFormatter.java         |  2 +-
 .../accumulo/core/util/format/Formatter.java       |  2 +-
 .../accumulo/core/util/format/FormatterConfig.java |  2 +-
 .../core/util/format/FormatterFactory.java         |  2 +-
 .../accumulo/core/util/format/HexFormatter.java    |  2 +-
 .../format/ShardedTableDistributionFormatter.java  |  2 +-
 .../util/format/StatisticsDisplayFormatter.java    |  2 +-
 .../util/interpret/DefaultScanInterpreter.java     |  2 +-
 .../core/util/interpret/HexScanInterpreter.java    |  2 +-
 .../core/util/interpret/ScanInterpreter.java       |  2 +-
 .../core/util/ratelimit/GuavaRateLimiter.java      |  2 +-
 .../core/util/ratelimit/NullRateLimiter.java       |  2 +-
 .../accumulo/core/util/ratelimit/RateLimiter.java  |  2 +-
 .../util/ratelimit/SharedRateLimiterFactory.java   |  2 +-
 .../apache/accumulo/core/util/tables/TableMap.java |  2 +-
 .../accumulo/core/util/tables/TableNameUtil.java   |  2 +-
 .../accumulo/core/util/tables/TableZooHelper.java  |  2 +-
 .../threads/AccumuloUncaughtExceptionHandler.java  |  2 +-
 .../accumulo/core/util/threads/NamedRunnable.java  |  2 +-
 .../core/util/threads/NamedThreadFactory.java      |  2 +-
 .../accumulo/core/util/threads/ThreadPools.java    |  2 +-
 .../apache/accumulo/core/util/threads/Threads.java |  2 +-
 .../org/apache/accumulo/core/volume/Volume.java    |  2 +-
 .../accumulo/core/volume/VolumeConfiguration.java  |  2 +-
 .../apache/accumulo/core/volume/VolumeImpl.java    |  2 +-
 .../apache/accumulo/fate/AcceptableException.java  |  2 +-
 .../java/org/apache/accumulo/fate/AdminUtil.java   |  2 +-
 .../java/org/apache/accumulo/fate/AgeOffStore.java |  2 +-
 .../main/java/org/apache/accumulo/fate/Fate.java   |  2 +-
 .../java/org/apache/accumulo/fate/FateTxId.java    |  2 +-
 .../org/apache/accumulo/fate/ReadOnlyRepo.java     |  2 +-
 .../org/apache/accumulo/fate/ReadOnlyStore.java    |  2 +-
 .../org/apache/accumulo/fate/ReadOnlyTStore.java   |  2 +-
 .../main/java/org/apache/accumulo/fate/Repo.java   |  2 +-
 .../accumulo/fate/StackOverflowException.java      |  2 +-
 .../main/java/org/apache/accumulo/fate/TStore.java |  2 +-
 .../java/org/apache/accumulo/fate/ZooStore.java    |  2 +-
 .../java/org/apache/accumulo/fate/util/Retry.java  |  2 +-
 .../apache/accumulo/fate/util/UtilWaitThread.java  |  2 +-
 .../fate/zookeeper/DistributedReadWriteLock.java   |  2 +-
 .../apache/accumulo/fate/zookeeper/FateLock.java   |  2 +-
 .../accumulo/fate/zookeeper/ServiceLock.java       |  2 +-
 .../apache/accumulo/fate/zookeeper/ZooCache.java   |  2 +-
 .../accumulo/fate/zookeeper/ZooCacheFactory.java   |  2 +-
 .../apache/accumulo/fate/zookeeper/ZooReader.java  |  2 +-
 .../accumulo/fate/zookeeper/ZooReaderWriter.java   |  2 +-
 .../accumulo/fate/zookeeper/ZooReservation.java    |  2 +-
 .../apache/accumulo/fate/zookeeper/ZooSession.java |  2 +-
 .../apache/accumulo/fate/zookeeper/ZooUtil.java    |  2 +-
 core/src/main/scripts/generate-thrift.sh           |  4 +--
 core/src/main/spotbugs/exclude-filter.xml          |  2 +-
 .../core/clientImpl/thrift/ClientService.java      |  2 +-
 .../core/clientImpl/thrift/ConfigurationType.java  |  2 +-
 .../core/clientImpl/thrift/SecurityErrorCode.java  |  2 +-
 .../core/clientImpl/thrift/TDiskUsage.java         |  2 +-
 .../core/clientImpl/thrift/TableOperation.java     |  2 +-
 .../thrift/TableOperationExceptionType.java        |  2 +-
 .../thrift/ThriftNotActiveServiceException.java    |  2 +-
 .../clientImpl/thrift/ThriftSecurityException.java |  2 +-
 .../thrift/ThriftTableOperationException.java      |  2 +-
 .../core/clientImpl/thrift/ThriftTest.java         |  2 +-
 .../thrift/CompactionCoordinatorService.java       |  2 +-
 .../core/compaction/thrift/CompactorService.java   |  2 +-
 .../core/compaction/thrift/TCompactionState.java   |  2 +-
 .../compaction/thrift/TCompactionStatusUpdate.java |  2 +-
 .../compaction/thrift/TExternalCompaction.java     |  2 +-
 .../compaction/thrift/TExternalCompactionList.java |  2 +-
 .../thrift/UnknownCompactionIdException.java       |  2 +-
 .../core/dataImpl/thrift/InitialMultiScan.java     |  2 +-
 .../accumulo/core/dataImpl/thrift/InitialScan.java |  2 +-
 .../accumulo/core/dataImpl/thrift/IterInfo.java    |  2 +-
 .../accumulo/core/dataImpl/thrift/MapFileInfo.java |  2 +-
 .../core/dataImpl/thrift/MultiScanResult.java      |  2 +-
 .../accumulo/core/dataImpl/thrift/ScanResult.java  |  2 +-
 .../accumulo/core/dataImpl/thrift/TCMResult.java   |  2 +-
 .../accumulo/core/dataImpl/thrift/TCMStatus.java   |  2 +-
 .../accumulo/core/dataImpl/thrift/TColumn.java     |  2 +-
 .../accumulo/core/dataImpl/thrift/TCondition.java  |  2 +-
 .../core/dataImpl/thrift/TConditionalMutation.java |  2 +-
 .../core/dataImpl/thrift/TConditionalSession.java  |  2 +-
 .../thrift/TConstraintViolationSummary.java        |  2 +-
 .../apache/accumulo/core/dataImpl/thrift/TKey.java |  2 +-
 .../accumulo/core/dataImpl/thrift/TKeyExtent.java  |  2 +-
 .../accumulo/core/dataImpl/thrift/TKeyValue.java   |  2 +-
 .../accumulo/core/dataImpl/thrift/TMutation.java   |  2 +-
 .../accumulo/core/dataImpl/thrift/TRange.java      |  2 +-
 .../accumulo/core/dataImpl/thrift/TRowRange.java   |  2 +-
 .../accumulo/core/dataImpl/thrift/TSummaries.java  |  2 +-
 .../dataImpl/thrift/TSummarizerConfiguration.java  |  2 +-
 .../accumulo/core/dataImpl/thrift/TSummary.java    |  2 +-
 .../core/dataImpl/thrift/TSummaryRequest.java      |  2 +-
 .../core/dataImpl/thrift/UpdateErrors.java         |  2 +-
 .../accumulo/core/gc/thrift/GCMonitorService.java  |  2 +-
 .../apache/accumulo/core/gc/thrift/GCStatus.java   |  2 +-
 .../accumulo/core/gc/thrift/GcCycleStats.java      |  2 +-
 .../accumulo/core/manager/thrift/DeadServer.java   |  2 +-
 .../core/manager/thrift/FateOperation.java         |  2 +-
 .../accumulo/core/manager/thrift/FateService.java  |  2 +-
 .../core/manager/thrift/ManagerClientService.java  |  2 +-
 .../core/manager/thrift/ManagerGoalState.java      |  2 +-
 .../core/manager/thrift/ManagerMonitorInfo.java    |  2 +-
 .../accumulo/core/manager/thrift/ManagerState.java |  2 +-
 .../core/manager/thrift/RecoveryException.java     |  2 +-
 .../core/manager/thrift/TabletLoadState.java       |  2 +-
 .../accumulo/core/manager/thrift/TabletSplit.java  |  2 +-
 .../core/master/thrift/BulkImportState.java        |  2 +-
 .../core/master/thrift/BulkImportStatus.java       |  2 +-
 .../accumulo/core/master/thrift/Compacting.java    |  2 +-
 .../core/master/thrift/RecoveryStatus.java         |  2 +-
 .../accumulo/core/master/thrift/TableInfo.java     |  2 +-
 .../core/master/thrift/TabletServerStatus.java     |  2 +-
 .../core/replication/thrift/KeyValues.java         |  2 +-
 .../thrift/RemoteReplicationErrorCode.java         |  2 +-
 .../thrift/RemoteReplicationException.java         |  2 +-
 .../replication/thrift/ReplicationCoordinator.java |  2 +-
 .../thrift/ReplicationCoordinatorErrorCode.java    |  2 +-
 .../thrift/ReplicationCoordinatorException.java    |  2 +-
 .../replication/thrift/ReplicationServicer.java    |  2 +-
 .../accumulo/core/replication/thrift/WalEdits.java |  2 +-
 .../securityImpl/thrift/TAuthenticationKey.java    |  2 +-
 .../thrift/TAuthenticationTokenIdentifier.java     |  2 +-
 .../core/securityImpl/thrift/TCredentials.java     |  2 +-
 .../core/securityImpl/thrift/TDelegationToken.java |  2 +-
 .../thrift/TDelegationTokenConfig.java             |  2 +-
 .../core/tabletserver/thrift/ActionStats.java      |  2 +-
 .../core/tabletserver/thrift/ActiveCompaction.java |  2 +-
 .../core/tabletserver/thrift/ActiveScan.java       |  2 +-
 .../thrift/ConstraintViolationException.java       |  2 +-
 .../core/tabletserver/thrift/InputFile.java        |  2 +-
 .../core/tabletserver/thrift/IteratorConfig.java   |  2 +-
 .../tabletserver/thrift/NoSuchScanIDException.java |  2 +-
 .../thrift/NotServingTabletException.java          |  2 +-
 .../core/tabletserver/thrift/ScanState.java        |  2 +-
 .../core/tabletserver/thrift/ScanType.java         |  2 +-
 .../core/tabletserver/thrift/TCompactionKind.java  |  2 +-
 .../thrift/TCompactionQueueSummary.java            |  2 +-
 .../tabletserver/thrift/TCompactionReason.java     |  2 +-
 .../core/tabletserver/thrift/TCompactionStats.java |  2 +-
 .../core/tabletserver/thrift/TCompactionType.java  |  2 +-
 .../core/tabletserver/thrift/TDurability.java      |  2 +-
 .../thrift/TExternalCompactionJob.java             |  2 +-
 .../core/tabletserver/thrift/TIteratorSetting.java |  2 +-
 .../thrift/TSampleNotPresentException.java         |  2 +-
 .../tabletserver/thrift/TSamplerConfiguration.java |  2 +-
 .../tabletserver/thrift/TUnloadTabletGoal.java     |  2 +-
 .../tabletserver/thrift/TabletClientService.java   |  2 +-
 .../thrift/TabletScanClientService.java            |  2 +-
 .../core/tabletserver/thrift/TabletStats.java      |  2 +-
 .../tabletserver/thrift/TooManyFilesException.java |  2 +-
 .../apache/accumulo/core/trace/thrift/TInfo.java   |  2 +-
 core/src/main/thrift/client.thrift                 |  2 +-
 core/src/main/thrift/compaction-coordinator.thrift |  2 +-
 core/src/main/thrift/data.thrift                   |  2 +-
 core/src/main/thrift/gc.thrift                     |  2 +-
 core/src/main/thrift/manager.thrift                |  2 +-
 core/src/main/thrift/master.thrift                 |  2 +-
 core/src/main/thrift/replication.thrift            |  2 +-
 core/src/main/thrift/security.thrift               |  2 +-
 core/src/main/thrift/tabletserver.thrift           |  2 +-
 core/src/main/thrift/trace.thrift                  |  2 +-
 .../org/apache/accumulo/core/WithTestNames.java    |  2 +-
 .../classloader/ContextClassLoaderFactoryTest.java |  2 +-
 .../core/classloader/URLClassLoaderFactory.java    |  2 +-
 .../accumulo/core/cli/PasswordConverterTest.java   |  2 +-
 .../apache/accumulo/core/cli/TestClientOpts.java   |  2 +-
 .../org/apache/accumulo/core/cli/TestHelp.java     |  2 +-
 .../core/client/BatchWriterConfigTest.java         |  2 +-
 .../core/client/ClientConfigurationTest.java       |  2 +-
 .../accumulo/core/client/ClientPropertiesTest.java |  2 +-
 .../accumulo/core/client/IteratorSettingTest.java  |  2 +-
 .../accumulo/core/client/RowIteratorTest.java      |  2 +-
 .../accumulo/core/client/TestThrift1474.java       |  2 +-
 .../core/client/ZooKeeperInstanceTest.java         |  2 +-
 .../client/admin/DelegationTokenConfigTest.java    |  2 +-
 .../client/admin/NewTableConfigurationTest.java    |  2 +-
 .../client/lexicoder/BigIntegerLexicoderTest.java  |  2 +-
 .../core/client/lexicoder/BytesLexicoderTest.java  |  2 +-
 .../core/client/lexicoder/DateLexicoderTest.java   |  2 +-
 .../core/client/lexicoder/DoubleLexicoderTest.java |  2 +-
 .../core/client/lexicoder/FloatLexicoderTest.java  |  2 +-
 .../client/lexicoder/IntegerLexicoderTest.java     |  2 +-
 .../core/client/lexicoder/LexicoderTest.java       |  2 +-
 .../core/client/lexicoder/ListLexicoderTest.java   |  2 +-
 .../core/client/lexicoder/LongLexicoderTest.java   |  2 +-
 .../core/client/lexicoder/PairLexicoderTest.java   |  2 +-
 .../client/lexicoder/ReverseLexicoderTest.java     |  2 +-
 .../client/lexicoder/SequenceLexicoderTest.java    |  2 +-
 .../core/client/lexicoder/StringLexicoderTest.java |  2 +-
 .../core/client/lexicoder/TextLexicoderTest.java   |  2 +-
 .../client/lexicoder/UIntegerLexicoderTest.java    |  2 +-
 .../core/client/lexicoder/ULongLexicoderTest.java  |  2 +-
 .../core/client/lexicoder/UUIDLexicoderTest.java   |  2 +-
 .../mapred/AccumuloFileOutputFormatTest.java       |  2 +-
 .../client/mapred/AccumuloInputFormatTest.java     |  2 +-
 .../mapred/AccumuloMultiTableInputFormatTest.java  |  2 +-
 .../client/mapred/AccumuloOutputFormatTest.java    |  2 +-
 .../core/client/mapred/RangeInputSplitTest.java    |  2 +-
 .../mapreduce/AccumuloFileOutputFormatTest.java    |  2 +-
 .../client/mapreduce/AccumuloInputFormatTest.java  |  2 +-
 .../AccumuloMultiTableInputFormatTest.java         |  2 +-
 .../client/mapreduce/AccumuloOutputFormatTest.java |  2 +-
 .../client/mapreduce/InputTableConfigTest.java     |  2 +-
 .../core/client/mapreduce/RangeInputSplitTest.java |  2 +-
 .../lib/partition/RangePartitionerTest.java        |  2 +-
 .../core/client/rfile/RFileClientTest.java         |  2 +-
 .../client/security/SecurityErrorCodeTest.java     |  2 +-
 .../tokens/CredentialProviderTokenTest.java        |  2 +-
 .../security/tokens/DelegationTokenImplTest.java   |  2 +-
 .../client/security/tokens/KerberosTokenTest.java  |  2 +-
 .../client/security/tokens/PasswordTokenTest.java  |  2 +-
 .../client/summary/CountingSummarizerTest.java     |  2 +-
 .../summarizers/AuthorizationSummarizerTest.java   |  2 +-
 .../summarizers/EntryLengthSummarizersTest.java    |  2 +-
 .../core/clientImpl/ClientConfConverterTest.java   |  2 +-
 .../core/clientImpl/ClientContextTest.java         |  2 +-
 .../core/clientImpl/ConditionalComparatorTest.java |  2 +-
 .../DelegationTokenConfigSerializerTest.java       |  2 +-
 .../core/clientImpl/RootTabletLocatorTest.java     |  2 +-
 .../accumulo/core/clientImpl/ScannerBaseTest.java  |  2 +-
 .../accumulo/core/clientImpl/ScannerImplTest.java  |  2 +-
 .../core/clientImpl/ScannerOptionsTest.java        |  2 +-
 .../core/clientImpl/TableOperationsHelperTest.java |  2 +-
 .../core/clientImpl/TabletLocatorImplTest.java     |  2 +-
 .../clientImpl/TabletServerBatchReaderTest.java    |  2 +-
 .../core/clientImpl/ThriftScannerTest.java         |  2 +-
 .../core/clientImpl/ThriftTransportKeyTest.java    |  2 +-
 .../core/clientImpl/ZookeeperLockCheckerTest.java  |  2 +-
 .../bulk/BulkImportFilterInvalidTest.java          |  2 +-
 .../core/clientImpl/bulk/BulkImportTest.java       |  2 +-
 .../core/clientImpl/bulk/BulkSerializeTest.java    |  2 +-
 .../bulk/ConcurrentKeyExtentCacheTest.java         |  2 +-
 .../lexicoder/AbstractLexicoderTest.java           |  2 +-
 .../core/clientImpl/lexicoder/ByteUtilsTest.java   |  2 +-
 .../clientImpl/mapreduce/BatchInputSplitTest.java  |  2 +-
 .../mapreduce/lib/ConfiguratorBaseTest.java        |  2 +-
 .../core/conf/AccumuloConfigurationTest.java       |  2 +-
 .../accumulo/core/conf/ClientPropertyTest.java     |  2 +-
 .../accumulo/core/conf/ConfigCheckUtilTest.java    |  2 +-
 .../core/conf/ConfigurationTypeHelperTest.java     |  2 +-
 .../core/conf/DefaultConfigurationTest.java        |  2 +-
 .../core/conf/DeprecatedPropertyUtilTest.java      |  2 +-
 .../core/conf/HadoopCredentialProviderTest.java    |  2 +-
 .../apache/accumulo/core/conf/PropertyTest.java    |  2 +-
 .../accumulo/core/conf/PropertyTypeTest.java       |  2 +-
 .../accumulo/core/conf/SiteConfigurationTest.java  |  2 +-
 .../core/conf/cluster/ClusterConfigParserTest.java |  2 +-
 .../constraints/DefaultKeySizeConstraintTest.java  |  2 +-
 .../DeprecatedConstraintExtendTest.java            |  2 +-
 .../core/constraints/NoDeleteConstraintTest.java   |  2 +-
 .../core/constraints/VisibilityConstraintTest.java |  2 +-
 .../accumulo/core/crypto/BlockedIOStreamTest.java  |  2 +-
 .../apache/accumulo/core/crypto/CryptoTest.java    |  2 +-
 .../accumulo/core/data/ArrayByteSequenceTest.java  |  2 +-
 .../accumulo/core/data/ByteSequenceTest.java       |  2 +-
 .../org/apache/accumulo/core/data/ColumnTest.java  |  2 +-
 .../apache/accumulo/core/data/ConditionTest.java   |  2 +-
 .../core/data/ConditionalMutationTest.java         |  2 +-
 .../core/data/ConstraintViolationSummaryTest.java  |  2 +-
 .../apache/accumulo/core/data/KeyBuilderTest.java  |  2 +-
 .../apache/accumulo/core/data/KeyExtentTest.java   |  2 +-
 .../org/apache/accumulo/core/data/KeyTest.java     |  2 +-
 .../apache/accumulo/core/data/LoadPlanTest.java    |  2 +-
 .../apache/accumulo/core/data/MutationTest.java    |  2 +-
 .../apache/accumulo/core/data/NamespaceIdTest.java |  2 +-
 .../org/apache/accumulo/core/data/OldMutation.java |  2 +-
 .../org/apache/accumulo/core/data/RangeTest.java   |  2 +-
 .../org/apache/accumulo/core/data/TableIdTest.java |  2 +-
 .../org/apache/accumulo/core/data/ValueTest.java   |  2 +-
 .../constraints/DefaultKeySizeConstraintTest.java  |  2 +-
 .../data/constraints/NoDeleteConstraintTest.java   |  2 +-
 .../data/constraints/VisibilityConstraintTest.java |  2 +-
 .../core/file/BloomFilterLayerLookupTest.java      |  2 +-
 .../accumulo/core/file/FileOperationsTest.java     |  2 +-
 .../blockfile/cache/BlockCacheFactoryTest.java     |  2 +-
 .../blockfile/cache/BlockCacheManagerTest.java     |  2 +-
 .../file/blockfile/cache/TestCachedBlockQueue.java |  2 +-
 .../file/blockfile/cache/TestLruBlockCache.java    |  2 +-
 .../accumulo/core/file/rfile/BlockIndexTest.java   |  2 +-
 .../core/file/rfile/CreateCompatTestFile.java      |  2 +-
 .../core/file/rfile/GenerateSplitsTest.java        |  2 +-
 .../accumulo/core/file/rfile/KeyShortenerTest.java |  2 +-
 .../core/file/rfile/MultiLevelIndexTest.java       |  2 +-
 .../core/file/rfile/MultiThreadedRFileTest.java    |  2 +-
 .../accumulo/core/file/rfile/RFileMetricsTest.java |  2 +-
 .../apache/accumulo/core/file/rfile/RFileTest.java |  2 +-
 .../accumulo/core/file/rfile/RelativeKeyTest.java  |  2 +-
 .../accumulo/core/file/rfile/RollingStatsTest.java |  2 +-
 .../core/file/rfile/bcfile/CompressionTest.java    |  2 +-
 .../file/streams/RateLimitedInputStreamTest.java   |  2 +-
 .../file/streams/RateLimitedOutputStreamTest.java  |  2 +-
 .../accumulo/core/iterators/CombinerTestUtil.java  |  2 +-
 .../core/iterators/DefaultIteratorEnvironment.java |  2 +-
 .../iterators/FirstEntryInRowIteratorTest.java     |  2 +-
 .../core/iterators/FirstEntryInRowTest.java        |  2 +-
 .../core/iterators/SortedMapIteratorTest.java      |  2 +-
 .../system/ColumnFamilySkippingIteratorTest.java   |  2 +-
 .../core/iterators/system/ColumnFilterTest.java    |  2 +-
 .../iterators/system/DeletingIteratorTest.java     |  2 +-
 .../core/iterators/system/MultiIteratorTest.java   |  2 +-
 .../system/SourceSwitchingIteratorTest.java        |  2 +-
 .../iterators/system/TimeSettingIteratorTest.java  |  2 +-
 .../iterators/system/VisibilityFilterTest.java     |  2 +-
 .../iterators/user/BigDecimalCombinerTest.java     |  2 +-
 .../core/iterators/user/ColumnSliceFilterTest.java |  2 +-
 .../accumulo/core/iterators/user/CombinerTest.java |  2 +-
 .../accumulo/core/iterators/user/FilterTest.java   |  2 +-
 .../core/iterators/user/GrepIteratorTest.java      |  2 +-
 .../iterators/user/IndexedDocIteratorTest.java     |  2 +-
 .../iterators/user/IntersectingIteratorTest.java   |  2 +-
 .../core/iterators/user/LargeRowFilterTest.java    |  2 +-
 .../core/iterators/user/RegExFilterTest.java       |  2 +-
 .../iterators/user/RowDeletingIteratorTest.java    |  2 +-
 .../iterators/user/RowEncodingIteratorTest.java    |  2 +-
 .../core/iterators/user/RowFilterTest.java         |  2 +-
 .../core/iterators/user/TestCfCqSlice.java         |  2 +-
 .../core/iterators/user/TestCfCqSliceFilter.java   |  2 +-
 .../iterators/user/TestCfCqSliceSeekingFilter.java |  2 +-
 .../iterators/user/TransformingIteratorTest.java   |  2 +-
 .../iterators/user/VersioningIteratorTest.java     |  2 +-
 .../core/iterators/user/VisibilityFilterTest.java  |  2 +-
 .../user/WholeColumnFamilyIteratorTest.java        | 18 +----------
 .../core/iterators/user/WholeRowIteratorTest.java  |  2 +-
 .../core/iteratorsImpl/IteratorConfigUtilTest.java |  2 +-
 .../core/metadata/MetadataServicerTest.java        |  2 +-
 .../core/metadata/schema/DeleteMetadataTest.java   |  2 +-
 .../core/metadata/schema/LinkingIteratorTest.java  |  2 +-
 .../core/metadata/schema/MetadataSchemaTest.java   |  2 +-
 .../core/metadata/schema/MetadataTimeTest.java     |  2 +-
 .../core/metadata/schema/SortSkewTest.java         |  2 +-
 .../core/metadata/schema/TabletFileTest.java       |  2 +-
 .../core/metadata/schema/TabletMetadataTest.java   |  2 +-
 .../ReplicationConfigurationUtilTest.java          |  2 +-
 .../core/replication/ReplicationSchemaTest.java    |  2 +-
 .../core/replication/ReplicationTargetTest.java    |  2 +-
 .../rpc/SaslClientDigestCallbackHandlerTest.java   |  2 +-
 .../core/rpc/SaslConnectionParamsTest.java         |  2 +-
 .../accumulo/core/rpc/TTimeoutTransportTest.java   |  2 +-
 .../AuthenticationTokenIdentifierTest.java         |  2 +-
 .../core/security/AuthenticationTokenTest.java     |  2 +-
 .../accumulo/core/security/AuthorizationsTest.java |  2 +-
 .../core/security/ColumnVisibilityTest.java        |  2 +-
 .../accumulo/core/security/CredentialsTest.java    |  2 +-
 .../core/security/NamespacePermissionsTest.java    |  2 +-
 .../core/security/VisibilityEvaluatorTest.java     |  2 +-
 .../core/singletons/SingletonManagerTest.java      |  2 +-
 .../BaseHostRegexTableLoadBalancerTest.java        |  2 +-
 .../core/spi/balancer/GroupBalancerTest.java       |  2 +-
 ...tRegexTableLoadBalancerReconfigurationTest.java |  2 +-
 .../balancer/HostRegexTableLoadBalancerTest.java   |  2 +-
 .../core/spi/balancer/SimpleLoadBalancerTest.java  |  2 +-
 .../core/spi/balancer/TableLoadBalancerTest.java   |  2 +-
 .../compaction/DefaultCompactionPlannerTest.java   |  2 +-
 .../core/spi/fs/DelegatingChooserTest.java         |  2 +-
 .../core/spi/fs/PreferredVolumeChooserTest.java    |  2 +-
 .../core/spi/fs/SpaceAwareVolumeChooserTest.java   |  2 +-
 .../core/spi/scan/HintScanPrioritizerTest.java     |  2 +-
 .../spi/scan/IdleRatioScanPrioritizerTest.java     |  2 +-
 .../core/spi/scan/SimpleScanDispatcherTest.java    |  2 +-
 .../accumulo/core/spi/scan/TestScanInfo.java       |  2 +-
 .../core/summary/SummaryCollectionTest.java        |  2 +-
 .../core/tabletserver/log/LogEntryTest.java        |  2 +-
 .../apache/accumulo/core/util/AddressUtilTest.java |  2 +-
 .../accumulo/core/util/ByteBufferUtilTest.java     |  2 +-
 .../core/util/CompletableFutureUtilTest.java       |  2 +-
 .../apache/accumulo/core/util/FastFormatTest.java  |  2 +-
 .../apache/accumulo/core/util/HostAndPortTest.java |  2 +-
 .../apache/accumulo/core/util/InternerTest.java    |  2 +-
 .../accumulo/core/util/LocalityGroupUtilTest.java  |  2 +-
 .../org/apache/accumulo/core/util/MergeTest.java   |  2 +-
 .../apache/accumulo/core/util/MonitorUtilTest.java |  2 +-
 .../org/apache/accumulo/core/util/NumUtilTest.java |  2 +-
 .../org/apache/accumulo/core/util/OpTimerTest.java |  2 +-
 .../org/apache/accumulo/core/util/PairTest.java    |  2 +-
 .../apache/accumulo/core/util/PartitionerTest.java |  2 +-
 .../accumulo/core/util/PreAllocatedArrayTest.java  |  2 +-
 .../org/apache/accumulo/core/util/StatTest.java    |  2 +-
 .../apache/accumulo/core/util/TextUtilTest.java    |  2 +-
 .../accumulo/core/util/ThriftMessageUtilTest.java  |  2 +-
 .../core/util/UnsynchronizedBufferTest.java        |  2 +-
 .../apache/accumulo/core/util/ValidatorTest.java   |  2 +-
 .../apache/accumulo/core/util/ValidatorsTest.java  |  2 +-
 .../util/compaction/CompactionPrioritizerTest.java |  3 +-
 .../core/util/format/DateFormatSupplierTest.java   |  2 +-
 .../core/util/format/DateStringFormatterTest.java  |  2 +-
 .../core/util/format/DefaultFormatterTest.java     |  2 +-
 .../core/util/format/FormatterConfigTest.java      |  2 +-
 .../core/util/format/FormatterFactoryTest.java     |  2 +-
 .../core/util/format/HexFormatterTest.java         |  2 +-
 .../ShardedTableDistributionFormatterTest.java     |  2 +-
 .../format/StatisticsDisplayFormatterTest.java     |  2 +-
 .../AccumuloUncaughtExceptionHandlerTest.java      |  2 +-
 .../accumulo/core/volume/VolumeImplTest.java       |  2 +-
 .../org/apache/accumulo/fate/AgeOffStoreTest.java  |  2 +-
 .../apache/accumulo/fate/ReadOnlyStoreTest.java    |  2 +-
 .../java/org/apache/accumulo/fate/TestStore.java   |  2 +-
 .../org/apache/accumulo/fate/util/RetryTest.java   |  2 +-
 .../zookeeper/DistributedReadWriteLockTest.java    |  2 +-
 .../accumulo/fate/zookeeper/ServiceLockTest.java   |  2 +-
 .../fate/zookeeper/ZooCacheFactoryTest.java        |  2 +-
 .../accumulo/fate/zookeeper/ZooCacheTest.java      |  2 +-
 .../fate/zookeeper/ZooReaderWriterTest.java        |  2 +-
 .../accumulo/fate/zookeeper/ZooSessionTest.java    |  2 +-
 core/src/test/resources/accumulo.properties        |  2 +-
 core/src/test/resources/accumulo2.properties       |  2 +-
 core/src/test/resources/log4j2-test.properties     |  2 +-
 .../cluster/cluster-with-external-compactions.yaml |  2 +-
 .../apache/accumulo/core/conf/cluster/cluster.yaml |  2 +-
 hadoop-mapreduce/.gitignore                        | 32 +++++++++++--------
 hadoop-mapreduce/pom.xml                           |  2 +-
 .../hadoop/mapred/AccumuloFileOutputFormat.java    |  2 +-
 .../hadoop/mapred/AccumuloInputFormat.java         |  2 +-
 .../hadoop/mapred/AccumuloOutputFormat.java        |  2 +-
 .../hadoop/mapred/AccumuloRowInputFormat.java      |  2 +-
 .../hadoop/mapreduce/AccumuloFileOutputFormat.java |  2 +-
 .../hadoop/mapreduce/AccumuloInputFormat.java      |  2 +-
 .../hadoop/mapreduce/AccumuloOutputFormat.java     |  2 +-
 .../hadoop/mapreduce/AccumuloRowInputFormat.java   |  2 +-
 .../hadoop/mapreduce/FileOutputFormatBuilder.java  |  2 +-
 .../hadoop/mapreduce/InputFormatBuilder.java       |  2 +-
 .../hadoop/mapreduce/OutputFormatBuilder.java      |  2 +-
 .../mapreduce/partition/KeyRangePartitioner.java   |  2 +-
 .../mapreduce/partition/RangePartitioner.java      |  2 +-
 .../hadoopImpl/mapred/AccumuloRecordReader.java    |  2 +-
 .../hadoopImpl/mapred/AccumuloRecordWriter.java    |  2 +-
 .../hadoopImpl/mapred/BatchInputSplit.java         |  2 +-
 .../hadoopImpl/mapred/RangeInputSplit.java         |  2 +-
 .../hadoopImpl/mapreduce/AccumuloRecordReader.java |  2 +-
 .../hadoopImpl/mapreduce/AccumuloRecordWriter.java |  2 +-
 .../hadoopImpl/mapreduce/BatchInputSplit.java      |  2 +-
 .../mapreduce/FileOutputFormatBuilderImpl.java     |  2 +-
 .../mapreduce/InputFormatBuilderImpl.java          |  2 +-
 .../hadoopImpl/mapreduce/InputTableConfig.java     |  2 +-
 .../mapreduce/OutputFormatBuilderImpl.java         |  2 +-
 .../hadoopImpl/mapreduce/RangeInputSplit.java      |  2 +-
 .../accumulo/hadoopImpl/mapreduce/SplitUtils.java  |  2 +-
 .../hadoopImpl/mapreduce/lib/ConfiguratorBase.java |  2 +-
 .../mapreduce/lib/FileOutputConfigurator.java      |  2 +-
 .../mapreduce/lib/InputConfigurator.java           |  2 +-
 .../mapreduce/lib/OutputConfigurator.java          |  2 +-
 .../src/main/spotbugs/exclude-filter.xml           |  2 +-
 .../apache/accumulo/hadoop/its/WithTestNames.java  |  2 +-
 .../its/mapred/AccumuloFileOutputFormatIT.java     |  2 +-
 .../hadoop/its/mapred/AccumuloInputFormatIT.java   |  2 +-
 .../hadoop/its/mapred/AccumuloOutputFormatIT.java  |  2 +-
 .../its/mapred/AccumuloRowInputFormatIT.java       |  2 +-
 .../hadoop/its/mapred/MultiTableInputFormatIT.java |  2 +-
 .../accumulo/hadoop/its/mapred/TokenFileIT.java    |  2 +-
 .../its/mapreduce/AccumuloFileOutputFormatIT.java  |  2 +-
 .../its/mapreduce/AccumuloInputFormatIT.java       |  2 +-
 .../its/mapreduce/AccumuloOutputFormatIT.java      |  2 +-
 .../its/mapreduce/AccumuloRowInputFormatIT.java    |  2 +-
 .../its/mapreduce/MultiTableInputFormatIT.java     |  2 +-
 .../accumulo/hadoop/its/mapreduce/RowHashIT.java   |  2 +-
 .../accumulo/hadoop/its/mapreduce/TokenFileIT.java |  2 +-
 .../mapred/AccumuloFileOutputFormatTest.java       |  2 +-
 .../hadoop/mapred/AccumuloInputFormatTest.java     |  2 +-
 .../hadoop/mapred/AccumuloOutputFormatTest.java    |  2 +-
 .../hadoop/mapred/MultiTableInputFormatTest.java   |  2 +-
 .../mapreduce/AccumuloFileOutputFormatTest.java    |  2 +-
 .../hadoop/mapreduce/AccumuloInputFormatTest.java  |  2 +-
 .../hadoop/mapreduce/AccumuloOutputFormatTest.java |  2 +-
 .../mapreduce/MultiTableInputFormatTest.java       |  2 +-
 .../mapreduce/partition/RangePartitionerTest.java  |  2 +-
 .../hadoopImpl/mapred/RangeInputSplitTest.java     |  2 +-
 .../hadoopImpl/mapreduce/BatchInputSplitTest.java  |  2 +-
 .../mapreduce/InputFormatBuilderTest.java          |  2 +-
 .../hadoopImpl/mapreduce/InputTableConfigTest.java |  2 +-
 .../hadoopImpl/mapreduce/RangeInputSplitTest.java  |  2 +-
 .../mapreduce/lib/ConfiguratorBaseTest.java        |  2 +-
 .../src/test/resources/log4j2-test.properties      |  2 +-
 iterator-test-harness/.gitignore                   | 36 ++++++++++++++--------
 iterator-test-harness/pom.xml                      |  2 +-
 .../accumulo/iteratortest/IteratorTestBase.java    |  2 +-
 .../accumulo/iteratortest/IteratorTestCase.java    |  2 +-
 .../accumulo/iteratortest/IteratorTestInput.java   |  2 +-
 .../accumulo/iteratortest/IteratorTestOutput.java  |  2 +-
 .../iteratortest/IteratorTestParameters.java       |  2 +-
 .../environments/SimpleIteratorEnvironment.java    |  2 +-
 .../iteratortest/testcases/DeepCopyTestCase.java   |  2 +-
 .../testcases/InstantiationTestCase.java           |  2 +-
 .../testcases/IsolatedDeepCopiesTestCase.java      |  2 +-
 .../iteratortest/testcases/IteratorTestUtil.java   |  2 +-
 .../testcases/MultipleHasTopCalls.java             |  2 +-
 .../iteratortest/testcases/ReSeekTestCase.java     |  2 +-
 .../testcases/SimpleKVReusingIterator.java         |  2 +-
 .../iteratortest/testcases/YieldingTestCase.java   |  2 +-
 .../iteratortest/framework/JUnitFrameworkTest.java |  2 +-
 .../src/test/resources/log4j2-test.properties      |  2 +-
 minicluster/.gitignore                             | 32 +++++++++++--------
 minicluster/minicluster.properties                 |  2 +-
 minicluster/pom.xml                                |  2 +-
 .../apache/accumulo/cluster/AccumuloCluster.java   |  2 +-
 .../apache/accumulo/cluster/ClusterControl.java    |  2 +-
 .../org/apache/accumulo/cluster/ClusterUser.java   |  2 +-
 .../org/apache/accumulo/cluster/ClusterUsers.java  |  2 +-
 .../org/apache/accumulo/cluster/RemoteShell.java   |  2 +-
 .../accumulo/cluster/RemoteShellOptions.java       |  2 +-
 .../standalone/StandaloneAccumuloCluster.java      |  2 +-
 .../standalone/StandaloneClusterControl.java       |  2 +-
 .../apache/accumulo/minicluster/MemoryUnit.java    |  2 +-
 .../accumulo/minicluster/MiniAccumuloCluster.java  |  2 +-
 .../accumulo/minicluster/MiniAccumuloConfig.java   |  2 +-
 .../accumulo/minicluster/MiniAccumuloInstance.java |  2 +-
 .../accumulo/minicluster/MiniAccumuloRunner.java   |  2 +-
 .../apache/accumulo/minicluster/ServerType.java    |  2 +-
 .../MiniAccumuloClusterControl.java                |  2 +-
 .../miniclusterImpl/MiniAccumuloClusterImpl.java   |  2 +-
 .../miniclusterImpl/MiniAccumuloConfigImpl.java    |  2 +-
 .../miniclusterImpl/MiniClusterExecutable.java     |  2 +-
 .../miniclusterImpl/ProcessNotFoundException.java  |  2 +-
 .../accumulo/miniclusterImpl/ProcessReference.java |  2 +-
 .../miniclusterImpl/ZooKeeperBindException.java    |  2 +-
 minicluster/src/main/spotbugs/exclude-filter.xml   |  2 +-
 .../standalone/StandaloneAccumuloClusterTest.java  |  2 +-
 .../standalone/StandaloneClusterControlTest.java   |  2 +-
 .../MiniAccumuloClusterExistingZooKeepersTest.java |  2 +-
 .../MiniAccumuloClusterStartStopTest.java          |  2 +-
 .../minicluster/MiniAccumuloClusterTest.java       |  2 +-
 .../apache/accumulo/minicluster/WithTestNames.java |  2 +-
 .../miniclusterImpl/CleanShutdownMacTest.java      |  2 +-
 .../MiniAccumuloClusterImplTest.java               |  2 +-
 .../MiniAccumuloConfigImplTest.java                |  2 +-
 .../src/test/resources/log4j2-test.properties      |  2 +-
 pom.xml                                            |  5 +--
 server/base/.gitignore                             | 32 +++++++++++--------
 server/base/pom.xml                                |  2 +-
 .../org/apache/accumulo/server/AbstractServer.java |  2 +-
 .../accumulo/server/AccumuloDataVersion.java       |  2 +-
 .../accumulo/server/GarbageCollectionLogger.java   |  2 +-
 .../accumulo/server/HighlyAvailableService.java    |  2 +-
 .../org/apache/accumulo/server/ServerContext.java  |  2 +-
 .../org/apache/accumulo/server/ServerDirs.java     |  2 +-
 .../org/apache/accumulo/server/ServerInfo.java     |  2 +-
 .../org/apache/accumulo/server/ServerOpts.java     |  2 +-
 .../accumulo/server/ServiceEnvironmentImpl.java    |  2 +-
 .../org/apache/accumulo/server/TabletLevel.java    |  2 +-
 .../apache/accumulo/server/cli/ServerUtilOpts.java |  2 +-
 .../accumulo/server/client/BulkImporter.java       |  2 +-
 .../server/client/ClientServiceHandler.java        |  2 +-
 .../accumulo/server/compaction/CompactionInfo.java |  2 +-
 .../server/compaction/CompactionStats.java         |  2 +-
 .../server/compaction/CompactionWatcher.java       |  2 +-
 .../server/compaction/CountingIterator.java        |  2 +-
 .../accumulo/server/compaction/FileCompactor.java  |  2 +-
 .../server/compaction/RetryableThriftCall.java     |  2 +-
 .../server/compaction/RetryableThriftFunction.java |  2 +-
 .../server/conf/CheckCompactionConfig.java         |  2 +-
 .../accumulo/server/conf/CheckServerConfig.java    |  2 +-
 .../server/conf/NamespaceConfiguration.java        |  2 +-
 .../server/conf/RuntimeFixedProperties.java        |  2 +-
 .../accumulo/server/conf/ServerConfiguration.java  |  2 +-
 .../server/conf/ServerConfigurationFactory.java    |  2 +-
 .../accumulo/server/conf/SystemConfiguration.java  |  2 +-
 .../accumulo/server/conf/TableConfiguration.java   |  2 +-
 .../server/conf/ZooBasedConfiguration.java         |  2 +-
 .../server/conf/codec/EncodingOptions.java         |  2 +-
 .../server/conf/codec/VersionedPropCodec.java      |  2 +-
 .../server/conf/codec/VersionedPropGzipCodec.java  |  2 +-
 .../server/conf/codec/VersionedProperties.java     |  2 +-
 .../server/conf/store/NamespacePropKey.java        |  2 +-
 .../accumulo/server/conf/store/PropCache.java      |  2 +-
 .../server/conf/store/PropChangeListener.java      |  2 +-
 .../accumulo/server/conf/store/PropStore.java      |  2 +-
 .../accumulo/server/conf/store/PropStoreKey.java   |  2 +-
 .../accumulo/server/conf/store/SystemPropKey.java  |  2 +-
 .../accumulo/server/conf/store/TablePropKey.java   |  2 +-
 .../conf/store/impl/PropCacheCaffeineImpl.java     |  2 +-
 .../server/conf/store/impl/PropStoreEventTask.java |  2 +-
 .../server/conf/store/impl/PropStoreMetrics.java   |  2 +-
 .../server/conf/store/impl/PropStoreWatcher.java   |  2 +-
 .../server/conf/store/impl/ReadyMonitor.java       |  2 +-
 .../server/conf/store/impl/ZooPropLoader.java      |  2 +-
 .../server/conf/store/impl/ZooPropStore.java       |  2 +-
 .../server/conf/util/ConfigPropertyUpgrader.java   |  2 +-
 .../server/conf/util/ConfigTransformer.java        |  2 +-
 .../accumulo/server/conf/util/PropSnapshot.java    |  2 +-
 .../accumulo/server/conf/util/TransformToken.java  |  2 +-
 .../server/constraints/MetadataConstraints.java    |  2 +-
 .../server/constraints/SystemEnvironment.java      |  2 +-
 .../accumulo/server/data/ServerColumnUpdate.java   |  2 +-
 .../accumulo/server/data/ServerMutation.java       |  2 +-
 .../org/apache/accumulo/server/fs/FileManager.java |  2 +-
 .../server/fs/InterfaceEvolutionWarner.java        |  2 +-
 .../accumulo/server/fs/PerTableVolumeChooser.java  |  2 +-
 .../accumulo/server/fs/PreferredVolumeChooser.java |  2 +-
 .../accumulo/server/fs/RandomVolumeChooser.java    |  2 +-
 .../server/fs/SpaceAwareVolumeChooser.java         |  2 +-
 .../accumulo/server/fs/TooManyFilesException.java  |  2 +-
 .../apache/accumulo/server/fs/VolumeChooser.java   |  2 +-
 .../server/fs/VolumeChooserEnvironment.java        |  2 +-
 .../server/fs/VolumeChooserEnvironmentImpl.java    |  2 +-
 .../apache/accumulo/server/fs/VolumeManager.java   |  2 +-
 .../accumulo/server/fs/VolumeManagerImpl.java      |  2 +-
 .../org/apache/accumulo/server/fs/VolumeUtil.java  |  2 +-
 .../apache/accumulo/server/gc/GcVolumeUtil.java    |  2 +-
 .../server/init/FileSystemInitializer.java         |  2 +-
 .../accumulo/server/init/InitialConfiguration.java |  2 +-
 .../apache/accumulo/server/init/Initialize.java    |  2 +-
 .../accumulo/server/init/ZooKeeperInitializer.java |  2 +-
 .../server/iterators/MetadataBulkLoadFilter.java   |  2 +-
 .../iterators/SystemIteratorEnvironment.java       |  2 +-
 .../iterators/TabletIteratorEnvironment.java       |  2 +-
 .../apache/accumulo/server/log/SortedLogState.java |  2 +-
 .../accumulo/server/log/WalStateManager.java       |  2 +-
 .../accumulo/server/manager/LiveTServerSet.java    |  2 +-
 .../manager/balancer/BalancerEnvironmentImpl.java  |  2 +-
 .../server/manager/recovery/HadoopLogCloser.java   |  2 +-
 .../server/manager/recovery/LogCloser.java         |  2 +-
 .../server/manager/recovery/RecoveryPath.java      |  2 +-
 .../accumulo/server/manager/state/Assignment.java  |  2 +-
 .../server/manager/state/ClosableIterator.java     |  2 +-
 .../server/manager/state/CurrentState.java         |  2 +-
 .../server/manager/state/DeadServerList.java       |  2 +-
 .../manager/state/DistributedStoreException.java   |  2 +-
 .../manager/state/LoggingTabletStateStore.java     |  2 +-
 .../accumulo/server/manager/state/MergeInfo.java   |  2 +-
 .../accumulo/server/manager/state/MergeState.java  |  2 +-
 .../server/manager/state/MetaDataStateStore.java   |  2 +-
 .../server/manager/state/MetaDataTableScanner.java |  2 +-
 .../server/manager/state/RootTabletStateStore.java |  2 +-
 .../server/manager/state/TabletServerState.java    |  2 +-
 .../manager/state/TabletStateChangeIterator.java   |  2 +-
 .../server/manager/state/TabletStateStore.java     |  2 +-
 .../server/manager/state/ZooTabletStateStore.java  |  2 +-
 .../master/balancer/DefaultLoadBalancer.java       |  2 +-
 .../server/master/balancer/GroupBalancer.java      |  2 +-
 .../balancer/HostRegexTableLoadBalancer.java       |  2 +-
 .../server/master/balancer/RegexGroupBalancer.java |  2 +-
 .../server/master/balancer/TableLoadBalancer.java  |  2 +-
 .../server/master/balancer/TabletBalancer.java     |  2 +-
 .../server/master/recovery/HadoopLogCloser.java    |  2 +-
 .../server/master/state/TabletMigration.java       |  2 +-
 .../accumulo/server/metadata/RootGcCandidates.java |  2 +-
 .../server/metadata/RootTabletMutatorImpl.java     |  2 +-
 .../accumulo/server/metadata/ServerAmpleImpl.java  |  2 +-
 .../server/metadata/TabletMutatorBase.java         |  2 +-
 .../server/metadata/TabletMutatorImpl.java         |  2 +-
 .../server/metadata/TabletsMutatorImpl.java        |  2 +-
 .../accumulo/server/metrics/ThriftMetrics.java     |  2 +-
 .../accumulo/server/problems/ProblemReport.java    |  2 +-
 .../server/problems/ProblemReportingIterator.java  |  2 +-
 .../accumulo/server/problems/ProblemReports.java   |  2 +-
 .../accumulo/server/problems/ProblemType.java      |  2 +-
 .../DistributedWorkQueueWorkAssignerHelper.java    |  2 +-
 .../accumulo/server/replication/ReplicaSystem.java |  2 +-
 .../server/replication/ReplicaSystemFactory.java   |  2 +-
 .../server/replication/ReplicaSystemHelper.java    |  2 +-
 .../server/replication/ReplicationUtil.java        |  2 +-
 .../server/replication/StatusCombiner.java         |  2 +-
 .../server/replication/StatusFormatter.java        |  2 +-
 .../accumulo/server/replication/StatusUtil.java    |  2 +-
 .../accumulo/server/replication/WorkAssigner.java  |  2 +-
 .../replication/ZooKeeperInitialization.java       |  2 +-
 .../server/replication/proto/Replication.java      |  2 +-
 .../server/rpc/ClientInfoProcessorFactory.java     |  2 +-
 .../server/rpc/CustomNonBlockingServer.java        |  2 +-
 .../server/rpc/CustomThreadedSelectorServer.java   |  2 +-
 .../HighlyAvailableServiceInvocationHandler.java   |  2 +-
 .../server/rpc/HighlyAvailableServiceWrapper.java  |  2 +-
 .../server/rpc/SaslServerConnectionParams.java     |  2 +-
 .../rpc/SaslServerDigestCallbackHandler.java       |  2 +-
 .../apache/accumulo/server/rpc/ServerAddress.java  |  2 +-
 .../rpc/TCredentialsUpdatingInvocationHandler.java |  2 +-
 .../server/rpc/TCredentialsUpdatingWrapper.java    |  2 +-
 .../apache/accumulo/server/rpc/TServerUtils.java   |  2 +-
 .../accumulo/server/rpc/ThriftProcessorTypes.java  |  2 +-
 .../accumulo/server/rpc/ThriftServerType.java      |  2 +-
 .../apache/accumulo/server/rpc/TimedProcessor.java |  2 +-
 .../accumulo/server/rpc/UGIAssumingProcessor.java  |  2 +-
 .../server/security/AuditedSecurityOperation.java  |  2 +-
 .../server/security/SecurityOperation.java         |  2 +-
 .../accumulo/server/security/SecurityUtil.java     |  2 +-
 .../server/security/SystemCredentials.java         |  2 +-
 .../server/security/UserImpersonation.java         |  2 +-
 .../security/delegation/AuthenticationKey.java     |  2 +-
 .../delegation/AuthenticationTokenKeyManager.java  |  2 +-
 .../AuthenticationTokenSecretManager.java          |  2 +-
 .../ZooAuthenticationKeyDistributor.java           |  2 +-
 .../delegation/ZooAuthenticationKeyWatcher.java    |  2 +-
 .../server/security/handler/Authenticator.java     |  2 +-
 .../server/security/handler/Authorizor.java        |  2 +-
 .../security/handler/KerberosAuthenticator.java    |  2 +-
 .../security/handler/KerberosAuthorizor.java       |  2 +-
 .../handler/KerberosPermissionHandler.java         |  2 +-
 .../server/security/handler/PermissionHandler.java |  2 +-
 .../server/security/handler/ZKAuthenticator.java   |  2 +-
 .../server/security/handler/ZKAuthorizor.java      |  2 +-
 .../server/security/handler/ZKPermHandler.java     |  2 +-
 .../server/security/handler/ZKSecurityTool.java    |  2 +-
 .../tables/IllegalTableTransitionException.java    |  2 +-
 .../accumulo/server/tables/TableManager.java       |  2 +-
 .../accumulo/server/tables/TableObserver.java      |  2 +-
 .../apache/accumulo/server/tablets/TabletTime.java |  2 +-
 .../server/tablets/UniqueNameAllocator.java        |  2 +-
 .../accumulo/server/util/AccumuloStatus.java       |  2 +-
 .../accumulo/server/util/ActionStatsUpdator.java   |  2 +-
 .../org/apache/accumulo/server/util/Admin.java     |  2 +-
 .../apache/accumulo/server/util/ChangeSecret.java  |  2 +-
 .../server/util/CheckForMetadataProblems.java      |  2 +-
 .../accumulo/server/util/CleanZookeeper.java       |  2 +-
 .../apache/accumulo/server/util/ConvertConfig.java |  2 +-
 .../accumulo/server/util/DeleteZooInstance.java    |  2 +-
 .../apache/accumulo/server/util/DumpZookeeper.java |  2 +-
 .../org/apache/accumulo/server/util/ECAdmin.java   |  2 +-
 .../accumulo/server/util/FileSystemMonitor.java    |  2 +-
 .../org/apache/accumulo/server/util/FileUtil.java  |  2 +-
 .../accumulo/server/util/FindOfflineTablets.java   |  2 +-
 .../java/org/apache/accumulo/server/util/Info.java |  2 +-
 .../apache/accumulo/server/util/ListInstances.java |  2 +-
 .../accumulo/server/util/ListVolumesUsed.java      |  2 +-
 .../apache/accumulo/server/util/LocalityCheck.java |  2 +-
 .../accumulo/server/util/LoginProperties.java      |  2 +-
 .../accumulo/server/util/ManagerMetadataUtil.java  |  2 +-
 .../accumulo/server/util/MetadataTableUtil.java    |  2 +-
 .../accumulo/server/util/NamespacePropUtil.java    |  2 +-
 .../org/apache/accumulo/server/util/PortUtils.java |  2 +-
 .../org/apache/accumulo/server/util/PropUtil.java  |  2 +-
 .../apache/accumulo/server/util/RandomWriter.java  |  2 +-
 .../server/util/RemoveEntriesForMissingFiles.java  |  2 +-
 .../accumulo/server/util/ReplicationTableUtil.java |  2 +-
 .../accumulo/server/util/RestoreZookeeper.java     |  2 +-
 .../server/util/ServerBulkImportStatus.java        |  2 +-
 .../accumulo/server/util/SystemPropUtil.java       |  2 +-
 .../accumulo/server/util/TableDiskUsage.java       |  2 +-
 .../apache/accumulo/server/util/TableInfoUtil.java |  2 +-
 .../apache/accumulo/server/util/TablePropUtil.java |  2 +-
 .../accumulo/server/util/TabletServerLocks.java    |  2 +-
 .../server/util/VerifyTabletAssignments.java       |  2 +-
 .../apache/accumulo/server/util/ZooKeeperMain.java |  2 +-
 .../org/apache/accumulo/server/util/ZooZap.java    |  2 +-
 .../server/util/time/BaseRelativeTime.java         |  2 +-
 .../accumulo/server/util/time/ProvidesTime.java    |  2 +-
 .../accumulo/server/util/time/RelativeTime.java    |  2 +-
 .../accumulo/server/util/time/SystemTime.java      |  2 +-
 .../server/zookeeper/DistributedWorkQueue.java     |  2 +-
 .../server/zookeeper/TransactionWatcher.java       |  2 +-
 server/base/src/main/protobuf/replication.proto    |  2 +-
 server/base/src/main/scripts/generate-protobuf.sh  |  4 +--
 server/base/src/main/spotbugs/exclude-filter.xml   |  2 +-
 .../apache/accumulo/server/MockServerContext.java  |  2 +-
 .../apache/accumulo/server/ServerContextTest.java  |  2 +-
 .../org/apache/accumulo/server/ServerDirsTest.java |  2 +-
 .../org/apache/accumulo/server/ServerOptsTest.java |  2 +-
 .../server/ServiceEnvironmentImplTest.java         |  2 +-
 .../org/apache/accumulo/server/WithTestNames.java  |  2 +-
 .../accumulo/server/client/BulkImporterTest.java   |  2 +-
 .../server/conf/CheckCompactionConfigTest.java     |  2 +-
 .../server/conf/NamespaceConfigurationTest.java    |  2 +-
 .../server/conf/RuntimeFixedPropertiesTest.java    |  2 +-
 .../conf/ServerConfigurationFactoryTest.java       |  2 +-
 .../server/conf/SystemConfigurationTest.java       |  2 +-
 .../server/conf/TableConfigurationTest.java        |  2 +-
 .../server/conf/ZooBasedConfigurationTest.java     |  2 +-
 .../server/conf/codec/VersionedPropCodecTest.java  |  2 +-
 .../conf/codec/VersionedPropEncryptCodec.java      |  2 +-
 .../conf/codec/VersionedPropEncryptCodecTest.java  |  2 +-
 .../conf/codec/VersionedPropGzipCodecTest.java     |  2 +-
 .../server/conf/codec/VersionedPropertiesTest.java |  2 +-
 .../server/conf/store/PropStoreKeyTest.java        |  2 +-
 .../conf/store/impl/PropCacheCaffeineImplTest.java |  2 +-
 .../server/conf/store/impl/PropStoreEventTest.java |  2 +-
 .../server/conf/store/impl/ReadyMonitorTest.java   |  2 +-
 .../server/conf/store/impl/ZooPropLoaderTest.java  |  2 +-
 .../server/conf/store/impl/ZooPropStoreTest.java   |  2 +-
 .../server/conf/util/PropSnapshotTest.java         |  2 +-
 .../constraints/MetadataConstraintsTest.java       |  2 +-
 .../accumulo/server/data/ServerMutationTest.java   |  2 +-
 .../apache/accumulo/server/fs/FileTypeTest.java    |  2 +-
 .../accumulo/server/fs/VolumeManagerImplTest.java  |  2 +-
 .../apache/accumulo/server/fs/VolumeUtilTest.java  |  2 +-
 .../accumulo/server/init/InitializeTest.java       |  2 +-
 .../iterators/MetadataBulkLoadFilterTest.java      |  2 +-
 .../server/manager/LiveTServerSetTest.java         |  2 +-
 .../server/manager/state/MergeInfoTest.java        |  2 +-
 .../manager/state/RootTabletStateStoreTest.java    |  2 +-
 .../manager/state/TabletLocationStateTest.java     |  2 +-
 .../BaseHostRegexTableLoadBalancerTest.java        |  2 +-
 .../master/balancer/DefaultLoadBalancerTest.java   |  2 +-
 .../server/master/balancer/GroupBalancerTest.java  |  2 +-
 ...tRegexTableLoadBalancerReconfigurationTest.java |  2 +-
 .../balancer/HostRegexTableLoadBalancerTest.java   |  2 +-
 .../master/balancer/TableLoadBalancerTest.java     |  2 +-
 .../server/problems/ProblemReportTest.java         |  2 +-
 .../problems/ProblemReportingIteratorTest.java     |  2 +-
 .../server/replication/ReplicationUtilTest.java    |  2 +-
 .../server/replication/StatusCombinerTest.java     |  2 +-
 .../server/replication/StatusUtilTest.java         |  2 +-
 .../server/replication/proto/StatusTest.java       |  2 +-
 .../server/rpc/SaslDigestCallbackHandlerTest.java  |  2 +-
 .../server/rpc/SaslServerConnectionParamsTest.java |  2 +-
 .../TCredentialsUpdatingInvocationHandlerTest.java |  2 +-
 .../accumulo/server/rpc/ThriftServerTypeTest.java  |  2 +-
 .../server/security/SystemCredentialsTest.java     |  2 +-
 .../server/security/UserImpersonationTest.java     |  2 +-
 .../security/delegation/AuthenticationKeyTest.java |  2 +-
 .../AuthenticationTokenKeyManagerTest.java         |  2 +-
 .../AuthenticationTokenSecretManagerTest.java      |  2 +-
 .../ZooAuthenticationKeyDistributorTest.java       |  2 +-
 .../ZooAuthenticationKeyWatcherTest.java           |  2 +-
 .../security/handler/ZKAuthenticatorTest.java      |  2 +-
 .../IllegalTableTransitionExceptionTest.java       |  2 +-
 .../accumulo/server/tablets/LogicalTimeTest.java   |  2 +-
 .../accumulo/server/tablets/MillisTimeTest.java    |  2 +-
 .../accumulo/server/tablets/TabletTimeTest.java    |  2 +-
 .../accumulo/server/util/AdminCommandsTest.java    |  2 +-
 .../org/apache/accumulo/server/util/AdminTest.java |  2 +-
 .../apache/accumulo/server/util/FileInfoTest.java  |  2 +-
 .../server/util/FileSystemMonitorTest.java         |  2 +-
 .../apache/accumulo/server/util/FileUtilTest.java  |  2 +-
 .../server/util/ReplicationTableUtilTest.java      |  2 +-
 .../accumulo/server/util/TServerUtilsTest.java     |  2 +-
 .../server/util/time/BaseRelativeTimeTest.java     |  2 +-
 .../server/zookeeper/TransactionWatcherTest.java   |  2 +-
 server/base/src/test/resources/accumulo.properties |  2 +-
 .../base/src/test/resources/log4j2-test.properties |  2 +-
 server/compaction-coordinator/.gitignore           | 32 +++++++++++--------
 server/compaction-coordinator/pom.xml              |  2 +-
 .../coordinator/CompactionCoordinator.java         |  2 +-
 .../accumulo/coordinator/CompactionFinalizer.java  |  2 +-
 .../coordinator/CoordinatorExecutable.java         |  2 +-
 .../coordinator/CoordinatorLockWatcher.java        |  2 +-
 .../coordinator/DeadCompactionDetector.java        |  2 +-
 .../accumulo/coordinator/QueueAndPriority.java     |  2 +-
 .../accumulo/coordinator/QueueSummaries.java       |  2 +-
 .../coordinator/CompactionCoordinatorTest.java     |  2 +-
 .../accumulo/coordinator/QueueSummariesTest.java   |  2 +-
 .../src/test/resources/log4j2-test.properties      |  2 +-
 server/compactor/.gitignore                        | 32 +++++++++++--------
 server/compactor/pom.xml                           |  2 +-
 .../accumulo/compactor/CompactionJobHolder.java    |  2 +-
 .../org/apache/accumulo/compactor/Compactor.java   |  2 +-
 .../accumulo/compactor/CompactorExecutable.java    |  2 +-
 .../org/apache/accumulo/compactor/ExtCEnv.java     |  2 +-
 .../apache/accumulo/compactor/CompactorTest.java   |  2 +-
 .../src/test/resources/log4j2-test.properties      |  2 +-
 server/gc/.gitignore                               | 32 +++++++++++--------
 server/gc/pom.xml                                  |  2 +-
 .../java/org/apache/accumulo/gc/GCExecutable.java  |  2 +-
 .../main/java/org/apache/accumulo/gc/GCRun.java    |  2 +-
 .../accumulo/gc/GarbageCollectWriteAheadLogs.java  |  2 +-
 .../accumulo/gc/GarbageCollectionAlgorithm.java    |  2 +-
 .../accumulo/gc/GarbageCollectionEnvironment.java  |  2 +-
 .../apache/accumulo/gc/SimpleGarbageCollector.java |  2 +-
 .../apache/accumulo/gc/metrics/GcCycleMetrics.java |  2 +-
 .../org/apache/accumulo/gc/metrics/GcMetrics.java  |  2 +-
 .../replication/CloseWriteAheadLogReferences.java  |  2 +-
 server/gc/src/main/spotbugs/exclude-filter.xml     |  2 +-
 .../gc/GarbageCollectWriteAheadLogsTest.java       |  2 +-
 .../apache/accumulo/gc/GarbageCollectionTest.java  |  2 +-
 .../accumulo/gc/SimpleGarbageCollectorTest.java    |  2 +-
 server/gc/src/test/resources/accumulo.properties   |  2 +-
 .../gc/src/test/resources/log4j2-test.properties   |  2 +-
 server/manager/.gitignore                          | 32 +++++++++++--------
 server/manager/pom.xml                             |  2 +-
 .../apache/accumulo/manager/EventCoordinator.java  |  2 +-
 .../accumulo/manager/FateServiceHandler.java       |  2 +-
 .../java/org/apache/accumulo/manager/Manager.java  |  2 +-
 .../manager/ManagerClientServiceHandler.java       |  2 +-
 .../apache/accumulo/manager/ManagerExecutable.java |  2 +-
 .../org/apache/accumulo/manager/ManagerTime.java   |  2 +-
 .../apache/accumulo/manager/MasterExecutable.java  |  2 +-
 .../accumulo/manager/TabletGroupWatcher.java       |  2 +-
 .../accumulo/manager/metrics/ManagerMetrics.java   |  2 +-
 .../manager/metrics/ReplicationMetrics.java        |  2 +-
 .../manager/metrics/fate/FateMetricValues.java     |  2 +-
 .../accumulo/manager/metrics/fate/FateMetrics.java |  2 +-
 .../accumulo/manager/recovery/RecoveryManager.java |  2 +-
 .../DistributedWorkQueueWorkAssigner.java          |  2 +-
 .../manager/replication/FinishedWorkUpdater.java   |  2 +-
 .../replication/ManagerReplicationCoordinator.java |  2 +-
 .../RemoveCompleteReplicationRecords.java          |  2 +-
 .../manager/replication/ReplicationDriver.java     |  2 +-
 .../replication/SequentialWorkAssigner.java        |  2 +-
 .../accumulo/manager/replication/StatusMaker.java  |  2 +-
 .../manager/replication/UnorderedWorkAssigner.java |  2 +-
 .../accumulo/manager/replication/WorkDriver.java   |  2 +-
 .../accumulo/manager/replication/WorkMaker.java    |  2 +-
 .../apache/accumulo/manager/state/MergeStats.java  |  2 +-
 .../accumulo/manager/state/SetGoalState.java       |  2 +-
 .../apache/accumulo/manager/state/TableCounts.java |  2 +-
 .../apache/accumulo/manager/state/TableStats.java  |  2 +-
 .../manager/tableOps/ChangeTableState.java         |  2 +-
 .../accumulo/manager/tableOps/ManagerRepo.java     |  2 +-
 .../accumulo/manager/tableOps/TableInfo.java       |  2 +-
 .../accumulo/manager/tableOps/TraceRepo.java       |  2 +-
 .../apache/accumulo/manager/tableOps/Utils.java    |  2 +-
 .../manager/tableOps/bulkVer1/BulkImport.java      |  2 +-
 .../tableOps/bulkVer1/CleanUpBulkImport.java       |  2 +-
 .../tableOps/bulkVer1/CompleteBulkImport.java      |  2 +-
 .../manager/tableOps/bulkVer1/CopyFailed.java      |  2 +-
 .../manager/tableOps/bulkVer1/LoadFiles.java       |  2 +-
 .../manager/tableOps/bulkVer2/BulkImportMove.java  |  2 +-
 .../manager/tableOps/bulkVer2/BulkInfo.java        |  2 +-
 .../tableOps/bulkVer2/CleanUpBulkImport.java       |  2 +-
 .../tableOps/bulkVer2/CompleteBulkImport.java      |  2 +-
 .../manager/tableOps/bulkVer2/LoadFiles.java       |  2 +-
 .../manager/tableOps/bulkVer2/PrepBulkImport.java  |  2 +-
 .../accumulo/manager/tableOps/clone/CloneInfo.java |  2 +-
 .../manager/tableOps/clone/CloneMetadata.java      |  2 +-
 .../manager/tableOps/clone/ClonePermissions.java   |  2 +-
 .../manager/tableOps/clone/CloneTable.java         |  2 +-
 .../manager/tableOps/clone/CloneZookeeper.java     |  2 +-
 .../manager/tableOps/clone/FinishCloneTable.java   |  2 +-
 .../manager/tableOps/compact/CompactRange.java     |  2 +-
 .../manager/tableOps/compact/CompactionDriver.java |  2 +-
 .../tableOps/compact/cancel/CancelCompactions.java |  2 +-
 .../compact/cancel/FinishCancelCompaction.java     |  2 +-
 .../manager/tableOps/create/ChooseDir.java         |  2 +-
 .../manager/tableOps/create/CreateTable.java       |  2 +-
 .../manager/tableOps/create/FinishCreateTable.java |  2 +-
 .../manager/tableOps/create/PopulateMetadata.java  |  2 +-
 .../manager/tableOps/create/PopulateZookeeper.java |  2 +-
 .../manager/tableOps/create/SetupPermissions.java  |  2 +-
 .../accumulo/manager/tableOps/delete/CleanUp.java  |  2 +-
 .../manager/tableOps/delete/DeleteTable.java       |  2 +-
 .../manager/tableOps/delete/PreDeleteTable.java    |  2 +-
 .../manager/tableOps/merge/TableRangeOp.java       |  2 +-
 .../manager/tableOps/merge/TableRangeOpWait.java   |  2 +-
 .../tableOps/namespace/create/CreateNamespace.java |  2 +-
 .../namespace/create/FinishCreateNamespace.java    |  2 +-
 .../tableOps/namespace/create/NamespaceInfo.java   |  2 +-
 .../create/PopulateZookeeperWithNamespace.java     |  2 +-
 .../create/SetupNamespacePermissions.java          |  2 +-
 .../tableOps/namespace/delete/DeleteNamespace.java |  2 +-
 .../namespace/delete/NamespaceCleanUp.java         |  2 +-
 .../tableOps/namespace/rename/RenameNamespace.java |  2 +-
 .../manager/tableOps/rename/RenameTable.java       |  2 +-
 .../manager/tableOps/tableExport/ExportInfo.java   |  2 +-
 .../manager/tableOps/tableExport/ExportTable.java  |  2 +-
 .../tableOps/tableExport/WriteExportFiles.java     |  2 +-
 .../tableOps/tableImport/CreateImportDir.java      |  2 +-
 .../tableOps/tableImport/FinishImportTable.java    |  2 +-
 .../tableImport/ImportPopulateZookeeper.java       |  2 +-
 .../tableImport/ImportSetupPermissions.java        |  2 +-
 .../manager/tableOps/tableImport/ImportTable.java  |  2 +-
 .../tableOps/tableImport/ImportedTableInfo.java    |  2 +-
 .../tableOps/tableImport/MapImportFileNames.java   |  2 +-
 .../tableOps/tableImport/MoveExportedFiles.java    |  2 +-
 .../tableImport/PopulateMetadataTable.java         |  2 +-
 .../manager/tserverOps/ShutdownTServer.java        |  2 +-
 .../manager/upgrade/RenameMasterDirInZK.java       |  2 +-
 .../manager/upgrade/UpgradeCoordinator.java        |  2 +-
 .../apache/accumulo/manager/upgrade/Upgrader.java  |  2 +-
 .../accumulo/manager/upgrade/Upgrader8to9.java     |  2 +-
 .../accumulo/manager/upgrade/Upgrader9to10.java    |  2 +-
 .../apache/accumulo/manager/util/FateAdmin.java    |  2 +-
 .../java/org/apache/accumulo/master/Master.java    |  2 +-
 .../master/replication/UnorderedWorkAssigner.java  |  2 +-
 .../apache/accumulo/master/state/MergeStats.java   |  2 +-
 .../apache/accumulo/master/state/SetGoalState.java |  2 +-
 .../org/apache/accumulo/master/util/FateAdmin.java |  2 +-
 .../manager/src/main/spotbugs/exclude-filter.xml   |  2 +-
 .../org/apache/accumulo/manager/WithTestNames.java |  2 +-
 .../manager/metrics/ReplicationMetricsTest.java    |  2 +-
 .../manager/metrics/fate/FateMetricValuesTest.java |  2 +-
 ...DistributedWorkQueueWorkAssignerHelperTest.java |  2 +-
 .../ManagerReplicationCoordinatorTest.java         |  2 +-
 .../replication/SequentialWorkAssignerTest.java    |  2 +-
 .../replication/UnorderedWorkAssignerTest.java     |  2 +-
 .../manager/replication/WorkMakerTest.java         |  2 +-
 .../manager/tableOps/ShutdownTServerTest.java      |  2 +-
 .../tableOps/bulkVer2/PrepBulkImportTest.java      |  2 +-
 .../tableOps/compact/CompactionDriverTest.java     |  2 +-
 .../tableOps/tableImport/ImportTableTest.java      |  2 +-
 .../accumulo/manager/upgrade/AccumuloTest.java     |  2 +-
 .../manager/upgrade/RootFilesUpgradeTest.java      |  2 +-
 .../manager/upgrade/Upgrader9to10Test.java         |  2 +-
 .../manager/src/test/resources/accumulo.properties |  2 +-
 .../src/test/resources/conf/accumulo-site.xml      |  2 +-
 .../src/test/resources/conf/generic_logger.xml     |  2 +-
 .../src/test/resources/conf/monitor_logger.xml     |  2 +-
 .../src/test/resources/log4j2-test.properties      |  2 +-
 server/master/.gitignore                           | 32 +++++++++++--------
 server/master/pom.xml                              |  2 +-
 server/monitor/.gitignore                          | 32 +++++++++++--------
 server/monitor/pom.xml                             |  2 +-
 .../apache/accumulo/monitor/EmbeddedWebServer.java |  2 +-
 .../java/org/apache/accumulo/monitor/Monitor.java  |  2 +-
 .../apache/accumulo/monitor/MonitorExecutable.java |  2 +-
 .../accumulo/monitor/rest/SummaryInformation.java  |  2 +-
 .../org/apache/accumulo/monitor/rest/Totals.java   |  2 +-
 .../apache/accumulo/monitor/rest/XMLResource.java  |  2 +-
 .../monitor/rest/bulkImports/BulkImport.java       |  2 +-
 .../rest/bulkImports/BulkImportInformation.java    |  2 +-
 .../rest/bulkImports/BulkImportResource.java       |  2 +-
 .../TabletServerBulkImportInformation.java         |  2 +-
 .../monitor/rest/compactions/CompactionInfo.java   |  2 +-
 .../monitor/rest/compactions/Compactions.java      |  2 +-
 .../rest/compactions/CompactionsResource.java      |  2 +-
 .../compactions/external/CompactionInputFile.java  |  2 +-
 .../rest/compactions/external/CompactorInfo.java   |  2 +-
 .../rest/compactions/external/Compactors.java      |  2 +-
 .../rest/compactions/external/CoordinatorInfo.java |  2 +-
 .../rest/compactions/external/ECResource.java      |  2 +-
 .../external/ExternalCompactionInfo.java           |  2 +-
 .../compactions/external/RunningCompactions.java   |  2 +-
 .../external/RunningCompactorDetails.java          |  2 +-
 .../monitor/rest/gc/GarbageCollectorResource.java  |  2 +-
 .../monitor/rest/gc/GarbageCollectorStats.java     |  2 +-
 .../monitor/rest/gc/GarbageCollectorStatus.java    |  2 +-
 .../monitor/rest/logs/DeadLoggerInformation.java   |  2 +-
 .../accumulo/monitor/rest/logs/DeadLoggerList.java |  2 +-
 .../accumulo/monitor/rest/logs/LogResource.java    |  2 +-
 .../monitor/rest/logs/SanitizedLogEvent.java       |  2 +-
 .../accumulo/monitor/rest/logs/SingleLogEvent.java |  2 +-
 .../monitor/rest/manager/ManagerInformation.java   |  2 +-
 .../monitor/rest/manager/ManagerResource.java      |  2 +-
 .../monitor/rest/problems/ProblemDetail.java       |  2 +-
 .../rest/problems/ProblemDetailInformation.java    |  2 +-
 .../monitor/rest/problems/ProblemSummary.java      |  2 +-
 .../rest/problems/ProblemSummaryInformation.java   |  2 +-
 .../monitor/rest/problems/ProblemsResource.java    |  2 +-
 .../rest/replication/ReplicationInformation.java   |  2 +-
 .../rest/replication/ReplicationResource.java      |  2 +-
 .../monitor/rest/scans/ScanInformation.java        |  2 +-
 .../apache/accumulo/monitor/rest/scans/Scans.java  |  2 +-
 .../accumulo/monitor/rest/scans/ScansResource.java |  2 +-
 .../rest/statistics/StatisticsResource.java        |  2 +-
 .../monitor/rest/status/StatusInformation.java     |  2 +-
 .../monitor/rest/status/StatusResource.java        |  2 +-
 .../monitor/rest/tables/CompactionsList.java       |  2 +-
 .../monitor/rest/tables/CompactionsTypes.java      |  2 +-
 .../monitor/rest/tables/TableInformation.java      |  2 +-
 .../monitor/rest/tables/TableInformationList.java  |  2 +-
 .../monitor/rest/tables/TableNamespace.java        |  2 +-
 .../accumulo/monitor/rest/tables/TablesList.java   |  2 +-
 .../monitor/rest/tables/TablesResource.java        |  2 +-
 .../monitor/rest/trace/AddlInformation.java        |  2 +-
 .../monitor/rest/trace/AnnotationInformation.java  |  2 +-
 .../monitor/rest/trace/DataInformation.java        |  2 +-
 .../rest/trace/RecentTracesInformation.java        |  2 +-
 .../monitor/rest/trace/RecentTracesList.java       |  2 +-
 .../rest/trace/RecoveryStatusInformation.java      |  2 +-
 .../monitor/rest/trace/TraceInformation.java       |  2 +-
 .../accumulo/monitor/rest/trace/TraceList.java     |  2 +-
 .../accumulo/monitor/rest/trace/TraceType.java     |  2 +-
 .../rest/trace/TracesForTypeInformation.java       |  2 +-
 .../monitor/rest/trace/TracesResource.java         |  2 +-
 .../rest/tservers/AllTimeTabletResults.java        |  2 +-
 .../rest/tservers/BadTabletServerInformation.java  |  2 +-
 .../monitor/rest/tservers/BadTabletServers.java    |  2 +-
 .../monitor/rest/tservers/CurrentOperations.java   |  2 +-
 .../rest/tservers/CurrentTabletResults.java        |  2 +-
 .../rest/tservers/DeadServerInformation.java       |  2 +-
 .../monitor/rest/tservers/DeadServerList.java      |  2 +-
 .../tservers/ServerShuttingDownInformation.java    |  2 +-
 .../accumulo/monitor/rest/tservers/ServerStat.java |  2 +-
 .../monitor/rest/tservers/ServerStats.java         |  2 +-
 .../monitor/rest/tservers/ServersShuttingDown.java |  2 +-
 .../monitor/rest/tservers/TabletServer.java        |  2 +-
 .../tservers/TabletServerDetailInformation.java    |  2 +-
 .../rest/tservers/TabletServerInformation.java     |  2 +-
 .../tservers/TabletServerRecoveryInformation.java  |  2 +-
 .../rest/tservers/TabletServerResource.java        |  2 +-
 .../monitor/rest/tservers/TabletServerSummary.java |  2 +-
 .../tservers/TabletServerWithTableInformation.java |  2 +-
 .../monitor/rest/tservers/TabletServers.java       |  2 +-
 .../rest/tservers/TabletServersRecovery.java       |  2 +-
 .../monitor/util/JaxbAbstractIdSerializer.java     |  2 +-
 .../accumulo/monitor/util/ParameterValidator.java  |  2 +-
 .../util/logging/AccumuloMonitorAppender.java      |  2 +-
 .../accumulo/monitor/util/logging/RecentLogs.java  |  2 +-
 .../org/apache/accumulo/monitor/view/WebViews.java |  2 +-
 .../accumulo/monitor/resources/css/screen.css      |  3 +-
 .../accumulo/monitor/resources/js/bulkImport.js    |  2 +-
 .../accumulo/monitor/resources/js/compactions.js   |  2 +-
 .../org/apache/accumulo/monitor/resources/js/ec.js |  2 +-
 .../accumulo/monitor/resources/js/functions.js     |  2 +-
 .../org/apache/accumulo/monitor/resources/js/gc.js |  2 +-
 .../apache/accumulo/monitor/resources/js/global.js |  2 +-
 .../accumulo/monitor/resources/js/listType.js      |  2 +-
 .../accumulo/monitor/resources/js/manager.js       |  2 +-
 .../apache/accumulo/monitor/resources/js/navbar.js |  2 +-
 .../accumulo/monitor/resources/js/overview.js      |  2 +-
 .../accumulo/monitor/resources/js/problems.js      |  2 +-
 .../accumulo/monitor/resources/js/replication.js   |  2 +-
 .../apache/accumulo/monitor/resources/js/scans.js  |  2 +-
 .../apache/accumulo/monitor/resources/js/server.js |  2 +-
 .../apache/accumulo/monitor/resources/js/show.js   |  2 +-
 .../accumulo/monitor/resources/js/summary.js       |  2 +-
 .../apache/accumulo/monitor/resources/js/table.js  |  2 +-
 .../accumulo/monitor/resources/js/tservers.js      |  2 +-
 .../accumulo/monitor/templates/bulkImport.ftl      |  2 +-
 .../accumulo/monitor/templates/compactions.ftl     |  2 +-
 .../apache/accumulo/monitor/templates/default.ftl  |  2 +-
 .../org/apache/accumulo/monitor/templates/ec.ftl   |  2 +-
 .../org/apache/accumulo/monitor/templates/gc.ftl   |  2 +-
 .../apache/accumulo/monitor/templates/listType.ftl |  2 +-
 .../org/apache/accumulo/monitor/templates/log.ftl  |  2 +-
 .../apache/accumulo/monitor/templates/manager.ftl  |  2 +-
 .../apache/accumulo/monitor/templates/modals.ftl   |  2 +-
 .../apache/accumulo/monitor/templates/navbar.ftl   |  2 +-
 .../apache/accumulo/monitor/templates/overview.ftl |  2 +-
 .../apache/accumulo/monitor/templates/problems.ftl |  2 +-
 .../accumulo/monitor/templates/replication.ftl     |  2 +-
 .../apache/accumulo/monitor/templates/scans.ftl    |  2 +-
 .../apache/accumulo/monitor/templates/server.ftl   |  2 +-
 .../org/apache/accumulo/monitor/templates/show.ftl |  2 +-
 .../apache/accumulo/monitor/templates/summary.ftl  |  2 +-
 .../apache/accumulo/monitor/templates/table.ftl    |  2 +-
 .../apache/accumulo/monitor/templates/tables.ftl   |  2 +-
 .../apache/accumulo/monitor/templates/tservers.ftl |  2 +-
 server/monitor/src/main/scripts/format-js.sh       |  2 +-
 .../accumulo/monitor/it/TagNameConstants.java      |  2 +-
 .../org/apache/accumulo/monitor/it/WebViewsIT.java |  2 +-
 .../rest/tservers/TabletServerInformationTest.java |  2 +-
 .../monitor/util/ParameterValidatorTest.java       |  2 +-
 .../src/test/resources/log4j2-test.properties      |  2 +-
 server/native/.gitignore                           | 32 +++++++++++--------
 server/native/pom.xml                              |  2 +-
 server/native/src/main/assemblies/component.xml    |  4 +--
 server/native/src/main/assemblies/native-dir.xml   |  4 +--
 .../native/src/main/assemblies/native-tarball.xml  |  4 +--
 .../native/src/main/c++/nativeMap/BlockAllocator.h |  2 +-
 server/native/src/main/c++/nativeMap/Field.h       |  2 +-
 server/native/src/main/c++/nativeMap/Key.h         |  2 +-
 server/native/src/main/c++/nativeMap/NativeMap.h   |  2 +-
 server/native/src/main/c++/nativeMap/SubKey.h      |  2 +-
 .../org_apache_accumulo_tserver_NativeMap.cc       |  2 +-
 server/native/src/main/resources/Makefile          |  2 +-
 server/native/src/main/resources/NOTICE            |  2 +-
 server/native/src/test/c++/nativeMap/test.cc       |  2 +-
 server/native/src/test/c++/nativeMap/util.cc       |  2 +-
 server/native/src/test/c++/nativeMap/util.h        |  3 +-
 server/tserver/.gitignore                          | 32 +++++++++++--------
 server/tserver/pom.xml                             |  2 +-
 .../accumulo/tserver/ActiveAssignmentRunnable.java |  2 +-
 .../apache/accumulo/tserver/AssignmentHandler.java |  2 +-
 .../accumulo/tserver/BulkFailedCopyProcessor.java  |  2 +-
 .../apache/accumulo/tserver/BusiestTracker.java    |  2 +-
 .../accumulo/tserver/ConditionCheckerContext.java  |  2 +-
 .../accumulo/tserver/ConditionalMutationSet.java   |  2 +-
 .../accumulo/tserver/HoldTimeoutException.java     |  2 +-
 .../org/apache/accumulo/tserver/InMemoryMap.java   |  2 +-
 .../java/org/apache/accumulo/tserver/MemKey.java   |  2 +-
 .../apache/accumulo/tserver/MemKeyComparator.java  |  2 +-
 .../accumulo/tserver/MemKeyConversionIterator.java |  2 +-
 .../java/org/apache/accumulo/tserver/MemValue.java |  2 +-
 .../accumulo/tserver/MinorCompactionReason.java    |  2 +-
 .../org/apache/accumulo/tserver/NativeMap.java     |  2 +-
 .../accumulo/tserver/NativeMapCleanerUtil.java     |  2 +-
 .../org/apache/accumulo/tserver/OnlineTablets.java |  2 +-
 .../tserver/PartialMutationSkippingIterator.java   |  2 +-
 .../java/org/apache/accumulo/tserver/RowLocks.java |  2 +-
 .../apache/accumulo/tserver/RunnableStartedAt.java |  2 +-
 .../apache/accumulo/tserver/TServerExecutable.java |  2 +-
 .../accumulo/tserver/TabletClientHandler.java      |  2 +-
 .../accumulo/tserver/TabletHostingServer.java      |  2 +-
 .../apache/accumulo/tserver/TabletMutations.java   |  2 +-
 .../org/apache/accumulo/tserver/TabletServer.java  |  2 +-
 .../tserver/TabletServerResourceManager.java       |  2 +-
 .../apache/accumulo/tserver/TabletStatsKeeper.java |  2 +-
 .../accumulo/tserver/ThriftScanClientHandler.java  |  2 +-
 .../accumulo/tserver/TservConstraintEnv.java       |  2 +-
 .../accumulo/tserver/UnloadTabletHandler.java      |  2 +-
 .../org/apache/accumulo/tserver/WriteTracker.java  |  2 +-
 .../tserver/compaction/CompactionPlan.java         |  2 +-
 .../tserver/compaction/CompactionStrategy.java     |  2 +-
 .../compaction/DefaultCompactionStrategy.java      |  2 +-
 .../compaction/EverythingCompactionStrategy.java   |  2 +-
 .../tserver/compaction/MajorCompactionReason.java  |  2 +-
 .../tserver/compaction/MajorCompactionRequest.java |  2 +-
 .../compaction/SizeLimitCompactionStrategy.java    |  2 +-
 .../tserver/compaction/WriteParameters.java        |  2 +-
 .../strategies/BasicCompactionStrategy.java        |  2 +-
 .../strategies/ConfigurableCompactionStrategy.java |  2 +-
 .../TooManyDeletesCompactionStrategy.java          |  2 +-
 .../accumulo/tserver/compactions/Compactable.java  |  2 +-
 .../tserver/compactions/CompactionExecutor.java    |  2 +-
 .../tserver/compactions/CompactionManager.java     |  2 +-
 .../tserver/compactions/CompactionService.java     |  2 +-
 .../compactions/ExternalCompactionExecutor.java    |  2 +-
 .../tserver/compactions/ExternalCompactionJob.java |  2 +-
 .../compactions/InternalCompactionExecutor.java    |  2 +-
 .../tserver/compactions/PrintableTable.java        |  2 +-
 .../accumulo/tserver/compactions/SubmittedJob.java |  2 +-
 .../tserver/constraints/ConstraintChecker.java     |  2 +-
 .../tserver/constraints/SystemConstraint.java      |  2 +-
 .../constraints/UnsatisfiableConstraint.java       |  2 +-
 .../tserver/data/ServerConditionalMutation.java    |  2 +-
 .../accumulo/tserver/log/CloseableIterator.java    |  2 +-
 .../org/apache/accumulo/tserver/log/DfsLogger.java |  2 +-
 .../org/apache/accumulo/tserver/log/LogSorter.java |  2 +-
 .../accumulo/tserver/log/MutationReceiver.java     |  2 +-
 .../accumulo/tserver/log/RecoveryLogsIterator.java |  2 +-
 .../accumulo/tserver/log/SortedLogRecovery.java    |  2 +-
 .../accumulo/tserver/log/TabletServerLogger.java   |  2 +-
 .../apache/accumulo/tserver/logger/LogEvents.java  |  2 +-
 .../apache/accumulo/tserver/logger/LogFileKey.java |  2 +-
 .../accumulo/tserver/logger/LogFileValue.java      |  2 +-
 .../apache/accumulo/tserver/logger/LogReader.java  |  2 +-
 .../tserver/managermessage/ManagerMessage.java     |  2 +-
 .../tserver/managermessage/SplitReportMessage.java |  2 +-
 .../managermessage/TabletStatusMessage.java        |  2 +-
 .../tserver/memory/LargestFirstMemoryManager.java  |  2 +-
 .../accumulo/tserver/memory/NativeMapLoader.java   |  2 +-
 .../tserver/memory/TabletMemoryReport.java         |  2 +-
 .../metrics/CompactionExecutorsMetrics.java        |  2 +-
 .../tserver/metrics/TabletServerMetrics.java       |  2 +-
 .../tserver/metrics/TabletServerMetricsUtil.java   |  2 +-
 .../tserver/metrics/TabletServerMinCMetrics.java   |  2 +-
 .../tserver/metrics/TabletServerScanMetrics.java   |  2 +-
 .../tserver/metrics/TabletServerUpdateMetrics.java |  2 +-
 .../tserver/replication/AccumuloReplicaSystem.java |  2 +-
 .../BatchWriterReplicationReplayer.java            |  2 +-
 .../tserver/replication/ReplicationProcessor.java  |  2 +-
 .../replication/ReplicationServicerHandler.java    |  2 +-
 .../tserver/replication/ReplicationStats.java      |  2 +-
 .../tserver/replication/ReplicationWorker.java     |  2 +-
 .../tserver/replication/WalClientExecReturn.java   |  2 +-
 .../tserver/replication/WalReplication.java        |  2 +-
 .../apache/accumulo/tserver/scan/LookupTask.java   |  2 +-
 .../accumulo/tserver/scan/NextBatchTask.java       |  2 +-
 .../accumulo/tserver/scan/ScanParameters.java      |  2 +-
 .../apache/accumulo/tserver/scan/ScanRunState.java |  2 +-
 .../org/apache/accumulo/tserver/scan/ScanTask.java |  2 +-
 .../tserver/session/ConditionalSession.java        |  2 +-
 .../accumulo/tserver/session/MultiScanSession.java |  2 +-
 .../accumulo/tserver/session/ScanSession.java      |  2 +-
 .../apache/accumulo/tserver/session/Session.java   |  2 +-
 .../accumulo/tserver/session/SessionManager.java   |  2 +-
 .../tserver/session/SingleScanSession.java         |  2 +-
 .../accumulo/tserver/session/SummarySession.java   |  2 +-
 .../accumulo/tserver/session/UpdateSession.java    |  2 +-
 .../org/apache/accumulo/tserver/tablet/Batch.java  |  2 +-
 .../tserver/tablet/BulkImportCacheCleaner.java     |  2 +-
 .../accumulo/tserver/tablet/CommitSession.java     |  2 +-
 .../accumulo/tserver/tablet/CompactableImpl.java   |  2 +-
 .../accumulo/tserver/tablet/CompactableUtils.java  |  2 +-
 .../accumulo/tserver/tablet/DatafileManager.java   |  2 +-
 .../apache/accumulo/tserver/tablet/KVEntry.java    |  2 +-
 .../apache/accumulo/tserver/tablet/MajCEnv.java    |  2 +-
 .../tserver/tablet/MetadataUpdateCount.java        |  2 +-
 .../apache/accumulo/tserver/tablet/MinCEnv.java    |  2 +-
 .../tserver/tablet/MinorCompactionTask.java        |  2 +-
 .../accumulo/tserver/tablet/MinorCompactor.java    |  2 +-
 .../accumulo/tserver/tablet/PreparedMutations.java |  2 +-
 .../org/apache/accumulo/tserver/tablet/Rate.java   |  2 +-
 .../apache/accumulo/tserver/tablet/ScanBatch.java  |  2 +-
 .../accumulo/tserver/tablet/ScanDataSource.java    |  2 +-
 .../apache/accumulo/tserver/tablet/Scanner.java    |  2 +-
 .../accumulo/tserver/tablet/SplitRowSpec.java      |  2 +-
 .../org/apache/accumulo/tserver/tablet/Tablet.java |  2 +-
 .../apache/accumulo/tserver/tablet/TabletBase.java |  2 +-
 .../tserver/tablet/TabletClosedException.java      |  2 +-
 .../apache/accumulo/tserver/tablet/TabletData.java |  2 +-
 .../accumulo/tserver/tablet/TabletMemory.java      |  2 +-
 .../tserver/src/main/spotbugs/exclude-filter.xml   |  2 +-
 .../accumulo/tserver/AssignmentWatcherTest.java    |  2 +-
 .../accumulo/tserver/BusiestTrackerTest.java       |  2 +-
 .../accumulo/tserver/CheckTabletMetadataTest.java  |  2 +-
 .../accumulo/tserver/CountingIteratorTest.java     |  2 +-
 .../apache/accumulo/tserver/InMemoryMapTest.java   |  2 +-
 .../org/apache/accumulo/tserver/MemValueTest.java  |  2 +-
 .../tserver/TabletResourceManagerTest.java         |  2 +-
 .../tserver/TabletServerSyncCheckTest.java         |  2 +-
 .../accumulo/tserver/TservConstraintEnvTest.java   |  2 +-
 .../accumulo/tserver/WalRemovalOrderTest.java      |  2 +-
 .../org/apache/accumulo/tserver/WithTestNames.java |  2 +-
 .../tserver/compaction/CompactableUtilsTest.java   |  2 +-
 .../tserver/compaction/CompactionPlanTest.java     |  2 +-
 .../compaction/DefaultCompactionStrategyTest.java  |  2 +-
 .../SizeLimitCompactionStrategyTest.java           |  2 +-
 .../tserver/compaction/SizeWindowTest.java         |  2 +-
 .../strategies/BasicCompactionStrategyTest.java    |  2 +-
 .../ConfigurableCompactionStrategyTest.java        |  2 +-
 .../tserver/constraints/ConstraintCheckerTest.java |  2 +-
 .../apache/accumulo/tserver/log/DfsLoggerTest.java |  2 +-
 .../apache/accumulo/tserver/log/LogEventsTest.java |  2 +-
 .../accumulo/tserver/log/LogFileKeyTest.java       |  2 +-
 .../tserver/log/RecoveryLogsIteratorTest.java      |  2 +-
 .../tserver/log/SortedLogRecoveryTest.java         |  2 +-
 .../tserver/log/TestUpgradePathForWALogs.java      |  2 +-
 .../accumulo/tserver/logger/LogFileTest.java       |  2 +-
 .../memory/LargestFirstMemoryManagerTest.java      |  2 +-
 .../replication/AccumuloReplicaSystemTest.java     |  2 +-
 .../BatchWriterReplicationReplayerTest.java        |  2 +-
 .../replication/ReplicationProcessorTest.java      |  2 +-
 .../tablet/CompactableImplFileManagerTest.java     |  2 +-
 .../tserver/tablet/CompactableImplTest.java        |  2 +-
 .../tablet/TabletMutationPrepAttemptTest.java      |  2 +-
 .../apache/accumulo/tserver/tablet/TabletTest.java |  2 +-
 .../src/test/resources/log4j2-test.properties      |  2 +-
 shell/.gitignore                                   | 32 +++++++++++--------
 shell/pom.xml                                      |  2 +-
 .../main/java/org/apache/accumulo/shell/Shell.java |  2 +-
 .../accumulo/shell/ShellCommandException.java      |  2 +-
 .../org/apache/accumulo/shell/ShellCompletor.java  |  2 +-
 .../org/apache/accumulo/shell/ShellExtension.java  |  2 +-
 .../org/apache/accumulo/shell/ShellOptions.java    |  2 +-
 .../org/apache/accumulo/shell/ShellOptionsJC.java  |  2 +-
 .../java/org/apache/accumulo/shell/ShellUtil.java  |  2 +-
 .../main/java/org/apache/accumulo/shell/Token.java |  2 +-
 .../accumulo/shell/commands/AboutCommand.java      |  2 +-
 .../shell/commands/ActiveCompactionHelper.java     |  2 +-
 .../shell/commands/ActiveScanIterator.java         |  2 +-
 .../accumulo/shell/commands/AddAuthsCommand.java   |  2 +-
 .../accumulo/shell/commands/AddSplitsCommand.java  |  2 +-
 .../shell/commands/AuthenticateCommand.java        |  2 +-
 .../shell/commands/BulkImportListIterator.java     |  2 +-
 .../apache/accumulo/shell/commands/ByeCommand.java |  2 +-
 .../accumulo/shell/commands/ClasspathCommand.java  |  2 +-
 .../accumulo/shell/commands/ClearCommand.java      |  2 +-
 .../accumulo/shell/commands/CloneTableCommand.java |  2 +-
 .../apache/accumulo/shell/commands/ClsCommand.java |  2 +-
 .../accumulo/shell/commands/CompactCommand.java    |  2 +-
 .../accumulo/shell/commands/ConfigCommand.java     |  2 +-
 .../accumulo/shell/commands/ConstraintCommand.java |  2 +-
 .../shell/commands/CreateNamespaceCommand.java     |  2 +-
 .../shell/commands/CreateTableCommand.java         |  2 +-
 .../accumulo/shell/commands/CreateUserCommand.java |  2 +-
 .../apache/accumulo/shell/commands/DUCommand.java  |  2 +-
 .../accumulo/shell/commands/DebugCommand.java      |  2 +-
 .../shell/commands/DeleteAuthsCommand.java         |  2 +-
 .../accumulo/shell/commands/DeleteCommand.java     |  2 +-
 .../accumulo/shell/commands/DeleteIterCommand.java |  2 +-
 .../accumulo/shell/commands/DeleteManyCommand.java |  2 +-
 .../shell/commands/DeleteNamespaceCommand.java     |  2 +-
 .../accumulo/shell/commands/DeleteRowsCommand.java |  2 +-
 .../shell/commands/DeleteScanIterCommand.java      |  2 +-
 .../shell/commands/DeleteShellIterCommand.java     |  2 +-
 .../shell/commands/DeleteTableCommand.java         |  2 +-
 .../accumulo/shell/commands/DeleteUserCommand.java |  2 +-
 .../accumulo/shell/commands/DropTableCommand.java  |  2 +-
 .../accumulo/shell/commands/DropUserCommand.java   |  2 +-
 .../accumulo/shell/commands/EGrepCommand.java      |  2 +-
 .../accumulo/shell/commands/ExecfileCommand.java   |  2 +-
 .../accumulo/shell/commands/ExitCommand.java       |  2 +-
 .../shell/commands/ExportTableCommand.java         |  2 +-
 .../accumulo/shell/commands/ExtensionCommand.java  |  2 +-
 .../accumulo/shell/commands/FateCommand.java       |  2 +-
 .../accumulo/shell/commands/FlushCommand.java      |  2 +-
 .../accumulo/shell/commands/FormatterCommand.java  |  2 +-
 .../accumulo/shell/commands/GetAuthsCommand.java   |  2 +-
 .../accumulo/shell/commands/GetGroupsCommand.java  |  2 +-
 .../accumulo/shell/commands/GetSplitsCommand.java  |  2 +-
 .../accumulo/shell/commands/GrantCommand.java      |  2 +-
 .../accumulo/shell/commands/GrepCommand.java       |  2 +-
 .../accumulo/shell/commands/HelpCommand.java       |  2 +-
 .../accumulo/shell/commands/HiddenCommand.java     |  2 +-
 .../accumulo/shell/commands/HistoryCommand.java    |  2 +-
 .../shell/commands/ImportDirectoryCommand.java     |  2 +-
 .../shell/commands/ImportTableCommand.java         |  2 +-
 .../accumulo/shell/commands/InfoCommand.java       |  2 +-
 .../accumulo/shell/commands/InsertCommand.java     |  2 +-
 .../shell/commands/InterpreterCommand.java         |  2 +-
 .../accumulo/shell/commands/ListBulkCommand.java   |  2 +-
 .../shell/commands/ListCompactionsCommand.java     |  2 +-
 .../accumulo/shell/commands/ListIterCommand.java   |  2 +-
 .../accumulo/shell/commands/ListScansCommand.java  |  2 +-
 .../shell/commands/ListShellIterCommand.java       |  2 +-
 .../shell/commands/ListTabletsCommand.java         |  2 +-
 .../accumulo/shell/commands/MaxRowCommand.java     |  2 +-
 .../accumulo/shell/commands/MergeCommand.java      |  2 +-
 .../commands/NamespacePermissionsCommand.java      |  2 +-
 .../accumulo/shell/commands/NamespacesCommand.java |  2 +-
 .../accumulo/shell/commands/NoTableCommand.java    |  2 +-
 .../accumulo/shell/commands/OfflineCommand.java    |  2 +-
 .../accumulo/shell/commands/OnlineCommand.java     |  2 +-
 .../apache/accumulo/shell/commands/OptUtil.java    |  2 +-
 .../accumulo/shell/commands/PasswdCommand.java     |  2 +-
 .../accumulo/shell/commands/PingCommand.java       |  2 +-
 .../accumulo/shell/commands/PingIterator.java      |  2 +-
 .../accumulo/shell/commands/QuestionCommand.java   |  2 +-
 .../accumulo/shell/commands/QuitCommand.java       |  2 +-
 .../shell/commands/QuotedStringTokenizer.java      |  2 +-
 .../shell/commands/RenameNamespaceCommand.java     |  2 +-
 .../shell/commands/RenameTableCommand.java         |  2 +-
 .../accumulo/shell/commands/RevokeCommand.java     |  2 +-
 .../accumulo/shell/commands/ScanCommand.java       |  2 +-
 .../accumulo/shell/commands/ScriptCommand.java     |  4 +--
 .../accumulo/shell/commands/SetAuthsCommand.java   |  2 +-
 .../accumulo/shell/commands/SetGroupsCommand.java  |  2 +-
 .../accumulo/shell/commands/SetIterCommand.java    |  2 +-
 .../shell/commands/SetScanIterCommand.java         |  2 +-
 .../shell/commands/SetShellIterCommand.java        |  2 +-
 .../commands/ShellPluginConfigurationCommand.java  |  2 +-
 .../accumulo/shell/commands/SleepCommand.java      |  2 +-
 .../accumulo/shell/commands/SummariesCommand.java  |  2 +-
 .../shell/commands/SystemPermissionsCommand.java   |  2 +-
 .../accumulo/shell/commands/TableCommand.java      |  2 +-
 .../accumulo/shell/commands/TableOperation.java    |  2 +-
 .../shell/commands/TablePermissionsCommand.java    |  2 +-
 .../accumulo/shell/commands/TablesCommand.java     |  2 +-
 .../accumulo/shell/commands/TraceCommand.java      |  2 +-
 .../accumulo/shell/commands/UserCommand.java       |  2 +-
 .../shell/commands/UserPermissionsCommand.java     |  2 +-
 .../accumulo/shell/commands/UsersCommand.java      |  2 +-
 .../accumulo/shell/commands/WhoAmICommand.java     |  2 +-
 .../accumulo/shell/format/DeleterFormatter.java    |  2 +-
 shell/src/main/resources/.gitignore                |  0
 shell/src/main/spotbugs/exclude-filter.xml         |  2 +-
 .../org/apache/accumulo/shell/ShellConfigTest.java |  2 +-
 .../apache/accumulo/shell/ShellOptionsJCTest.java  |  2 +-
 .../org/apache/accumulo/shell/ShellUtilTest.java   |  2 +-
 .../shell/commands/CompactCommandTest.java         |  2 +-
 .../shell/commands/DeleteAuthsCommandTest.java     |  2 +-
 .../shell/commands/DeleteManyCommandTest.java      |  2 +-
 .../shell/commands/DeleteRowsCommandTest.java      |  2 +-
 .../shell/commands/DeleteTableCommandTest.java     |  2 +-
 .../shell/commands/DropUserCommandTest.java        |  2 +-
 .../accumulo/shell/commands/FateCommandTest.java   |  2 +-
 .../accumulo/shell/commands/FlushCommandTest.java  |  2 +-
 .../shell/commands/GetAuthsCommandTest.java        |  2 +-
 .../shell/commands/HistoryCommandTest.java         |  2 +-
 .../shell/commands/ImportDirectoryCommandTest.java |  2 +-
 .../shell/commands/ListBulkCommandTest.java        |  2 +-
 .../shell/commands/ListTabletsCommandTest.java     |  2 +-
 .../accumulo/shell/commands/MergeCommandTest.java  |  2 +-
 .../accumulo/shell/commands/ScanCommandTest.java   |  2 +-
 .../shell/commands/SetIterCommandTest.java         |  2 +-
 .../shell/format/DeleterFormatterTest.java         |  2 +-
 shell/src/test/resources/log4j2-test.properties    |  2 +-
 src/site/site.xml                                  | 12 ++++----
 start/.gitignore                                   | 32 +++++++++++--------
 start/pom.xml                                      |  2 +-
 .../main/java/org/apache/accumulo/start/Main.java  |  2 +-
 .../java/org/apache/accumulo/start/TestMain.java   |  2 +-
 .../start/classloader/AccumuloClassLoader.java     |  2 +-
 .../vfs/AccumuloReloadingVFSClassLoader.java       |  2 +-
 .../classloader/vfs/AccumuloVFSClassLoader.java    |  2 +-
 .../start/classloader/vfs/ContextManager.java      |  2 +-
 .../start/classloader/vfs/MiniDFSUtil.java         |  2 +-
 .../vfs/PostDelegatingVFSClassLoader.java          |  2 +-
 .../classloader/vfs/ReloadingClassLoader.java      |  2 +-
 .../classloader/vfs/UniqueFileReplicator.java      |  2 +-
 .../accumulo/start/spi/KeywordExecutable.java      |  2 +-
 start/src/main/spotbugs/exclude-filter.xml         |  2 +-
 .../classloader/vfs/AccumuloClasspathTest.java     |  2 +-
 .../vfs/AccumuloReloadingVFSClassLoaderTest.java   |  2 +-
 .../vfs/AccumuloVFSClassLoaderTest.java            |  2 +-
 .../start/classloader/vfs/ContextManagerTest.java  |  2 +-
 .../start/classloader/vfs/WithTestNames.java       |  2 +-
 .../vfs/providers/VfsClassLoaderTest.java          |  2 +-
 .../accumulo/start/test/AccumuloDFSBase.java       |  2 +-
 start/src/test/java/test/HelloWorldTemplate        |  2 +-
 start/src/test/java/test/Test.java                 |  2 +-
 start/src/test/java/test/TestTemplate              |  2 +-
 start/src/test/resources/log4j2-test.properties    |  2 +-
 start/src/test/shell/makeHelloWorldJars.sh         |  2 +-
 start/src/test/shell/makeTestJars.sh               |  2 +-
 test/.gitignore                                    | 36 ++++++++++++----------
 test/pom.xml                                       |  2 +-
 .../accumulo/harness/AccumuloClusterHarness.java   |  2 +-
 .../apache/accumulo/harness/AccumuloITBase.java    |  2 +-
 .../harness/MiniClusterConfigurationCallback.java  |  2 +-
 .../accumulo/harness/MiniClusterHarness.java       |  2 +-
 .../accumulo/harness/SharedMiniClusterBase.java    |  2 +-
 .../org/apache/accumulo/harness/TestingKdc.java    |  2 +-
 .../java/org/apache/accumulo/harness/Timeout.java  |  2 +-
 .../org/apache/accumulo/harness/WithTestNames.java |  2 +-
 .../harness/conf/AccumuloClusterConfiguration.java |  2 +-
 .../conf/AccumuloClusterPropertyConfiguration.java |  2 +-
 .../conf/AccumuloMiniClusterConfiguration.java     |  2 +-
 .../StandaloneAccumuloClusterConfiguration.java    |  2 +-
 .../org/apache/accumulo/test/AuditMessageIT.java   |  2 +-
 .../accumulo/test/BadDeleteMarkersCreatedIT.java   |  2 +-
 .../java/org/apache/accumulo/test/BalanceIT.java   |  2 +-
 .../accumulo/test/BalanceWithOfflineTableIT.java   |  2 +-
 .../org/apache/accumulo/test/BatchWriterIT.java    |  2 +-
 .../accumulo/test/BatchWriterInTabletServerIT.java |  2 +-
 .../apache/accumulo/test/BatchWriterIterator.java  |  2 +-
 .../accumulo/test/BulkImportMonitoringIT.java      |  2 +-
 .../accumulo/test/BulkImportSequentialRowsIT.java  |  2 +-
 .../apache/accumulo/test/BulkImportVolumeIT.java   |  2 +-
 .../apache/accumulo/test/ChaoticLoadBalancer.java  |  2 +-
 .../java/org/apache/accumulo/test/CleanWalIT.java  |  2 +-
 .../apache/accumulo/test/ClientSideIteratorIT.java |  2 +-
 .../java/org/apache/accumulo/test/CloneIT.java     |  2 +-
 .../org/apache/accumulo/test/CloseScannerIT.java   |  2 +-
 .../apache/accumulo/test/ConditionalWriterIT.java  |  2 +-
 .../accumulo/test/CountNameNodeOpsBulkIT.java      |  2 +-
 .../accumulo/test/DeprecatedPropertyUtilIT.java    |  2 +-
 .../accumulo/test/DetectDeadTabletServersIT.java   |  2 +-
 .../org/apache/accumulo/test/DumpConfigIT.java     |  2 +-
 .../org/apache/accumulo/test/ExistingMacIT.java    |  2 +-
 .../apache/accumulo/test/FairVolumeChooser.java    |  2 +-
 .../java/org/apache/accumulo/test/FindMaxIT.java   |  2 +-
 .../apache/accumulo/test/GarbageCollectWALIT.java  |  2 +-
 .../accumulo/test/GenerateSequentialRFile.java     |  2 +-
 .../org/apache/accumulo/test/GetManagerStats.java  |  2 +-
 .../org/apache/accumulo/test/HardListIterator.java |  2 +-
 .../org/apache/accumulo/test/ImportExportIT.java   |  2 +-
 .../org/apache/accumulo/test/InMemoryMapIT.java    |  2 +-
 .../accumulo/test/InterruptibleScannersIT.java     |  2 +-
 .../accumulo/test/IsolationAndDeepCopyIT.java      |  2 +-
 .../org/apache/accumulo/test/IteratorEnvIT.java    |  2 +-
 .../apache/accumulo/test/KeyValueEqualityIT.java   |  2 +-
 .../org/apache/accumulo/test/LargeSplitRowIT.java  |  2 +-
 .../java/org/apache/accumulo/test/LocatorIT.java   |  2 +-
 .../test/ManagerRepairsDualAssignmentIT.java       |  2 +-
 .../accumulo/test/MetaConstraintRetryIT.java       |  2 +-
 .../apache/accumulo/test/MetaGetsReadersIT.java    |  2 +-
 .../org/apache/accumulo/test/MetaRecoveryIT.java   |  2 +-
 .../java/org/apache/accumulo/test/MetaSplitIT.java |  2 +-
 .../test/MissingWalHeaderCompletesRecoveryIT.java  |  2 +-
 .../accumulo/test/MultiTableBatchWriterIT.java     |  2 +-
 .../apache/accumulo/test/MultiTableRecoveryIT.java |  2 +-
 .../org/apache/accumulo/test/NamespacesIT.java     |  2 +-
 .../accumulo/test/NewTableConfigurationIT.java     |  2 +-
 .../org/apache/accumulo/test/OrIteratorIT.java     |  2 +-
 .../test/RecoveryCompactionsAreFlushesIT.java      |  2 +-
 .../java/org/apache/accumulo/test/SampleIT.java    |  2 +-
 .../apache/accumulo/test/ScanFlushWithTimeIT.java  |  2 +-
 .../org/apache/accumulo/test/SplitRecoveryIT.java  |  2 +-
 .../accumulo/test/TableConfigurationUpdateIT.java  |  2 +-
 .../apache/accumulo/test/TableOperationsIT.java    |  2 +-
 .../accumulo/test/TabletServerGivesUpIT.java       |  2 +-
 .../accumulo/test/TabletServerHdfsRestartIT.java   |  2 +-
 .../org/apache/accumulo/test/TestBinaryRows.java   |  2 +-
 .../java/org/apache/accumulo/test/TestIngest.java  |  2 +-
 .../apache/accumulo/test/TestMultiTableIngest.java |  2 +-
 .../apache/accumulo/test/TestRandomDeletes.java    |  2 +-
 .../ThriftServerBindsBeforeZooKeeperLockIT.java    |  2 +-
 .../org/apache/accumulo/test/TotalQueuedIT.java    |  2 +-
 .../apache/accumulo/test/TransportCachingIT.java   |  2 +-
 .../java/org/apache/accumulo/test/UnusedWALIT.java |  2 +-
 .../java/org/apache/accumulo/test/UsersIT.java     |  2 +-
 .../org/apache/accumulo/test/VerifyIngest.java     |  2 +-
 .../accumulo/test/VerifySerialRecoveryIT.java      |  2 +-
 .../org/apache/accumulo/test/VolumeChooserIT.java  |  2 +-
 .../java/org/apache/accumulo/test/VolumeIT.java    |  2 +-
 .../org/apache/accumulo/test/WaitForBalanceIT.java |  2 +-
 .../org/apache/accumulo/test/YieldScannersIT.java  |  2 +-
 .../accumulo/test/ZooKeeperPropertiesIT.java       |  2 +-
 .../test/compaction/CompactionExecutorIT.java      |  3 +-
 .../CompactionRateLimitingDeprecatedIT.java        |  2 +-
 .../test/compaction/CompactionRateLimitingIT.java  |  2 +-
 .../compaction/ConfigurableMajorCompactionIT.java  |  2 +-
 .../compaction/ExternalCompactionMetricsIT.java    |  2 +-
 .../compaction/ExternalCompactionProgressIT.java   |  2 +-
 .../test/compaction/ExternalCompactionTServer.java |  2 +-
 .../compaction/ExternalCompactionTestUtils.java    |  2 +-
 .../test/compaction/ExternalCompaction_1_IT.java   |  2 +-
 .../test/compaction/ExternalCompaction_2_IT.java   |  2 +-
 .../test/compaction/ExternalCompaction_3_IT.java   |  2 +-
 .../compaction/ExternalDoNothingCompactor.java     |  2 +-
 ...ttingExternalCompactionTabletClientHandler.java |  2 +-
 .../test/compaction/SizeCompactionStrategy.java    |  2 +-
 .../test/compaction/SplitCancelsMajCIT.java        |  2 +-
 .../TestCompactionCoordinatorForOfflineTable.java  |  2 +-
 .../test/compaction/TestCompactionStrategy.java    |  2 +-
 .../test/compaction/UserCompactionStrategyIT.java  |  2 +-
 .../accumulo/test/conf/PropStoreConfigIT.java      |  2 +-
 .../test/conf/store/PropCacheCaffeineImplZkIT.java |  2 +-
 .../test/conf/store/PropStoreZooKeeperIT.java      |  2 +-
 .../accumulo/test/conf/store/ZooBasedConfigIT.java |  2 +-
 .../test/conf/util/ConfigTransformerIT.java        |  2 +-
 .../accumulo/test/conf/util/LegacyPropData.java    |  2 +-
 .../accumulo/test/conf/util/TransformTokenIT.java  |  2 +-
 .../test/constraints/AlphaNumKeyConstraint.java    |  2 +-
 .../accumulo/test/constraints/MaxMutationSize.java |  2 +-
 .../test/constraints/NumericValueConstraint.java   |  2 +-
 .../accumulo/test/fate/zookeeper/FateIT.java       |  2 +-
 .../test/fate/zookeeper/ServiceLockIT.java         |  2 +-
 .../accumulo/test/fate/zookeeper/ZooMutatorIT.java |  2 +-
 .../accumulo/test/functional/AccumuloClientIT.java |  2 +-
 .../accumulo/test/functional/AddSplitIT.java       |  2 +-
 .../accumulo/test/functional/AuthsIterator.java    |  2 +-
 .../accumulo/test/functional/BackupManagerIT.java  |  2 +-
 .../accumulo/test/functional/BadCombiner.java      |  2 +-
 .../accumulo/test/functional/BadIterator.java      |  2 +-
 .../test/functional/BadIteratorMincIT.java         |  2 +-
 .../test/functional/BadLocalityGroupMincIT.java    |  2 +-
 .../functional/BalanceAfterCommsFailureIT.java     |  2 +-
 .../BalanceInPresenceOfOfflineTableIT.java         |  2 +-
 .../accumulo/test/functional/BasicSummarizer.java  |  2 +-
 .../accumulo/test/functional/BatchScanSplitIT.java |  2 +-
 .../test/functional/BatchWriterFlushIT.java        |  2 +-
 .../accumulo/test/functional/BigRootTabletIT.java  |  2 +-
 .../apache/accumulo/test/functional/BinaryIT.java  |  2 +-
 .../accumulo/test/functional/BinaryStressIT.java   |  2 +-
 .../accumulo/test/functional/BloomFilterIT.java    |  2 +-
 .../accumulo/test/functional/BulkFailureIT.java    |  2 +-
 .../apache/accumulo/test/functional/BulkIT.java    |  2 +-
 .../apache/accumulo/test/functional/BulkNewIT.java |  2 +-
 .../apache/accumulo/test/functional/BulkOldIT.java |  2 +-
 .../test/functional/BulkSplitOptimizationIT.java   |  2 +-
 .../accumulo/test/functional/CacheTestClean.java   |  2 +-
 .../accumulo/test/functional/CacheTestReader.java  |  2 +-
 .../accumulo/test/functional/CacheTestWriter.java  |  2 +-
 .../test/functional/ChaoticBalancerIT.java         |  2 +-
 .../accumulo/test/functional/ClassLoaderIT.java    |  2 +-
 .../accumulo/test/functional/CleanTmpIT.java       |  2 +-
 .../apache/accumulo/test/functional/CleanUpIT.java |  2 +-
 .../accumulo/test/functional/CloneTestIT.java      |  2 +-
 .../accumulo/test/functional/CombinerIT.java       |  2 +-
 .../accumulo/test/functional/CompactionIT.java     |  2 +-
 .../accumulo/test/functional/ConcurrencyIT.java    |  2 +-
 .../test/functional/ConcurrentDeleteTableIT.java   |  2 +-
 .../test/functional/ConfigurableCompactionIT.java  |  2 +-
 .../test/functional/ConfigurableMacBase.java       |  2 +-
 .../accumulo/test/functional/ConstraintIT.java     |  2 +-
 .../accumulo/test/functional/CreateAndUseIT.java   |  2 +-
 .../test/functional/CreateInitialSplitsIT.java     |  2 +-
 .../test/functional/CreateManyScannersIT.java      |  2 +-
 .../accumulo/test/functional/CredentialsIT.java    |  2 +-
 .../test/functional/DeleteEverythingIT.java        |  2 +-
 .../accumulo/test/functional/DeleteFailIT.java     |  2 +-
 .../apache/accumulo/test/functional/DeleteIT.java  |  2 +-
 .../accumulo/test/functional/DeleteRowsIT.java     |  2 +-
 .../test/functional/DeleteRowsSplitIT.java         |  2 +-
 .../test/functional/DeletedTablesDontFlushIT.java  |  2 +-
 .../accumulo/test/functional/DropModIter.java      |  2 +-
 .../accumulo/test/functional/DurabilityIT.java     |  2 +-
 .../test/functional/FateConcurrencyIT.java         |  2 +-
 .../accumulo/test/functional/FateStarvationIT.java |  2 +-
 .../accumulo/test/functional/FlushNoFileIT.java    |  2 +-
 .../test/functional/FunctionalTestUtils.java       |  2 +-
 .../test/functional/GarbageCollectorIT.java        |  2 +-
 .../test/functional/HalfDeadTServerIT.java         |  2 +-
 .../functional/IteratorMincClassCastBugIT.java     |  2 +-
 .../accumulo/test/functional/KerberosIT.java       |  2 +-
 .../test/functional/KerberosRenewalIT.java         |  2 +-
 .../accumulo/test/functional/LargeRowIT.java       |  2 +-
 .../test/functional/LateLastContactIT.java         |  2 +-
 .../accumulo/test/functional/LogicalTimeIT.java    |  2 +-
 .../accumulo/test/functional/ManagerApiIT.java     |  2 +-
 .../test/functional/ManagerAssignmentIT.java       |  2 +-
 .../test/functional/ManagerFailoverIT.java         |  2 +-
 .../test/functional/ManyWriteAheadLogsIT.java      |  2 +-
 .../apache/accumulo/test/functional/MaxOpenIT.java |  2 +-
 .../apache/accumulo/test/functional/MergeIT.java   |  2 +-
 .../accumulo/test/functional/MetadataIT.java       |  2 +-
 .../test/functional/MetadataMaxFilesIT.java        |  2 +-
 .../accumulo/test/functional/MetadataSplitIT.java  |  2 +-
 .../accumulo/test/functional/MonitorSslIT.java     |  2 +-
 .../accumulo/test/functional/NativeMapIT.java      |  2 +-
 .../accumulo/test/functional/PermissionsIT.java    |  2 +-
 .../accumulo/test/functional/ReadWriteIT.java      |  2 +-
 .../test/functional/RecoveryWithEmptyRFileIT.java  |  2 +-
 .../test/functional/RegexGroupBalanceIT.java       |  2 +-
 .../apache/accumulo/test/functional/RenameIT.java  |  2 +-
 .../apache/accumulo/test/functional/RestartIT.java |  2 +-
 .../accumulo/test/functional/RestartStressIT.java  |  2 +-
 .../accumulo/test/functional/RowDeleteIT.java      |  2 +-
 .../apache/accumulo/test/functional/ScanIdIT.java  |  2 +-
 .../accumulo/test/functional/ScanIteratorIT.java   |  2 +-
 .../accumulo/test/functional/ScanRangeIT.java      |  2 +-
 .../test/functional/ScanSessionTimeOutIT.java      |  2 +-
 .../accumulo/test/functional/ScannerContextIT.java |  2 +-
 .../apache/accumulo/test/functional/ScannerIT.java |  2 +-
 .../test/functional/ServerSideErrorIT.java         |  2 +-
 .../test/functional/SessionBlockVerifyIT.java      |  2 +-
 .../test/functional/SessionDurabilityIT.java       |  2 +-
 .../accumulo/test/functional/ShutdownIT.java       |  2 +-
 .../test/functional/SimpleBalancerFairnessIT.java  |  2 +-
 .../accumulo/test/functional/SlowConstraint.java   |  2 +-
 .../accumulo/test/functional/SlowIterator.java     |  2 +-
 .../test/functional/SparseColumnFamilyIT.java      |  2 +-
 .../apache/accumulo/test/functional/SplitIT.java   |  2 +-
 .../accumulo/test/functional/SplitRecoveryIT.java  |  2 +-
 .../org/apache/accumulo/test/functional/SslIT.java |  2 +-
 .../test/functional/SslWithClientAuthIT.java       |  2 +-
 .../apache/accumulo/test/functional/StartIT.java   |  2 +-
 .../apache/accumulo/test/functional/SummaryIT.java |  2 +-
 .../apache/accumulo/test/functional/TableIT.java   |  2 +-
 .../apache/accumulo/test/functional/TabletIT.java  |  2 +-
 .../accumulo/test/functional/TabletMetadataIT.java |  2 +-
 .../functional/TabletStateChangeIteratorIT.java    |  2 +-
 .../apache/accumulo/test/functional/TimeoutIT.java |  2 +-
 .../accumulo/test/functional/TooManyDeletesIT.java |  2 +-
 .../accumulo/test/functional/VisibilityIT.java     |  2 +-
 .../accumulo/test/functional/WALSunnyDayIT.java    |  2 +-
 .../test/functional/WatchTheWatchCountIT.java      |  2 +-
 .../test/functional/WriteAheadLogEncryptedIT.java  |  2 +-
 .../accumulo/test/functional/WriteAheadLogIT.java  |  2 +-
 .../accumulo/test/functional/WriteLotsIT.java      |  2 +-
 .../accumulo/test/functional/YieldingIterator.java |  2 +-
 .../accumulo/test/functional/ZombieTServer.java    |  2 +-
 .../accumulo/test/functional/ZooCacheIT.java       |  2 +-
 .../test/functional/ZookeeperRestartIT.java        |  2 +-
 .../CloseWriteAheadLogReferencesIT.java            |  2 +-
 .../apache/accumulo/test/manager/MergeStateIT.java |  2 +-
 .../accumulo/test/manager/SuspendedTabletsIT.java  |  2 +-
 .../test/mapred/AccumuloFileOutputFormatIT.java    |  2 +-
 .../test/mapred/AccumuloInputFormatIT.java         |  2 +-
 .../mapred/AccumuloMultiTableInputFormatIT.java    |  2 +-
 .../test/mapred/AccumuloOutputFormatIT.java        |  2 +-
 .../test/mapred/AccumuloRowInputFormatIT.java      |  2 +-
 .../apache/accumulo/test/mapred/TokenFileIT.java   |  2 +-
 .../test/mapreduce/AccumuloFileOutputFormatIT.java |  2 +-
 .../test/mapreduce/AccumuloInputFormatIT.java      |  2 +-
 .../mapreduce/AccumuloMultiTableInputFormatIT.java |  2 +-
 .../test/mapreduce/AccumuloOutputFormatIT.java     |  2 +-
 .../test/mapreduce/AccumuloRowInputFormatIT.java   |  2 +-
 .../accumulo/test/mapreduce/MapReduceIT.java       |  2 +-
 .../apache/accumulo/test/mapreduce/RowHash.java    |  2 +-
 .../accumulo/test/mapreduce/TokenFileIT.java       |  2 +-
 .../apache/accumulo/test/metrics/MetricsIT.java    |  2 +-
 .../test/metrics/TestStatsDRegistryFactory.java    |  2 +-
 .../accumulo/test/metrics/TestStatsDSink.java      |  2 +-
 .../accumulo/test/performance/NullTserver.java     |  2 +-
 .../test/performance/scan/CollectTabletStats.java  |  2 +-
 .../test/replication/CyclicReplicationIT.java      |  2 +-
 .../test/replication/FinishedWorkUpdaterIT.java    |  2 +-
 ...GarbageCollectorCommunicatesWithTServersIT.java |  2 +-
 .../test/replication/KerberosReplicationIT.java    |  2 +-
 .../test/replication/MockReplicaSystem.java        |  2 +-
 .../replication/MultiInstanceReplicationIT.java    |  2 +-
 .../replication/MultiTserverReplicationIT.java     |  2 +-
 .../RemoveCompleteReplicationRecordsIT.java        |  2 +-
 .../accumulo/test/replication/ReplicationIT.java   |  2 +-
 .../replication/ReplicationOperationsImplIT.java   |  2 +-
 .../test/replication/SequentialWorkAssignerIT.java |  2 +-
 .../test/replication/StatusCombinerMacIT.java      |  2 +-
 .../accumulo/test/replication/StatusMakerIT.java   |  2 +-
 .../test/replication/UnorderedWorkAssignerIT.java  |  2 +-
 .../UnorderedWorkAssignerReplicationIT.java        |  2 +-
 .../UnusedWalDoesntCloseReplicationStatusIT.java   |  2 +-
 .../accumulo/test/replication/WorkMakerIT.java     |  2 +-
 .../java/org/apache/accumulo/test/rpc/Mocket.java  |  2 +-
 .../test/rpc/SimpleThriftServiceHandler.java       |  2 +-
 .../test/rpc/SimpleThriftServiceRunner.java        |  2 +-
 .../apache/accumulo/test/rpc/ThriftBehaviorIT.java |  2 +-
 .../test/server/security/SystemCredentialsIT.java  |  2 +-
 .../apache/accumulo/test/shell/DebugCommand.java   |  2 +-
 .../accumulo/test/shell/ErrorMessageCallback.java  |  2 +-
 .../accumulo/test/shell/ExampleShellExtension.java |  2 +-
 .../org/apache/accumulo/test/shell/MockShell.java  |  2 +-
 .../apache/accumulo/test/shell/ShellConfigIT.java  |  2 +-
 .../accumulo/test/shell/ShellCreateTableIT.java    |  2 +-
 .../org/apache/accumulo/test/shell/ShellIT.java    |  2 +-
 .../apache/accumulo/test/shell/ShellServerIT.java  |  2 +-
 .../apache/accumulo/test/start/KeywordStartIT.java |  2 +-
 .../test/upgrade/ConfigPropertyUpgraderIT.java     |  2 +-
 .../test/upgrade/GCUpgrade9to10TestIT.java         |  2 +-
 .../org/apache/accumulo/test/util/CertUtils.java   |  2 +-
 .../accumulo/test/util/SerializationUtil.java      |  2 +-
 .../org/apache/accumulo/test/util/SlowOps.java     |  2 +-
 .../test/zookeeper/ZooKeeperTestingServer.java     |  2 +-
 test/src/main/resources/log4j2-test.properties     |  2 +-
 .../org/apache/accumulo/test/shellit.shellit       |  2 +-
 test/src/main/scripts/generate-thrift.sh           |  2 +-
 test/src/main/spotbugs/exclude-filter.xml          |  2 +-
 test/src/main/test-jars/Iterators.xml              |  4 +--
 .../test/rpc/thrift/SimpleThriftService.java       |  2 +-
 test/src/main/thrift/test.thrift                   |  2 +-
 test/src/test/c/fake_disk_failure.c                |  2 +-
 .../accumulo/test/ChaoticLoadBalancerTest.java     |  2 +-
 .../constraints/AlphaNumKeyConstraintTest.java     |  2 +-
 .../constraints/NumericValueConstraintTest.java    |  2 +-
 .../test/functional/ValueReversingIterator.java    |  2 +-
 .../accumulo/test/iterator/AgeOffFilterTest.java   |  2 +-
 .../test/iterator/CfCqSliceFilterTest.java         |  2 +-
 .../apache/accumulo/test/iterator/RegExTest.java   |  2 +-
 .../test/iterator/SummingCombinerTest.java         |  2 +-
 .../test/iterator/WholeRowIteratorTest.java        |  2 +-
 .../performance/scan/CollectTabletStatsTest.java   |  2 +-
 .../security/KerberosTokenEmbeddedKDCTest.java     |  2 +-
 .../apache/accumulo/test/util/CertUtilsTest.java   |  2 +-
 test/src/test/scripts/run-test.sh                  |  2 +-
 2428 files changed, 2868 insertions(+), 2737 deletions(-)

diff --git a/.asf.yaml b/.asf.yaml
index fcb2b80a12..bc2c943e82 100644
--- a/.asf.yaml
+++ b/.asf.yaml
@@ -7,7 +7,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/.github/CONTRIBUTING.md b/.github/CONTRIBUTING.md
index 76d397a24f..6f30986615 100644
--- a/.github/CONTRIBUTING.md
+++ b/.github/CONTRIBUTING.md
@@ -1,18 +1,22 @@
 <!--
-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.
-The ASF licenses this file to You under the Apache License, Version 2.0
-(the "License"); you may not use this file except in compliance with
-the License.  You may obtain a copy of the License at
-
-    http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing, software
-distributed under the License is distributed on an "AS IS" BASIS,
-WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-See the License for the specific language governing permissions and
-limitations under the License.
+
+    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.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+      https://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+
 -->
 
 # Contributors Guide
diff --git a/.github/ISSUE_TEMPLATE/post_vote_checklist.md b/.github/ISSUE_TEMPLATE/post_vote_checklist.md
index ef404b0142..7171bc8acf 100644
--- a/.github/ISSUE_TEMPLATE/post_vote_checklist.md
+++ b/.github/ISSUE_TEMPLATE/post_vote_checklist.md
@@ -25,7 +25,7 @@ assignees: ''
   - [ ] In [Maven Central](https://repo1.maven.org/maven2/org/apache/accumulo/accumulo-core/)
   - [ ] In [ASF Downloads](https://downloads.apache.org/accumulo)
   - [ ] In [several mirrors](https://www.apache.org/dyn/closer.lua/accumulo)
-- Update the [staging website](http://accumulo.staged.apache.org/)
+- Update the [staging website](https://accumulo.staged.apache.org/)
   - [ ] Release notes
   - [ ] Add `LTM: true` to the release notes front-matter for LTM releases
   - [ ] Navigation
diff --git a/.github/workflows/maven-full-its.yaml b/.github/workflows/maven-full-its.yaml
index de86e2791a..d81e975434 100644
--- a/.github/workflows/maven-full-its.yaml
+++ b/.github/workflows/maven-full-its.yaml
@@ -7,7 +7,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/.github/workflows/maven-on-demand.yaml b/.github/workflows/maven-on-demand.yaml
index 7b05fe2731..29a50e0785 100644
--- a/.github/workflows/maven-on-demand.yaml
+++ b/.github/workflows/maven-on-demand.yaml
@@ -7,7 +7,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/.github/workflows/maven.yaml b/.github/workflows/maven.yaml
index 7500efbcab..ae4b31e522 100644
--- a/.github/workflows/maven.yaml
+++ b/.github/workflows/maven.yaml
@@ -7,7 +7,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/.github/workflows/scripts.yaml b/.github/workflows/scripts.yaml
index 6f78957c31..a982a04e9b 100644
--- a/.github/workflows/scripts.yaml
+++ b/.github/workflows/scripts.yaml
@@ -7,7 +7,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/.gitignore b/.gitignore
index 3d5bdae59a..55d7f58f9d 100644
--- a/.gitignore
+++ b/.gitignore
@@ -1,17 +1,21 @@
-# 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.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
 #
-#     http://www.apache.org/licenses/LICENSE-2.0
+# 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.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   https://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
 #
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
 
 # Maven ignores
 /target/
@@ -28,5 +32,5 @@
 /nbproject/
 /nbactions.xml
 /nb-configuration.xml
-.vscode/
-.factorypath
+/.vscode/
+/.factorypath
diff --git a/DEPENDENCIES b/DEPENDENCIES
index 5a98c0fbb6..1fe2aae1b2 100644
--- a/DEPENDENCIES
+++ b/DEPENDENCIES
@@ -1,18 +1,22 @@
 <!--
-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.
-The ASF licenses this file to You under the Apache License, Version 2.0
-(the "License"); you may not use this file except in compliance with
-the License.  You may obtain a copy of the License at
 
-    http://www.apache.org/licenses/LICENSE-2.0
+    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.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+      https://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
 
-Unless required by applicable law or agreed to in writing, software
-distributed under the License is distributed on an "AS IS" BASIS,
-WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-See the License for the specific language governing permissions and
-limitations under the License.
 -->
 
 Apache Accumulo depends on artifacts which can be found in Maven Central.
diff --git a/NOTICE b/NOTICE
index 0cb594bf16..d57731eeea 100644
--- a/NOTICE
+++ b/NOTICE
@@ -2,4 +2,4 @@ Apache Accumulo
 Copyright 2011-2022 The Apache Software Foundation
 
 This product includes software developed at
-The Apache Software Foundation (http://www.apache.org/).
+The Apache Software Foundation (https://www.apache.org/).
diff --git a/README.md b/README.md
index ed1a335ec1..0de1f9366c 100644
--- a/README.md
+++ b/README.md
@@ -1,18 +1,22 @@
 <!--
-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.
-The ASF licenses this file to You under the Apache License, Version 2.0
-(the "License"); you may not use this file except in compliance with
-the License.  You may obtain a copy of the License at
-
-    http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing, software
-distributed under the License is distributed on an "AS IS" BASIS,
-WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-See the License for the specific language governing permissions and
-limitations under the License.
+
+    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.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+      https://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+
 -->
 
 [![Apache Accumulo][logo]][accumulo]
diff --git a/TESTING.md b/TESTING.md
index 805bddf1b4..3b5211adda 100644
--- a/TESTING.md
+++ b/TESTING.md
@@ -1,18 +1,22 @@
 <!--
-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.
-The ASF licenses this file to You under the Apache License, Version 2.0
-(the "License"); you may not use this file except in compliance with
-the License.  You may obtain a copy of the License at
-
-    http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing, software
-distributed under the License is distributed on an "AS IS" BASIS,
-WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-See the License for the specific language governing permissions and
-limitations under the License.
+
+    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.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+      https://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+
 -->
 
 # Testing Apache Accumulo
diff --git a/assemble/.gitignore b/assemble/.gitignore
index e77a822fe7..55d7f58f9d 100644
--- a/assemble/.gitignore
+++ b/assemble/.gitignore
@@ -1,17 +1,21 @@
-# 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.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
 #
-#     http://www.apache.org/licenses/LICENSE-2.0
+# 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.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   https://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
 #
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
 
 # Maven ignores
 /target/
@@ -23,6 +27,10 @@
 /.pydevproject
 /.idea
 /*.iml
+/*.ipr
+/*.iws
 /nbproject/
 /nbactions.xml
 /nb-configuration.xml
+/.vscode/
+/.factorypath
diff --git a/assemble/bin/accumulo b/assemble/bin/accumulo
index dc20572406..0207cb6987 100755
--- a/assemble/bin/accumulo
+++ b/assemble/bin/accumulo
@@ -8,7 +8,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/assemble/bin/accumulo-cluster b/assemble/bin/accumulo-cluster
index b4b5eab722..498abdad59 100755
--- a/assemble/bin/accumulo-cluster
+++ b/assemble/bin/accumulo-cluster
@@ -8,7 +8,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/assemble/bin/accumulo-service b/assemble/bin/accumulo-service
index 86ac440885..1ae8d5af51 100755
--- a/assemble/bin/accumulo-service
+++ b/assemble/bin/accumulo-service
@@ -8,7 +8,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/assemble/bin/accumulo-util b/assemble/bin/accumulo-util
index 1a2dc3c11f..bc7fcb32e3 100755
--- a/assemble/bin/accumulo-util
+++ b/assemble/bin/accumulo-util
@@ -8,7 +8,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/assemble/build.sh b/assemble/build.sh
index 9678baf964..6661bbaffa 100755
--- a/assemble/build.sh
+++ b/assemble/build.sh
@@ -8,7 +8,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/assemble/conf/accumulo-env.sh b/assemble/conf/accumulo-env.sh
index 46109c9eea..452130a12a 100644
--- a/assemble/conf/accumulo-env.sh
+++ b/assemble/conf/accumulo-env.sh
@@ -8,7 +8,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/assemble/conf/accumulo.properties b/assemble/conf/accumulo.properties
index bd12ada384..8aea483153 100644
--- a/assemble/conf/accumulo.properties
+++ b/assemble/conf/accumulo.properties
@@ -7,7 +7,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/assemble/conf/log4j2-service.properties b/assemble/conf/log4j2-service.properties
index 2355f87632..01e5e28314 100644
--- a/assemble/conf/log4j2-service.properties
+++ b/assemble/conf/log4j2-service.properties
@@ -7,7 +7,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/assemble/conf/log4j2.properties b/assemble/conf/log4j2.properties
index 6decfa4bfa..6906e9bb80 100644
--- a/assemble/conf/log4j2.properties
+++ b/assemble/conf/log4j2.properties
@@ -7,7 +7,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/assemble/pom.xml b/assemble/pom.xml
index ac108c0d12..84e0611bc7 100644
--- a/assemble/pom.xml
+++ b/assemble/pom.xml
@@ -9,7 +9,7 @@
     "License"); you may not use this file except in compliance
     with the License.  You may obtain a copy of the License at
 
-      http://www.apache.org/licenses/LICENSE-2.0
+      https://www.apache.org/licenses/LICENSE-2.0
 
     Unless required by applicable law or agreed to in writing,
     software distributed under the License is distributed on an
diff --git a/assemble/src/main/assemblies/binary-release.xml b/assemble/src/main/assemblies/binary-release.xml
index 2fcde541b9..137c103d84 100644
--- a/assemble/src/main/assemblies/binary-release.xml
+++ b/assemble/src/main/assemblies/binary-release.xml
@@ -9,7 +9,7 @@
     "License"); you may not use this file except in compliance
     with the License.  You may obtain a copy of the License at
 
-      http://www.apache.org/licenses/LICENSE-2.0
+      https://www.apache.org/licenses/LICENSE-2.0
 
     Unless required by applicable law or agreed to in writing,
     software distributed under the License is distributed on an
@@ -20,7 +20,7 @@
 
 -->
 <assembly xmlns="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-  xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2 http://maven.apache.org/xsd/assembly-1.1.2.xsd">
+  xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2 https://maven.apache.org/xsd/assembly-1.1.2.xsd">
   <id>bin</id>
   <formats>
     <format>tar.gz</format>
diff --git a/assemble/src/main/assemblies/component.xml b/assemble/src/main/assemblies/component.xml
index 1d577ed3e0..81e59f0694 100644
--- a/assemble/src/main/assemblies/component.xml
+++ b/assemble/src/main/assemblies/component.xml
@@ -9,7 +9,7 @@
     "License"); you may not use this file except in compliance
     with the License.  You may obtain a copy of the License at
 
-      http://www.apache.org/licenses/LICENSE-2.0
+      https://www.apache.org/licenses/LICENSE-2.0
 
     Unless required by applicable law or agreed to in writing,
     software distributed under the License is distributed on an
@@ -20,7 +20,7 @@
 
 -->
 <component xmlns="http://maven.apache.org/plugins/maven-assembly-plugin/component/1.1.2" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-  xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/component/1.1.2 http://maven.apache.org/xsd/component-1.1.2.xsd">
+  xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/component/1.1.2 https://maven.apache.org/xsd/component-1.1.2.xsd">
   <dependencySets>
     <dependencySet>
       <outputDirectory>lib</outputDirectory>
diff --git a/assemble/src/main/resources/NOTICE b/assemble/src/main/resources/NOTICE
index e91cf14574..f1dfcb50ba 100644
--- a/assemble/src/main/resources/NOTICE
+++ b/assemble/src/main/resources/NOTICE
@@ -2,7 +2,7 @@ Apache Accumulo
 Copyright 2011-2022 The Apache Software Foundation
 
 This product includes software developed at
-The Apache Software Foundation (http://www.apache.org/).
+The Apache Software Foundation (https://www.apache.org/).
 
 **********
 
diff --git a/assemble/src/main/scripts/create-jshell.sh b/assemble/src/main/scripts/create-jshell.sh
index b550439ae6..aa46b26f1e 100755
--- a/assemble/src/main/scripts/create-jshell.sh
+++ b/assemble/src/main/scripts/create-jshell.sh
@@ -8,7 +8,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/contrib/Eclipse-Accumulo-Codestyle.xml b/contrib/Eclipse-Accumulo-Codestyle.xml
index 9f1f117dbc..98eaad8b34 100644
--- a/contrib/Eclipse-Accumulo-Codestyle.xml
+++ b/contrib/Eclipse-Accumulo-Codestyle.xml
@@ -9,7 +9,7 @@
     "License"); you may not use this file except in compliance
     with the License.  You may obtain a copy of the License at
 
-      http://www.apache.org/licenses/LICENSE-2.0
+      https://www.apache.org/licenses/LICENSE-2.0
 
     Unless required by applicable law or agreed to in writing,
     software distributed under the License is distributed on an
diff --git a/contrib/ci/find-unapproved-chars.sh b/contrib/ci/find-unapproved-chars.sh
index 2558319497..5f7c7b0efa 100755
--- a/contrib/ci/find-unapproved-chars.sh
+++ b/contrib/ci/find-unapproved-chars.sh
@@ -8,7 +8,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/contrib/ci/find-unapproved-junit.sh b/contrib/ci/find-unapproved-junit.sh
index 45e12d86a8..8007eccf94 100755
--- a/contrib/ci/find-unapproved-junit.sh
+++ b/contrib/ci/find-unapproved-junit.sh
@@ -8,7 +8,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/contrib/ci/install-shfmt.sh b/contrib/ci/install-shfmt.sh
index 53eb76d863..fd73efc3c6 100755
--- a/contrib/ci/install-shfmt.sh
+++ b/contrib/ci/install-shfmt.sh
@@ -8,7 +8,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/contrib/ci/it-matrix.sh b/contrib/ci/it-matrix.sh
index 4fa9990959..f84c93fc57 100755
--- a/contrib/ci/it-matrix.sh
+++ b/contrib/ci/it-matrix.sh
@@ -8,7 +8,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/contrib/ci/run-shellcheck.sh b/contrib/ci/run-shellcheck.sh
index f69ebbddfb..5d6ca75d2d 100755
--- a/contrib/ci/run-shellcheck.sh
+++ b/contrib/ci/run-shellcheck.sh
@@ -8,7 +8,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/contrib/ci/run-shfmt.sh b/contrib/ci/run-shfmt.sh
index 5ecbefca09..233df9aff4 100755
--- a/contrib/ci/run-shfmt.sh
+++ b/contrib/ci/run-shfmt.sh
@@ -8,7 +8,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/contrib/license-header.txt b/contrib/license-header.txt
index 60b675e310..f808223cba 100644
--- a/contrib/license-header.txt
+++ b/contrib/license-header.txt
@@ -6,7 +6,7 @@ to you under the Apache License, Version 2.0 (the
 "License"); you may not use this file except in compliance
 with the License.  You may obtain a copy of the License at
 
-  http://www.apache.org/licenses/LICENSE-2.0
+  https://www.apache.org/licenses/LICENSE-2.0
 
 Unless required by applicable law or agreed to in writing,
 software distributed under the License is distributed on an
diff --git a/contrib/scripts/check-tservers.py b/contrib/scripts/check-tservers.py
index 9129870723..be1b9f650c 100755
--- a/contrib/scripts/check-tservers.py
+++ b/contrib/scripts/check-tservers.py
@@ -8,7 +8,7 @@
 # "License"); you may not use this file except in compliance
 # with the License.  You may obtain a copy of the License at
 #
-#   http://www.apache.org/licenses/LICENSE-2.0
+#   https://www.apache.org/licenses/LICENSE-2.0
 #
 # Unless required by applicable law or agreed to in writing,
 # software distributed under the License is distributed on an
diff --git a/core/.gitignore b/core/.gitignore
index e77a822fe7..55d7f58f9d 100644
--- a/core/.gitignore
+++ b/core/.gitignore
@@ -1,17 +1,21 @@
-# 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.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
 #
-#     http://www.apache.org/licenses/LICENSE-2.0
+# 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.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   https://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
 #
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
 
 # Maven ignores
 /target/
@@ -23,6 +27,10 @@
 /.pydevproject
 /.idea
 /*.iml
+/*.ipr
+/*.iws
 /nbproject/
 /nbactions.xml
 /nb-configuration.xml
+/.vscode/
+/.factorypath
diff --git a/core/pom.xml b/core/pom.xml
index 19bd3d8497..ff4f657a6b 100644
--- a/core/pom.xml
+++ b/core/pom.xml
@@ -9,7 +9,7 @@
     "License"); you may not use this file except in compliance
     with the License.  You may obtain a copy of the License at
 
-      http://www.apache.org/licenses/LICENSE-2.0
+      https://www.apache.org/licenses/LICENSE-2.0
 
     Unless required by applicable law or agreed to in writing,
     software distributed under the License is distributed on an
diff --git a/core/src/main/java-filtered/org/apache/accumulo/core/FilteredConstants.java b/core/src/main/java-filtered/org/apache/accumulo/core/FilteredConstants.java
index 7a90aff6f2..f130c3cba7 100644
--- a/core/src/main/java-filtered/org/apache/accumulo/core/FilteredConstants.java
+++ b/core/src/main/java-filtered/org/apache/accumulo/core/FilteredConstants.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 c669921485..dc7326d9fa 100644
--- a/core/src/main/java/org/apache/accumulo/core/Constants.java
+++ b/core/src/main/java/org/apache/accumulo/core/Constants.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 f72d744123..1b5843a7e8 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
@@ -64,7 +64,7 @@ import edu.umd.cs.findbugs.annotations.SuppressFBWarnings;
  *
  * @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
+ * @see <a href="https://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 {
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 b985d8520f..476f2a272f 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
@@ -64,7 +64,7 @@ import org.apache.hadoop.util.bloom.Key;
  * @see BloomFilter A Bloom filter
  *
  * @see <a href=
- *      "http://www.cse.fau.edu/~jie/research/publications/Publication_files/infocom2006.pdf">Theory
+ *      "https://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 {
diff --git a/core/src/main/java/org/apache/accumulo/core/classloader/ClassLoaderUtil.java b/core/src/main/java/org/apache/accumulo/core/classloader/ClassLoaderUtil.java
index 1ac0474c43..f58b1a1bfb 100644
--- a/core/src/main/java/org/apache/accumulo/core/classloader/ClassLoaderUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/classloader/ClassLoaderUtil.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/classloader/DefaultContextClassLoaderFactory.java b/core/src/main/java/org/apache/accumulo/core/classloader/DefaultContextClassLoaderFactory.java
index b9428e6f6e..984e86d0b8 100644
--- a/core/src/main/java/org/apache/accumulo/core/classloader/DefaultContextClassLoaderFactory.java
+++ b/core/src/main/java/org/apache/accumulo/core/classloader/DefaultContextClassLoaderFactory.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 296728df0e..389f852b25 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/cli/ConfigOpts.java b/core/src/main/java/org/apache/accumulo/core/cli/ConfigOpts.java
index 113a75950b..b93f85b85e 100644
--- a/core/src/main/java/org/apache/accumulo/core/cli/ConfigOpts.java
+++ b/core/src/main/java/org/apache/accumulo/core/cli/ConfigOpts.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/cli/Help.java b/core/src/main/java/org/apache/accumulo/core/cli/Help.java
index 0209eacc1b..2389bf2ae1 100644
--- a/core/src/main/java/org/apache/accumulo/core/cli/Help.java
+++ b/core/src/main/java/org/apache/accumulo/core/cli/Help.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/Accumulo.java b/core/src/main/java/org/apache/accumulo/core/client/Accumulo.java
index ddf198e7f8..88cdd0c93f 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/Accumulo.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/Accumulo.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
@@ -29,21 +29,20 @@ import org.apache.accumulo.core.clientImpl.ClientContext;
  * accessible indirectly via methods in this class. Below are a list of APIs entry points that are
  * not accessible from here.
  *
- * <UL>
- * <LI>Hadoop input, output formats and partitioners in {@code org.apache.accumulo.hadoop.mapred}
+ * <ul>
+ * <li>Hadoop input, output formats and partitioners in {@code org.apache.accumulo.hadoop.mapred}
  * and {@code org.apache.accumulo.hadoop.mapreduce} packages.
- * <LI>{@code org.apache.accumulo.minicluster.MiniAccumuloCluster} Not linkable by javadoc, because
+ * <li>{@code org.apache.accumulo.minicluster.MiniAccumuloCluster} Not linkable by javadoc, because
  * in a separate module.
- * <LI>{@link Lexicoder} and all of its implementations in the same package.
- * <LI>{@link RFile}
- * </UL>
+ * <li>{@link Lexicoder} and all of its implementations in the same package.
+ * <li>{@link RFile}
+ * </ul>
  *
- * @see <a href="http://accumulo.apache.org/">Accumulo Website</a>
- * @see <a href="http://accumulo.apache.org/api">Accumulo Public API</a>
- * @see <a href="http://semver.org/spec/v2.0.0">Semver 2.0</a>
+ * @see <a href="https://accumulo.apache.org/">Accumulo Website</a>
+ * @see <a href="https://accumulo.apache.org/api">Accumulo Public API</a>
+ * @see <a href="https://semver.org/spec/v2.0.0">Semver 2.0</a>
  * @since 2.0.0
  */
-// CHECKSTYLE:ON
 public final class Accumulo {
 
   private Accumulo() {}
diff --git a/core/src/main/java/org/apache/accumulo/core/client/AccumuloClient.java b/core/src/main/java/org/apache/accumulo/core/client/AccumuloClient.java
index 39f88863ab..70537040dc 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/AccumuloClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/AccumuloClient.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/AccumuloException.java b/core/src/main/java/org/apache/accumulo/core/client/AccumuloException.java
index 8921c2b601..cd5b0ca4a3 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/AccumuloException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/AccumuloException.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 b790a54e00..d2fa983e89 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/BatchDeleter.java b/core/src/main/java/org/apache/accumulo/core/client/BatchDeleter.java
index 0e75445256..b98d96f300 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/BatchDeleter.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/BatchDeleter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 c952741155..ee14509327 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 7d898e80fe..11194f782c 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 192b147d86..98cf8ee3e9 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 cdf665c836..257bc6bb57 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 d561ce3918..8b50049eaa 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 6022154cdc..a004c195e9 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 67c258ff20..532a5851a8 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 8c3fafe9f2..7a639cec5c 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 503362551e..45da0a3ed4 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 8a60068fbe..45e664e8d4 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 a1471642ae..c2c399aa73 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 6077218a69..d81af7477f 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 a558741693..7138a49bd1 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 7111733f24..53378b3f0b 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 73c98a1684..708c13ee30 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 d5f8592f1d..6294d6deef 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 d8430bc7d5..cff08790b2 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/PluginEnvironment.java b/core/src/main/java/org/apache/accumulo/core/client/PluginEnvironment.java
index 55ff67f535..f0fb5c2b10 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/PluginEnvironment.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/PluginEnvironment.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 f9681a190c..59a8128836 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 ad85c1f047..a85be563c9 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 df539a1d64..0e2e9c07c1 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 f33bcc0c7b..990da83bac 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 be9dff10b2..b19170f775 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 146a04af9b..a93d6cfcab 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 6d6abcb2b7..ad6804c018 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/TableOfflineException.java b/core/src/main/java/org/apache/accumulo/core/client/TableOfflineException.java
index 82aed83ec4..2dbeb1476d 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/TableOfflineException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/TableOfflineException.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 43b26124da..bd647099f9 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 1b7af13265..cdf612e5cc 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 4506692caa..45a31e98bf 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveScan.java b/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveScan.java
index 824db187a9..d294acf6bf 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveScan.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveScan.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/CloneConfiguration.java b/core/src/main/java/org/apache/accumulo/core/client/admin/CloneConfiguration.java
index 265d3bc628..fa2c104258 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/CloneConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/CloneConfiguration.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 a06493966d..f49ee696a7 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 19e2a8ff67..8c915dd068 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 d96ccbd9cc..bc666603ac 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/DiskUsage.java b/core/src/main/java/org/apache/accumulo/core/client/admin/DiskUsage.java
index 3b31a4de50..85a2983eef 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/DiskUsage.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/DiskUsage.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 b48e9f6877..5e8794ee03 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/InitialTableState.java b/core/src/main/java/org/apache/accumulo/core/client/admin/InitialTableState.java
index 029b4acb46..1bf903e591 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/InitialTableState.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/InitialTableState.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 46a309d4b8..227b1d3ae7 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 9783060492..3b80258cba 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 6af33448bc..740885fbfb 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 364a6ff122..7ab5935fd1 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/PluginConfig.java b/core/src/main/java/org/apache/accumulo/core/client/admin/PluginConfig.java
index acbd28ee86..bd5e20685f 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/PluginConfig.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/PluginConfig.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 3c815da2c2..9c2ad477c5 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/ScanState.java b/core/src/main/java/org/apache/accumulo/core/client/admin/ScanState.java
index 8fd355490d..7fbe2f28bb 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/ScanState.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/ScanState.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/ScanType.java b/core/src/main/java/org/apache/accumulo/core/client/admin/ScanType.java
index bdbd3bf8dc..2eace88311 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/ScanType.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/ScanType.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 80eba8214b..8ee7a1815e 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/SummaryRetriever.java b/core/src/main/java/org/apache/accumulo/core/client/admin/SummaryRetriever.java
index 81fbec8316..9b8b4a6c9a 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/SummaryRetriever.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/SummaryRetriever.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 56c1247afa..09a1b0e3dd 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 21896fee91..39abdf7022 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompactableFile.java b/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompactableFile.java
index 8be4985ad6..baf5f04949 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompactableFile.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompactableFile.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompactionConfigurer.java b/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompactionConfigurer.java
index f57db0f46b..6a58704e54 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompactionConfigurer.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompactionConfigurer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompactionSelector.java b/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompactionSelector.java
index fe833f2b87..d54f612c16 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompactionSelector.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompactionSelector.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompressionConfigurer.java b/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompressionConfigurer.java
index 38ab9dca74..d68601d101 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompressionConfigurer.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/CompressionConfigurer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/TooManyDeletesSelector.java b/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/TooManyDeletesSelector.java
index 22c367a154..98e9ff1622 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/TooManyDeletesSelector.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/compaction/TooManyDeletesSelector.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
@@ -16,7 +16,6 @@
  * specific language governing permissions and limitations
  * under the License.
  */
-
 package org.apache.accumulo.core.client.admin.compaction;
 
 import static org.apache.accumulo.core.client.summary.summarizers.DeletesSummarizer.DELETES_STAT;
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/AbstractEncoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/AbstractEncoder.java
index 84d1257d4c..d8edc403f8 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/AbstractEncoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/AbstractEncoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/AbstractLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/AbstractLexicoder.java
index 287e5bfd24..cd9bfb3453 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/AbstractLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/AbstractLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/BigIntegerLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/BigIntegerLexicoder.java
index 184e29dd97..41aa8d4a55 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/BigIntegerLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/BigIntegerLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/BytesLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/BytesLexicoder.java
index a79bd318c4..abb04a1018 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/BytesLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/BytesLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/DateLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/DateLexicoder.java
index 81520d3252..8bb3c63055 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/DateLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/DateLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/DoubleLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/DoubleLexicoder.java
index 446c8c34c9..0c9b834537 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/DoubleLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/DoubleLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/Encoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/Encoder.java
index 27956b0213..cbf8ca18d4 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/Encoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/Encoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/FloatLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/FloatLexicoder.java
index c14dede031..ef832bb3af 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/FloatLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/FloatLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/IntegerLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/IntegerLexicoder.java
index 6e497d39be..795158aa0c 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/IntegerLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/IntegerLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/Lexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/Lexicoder.java
index 95cae87f14..1d9ab1acc5 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/Lexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/Lexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/ListLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/ListLexicoder.java
index 0400e1c234..7cc44dd004 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/ListLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/ListLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/LongLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/LongLexicoder.java
index 8c9608f8c9..a37fbcedcb 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/LongLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/LongLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 ba8a7b9f3b..590c370745 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/ReverseLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/ReverseLexicoder.java
index 0acb349135..cd08316a84 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/ReverseLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/ReverseLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/SequenceLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/SequenceLexicoder.java
index 0e1fd2a33f..1d1d24d8c3 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/SequenceLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/SequenceLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/StringLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/StringLexicoder.java
index 2ffca1c7e6..14ffdae8b1 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/StringLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/StringLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/TextLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/TextLexicoder.java
index cc9fbc8afc..e7222b7aaa 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/TextLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/TextLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/UIntegerLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/UIntegerLexicoder.java
index a9efa10bd4..529039929a 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/UIntegerLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/UIntegerLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/ULongLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/ULongLexicoder.java
index 4eef8922a3..9eef584cc6 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/ULongLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/ULongLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/UUIDLexicoder.java b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/UUIDLexicoder.java
index 3bda88a415..b3a7bc2e87 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/lexicoder/UUIDLexicoder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/lexicoder/UUIDLexicoder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
@@ -36,7 +36,7 @@ public class UUIDLexicoder extends AbstractLexicoder<UUID> {
   /**
    * {@inheritDoc}
    *
-   * @see <a href="http://www.ietf.org/rfc/rfc4122.txt"> RFC 4122: A Universally Unique IDentifier
+   * @see <a href="https://www.ietf.org/rfc/rfc4122.txt"> RFC 4122: A Universally Unique IDentifier
    *      (UUID) URN Namespace, "Rules for Lexical Equivalence" in Section 3.</a>
    */
   @Override
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 955c3f2d39..512248cb43 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloFileOutputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloFileOutputFormat.java
index 498bc1d933..36a1c6261d 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloFileOutputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloFileOutputFormat.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 4d99114d02..ba1635980f 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 7bd94eaafd..e33d1473ec 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 ff89a4fd20..4d2be461c0 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 c46cd58a84..e8b096a008 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapred/InputFormatBase.java b/core/src/main/java/org/apache/accumulo/core/client/mapred/InputFormatBase.java
index 7daa7b7874..b4afdb2625 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapred/InputFormatBase.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapred/InputFormatBase.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapred/RangeInputSplit.java b/core/src/main/java/org/apache/accumulo/core/client/mapred/RangeInputSplit.java
index 600b075eb7..3c1e74953f 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapred/RangeInputSplit.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapred/RangeInputSplit.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 9371d45af8..ec25ef6257 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloFileOutputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloFileOutputFormat.java
index a0dca0000e..e9fb133ee7 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloFileOutputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloFileOutputFormat.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 e4865a87aa..8202f88eeb 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloMultiTableInputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloMultiTableInputFormat.java
index 5679591294..8edc6c3e6d 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloMultiTableInputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloMultiTableInputFormat.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 018d7e4220..11b26ebec7 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloRowInputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloRowInputFormat.java
index 7e065101c3..4b665ab4cf 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloRowInputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloRowInputFormat.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputFormatBase.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputFormatBase.java
index 9b00c868cc..431024d674 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputFormatBase.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputFormatBase.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputTableConfig.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputTableConfig.java
index 4cc19d92e0..11fdcc5e44 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputTableConfig.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputTableConfig.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplit.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplit.java
index 3aafe91172..69cfd95a24 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplit.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplit.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/partition/KeyRangePartitioner.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/partition/KeyRangePartitioner.java
index 8db39a9841..fea37aee9c 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/partition/KeyRangePartitioner.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/partition/KeyRangePartitioner.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/partition/RangePartitioner.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/partition/RangePartitioner.java
index e67733da5f..91ccf3c59e 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/partition/RangePartitioner.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/partition/RangePartitioner.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/replication/PeerExistsException.java b/core/src/main/java/org/apache/accumulo/core/client/replication/PeerExistsException.java
index 1a02d31ff7..34b305219f 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/replication/PeerExistsException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/replication/PeerExistsException.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/replication/PeerNotFoundException.java b/core/src/main/java/org/apache/accumulo/core/client/replication/PeerNotFoundException.java
index d82e4d8cec..4da5ec93cd 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/replication/PeerNotFoundException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/replication/PeerNotFoundException.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/rfile/FSConfArgs.java b/core/src/main/java/org/apache/accumulo/core/client/rfile/FSConfArgs.java
index b2f59f11cb..4062b4c02b 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/rfile/FSConfArgs.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/rfile/FSConfArgs.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFile.java b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFile.java
index 25c5a520e3..b8ea961a91 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFile.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFile.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileScanner.java b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileScanner.java
index b181e36261..11f447ff17 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileScanner.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileScanner.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileScannerBuilder.java b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileScannerBuilder.java
index 640573a0b8..f4ab7e9b72 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileScannerBuilder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileScannerBuilder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileSource.java b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileSource.java
index dce8b0e069..cb5d0bbe78 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileSource.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileSource.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileSummariesRetriever.java b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileSummariesRetriever.java
index 9341f50424..aeaf9af891 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileSummariesRetriever.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileSummariesRetriever.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 7d1a30c2a4..151997d3cf 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileWriterBuilder.java b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileWriterBuilder.java
index eae6c1f475..f26348d3b5 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileWriterBuilder.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFileWriterBuilder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/sample/AbstractHashSampler.java b/core/src/main/java/org/apache/accumulo/core/client/sample/AbstractHashSampler.java
index 5fb28b2cd1..f4e79d8e1a 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/sample/AbstractHashSampler.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/sample/AbstractHashSampler.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 7eedeb95c9..dbc2ca1e67 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 d3a3a11130..1cfa1fd2c2 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/sample/Sampler.java b/core/src/main/java/org/apache/accumulo/core/client/sample/Sampler.java
index 810b8ae7b1..e093b3e2f5 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/sample/Sampler.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/sample/Sampler.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/sample/SamplerConfiguration.java b/core/src/main/java/org/apache/accumulo/core/client/sample/SamplerConfiguration.java
index e2f80860f2..397dc16755 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/sample/SamplerConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/sample/SamplerConfiguration.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/security/SecurityErrorCode.java b/core/src/main/java/org/apache/accumulo/core/client/security/SecurityErrorCode.java
index 95db01b2a3..f40794f029 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/security/SecurityErrorCode.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/security/SecurityErrorCode.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 7126705f6c..21d8526557 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/CredentialProviderToken.java b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/CredentialProviderToken.java
index a2f6ddc537..4db45c8f4e 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/CredentialProviderToken.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/CredentialProviderToken.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/DelegationToken.java b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/DelegationToken.java
index 491d19c8db..295cd982c8 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/DelegationToken.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/DelegationToken.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 3cedd582ea..6f0b742950 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/NullToken.java b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/NullToken.java
index 96a4bdc670..e3653fc31f 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/NullToken.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/NullToken.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/PasswordToken.java b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/PasswordToken.java
index 9348ed6038..167003b998 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/PasswordToken.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/PasswordToken.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/summary/CounterSummary.java b/core/src/main/java/org/apache/accumulo/core/client/summary/CounterSummary.java
index c4ee00453c..372481954c 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/summary/CounterSummary.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/summary/CounterSummary.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/summary/CountingSummarizer.java b/core/src/main/java/org/apache/accumulo/core/client/summary/CountingSummarizer.java
index bc343737e9..272003abd0 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/summary/CountingSummarizer.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/summary/CountingSummarizer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/summary/Summarizer.java b/core/src/main/java/org/apache/accumulo/core/client/summary/Summarizer.java
index ba138e3e91..3148010777 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/summary/Summarizer.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/summary/Summarizer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/summary/SummarizerConfiguration.java b/core/src/main/java/org/apache/accumulo/core/client/summary/SummarizerConfiguration.java
index eed7042a82..80739030f0 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/summary/SummarizerConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/summary/SummarizerConfiguration.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/summary/Summary.java b/core/src/main/java/org/apache/accumulo/core/client/summary/Summary.java
index 624399e1e8..1012370c42 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/summary/Summary.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/summary/Summary.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/AuthorizationSummarizer.java b/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/AuthorizationSummarizer.java
index ef7e7d337f..5660f665c3 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/AuthorizationSummarizer.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/AuthorizationSummarizer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/DeletesSummarizer.java b/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/DeletesSummarizer.java
index e94ddca606..971042528f 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/DeletesSummarizer.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/DeletesSummarizer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/EntryLengthSummarizer.java b/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/EntryLengthSummarizer.java
index 7002c18020..9b70a58fcc 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/EntryLengthSummarizer.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/EntryLengthSummarizer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/FamilySummarizer.java b/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/FamilySummarizer.java
index 71aeaf47e1..f749bbebb9 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/FamilySummarizer.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/FamilySummarizer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/VisibilitySummarizer.java b/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/VisibilitySummarizer.java
index 7ed0c7d5db..2763bb6efe 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/VisibilitySummarizer.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/summary/summarizers/VisibilitySummarizer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/AcceptableThriftTableOperationException.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/AcceptableThriftTableOperationException.java
index d416527065..e9d79ab8f3 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/AcceptableThriftTableOperationException.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/AcceptableThriftTableOperationException.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/AccumuloBulkMergeException.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/AccumuloBulkMergeException.java
index c30c70b831..2777bb3a36 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/AccumuloBulkMergeException.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/AccumuloBulkMergeException.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/AccumuloServerException.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/AccumuloServerException.java
index ea1200a96e..ad568c7f50 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/AccumuloServerException.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/AccumuloServerException.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ActiveCompactionImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ActiveCompactionImpl.java
index 92b5e055a1..b7889c3bfa 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ActiveCompactionImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ActiveCompactionImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ActiveScanImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ActiveScanImpl.java
index b910f4288d..d8b5cac810 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ActiveScanImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ActiveScanImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/AuthenticationTokenIdentifier.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/AuthenticationTokenIdentifier.java
index a982e8380e..f23cd083d6 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/AuthenticationTokenIdentifier.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/AuthenticationTokenIdentifier.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/BatchWriterImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/BatchWriterImpl.java
index e18d7b382d..0fe1768e19 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/BatchWriterImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/BatchWriterImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientConfConverter.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientConfConverter.java
index 45c2db17a4..f7792468bb 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientConfConverter.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientConfConverter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientContext.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientContext.java
index 08a852c3f0..4f083757b8 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientContext.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientContext.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientInfo.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientInfo.java
index fdb80977df..7306d8f804 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientInfo.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientInfo.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientInfoImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientInfoImpl.java
index 5493b01a04..372906ca6a 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientInfoImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ClientInfoImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/CloneConfigurationImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/CloneConfigurationImpl.java
index 1264fc4b9c..d380090dae 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/CloneConfigurationImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/CloneConfigurationImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/CompactionStrategyConfigUtil.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/CompactionStrategyConfigUtil.java
index e3f3a829d0..f09adc29b6 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/CompactionStrategyConfigUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/CompactionStrategyConfigUtil.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/CompressedIterators.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/CompressedIterators.java
index 7eb87c5e68..1b91bc1588 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/CompressedIterators.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/CompressedIterators.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ConditionalWriterImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ConditionalWriterImpl.java
index 9450dde82d..708623c10e 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ConditionalWriterImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ConditionalWriterImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ConnectorImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ConnectorImpl.java
index 8654779c50..b5341fe8ca 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ConnectorImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ConnectorImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/Credentials.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/Credentials.java
index a3cc682d05..1056acd8f1 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/Credentials.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/Credentials.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/DelegationTokenConfigSerializer.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/DelegationTokenConfigSerializer.java
index d412996872..9d8668e0ff 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/DelegationTokenConfigSerializer.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/DelegationTokenConfigSerializer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/DelegationTokenImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/DelegationTokenImpl.java
index cf1c1da79b..6818541104 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/DelegationTokenImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/DelegationTokenImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/DurabilityImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/DurabilityImpl.java
index 9c4f7eeb07..f59f9f39ee 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/DurabilityImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/DurabilityImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/InstanceOperationsImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/InstanceOperationsImpl.java
index e7b8604e75..561c43206d 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/InstanceOperationsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/InstanceOperationsImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/IsolationException.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/IsolationException.java
index f46d259101..c18f7472c5 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/IsolationException.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/IsolationException.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/MultiTableBatchWriterImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/MultiTableBatchWriterImpl.java
index c73d9a29a9..ec7308b591 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/MultiTableBatchWriterImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/MultiTableBatchWriterImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/Namespace.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/Namespace.java
index 0784081a90..1add3ff380 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/Namespace.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/Namespace.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/NamespaceOperationsHelper.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/NamespaceOperationsHelper.java
index 1cbdc830b8..59336acebd 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/NamespaceOperationsHelper.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/NamespaceOperationsHelper.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/NamespaceOperationsImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/NamespaceOperationsImpl.java
index 080eb5a578..cf9429c389 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/NamespaceOperationsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/NamespaceOperationsImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/Namespaces.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/Namespaces.java
index 9b826683b3..b5ab93af69 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/Namespaces.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/Namespaces.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/OfflineIterator.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/OfflineIterator.java
index e28612c956..9948d355ec 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/OfflineIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/OfflineIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/OfflineScanner.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/OfflineScanner.java
index db48cb0e51..536c8a876f 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/OfflineScanner.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/OfflineScanner.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ReplicationOperationsImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ReplicationOperationsImpl.java
index 12dc50bb8f..49aa1f5002 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ReplicationOperationsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ReplicationOperationsImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/RootTabletLocator.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/RootTabletLocator.java
index 81f0e55258..b66d9875a6 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/RootTabletLocator.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/RootTabletLocator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ScannerImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ScannerImpl.java
index b4d989f057..c48585e935 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ScannerImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ScannerImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ScannerIterator.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ScannerIterator.java
index f998845612..38f02643eb 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ScannerIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ScannerIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ScannerOptions.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ScannerOptions.java
index ee7b1becbc..07db160c6b 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ScannerOptions.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ScannerOptions.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/SecurityOperationsImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/SecurityOperationsImpl.java
index 5bc74c286a..ae7f98e5b5 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/SecurityOperationsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/SecurityOperationsImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/SyncingTabletLocator.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/SyncingTabletLocator.java
index 2ccfd6d27e..8f6daed955 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/SyncingTabletLocator.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/SyncingTabletLocator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/TableOperationsHelper.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/TableOperationsHelper.java
index 65b19f0bc9..27f7a9f4a5 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/TableOperationsHelper.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/TableOperationsHelper.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/TableOperationsImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/TableOperationsImpl.java
index 4d0019b491..60868ba229 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/TableOperationsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/TableOperationsImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletLocator.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletLocator.java
index 7161b67cb8..d0f7a788b1 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletLocator.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletLocator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletLocatorImpl.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletLocatorImpl.java
index b4eb6d5a4a..0a6a9df0c3 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletLocatorImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletLocatorImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchDeleter.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchDeleter.java
index 4eb45574ca..13889a6273 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchDeleter.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchDeleter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchReader.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchReader.java
index 71f7396c39..c0de759516 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchReader.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchReader.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchReaderIterator.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchReaderIterator.java
index dd544e7387..264accf92b 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchReaderIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchReaderIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchWriter.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchWriter.java
index 021e2d1cfb..764a877256 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchWriter.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletServerBatchWriter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletType.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletType.java
index 60525a3532..1cc2140a18 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletType.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/TabletType.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ThriftScanner.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ThriftScanner.java
index ded0430f79..41cc713085 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ThriftScanner.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ThriftScanner.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ThriftTransportKey.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ThriftTransportKey.java
index aed931d804..0f252508ff 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ThriftTransportKey.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ThriftTransportKey.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ThriftTransportPool.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ThriftTransportPool.java
index 7dd9a8cde0..426dffe136 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ThriftTransportPool.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ThriftTransportPool.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/TimeoutTabletLocator.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/TimeoutTabletLocator.java
index e067415357..b7774839ae 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/TimeoutTabletLocator.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/TimeoutTabletLocator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/UserCompactionUtils.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/UserCompactionUtils.java
index cbb7e31943..2c71bc542d 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/UserCompactionUtils.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/UserCompactionUtils.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/Writer.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/Writer.java
index 4c211fa9cc..2d50820a2c 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/Writer.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/Writer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/ZookeeperLockChecker.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/ZookeeperLockChecker.java
index fccd89cc4c..76096c2ebf 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/ZookeeperLockChecker.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/ZookeeperLockChecker.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/Bulk.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/Bulk.java
index 21cef9057e..288876af92 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/Bulk.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/Bulk.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/BulkImport.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/BulkImport.java
index b20785aa9f..786b2a100f 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/BulkImport.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/BulkImport.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/BulkSerialize.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/BulkSerialize.java
index f20efaa9ef..0f8d46c58a 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/BulkSerialize.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/BulkSerialize.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/ConcurrentKeyExtentCache.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/ConcurrentKeyExtentCache.java
index 1c8d5b6bb4..03d9bda441 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/ConcurrentKeyExtentCache.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/ConcurrentKeyExtentCache.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/LoadMappingIterator.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/LoadMappingIterator.java
index c31def2182..30e104196c 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/LoadMappingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/bulk/LoadMappingIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/lexicoder/ByteUtils.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/lexicoder/ByteUtils.java
index 347ebc9f8b..c11b913046 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/lexicoder/ByteUtils.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/lexicoder/ByteUtils.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/lexicoder/FixedByteArrayOutputStream.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/lexicoder/FixedByteArrayOutputStream.java
index 41fb6f2c90..5fac123390 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/lexicoder/FixedByteArrayOutputStream.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/lexicoder/FixedByteArrayOutputStream.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapred/BatchInputSplit.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapred/BatchInputSplit.java
index d0ecb8cc82..db69081c49 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapred/BatchInputSplit.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapred/BatchInputSplit.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/BatchInputSplit.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/BatchInputSplit.java
index a31b7569af..7f2b9ae613 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/BatchInputSplit.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/BatchInputSplit.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/DelegationTokenStub.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/DelegationTokenStub.java
index 21325b4b2a..7871624e50 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/DelegationTokenStub.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/DelegationTokenStub.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/SplitUtils.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/SplitUtils.java
index 99dc5aefbd..18ed602e63 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/SplitUtils.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/SplitUtils.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/ConfiguratorBase.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/ConfiguratorBase.java
index 6f73dcb25f..63c04c5f72 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/ConfiguratorBase.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/ConfiguratorBase.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/DistributedCacheHelper.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/DistributedCacheHelper.java
index eb34a83ff8..90f66917f9 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/DistributedCacheHelper.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/DistributedCacheHelper.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/FileOutputConfigurator.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/FileOutputConfigurator.java
index d55752596c..92ca14ff0e 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/FileOutputConfigurator.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/FileOutputConfigurator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/InputConfigurator.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/InputConfigurator.java
index 73a598a60a..17fd9e97bf 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/InputConfigurator.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/InputConfigurator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/OutputConfigurator.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/OutputConfigurator.java
index 388d3b5b87..96f731a291 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/OutputConfigurator.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/mapreduce/lib/OutputConfigurator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/compaction/CompactionSettings.java b/core/src/main/java/org/apache/accumulo/core/compaction/CompactionSettings.java
index 08952d1392..9f2d01defe 100644
--- a/core/src/main/java/org/apache/accumulo/core/compaction/CompactionSettings.java
+++ b/core/src/main/java/org/apache/accumulo/core/compaction/CompactionSettings.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/compaction/NullType.java b/core/src/main/java/org/apache/accumulo/core/compaction/NullType.java
index 893110a0f0..d05154c151 100644
--- a/core/src/main/java/org/apache/accumulo/core/compaction/NullType.java
+++ b/core/src/main/java/org/apache/accumulo/core/compaction/NullType.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/compaction/PatternType.java b/core/src/main/java/org/apache/accumulo/core/compaction/PatternType.java
index bd61e016ba..cbef78c70f 100644
--- a/core/src/main/java/org/apache/accumulo/core/compaction/PatternType.java
+++ b/core/src/main/java/org/apache/accumulo/core/compaction/PatternType.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/compaction/SizeType.java b/core/src/main/java/org/apache/accumulo/core/compaction/SizeType.java
index c558b29bc0..e1b23d2327 100644
--- a/core/src/main/java/org/apache/accumulo/core/compaction/SizeType.java
+++ b/core/src/main/java/org/apache/accumulo/core/compaction/SizeType.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/compaction/StringType.java b/core/src/main/java/org/apache/accumulo/core/compaction/StringType.java
index 73727ac24a..fed92c5ca4 100644
--- a/core/src/main/java/org/apache/accumulo/core/compaction/StringType.java
+++ b/core/src/main/java/org/apache/accumulo/core/compaction/StringType.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/compaction/Type.java b/core/src/main/java/org/apache/accumulo/core/compaction/Type.java
index e7a4087261..7efd192658 100644
--- a/core/src/main/java/org/apache/accumulo/core/compaction/Type.java
+++ b/core/src/main/java/org/apache/accumulo/core/compaction/Type.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/compaction/UIntType.java b/core/src/main/java/org/apache/accumulo/core/compaction/UIntType.java
index 4e278c0d32..0819e2857a 100644
--- a/core/src/main/java/org/apache/accumulo/core/compaction/UIntType.java
+++ b/core/src/main/java/org/apache/accumulo/core/compaction/UIntType.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 7652db531f..dce79bcf98 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/ClientConfigGenerate.java b/core/src/main/java/org/apache/accumulo/core/conf/ClientConfigGenerate.java
index 961b9653de..c0ef12ce7a 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/ClientConfigGenerate.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/ClientConfigGenerate.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
@@ -136,7 +136,7 @@ public class ClientConfigGenerate {
       doc.println("# (the \"License\"); you may not use this file except in compliance with");
       doc.println("# the License.  You may obtain a copy of the License at");
       doc.println("#");
-      doc.println("#     http://www.apache.org/licenses/LICENSE-2.0");
+      doc.println("#     https://www.apache.org/licenses/LICENSE-2.0");
       doc.println("#");
       doc.println("# Unless required by applicable law or agreed to in writing, software");
       doc.println("# distributed under the License is distributed on an \"AS IS\" BASIS,");
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/ClientProperty.java b/core/src/main/java/org/apache/accumulo/core/conf/ClientProperty.java
index b20f6ac51d..db5bd3f483 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/ClientProperty.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/ClientProperty.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/ConfigCheckUtil.java b/core/src/main/java/org/apache/accumulo/core/conf/ConfigCheckUtil.java
index b0bc09958f..dfa9047c3c 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/ConfigCheckUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/ConfigCheckUtil.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationCopy.java b/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationCopy.java
index a08808573f..221934c7c2 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationCopy.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationCopy.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationDocGen.java b/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationDocGen.java
index e434b008d9..c3e0d000ca 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationDocGen.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationDocGen.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationTypeHelper.java b/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationTypeHelper.java
index d43e8dd674..301d6b3756 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationTypeHelper.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationTypeHelper.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/DefaultConfiguration.java b/core/src/main/java/org/apache/accumulo/core/conf/DefaultConfiguration.java
index e7ca93c93f..2c3abca0f1 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/DefaultConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/DefaultConfiguration.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/DeprecatedPropertyUtil.java b/core/src/main/java/org/apache/accumulo/core/conf/DeprecatedPropertyUtil.java
index 87e467aeb5..5017c90940 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/DeprecatedPropertyUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/DeprecatedPropertyUtil.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/Experimental.java b/core/src/main/java/org/apache/accumulo/core/conf/Experimental.java
index 515abd2ca4..3444a8aa1e 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/Experimental.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/Experimental.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/HadoopCredentialProvider.java b/core/src/main/java/org/apache/accumulo/core/conf/HadoopCredentialProvider.java
index b0e0092529..773ba20737 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/HadoopCredentialProvider.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/HadoopCredentialProvider.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 3c31a2fc60..82d0264284 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 12f7666477..c590054485 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/ReplacedBy.java b/core/src/main/java/org/apache/accumulo/core/conf/ReplacedBy.java
index 36e85185ac..fdf56fe534 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/ReplacedBy.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/ReplacedBy.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/Sensitive.java b/core/src/main/java/org/apache/accumulo/core/conf/Sensitive.java
index bb35d90d11..26ddaf0e19 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/Sensitive.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/Sensitive.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 d88c7f58bd..c20aab006b 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/cluster/ClusterConfigParser.java b/core/src/main/java/org/apache/accumulo/core/conf/cluster/ClusterConfigParser.java
index a1d7b6a2f4..9134742e9c 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/cluster/ClusterConfigParser.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/cluster/ClusterConfigParser.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/constraints/Constraint.java b/core/src/main/java/org/apache/accumulo/core/constraints/Constraint.java
index bad12684ed..b14d06988f 100644
--- a/core/src/main/java/org/apache/accumulo/core/constraints/Constraint.java
+++ b/core/src/main/java/org/apache/accumulo/core/constraints/Constraint.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/constraints/DefaultKeySizeConstraint.java b/core/src/main/java/org/apache/accumulo/core/constraints/DefaultKeySizeConstraint.java
index 6e92a78cec..8930ea355c 100644
--- a/core/src/main/java/org/apache/accumulo/core/constraints/DefaultKeySizeConstraint.java
+++ b/core/src/main/java/org/apache/accumulo/core/constraints/DefaultKeySizeConstraint.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/constraints/NoDeleteConstraint.java b/core/src/main/java/org/apache/accumulo/core/constraints/NoDeleteConstraint.java
index eab748ed25..f0f5db5153 100644
--- a/core/src/main/java/org/apache/accumulo/core/constraints/NoDeleteConstraint.java
+++ b/core/src/main/java/org/apache/accumulo/core/constraints/NoDeleteConstraint.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/constraints/Violations.java b/core/src/main/java/org/apache/accumulo/core/constraints/Violations.java
index 821de1e871..9ad286598a 100644
--- a/core/src/main/java/org/apache/accumulo/core/constraints/Violations.java
+++ b/core/src/main/java/org/apache/accumulo/core/constraints/Violations.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/constraints/VisibilityConstraint.java b/core/src/main/java/org/apache/accumulo/core/constraints/VisibilityConstraint.java
index 80e6392d51..4066b96ea1 100644
--- a/core/src/main/java/org/apache/accumulo/core/constraints/VisibilityConstraint.java
+++ b/core/src/main/java/org/apache/accumulo/core/constraints/VisibilityConstraint.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/crypto/CryptoEnvironmentImpl.java b/core/src/main/java/org/apache/accumulo/core/crypto/CryptoEnvironmentImpl.java
index ba2deae1aa..16559e90cf 100644
--- a/core/src/main/java/org/apache/accumulo/core/crypto/CryptoEnvironmentImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/crypto/CryptoEnvironmentImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/crypto/CryptoServiceFactory.java b/core/src/main/java/org/apache/accumulo/core/crypto/CryptoServiceFactory.java
index 1415b0d341..c4cac54ada 100644
--- a/core/src/main/java/org/apache/accumulo/core/crypto/CryptoServiceFactory.java
+++ b/core/src/main/java/org/apache/accumulo/core/crypto/CryptoServiceFactory.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/crypto/CryptoUtils.java b/core/src/main/java/org/apache/accumulo/core/crypto/CryptoUtils.java
index 76eb7641d8..9344935175 100644
--- a/core/src/main/java/org/apache/accumulo/core/crypto/CryptoUtils.java
+++ b/core/src/main/java/org/apache/accumulo/core/crypto/CryptoUtils.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/crypto/streams/BlockedInputStream.java b/core/src/main/java/org/apache/accumulo/core/crypto/streams/BlockedInputStream.java
index 269518b4b2..a042d95834 100644
--- a/core/src/main/java/org/apache/accumulo/core/crypto/streams/BlockedInputStream.java
+++ b/core/src/main/java/org/apache/accumulo/core/crypto/streams/BlockedInputStream.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/crypto/streams/BlockedOutputStream.java b/core/src/main/java/org/apache/accumulo/core/crypto/streams/BlockedOutputStream.java
index 36d545079b..fe0db55ead 100644
--- a/core/src/main/java/org/apache/accumulo/core/crypto/streams/BlockedOutputStream.java
+++ b/core/src/main/java/org/apache/accumulo/core/crypto/streams/BlockedOutputStream.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/crypto/streams/DiscardCloseOutputStream.java b/core/src/main/java/org/apache/accumulo/core/crypto/streams/DiscardCloseOutputStream.java
index e1e3e220e6..c460bee38d 100644
--- a/core/src/main/java/org/apache/accumulo/core/crypto/streams/DiscardCloseOutputStream.java
+++ b/core/src/main/java/org/apache/accumulo/core/crypto/streams/DiscardCloseOutputStream.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/crypto/streams/NoFlushOutputStream.java b/core/src/main/java/org/apache/accumulo/core/crypto/streams/NoFlushOutputStream.java
index 4202b7394b..f94a37b4f5 100644
--- a/core/src/main/java/org/apache/accumulo/core/crypto/streams/NoFlushOutputStream.java
+++ b/core/src/main/java/org/apache/accumulo/core/crypto/streams/NoFlushOutputStream.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/crypto/streams/RFileCipherOutputStream.java b/core/src/main/java/org/apache/accumulo/core/crypto/streams/RFileCipherOutputStream.java
index 5a96d4e44b..519af97cc5 100644
--- a/core/src/main/java/org/apache/accumulo/core/crypto/streams/RFileCipherOutputStream.java
+++ b/core/src/main/java/org/apache/accumulo/core/crypto/streams/RFileCipherOutputStream.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/AbstractId.java b/core/src/main/java/org/apache/accumulo/core/data/AbstractId.java
index 8f72ff4deb..0b0f84e8f1 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/AbstractId.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/AbstractId.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/ArrayByteSequence.java b/core/src/main/java/org/apache/accumulo/core/data/ArrayByteSequence.java
index c209b8d2eb..0aa62cb093 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/ArrayByteSequence.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/ArrayByteSequence.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/ByteSequence.java b/core/src/main/java/org/apache/accumulo/core/data/ByteSequence.java
index 4e5a328bbf..f98d9ce89b 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/ByteSequence.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/ByteSequence.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/Column.java b/core/src/main/java/org/apache/accumulo/core/data/Column.java
index 649c8a67a2..f5a2519601 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/Column.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/Column.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/ColumnUpdate.java b/core/src/main/java/org/apache/accumulo/core/data/ColumnUpdate.java
index ebd45b14b1..143bbe1423 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/ColumnUpdate.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/ColumnUpdate.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/Condition.java b/core/src/main/java/org/apache/accumulo/core/data/Condition.java
index 404f31dd5d..83d2e81e89 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/Condition.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/Condition.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/ConditionalMutation.java b/core/src/main/java/org/apache/accumulo/core/data/ConditionalMutation.java
index a111b9d4c7..1f2999e844 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/ConditionalMutation.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/ConditionalMutation.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 ba45bb0e84..7ad28f70d9 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/InstanceId.java b/core/src/main/java/org/apache/accumulo/core/data/InstanceId.java
index 8768b9a6d9..53f0f5c7b8 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/InstanceId.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/InstanceId.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/Key.java b/core/src/main/java/org/apache/accumulo/core/data/Key.java
index ab8c7b12d9..a3ad8628b9 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/Key.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/Key.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/KeyBuilder.java b/core/src/main/java/org/apache/accumulo/core/data/KeyBuilder.java
index 1d625b89a2..a793fa2e34 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/KeyBuilder.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/KeyBuilder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/KeyValue.java b/core/src/main/java/org/apache/accumulo/core/data/KeyValue.java
index e819387952..8e26a847d5 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/KeyValue.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/KeyValue.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/LoadPlan.java b/core/src/main/java/org/apache/accumulo/core/data/LoadPlan.java
index 9917ce0f40..1556e29eb9 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/LoadPlan.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/LoadPlan.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/Mutation.java b/core/src/main/java/org/apache/accumulo/core/data/Mutation.java
index f0261b20b0..6410704801 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/Mutation.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/Mutation.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/NamespaceId.java b/core/src/main/java/org/apache/accumulo/core/data/NamespaceId.java
index cc6ec46978..2a37437881 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/NamespaceId.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/NamespaceId.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/PartialKey.java b/core/src/main/java/org/apache/accumulo/core/data/PartialKey.java
index 808bc63ff2..f5ff0ae08c 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/PartialKey.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/PartialKey.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/Range.java b/core/src/main/java/org/apache/accumulo/core/data/Range.java
index 57405b1b2f..09e0df1854 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/Range.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/Range.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/TableId.java b/core/src/main/java/org/apache/accumulo/core/data/TableId.java
index 581ba1a69e..311a120a5e 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/TableId.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/TableId.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/TabletId.java b/core/src/main/java/org/apache/accumulo/core/data/TabletId.java
index ec17935448..51bfa1aaae 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/TabletId.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/TabletId.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/Value.java b/core/src/main/java/org/apache/accumulo/core/data/Value.java
index 077ed8a808..54134b84e1 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/Value.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/Value.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/constraints/Constraint.java b/core/src/main/java/org/apache/accumulo/core/data/constraints/Constraint.java
index 5ce7840bcd..99348bf4c9 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/constraints/Constraint.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/constraints/Constraint.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/constraints/DefaultKeySizeConstraint.java b/core/src/main/java/org/apache/accumulo/core/data/constraints/DefaultKeySizeConstraint.java
index 6c0ff8eb6c..3e63314d21 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/constraints/DefaultKeySizeConstraint.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/constraints/DefaultKeySizeConstraint.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/constraints/NoDeleteConstraint.java b/core/src/main/java/org/apache/accumulo/core/data/constraints/NoDeleteConstraint.java
index 7d219b4568..53b87fd4f2 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/constraints/NoDeleteConstraint.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/constraints/NoDeleteConstraint.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/constraints/VisibilityConstraint.java b/core/src/main/java/org/apache/accumulo/core/data/constraints/VisibilityConstraint.java
index a4d75b1bf7..c0a1810a0c 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/constraints/VisibilityConstraint.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/constraints/VisibilityConstraint.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/data/doc-files/mutation-serialization.html b/core/src/main/java/org/apache/accumulo/core/data/doc-files/mutation-serialization.html
index f5378c586d..87f183f2ec 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/doc-files/mutation-serialization.html
+++ b/core/src/main/java/org/apache/accumulo/core/data/doc-files/mutation-serialization.html
@@ -8,7 +8,7 @@
     "License"); you may not use this file except in compliance
     with the License.  You may obtain a copy of the License at
 
-      http://www.apache.org/licenses/LICENSE-2.0
+      https://www.apache.org/licenses/LICENSE-2.0
 
     Unless required by applicable law or agreed to in writing,
     software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/dataImpl/ComparableBytes.java b/core/src/main/java/org/apache/accumulo/core/dataImpl/ComparableBytes.java
index 0a948ed055..eebebc0632 100644
--- a/core/src/main/java/org/apache/accumulo/core/dataImpl/ComparableBytes.java
+++ b/core/src/main/java/org/apache/accumulo/core/dataImpl/ComparableBytes.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/dataImpl/KeyExtent.java b/core/src/main/java/org/apache/accumulo/core/dataImpl/KeyExtent.java
index 7ed868efd7..021ebf14d4 100644
--- a/core/src/main/java/org/apache/accumulo/core/dataImpl/KeyExtent.java
+++ b/core/src/main/java/org/apache/accumulo/core/dataImpl/KeyExtent.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/dataImpl/TabletIdImpl.java b/core/src/main/java/org/apache/accumulo/core/dataImpl/TabletIdImpl.java
index bf970eac7e..e5a16dd4a6 100644
--- a/core/src/main/java/org/apache/accumulo/core/dataImpl/TabletIdImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/dataImpl/TabletIdImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/BloomFilterLayer.java b/core/src/main/java/org/apache/accumulo/core/file/BloomFilterLayer.java
index 873cfb22af..47691381d9 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/BloomFilterLayer.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/BloomFilterLayer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/DispatchingFileFactory.java b/core/src/main/java/org/apache/accumulo/core/file/DispatchingFileFactory.java
index b6933327da..fb16b85741 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/DispatchingFileFactory.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/DispatchingFileFactory.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 ce4b678bce..b5c5c9e817 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/FileSKVIterator.java b/core/src/main/java/org/apache/accumulo/core/file/FileSKVIterator.java
index cd1b227378..32ee710cb1 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/FileSKVIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/FileSKVIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/FileSKVWriter.java b/core/src/main/java/org/apache/accumulo/core/file/FileSKVWriter.java
index a85a827220..e4c38bdd6e 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/FileSKVWriter.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/FileSKVWriter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/NoSuchMetaStoreException.java b/core/src/main/java/org/apache/accumulo/core/file/NoSuchMetaStoreException.java
index eec16a1a1a..ee28b7b99c 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/NoSuchMetaStoreException.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/NoSuchMetaStoreException.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/BlockCacheConfiguration.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/BlockCacheConfiguration.java
index 276d6855b6..d2cda1c63c 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/BlockCacheConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/BlockCacheConfiguration.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/BlockCacheManagerFactory.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/BlockCacheManagerFactory.java
index 5ba4b0fc90..9997c96467 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/BlockCacheManagerFactory.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/BlockCacheManagerFactory.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/ClassSize.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/ClassSize.java
index 6445949175..392ac7d239 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/ClassSize.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/ClassSize.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/SizeConstants.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/SizeConstants.java
index d7eb08ff24..d192a738ea 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/SizeConstants.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/impl/SizeConstants.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/CachedBlock.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/CachedBlock.java
index c94e3dea50..4a4e6b0f90 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/CachedBlock.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/CachedBlock.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/CachedBlockQueue.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/CachedBlockQueue.java
index 2e6c186a41..89565170c0 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/CachedBlockQueue.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/CachedBlockQueue.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/HeapSize.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/HeapSize.java
index 388ff3948c..f3bbc9c823 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/HeapSize.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/HeapSize.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/LruBlockCache.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/LruBlockCache.java
index 2e716d02a4..b46ef256cc 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/LruBlockCache.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/LruBlockCache.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/LruBlockCacheConfiguration.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/LruBlockCacheConfiguration.java
index c9acc16496..490271e6c2 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/LruBlockCacheConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/LruBlockCacheConfiguration.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/LruBlockCacheManager.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/LruBlockCacheManager.java
index 19eb13b758..a4132b7d75 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/LruBlockCacheManager.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/LruBlockCacheManager.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/SynchronousLoadingBlockCache.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/SynchronousLoadingBlockCache.java
index 0d49ecd28f..d72ec2d2b0 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/SynchronousLoadingBlockCache.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/lru/SynchronousLoadingBlockCache.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/tinylfu/TinyLfuBlockCache.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/tinylfu/TinyLfuBlockCache.java
index 53c9b857db..7bb01e0ecf 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/tinylfu/TinyLfuBlockCache.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/tinylfu/TinyLfuBlockCache.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
@@ -48,9 +48,9 @@ import com.github.benmanes.caffeine.cache.stats.CacheStats;
  * A block cache that is memory bounded using the W-TinyLFU eviction algorithm. This implementation
  * delegates to a Caffeine cache to provide concurrent O(1) read and write operations.
  * <ul>
- * <li><a href="http://arxiv.org/pdf/1512.00727.pdf">W-TinyLFU</a></li>
+ * <li><a href="https://arxiv.org/pdf/1512.00727.pdf">W-TinyLFU</a></li>
  * <li><a href="https://github.com/ben-manes/caffeine">Caffeine</a></li>
- * <li><a href="http://highscalability.com/blog/2016/1/25/design-of-a-modern-cache.html">Cache
+ * <li><a href="https://highscalability.com/blog/2016/1/25/design-of-a-modern-cache.html">Cache
  * design</a></li>
  * </ul>
  */
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/tinylfu/TinyLfuBlockCacheManager.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/tinylfu/TinyLfuBlockCacheManager.java
index 967d899009..77a3427b6e 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/tinylfu/TinyLfuBlockCacheManager.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/tinylfu/TinyLfuBlockCacheManager.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/BasicCacheProvider.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/BasicCacheProvider.java
index 7c3015c8b5..e8890640ad 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/BasicCacheProvider.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/BasicCacheProvider.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/CachableBlockFile.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/CachableBlockFile.java
index 3e4e7c98f5..878de6a058 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/CachableBlockFile.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/CachableBlockFile.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/CacheProvider.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/CacheProvider.java
index c7c6d6c987..4a64f9f2a1 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/CacheProvider.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/CacheProvider.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/OpportunisticBlockCache.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/OpportunisticBlockCache.java
index 60c8f0a2d7..70bde7877e 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/OpportunisticBlockCache.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/OpportunisticBlockCache.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/ScanCacheProvider.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/ScanCacheProvider.java
index c406b0a156..f82f534cf5 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/ScanCacheProvider.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/ScanCacheProvider.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/SeekableByteArrayInputStream.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/SeekableByteArrayInputStream.java
index c6cdb2566f..462b0ca1cc 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/SeekableByteArrayInputStream.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/SeekableByteArrayInputStream.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnFamilyFunctor.java b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnFamilyFunctor.java
index 65c3915516..19d53e2406 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnFamilyFunctor.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnFamilyFunctor.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnQualifierFunctor.java b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnQualifierFunctor.java
index 8675ec8af1..8486faf1af 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnQualifierFunctor.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnQualifierFunctor.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/KeyFunctor.java b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/KeyFunctor.java
index c151107246..321cd3aa27 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/KeyFunctor.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/KeyFunctor.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/RowFunctor.java b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/RowFunctor.java
index 0f84b7e325..fe9415400e 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/RowFunctor.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/RowFunctor.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/map/MapFileOperations.java b/core/src/main/java/org/apache/accumulo/core/file/map/MapFileOperations.java
index 38e7330d50..960e0c3755 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/map/MapFileOperations.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/map/MapFileOperations.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/map/MapFileUtil.java b/core/src/main/java/org/apache/accumulo/core/file/map/MapFileUtil.java
index 2d9c49d825..7fd7276fd8 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/map/MapFileUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/map/MapFileUtil.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/BlockIndex.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/BlockIndex.java
index 3a17838207..0bf1d545ef 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/BlockIndex.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/BlockIndex.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 975f4c1f0e..3aa91e8a9c 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/GenerateSplits.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/GenerateSplits.java
index aeb1a740d0..19a268a711 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/GenerateSplits.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/GenerateSplits.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/IndexIterator.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/IndexIterator.java
index 8b3473f17a..69550b00a8 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/IndexIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/IndexIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 22b0933973..9077e27843 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/MetricsGatherer.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/MetricsGatherer.java
index 513d57c1cf..e98fc60b68 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/MetricsGatherer.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/MetricsGatherer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/MultiIndexIterator.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/MultiIndexIterator.java
index dabb3cc2d8..b11d100359 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/MultiIndexIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/MultiIndexIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/MultiLevelIndex.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/MultiLevelIndex.java
index 0fb1bc13c6..b74d27b9db 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/MultiLevelIndex.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/MultiLevelIndex.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/PrintInfo.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/PrintInfo.java
index 81ce62d91d..7187a1cd71 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/PrintInfo.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/PrintInfo.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 eb457c8b8d..2c7d3cf493 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/RFileOperations.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/RFileOperations.java
index 645ae51dd7..833adb700d 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/RFileOperations.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/RFileOperations.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/RelativeKey.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/RelativeKey.java
index 184884af53..ef37ac1b9e 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/RelativeKey.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/RelativeKey.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/RollingStats.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/RollingStats.java
index 1ee0f7b1c9..ab7f9ac371 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/RollingStats.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/RollingStats.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
@@ -53,7 +53,7 @@ class RollingStats {
 
   /**
    * @see <a href=
-   *      "http://jonisalonen.com/2014/efficient-and-accurate-rolling-standard-deviation/">Efficient
+   *      "https://jonisalonen.com/2014/efficient-and-accurate-rolling-standard-deviation">Efficient
    *      and accurate rolling standard deviation</a>
    */
   private void update(double newValue, double oldValue, int windowSize) {
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/SplitLarge.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/SplitLarge.java
index cf2906b4bd..da1435ea28 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/SplitLarge.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/SplitLarge.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/VisMetricsGatherer.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/VisMetricsGatherer.java
index d41dad5b51..8b8f3c6d5b 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/VisMetricsGatherer.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/VisMetricsGatherer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/VisibilityMetric.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/VisibilityMetric.java
index 5837104627..5752986576 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/VisibilityMetric.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/VisibilityMetric.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 c82713a004..c9af6c4c42 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Compression.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Compression.java
index 3e9ac6409a..ab721aeeaf 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Compression.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Compression.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/CompressionAlgorithm.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/CompressionAlgorithm.java
index 9443348038..a42034db09 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/CompressionAlgorithm.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/CompressionAlgorithm.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/IdentityCodec.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/IdentityCodec.java
index ad9f58c078..f9c224eef1 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/IdentityCodec.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/IdentityCodec.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/MetaBlockAlreadyExists.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/MetaBlockAlreadyExists.java
index a1a3cec436..02813b759e 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/MetaBlockAlreadyExists.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/MetaBlockAlreadyExists.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/MetaBlockDoesNotExist.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/MetaBlockDoesNotExist.java
index 757810d133..dca7423179 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/MetaBlockDoesNotExist.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/MetaBlockDoesNotExist.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/PrintInfo.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/PrintInfo.java
index 695cf33133..949c89bac5 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/PrintInfo.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/PrintInfo.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/SimpleBufferedOutputStream.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/SimpleBufferedOutputStream.java
index 6a4deffc06..87e96a602d 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/SimpleBufferedOutputStream.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/SimpleBufferedOutputStream.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Utils.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Utils.java
index a53d7046b1..bb05426e67 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Utils.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Utils.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/streams/BoundedRangeFileInputStream.java b/core/src/main/java/org/apache/accumulo/core/file/streams/BoundedRangeFileInputStream.java
index 4091e0501b..177ebd2f4d 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/streams/BoundedRangeFileInputStream.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/streams/BoundedRangeFileInputStream.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/streams/RateLimitedInputStream.java b/core/src/main/java/org/apache/accumulo/core/file/streams/RateLimitedInputStream.java
index be9fa7b975..45d00a473b 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/streams/RateLimitedInputStream.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/streams/RateLimitedInputStream.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/streams/RateLimitedOutputStream.java b/core/src/main/java/org/apache/accumulo/core/file/streams/RateLimitedOutputStream.java
index b8819305f1..3ac7a761e7 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/streams/RateLimitedOutputStream.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/streams/RateLimitedOutputStream.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/file/streams/SeekableDataInputStream.java b/core/src/main/java/org/apache/accumulo/core/file/streams/SeekableDataInputStream.java
index c4f0e549b4..d46bf93978 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/streams/SeekableDataInputStream.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/streams/SeekableDataInputStream.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/gc/Reference.java b/core/src/main/java/org/apache/accumulo/core/gc/Reference.java
index cbc3a28193..f40424c62f 100644
--- a/core/src/main/java/org/apache/accumulo/core/gc/Reference.java
+++ b/core/src/main/java/org/apache/accumulo/core/gc/Reference.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/gc/ReferenceDirectory.java b/core/src/main/java/org/apache/accumulo/core/gc/ReferenceDirectory.java
index 67d8619d8e..f2d6e97e94 100644
--- a/core/src/main/java/org/apache/accumulo/core/gc/ReferenceDirectory.java
+++ b/core/src/main/java/org/apache/accumulo/core/gc/ReferenceDirectory.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/ColumnFamilyCounter.java b/core/src/main/java/org/apache/accumulo/core/iterators/ColumnFamilyCounter.java
index 871417f0a2..46174391a1 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/ColumnFamilyCounter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/ColumnFamilyCounter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 c3fd55509f..f502387ceb 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/DebugIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/DebugIterator.java
index 6919143409..fa79348a2f 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/DebugIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/DebugIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/DevNull.java b/core/src/main/java/org/apache/accumulo/core/iterators/DevNull.java
index 2cafd04015..5bb6aaa9e2 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/DevNull.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/DevNull.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 cff1703987..37e629d3fe 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/FirstEntryInRowIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/FirstEntryInRowIterator.java
index 7a7bc49a59..6b22da3cdb 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/FirstEntryInRowIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/FirstEntryInRowIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/IteratorAdapter.java b/core/src/main/java/org/apache/accumulo/core/iterators/IteratorAdapter.java
index faf220a19f..4674028ac9 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/IteratorAdapter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/IteratorAdapter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 cc9e41df77..bfb6972b63 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 01064721ff..416b0eb25c 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 2e6366e405..1dc915392f 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 3035d9430c..73b0756fb1 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/OrIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/OrIterator.java
index 13deec009e..0c5ec6755b 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/OrIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/OrIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/ServerFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/ServerFilter.java
index 527ea7b746..d4a56df753 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/ServerFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/ServerFilter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/ServerSkippingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/ServerSkippingIterator.java
index aed7f321fe..27d6267e7d 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/ServerSkippingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/ServerSkippingIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/ServerWrappingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/ServerWrappingIterator.java
index b5f4f86bf1..55dbc2a12a 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/ServerWrappingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/ServerWrappingIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/SkippingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/SkippingIterator.java
index e71d11ede6..037b6f5237 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/SkippingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/SkippingIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/SortedKeyIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/SortedKeyIterator.java
index 2b3e50065d..2d4e1d372e 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/SortedKeyIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/SortedKeyIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/SortedKeyValueIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/SortedKeyValueIterator.java
index 693f29235b..1abb4b2252 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/SortedKeyValueIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/SortedKeyValueIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/SynchronizedServerFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/SynchronizedServerFilter.java
index 9f8f638845..7be9b818e1 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/SynchronizedServerFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/SynchronizedServerFilter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 85a6640432..ae88c0f567 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/ValueFormatException.java b/core/src/main/java/org/apache/accumulo/core/iterators/ValueFormatException.java
index 82c2178649..f2494c07a8 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/ValueFormatException.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/ValueFormatException.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/WrappingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/WrappingIterator.java
index 0a100ac776..89eaf8f8de 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/WrappingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/WrappingIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/YieldCallback.java b/core/src/main/java/org/apache/accumulo/core/iterators/YieldCallback.java
index e08b462cbe..a69fe2ff51 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/YieldCallback.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/YieldCallback.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/YieldingKeyValueIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/YieldingKeyValueIterator.java
index c30b4b9dc5..059645599e 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/YieldingKeyValueIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/YieldingKeyValueIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 2e3f47329c..0a822ec0c1 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/BigDecimalCombiner.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/BigDecimalCombiner.java
index a207076e3b..f6ba02e5e0 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/BigDecimalCombiner.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/BigDecimalCombiner.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceFilter.java
index c1675b11ce..b4832f52f1 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceFilter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 c1307abfde..7b9e1de4c1 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceSeekingFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceSeekingFilter.java
index b9fb838029..97de228f60 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceSeekingFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceSeekingFilter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 a4b741ffb4..f359482180 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 407755d724..5e0aa4fb27 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/GrepIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/GrepIterator.java
index d31639d5a6..ff55b2c3da 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/GrepIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/GrepIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/IndexedDocIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/IndexedDocIterator.java
index 7d568fe01f..5c64ebe9bd 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/IndexedDocIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/IndexedDocIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/IntersectingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/IntersectingIterator.java
index 856a1b26d7..38a3bd3977 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/IntersectingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/IntersectingIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 6761cfa6d7..086784ef9c 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 738e6a1834..114fa5c213 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 b87d1c1485..fb286439cf 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 e0949f89c0..971031ac20 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/ReqVisFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/ReqVisFilter.java
index 3a35fb05d5..74eee28e0a 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/ReqVisFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/ReqVisFilter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/RowDeletingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/RowDeletingIterator.java
index c69f805a19..017b9a706b 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/RowDeletingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/RowDeletingIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 014f8f0f97..a717dc38c1 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/RowFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/RowFilter.java
index f44ce78eaa..abae2f6a40 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/RowFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/RowFilter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/SeekingFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/SeekingFilter.java
index 9a18258ab9..bdfb4da2d5 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/SeekingFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/SeekingFilter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 4784c0ccf4..35a7bb3732 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 a3a7ddfa74..e3e4e8695b 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/TimestampFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/TimestampFilter.java
index efeee4b56b..096f2cafd7 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/TimestampFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/TimestampFilter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 bc873f8812..c0169d8bcd 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/VersioningIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/VersioningIterator.java
index 70ee5dfec6..b52a925e7f 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/VersioningIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/VersioningIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 67deb60c1b..8b7fc94b55 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeColumnFamilyIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeColumnFamilyIterator.java
index 8ce4df3602..26b41751d2 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeColumnFamilyIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeColumnFamilyIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeRowIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeRowIterator.java
index 71f79b4576..3cfc195dbc 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeRowIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeRowIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/IteratorBuilder.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/IteratorBuilder.java
index d18388118e..ef9d54693e 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/IteratorBuilder.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/IteratorBuilder.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/IteratorBuilderImpl.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/IteratorBuilderImpl.java
index ebc78f4b75..c26df026d1 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/IteratorBuilderImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/IteratorBuilderImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/IteratorConfigUtil.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/IteratorConfigUtil.java
index 3da03ef615..9f89867620 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/IteratorConfigUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/IteratorConfigUtil.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/conf/ColumnSet.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/conf/ColumnSet.java
index 456f6081cd..e4ad6076d4 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/conf/ColumnSet.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/conf/ColumnSet.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/conf/ColumnToClassMapping.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/conf/ColumnToClassMapping.java
index 19539e32ad..5492c4cae3 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/conf/ColumnToClassMapping.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/conf/ColumnToClassMapping.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/conf/ColumnUtil.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/conf/ColumnUtil.java
index 942ba9c1ac..b6803040bd 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/conf/ColumnUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/conf/ColumnUtil.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/ColumnFamilySkippingIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/ColumnFamilySkippingIterator.java
index 07e0b47379..2dc754036e 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/ColumnFamilySkippingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/ColumnFamilySkippingIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/ColumnQualifierFilter.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/ColumnQualifierFilter.java
index 8687d15c09..e947082b4f 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/ColumnQualifierFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/ColumnQualifierFilter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/CountingIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/CountingIterator.java
index 91789d3fdd..6ce228ce79 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/CountingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/CountingIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/DeletingIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/DeletingIterator.java
index f29c061493..737c32f243 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/DeletingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/DeletingIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/EmptyIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/EmptyIterator.java
index 2f6e0b3b19..10a547bf4d 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/EmptyIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/EmptyIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/HeapIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/HeapIterator.java
index 8a56a27bc4..36fdb48936 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/HeapIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/HeapIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/InterruptibleIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/InterruptibleIterator.java
index f6657d92d5..c4ae03025e 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/InterruptibleIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/InterruptibleIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/IterationInterruptedException.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/IterationInterruptedException.java
index f5d20e1970..016db92246 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/IterationInterruptedException.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/IterationInterruptedException.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/LocalityGroupIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/LocalityGroupIterator.java
index 57185b8d25..010428797f 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/LocalityGroupIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/LocalityGroupIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/MapFileIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/MapFileIterator.java
index c5437507e7..d0f189b0a6 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/MapFileIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/MapFileIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/MultiIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/MultiIterator.java
index 02d530c3c8..94bab1e4a6 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/MultiIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/MultiIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SampleIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SampleIterator.java
index fddf68ed6f..0efd3a854e 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SampleIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SampleIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SequenceFileIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SequenceFileIterator.java
index a8b3118bf7..871c491dd2 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SequenceFileIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SequenceFileIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SortedMapIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SortedMapIterator.java
index f4c85253a6..53b67b0198 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SortedMapIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SortedMapIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SourceSwitchingIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SourceSwitchingIterator.java
index 92bffc6555..56a3f05764 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SourceSwitchingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SourceSwitchingIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/StatsIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/StatsIterator.java
index 6e5b206e1c..2fad547a03 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/StatsIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/StatsIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SynchronizedIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SynchronizedIterator.java
index 53fa0b5569..75bd69aaae 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SynchronizedIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SynchronizedIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SystemIteratorUtil.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SystemIteratorUtil.java
index 41a7acca48..bac1d31ef1 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SystemIteratorUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/SystemIteratorUtil.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/TimeSettingIterator.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/TimeSettingIterator.java
index 17edff644c..9fb340a5bc 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/TimeSettingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/TimeSettingIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/VisibilityFilter.java b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/VisibilityFilter.java
index 3ab50c97b4..20bf7cb44b 100644
--- a/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/VisibilityFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iteratorsImpl/system/VisibilityFilter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/logging/FateLogger.java b/core/src/main/java/org/apache/accumulo/core/logging/FateLogger.java
index 63b39cdc44..6fef24bd26 100644
--- a/core/src/main/java/org/apache/accumulo/core/logging/FateLogger.java
+++ b/core/src/main/java/org/apache/accumulo/core/logging/FateLogger.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
@@ -16,7 +16,6 @@
  * specific language governing permissions and limitations
  * under the License.
  */
-
 package org.apache.accumulo.core.logging;
 
 import static org.apache.accumulo.fate.FateTxId.formatTid;
diff --git a/core/src/main/java/org/apache/accumulo/core/logging/Logging.java b/core/src/main/java/org/apache/accumulo/core/logging/Logging.java
index f7f935a430..946ca2c267 100644
--- a/core/src/main/java/org/apache/accumulo/core/logging/Logging.java
+++ b/core/src/main/java/org/apache/accumulo/core/logging/Logging.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/logging/TabletLogger.java b/core/src/main/java/org/apache/accumulo/core/logging/TabletLogger.java
index 7ab5341e6a..7694229fd0 100644
--- a/core/src/main/java/org/apache/accumulo/core/logging/TabletLogger.java
+++ b/core/src/main/java/org/apache/accumulo/core/logging/TabletLogger.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/logging/package-info.java b/core/src/main/java/org/apache/accumulo/core/logging/package-info.java
index 70b5e4a6ef..aa6eef7b91 100644
--- a/core/src/main/java/org/apache/accumulo/core/logging/package-info.java
+++ b/core/src/main/java/org/apache/accumulo/core/logging/package-info.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/manager/balancer/AssignmentParamsImpl.java b/core/src/main/java/org/apache/accumulo/core/manager/balancer/AssignmentParamsImpl.java
index b490737754..ca7b6e76dd 100644
--- a/core/src/main/java/org/apache/accumulo/core/manager/balancer/AssignmentParamsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/manager/balancer/AssignmentParamsImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/manager/balancer/BalanceParamsImpl.java b/core/src/main/java/org/apache/accumulo/core/manager/balancer/BalanceParamsImpl.java
index 4053d161ce..a0c30d43f5 100644
--- a/core/src/main/java/org/apache/accumulo/core/manager/balancer/BalanceParamsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/manager/balancer/BalanceParamsImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/manager/balancer/TServerStatusImpl.java b/core/src/main/java/org/apache/accumulo/core/manager/balancer/TServerStatusImpl.java
index 31968a77ab..7ae694c8f7 100644
--- a/core/src/main/java/org/apache/accumulo/core/manager/balancer/TServerStatusImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/manager/balancer/TServerStatusImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/manager/balancer/TableStatisticsImpl.java b/core/src/main/java/org/apache/accumulo/core/manager/balancer/TableStatisticsImpl.java
index 93dd1ebe0e..b3ab1355a9 100644
--- a/core/src/main/java/org/apache/accumulo/core/manager/balancer/TableStatisticsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/manager/balancer/TableStatisticsImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/manager/balancer/TabletServerIdImpl.java b/core/src/main/java/org/apache/accumulo/core/manager/balancer/TabletServerIdImpl.java
index 8236efb7a7..b4da5eec9b 100644
--- a/core/src/main/java/org/apache/accumulo/core/manager/balancer/TabletServerIdImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/manager/balancer/TabletServerIdImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/manager/balancer/TabletStatisticsImpl.java b/core/src/main/java/org/apache/accumulo/core/manager/balancer/TabletStatisticsImpl.java
index 4373f84810..df5d235623 100644
--- a/core/src/main/java/org/apache/accumulo/core/manager/balancer/TabletStatisticsImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/manager/balancer/TabletStatisticsImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/manager/state/tables/TableState.java b/core/src/main/java/org/apache/accumulo/core/manager/state/tables/TableState.java
index 2058d38f36..0b5e8a2117 100644
--- a/core/src/main/java/org/apache/accumulo/core/manager/state/tables/TableState.java
+++ b/core/src/main/java/org/apache/accumulo/core/manager/state/tables/TableState.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/CompactableFileImpl.java b/core/src/main/java/org/apache/accumulo/core/metadata/CompactableFileImpl.java
index 4d8b14ea46..e8cf109060 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/CompactableFileImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/CompactableFileImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/MetadataLocationObtainer.java b/core/src/main/java/org/apache/accumulo/core/metadata/MetadataLocationObtainer.java
index b68cbf02c0..54631a7730 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/MetadataLocationObtainer.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/MetadataLocationObtainer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/MetadataServicer.java b/core/src/main/java/org/apache/accumulo/core/metadata/MetadataServicer.java
index 2408c57967..59faba9224 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/MetadataServicer.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/MetadataServicer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/MetadataTable.java b/core/src/main/java/org/apache/accumulo/core/metadata/MetadataTable.java
index d222d3f6da..b2a9a5d3d4 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/MetadataTable.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/MetadataTable.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/RootTable.java b/core/src/main/java/org/apache/accumulo/core/metadata/RootTable.java
index 5b7b4b0b52..7c00cc0e81 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/RootTable.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/RootTable.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForMetadataTable.java b/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForMetadataTable.java
index 8cab90a6dd..948fcc1340 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForMetadataTable.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForMetadataTable.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForRootTable.java b/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForRootTable.java
index 4472548e77..aa85fc916b 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForRootTable.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForRootTable.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForUserTables.java b/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForUserTables.java
index 0e0d2e29b9..eeb7f7a309 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForUserTables.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/ServicerForUserTables.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/StoredTabletFile.java b/core/src/main/java/org/apache/accumulo/core/metadata/StoredTabletFile.java
index 8dd904c84c..672d531788 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/StoredTabletFile.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/StoredTabletFile.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/SuspendingTServer.java b/core/src/main/java/org/apache/accumulo/core/metadata/SuspendingTServer.java
index 43412edb8e..8b307ca535 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/SuspendingTServer.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/SuspendingTServer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/TServerInstance.java b/core/src/main/java/org/apache/accumulo/core/metadata/TServerInstance.java
index 8ba58607e0..09309e7397 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/TServerInstance.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/TServerInstance.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/TableMetadataServicer.java b/core/src/main/java/org/apache/accumulo/core/metadata/TableMetadataServicer.java
index 4669ade959..08ab977c45 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/TableMetadataServicer.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/TableMetadataServicer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/TabletDirectory.java b/core/src/main/java/org/apache/accumulo/core/metadata/TabletDirectory.java
index 1fcab6e70b..470055b8c2 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/TabletDirectory.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/TabletDirectory.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/TabletFile.java b/core/src/main/java/org/apache/accumulo/core/metadata/TabletFile.java
index d9c90fcec7..0127c3eb6a 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/TabletFile.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/TabletFile.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/TabletLocationState.java b/core/src/main/java/org/apache/accumulo/core/metadata/TabletLocationState.java
index 3df92580b9..d42ea74f64 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/TabletLocationState.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/TabletLocationState.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/TabletState.java b/core/src/main/java/org/apache/accumulo/core/metadata/TabletState.java
index b398c7a686..33d6141a0a 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/TabletState.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/TabletState.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/ValidationUtil.java b/core/src/main/java/org/apache/accumulo/core/metadata/ValidationUtil.java
index 83e57a40d2..39c171d55e 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/ValidationUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/ValidationUtil.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/Ample.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/Ample.java
index 460f98133d..25bf516026 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/Ample.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/Ample.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/AmpleImpl.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/AmpleImpl.java
index c9a70c2f93..9f459219a7 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/AmpleImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/AmpleImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/DataFileValue.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/DataFileValue.java
index e567e95532..309dd6d180 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/DataFileValue.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/DataFileValue.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/ExternalCompactionFinalState.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/ExternalCompactionFinalState.java
index 6e2aaa15ed..58ab37cf32 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/ExternalCompactionFinalState.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/ExternalCompactionFinalState.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/ExternalCompactionId.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/ExternalCompactionId.java
index 499273fd1f..5b367723b2 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/ExternalCompactionId.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/ExternalCompactionId.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/ExternalCompactionMetadata.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/ExternalCompactionMetadata.java
index fcd6bf2c3f..71837f054c 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/ExternalCompactionMetadata.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/ExternalCompactionMetadata.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/LinkingIterator.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/LinkingIterator.java
index 7c9c230eb0..be64c17fde 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/LinkingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/LinkingIterator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 5f5abde7a6..707a46942c 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataTime.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataTime.java
index 40852d4e9f..60775fdecd 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataTime.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataTime.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/RootTabletMetadata.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/RootTabletMetadata.java
index c1e420164d..3f01eed6c4 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/RootTabletMetadata.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/RootTabletMetadata.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/SortSkew.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/SortSkew.java
index 7186d13cd4..a7cef76abf 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/SortSkew.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/SortSkew.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/TabletDeletedException.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/TabletDeletedException.java
index 2889f2c983..1064757d58 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/TabletDeletedException.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/TabletDeletedException.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/TabletMetadata.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/TabletMetadata.java
index 376fabf236..5305858d5d 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/TabletMetadata.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/TabletMetadata.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/TabletsMetadata.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/TabletsMetadata.java
index ff32a55dc4..5447c954f2 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/TabletsMetadata.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/TabletsMetadata.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metrics/MeterRegistryFactory.java b/core/src/main/java/org/apache/accumulo/core/metrics/MeterRegistryFactory.java
index 8f08e80be6..acb4c4cbd2 100644
--- a/core/src/main/java/org/apache/accumulo/core/metrics/MeterRegistryFactory.java
+++ b/core/src/main/java/org/apache/accumulo/core/metrics/MeterRegistryFactory.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metrics/MetricsProducer.java b/core/src/main/java/org/apache/accumulo/core/metrics/MetricsProducer.java
index 699ffc7d2b..121aeb6e69 100644
--- a/core/src/main/java/org/apache/accumulo/core/metrics/MetricsProducer.java
+++ b/core/src/main/java/org/apache/accumulo/core/metrics/MetricsProducer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/metrics/MetricsUtil.java b/core/src/main/java/org/apache/accumulo/core/metrics/MetricsUtil.java
index c88792390f..dbfda2aa31 100644
--- a/core/src/main/java/org/apache/accumulo/core/metrics/MetricsUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/metrics/MetricsUtil.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/protobuf/ProtobufUtil.java b/core/src/main/java/org/apache/accumulo/core/protobuf/ProtobufUtil.java
index 57baf5ab23..b7ab26685a 100644
--- a/core/src/main/java/org/apache/accumulo/core/protobuf/ProtobufUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/protobuf/ProtobufUtil.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/replication/AccumuloReplicationReplayer.java b/core/src/main/java/org/apache/accumulo/core/replication/AccumuloReplicationReplayer.java
index fe31b98549..512c7326ba 100644
--- a/core/src/main/java/org/apache/accumulo/core/replication/AccumuloReplicationReplayer.java
+++ b/core/src/main/java/org/apache/accumulo/core/replication/AccumuloReplicationReplayer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/replication/ReplicationConfigurationUtil.java b/core/src/main/java/org/apache/accumulo/core/replication/ReplicationConfigurationUtil.java
index e56ef5b434..b5ab2902af 100644
--- a/core/src/main/java/org/apache/accumulo/core/replication/ReplicationConfigurationUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/replication/ReplicationConfigurationUtil.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/replication/ReplicationConstants.java b/core/src/main/java/org/apache/accumulo/core/replication/ReplicationConstants.java
index 795e0651e3..4adde40862 100644
--- a/core/src/main/java/org/apache/accumulo/core/replication/ReplicationConstants.java
+++ b/core/src/main/java/org/apache/accumulo/core/replication/ReplicationConstants.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 9589fc835e..eeedb2986c 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/replication/ReplicationTable.java b/core/src/main/java/org/apache/accumulo/core/replication/ReplicationTable.java
index d84f64d10a..522393a0e3 100644
--- a/core/src/main/java/org/apache/accumulo/core/replication/ReplicationTable.java
+++ b/core/src/main/java/org/apache/accumulo/core/replication/ReplicationTable.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/replication/ReplicationTableOfflineException.java b/core/src/main/java/org/apache/accumulo/core/replication/ReplicationTableOfflineException.java
index 33e594baa3..008423fcec 100644
--- a/core/src/main/java/org/apache/accumulo/core/replication/ReplicationTableOfflineException.java
+++ b/core/src/main/java/org/apache/accumulo/core/replication/ReplicationTableOfflineException.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/replication/ReplicationTarget.java b/core/src/main/java/org/apache/accumulo/core/replication/ReplicationTarget.java
index 085a7d323f..994bcd8ec9 100644
--- a/core/src/main/java/org/apache/accumulo/core/replication/ReplicationTarget.java
+++ b/core/src/main/java/org/apache/accumulo/core/replication/ReplicationTarget.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 3aaba4a1ce..87f87f4c18 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/ProtocolOverridingSSLSocketFactory.java b/core/src/main/java/org/apache/accumulo/core/rpc/ProtocolOverridingSSLSocketFactory.java
index 769845c8f2..44d0915968 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/ProtocolOverridingSSLSocketFactory.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/ProtocolOverridingSSLSocketFactory.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
@@ -35,7 +35,7 @@ import javax.net.ssl.SSLSocketFactory;
  * This only appears to be an issue on the client sockets, not the server sockets.
  *
  * This class wraps the SSLSocketFactory ensuring that the Socket is properly configured.
- * http://www.coderanch.com/t/637177/Security/Disabling-handshake-message-Java
+ * https://www.coderanch.com/t/637177/Security/Disabling-handshake-message-Java
  *
  * This class can be removed when JDK6 support is officially unsupported by Accumulo
  */
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/SaslClientDigestCallbackHandler.java b/core/src/main/java/org/apache/accumulo/core/rpc/SaslClientDigestCallbackHandler.java
index ad25e9cd69..32507a4637 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/SaslClientDigestCallbackHandler.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/SaslClientDigestCallbackHandler.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/SaslConnectionParams.java b/core/src/main/java/org/apache/accumulo/core/rpc/SaslConnectionParams.java
index 4206daab4f..bb19d5b06d 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/SaslConnectionParams.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/SaslConnectionParams.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/SaslDigestCallbackHandler.java b/core/src/main/java/org/apache/accumulo/core/rpc/SaslDigestCallbackHandler.java
index 93370b19f5..56c319bb0b 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/SaslDigestCallbackHandler.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/SaslDigestCallbackHandler.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/SslConnectionParams.java b/core/src/main/java/org/apache/accumulo/core/rpc/SslConnectionParams.java
index 52a09153fa..7e72100230 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/SslConnectionParams.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/SslConnectionParams.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/TBufferedSocket.java b/core/src/main/java/org/apache/accumulo/core/rpc/TBufferedSocket.java
index aa68b96b19..17b93304dd 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/TBufferedSocket.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/TBufferedSocket.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/TTimeoutTransport.java b/core/src/main/java/org/apache/accumulo/core/rpc/TTimeoutTransport.java
index d214e483dd..c78729be79 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/TTimeoutTransport.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/TTimeoutTransport.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 9dc453f807..6b2a643396 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/TraceProtocolFactory.java b/core/src/main/java/org/apache/accumulo/core/rpc/TraceProtocolFactory.java
index 617811b52d..e7466c62e9 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/TraceProtocolFactory.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/TraceProtocolFactory.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 08b6d83aad..913cd19109 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/UGIAssumingTransportFactory.java b/core/src/main/java/org/apache/accumulo/core/rpc/UGIAssumingTransportFactory.java
index 93ae977eed..e9eb3845f7 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/UGIAssumingTransportFactory.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/UGIAssumingTransportFactory.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/clients/ClientServiceThriftClient.java b/core/src/main/java/org/apache/accumulo/core/rpc/clients/ClientServiceThriftClient.java
index a8ad54c380..5a6a912647 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/clients/ClientServiceThriftClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/clients/ClientServiceThriftClient.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/clients/CompactionCoordinatorServiceThriftClient.java b/core/src/main/java/org/apache/accumulo/core/rpc/clients/CompactionCoordinatorServiceThriftClient.java
index f89331ae52..faefc8b758 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/clients/CompactionCoordinatorServiceThriftClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/clients/CompactionCoordinatorServiceThriftClient.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/clients/CompactorServiceThriftClient.java b/core/src/main/java/org/apache/accumulo/core/rpc/clients/CompactorServiceThriftClient.java
index 20ed890416..c8c00aa326 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/clients/CompactorServiceThriftClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/clients/CompactorServiceThriftClient.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/clients/FateThriftClient.java b/core/src/main/java/org/apache/accumulo/core/rpc/clients/FateThriftClient.java
index b5b2277910..74782e68a0 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/clients/FateThriftClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/clients/FateThriftClient.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/clients/GCMonitorServiceThriftClient.java b/core/src/main/java/org/apache/accumulo/core/rpc/clients/GCMonitorServiceThriftClient.java
index 71b7705425..6a7ff721c5 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/clients/GCMonitorServiceThriftClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/clients/GCMonitorServiceThriftClient.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/clients/ManagerClient.java b/core/src/main/java/org/apache/accumulo/core/rpc/clients/ManagerClient.java
index 4d9bcb6377..b1adcf65ca 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/clients/ManagerClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/clients/ManagerClient.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/clients/ManagerThriftClient.java b/core/src/main/java/org/apache/accumulo/core/rpc/clients/ManagerThriftClient.java
index 0c9cdbb9c2..cc942568b6 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/clients/ManagerThriftClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/clients/ManagerThriftClient.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/clients/ReplicationCoordinatorThriftClient.java b/core/src/main/java/org/apache/accumulo/core/rpc/clients/ReplicationCoordinatorThriftClient.java
index 4c3f1299ee..eefab0bda3 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/clients/ReplicationCoordinatorThriftClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/clients/ReplicationCoordinatorThriftClient.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/clients/ReplicationServicerThriftClient.java b/core/src/main/java/org/apache/accumulo/core/rpc/clients/ReplicationServicerThriftClient.java
index dbf634fdb9..d347979f9c 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/clients/ReplicationServicerThriftClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/clients/ReplicationServicerThriftClient.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/clients/TServerClient.java b/core/src/main/java/org/apache/accumulo/core/rpc/clients/TServerClient.java
index 5a6c6737b8..177018274d 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/clients/TServerClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/clients/TServerClient.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/clients/TabletScanClientServiceThriftClient.java b/core/src/main/java/org/apache/accumulo/core/rpc/clients/TabletScanClientServiceThriftClient.java
index 87174bfade..55f7d539fd 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/clients/TabletScanClientServiceThriftClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/clients/TabletScanClientServiceThriftClient.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/clients/TabletServerThriftClient.java b/core/src/main/java/org/apache/accumulo/core/rpc/clients/TabletServerThriftClient.java
index e3707b3724..647bdec7d1 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/clients/TabletServerThriftClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/clients/TabletServerThriftClient.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/clients/ThriftClientTypes.java b/core/src/main/java/org/apache/accumulo/core/rpc/clients/ThriftClientTypes.java
index 0756ed2f09..c47a926b9f 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/clients/ThriftClientTypes.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/clients/ThriftClientTypes.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/sample/impl/DataoutputHasher.java b/core/src/main/java/org/apache/accumulo/core/sample/impl/DataoutputHasher.java
index ef9c709c50..cf2142187a 100644
--- a/core/src/main/java/org/apache/accumulo/core/sample/impl/DataoutputHasher.java
+++ b/core/src/main/java/org/apache/accumulo/core/sample/impl/DataoutputHasher.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/sample/impl/SamplerConfigurationImpl.java b/core/src/main/java/org/apache/accumulo/core/sample/impl/SamplerConfigurationImpl.java
index 77ee4016f4..b362d8e5d3 100644
--- a/core/src/main/java/org/apache/accumulo/core/sample/impl/SamplerConfigurationImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/sample/impl/SamplerConfigurationImpl.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/sample/impl/SamplerFactory.java b/core/src/main/java/org/apache/accumulo/core/sample/impl/SamplerFactory.java
index 8f2331445c..74f54f39e8 100644
--- a/core/src/main/java/org/apache/accumulo/core/sample/impl/SamplerFactory.java
+++ b/core/src/main/java/org/apache/accumulo/core/sample/impl/SamplerFactory.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/schema/Section.java b/core/src/main/java/org/apache/accumulo/core/schema/Section.java
index 37f6ae67d9..6615140cc9 100644
--- a/core/src/main/java/org/apache/accumulo/core/schema/Section.java
+++ b/core/src/main/java/org/apache/accumulo/core/schema/Section.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/security/AuthorizationContainer.java b/core/src/main/java/org/apache/accumulo/core/security/AuthorizationContainer.java
index 808a07d314..708b754cb3 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/AuthorizationContainer.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/AuthorizationContainer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/security/Authorizations.java b/core/src/main/java/org/apache/accumulo/core/security/Authorizations.java
index b603cb8b18..1df129b9a8 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/Authorizations.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/Authorizations.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
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 8e9b7de5d8..e751a0a6fa 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
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/security/NamespacePermission.java b/core/src/main/java/org/apache/accumulo/core/security/NamespacePermission.java
index 5f6f08d570..57b1f58d1c 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/NamespacePermission.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/NamespacePermission.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/security/SystemPermission.java b/core/src/main/java/org/apache/accumulo/core/security/SystemPermission.java
index 9cda38c3b9..f015d2c7d3 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/SystemPermission.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/SystemPermission.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/security/TablePermission.java b/core/src/main/java/org/apache/accumulo/core/security/TablePermission.java
index c58e769c1a..5826cfd649 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/TablePermission.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/TablePermission.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/security/VisibilityEvaluator.java b/core/src/main/java/org/apache/accumulo/core/security/VisibilityEvaluator.java
index 72accc0372..a03cd154e1 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/VisibilityEvaluator.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/VisibilityEvaluator.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/security/VisibilityParseException.java b/core/src/main/java/org/apache/accumulo/core/security/VisibilityParseException.java
index 13543dde48..e0bf076066 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/VisibilityParseException.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/VisibilityParseException.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/singletons/SingletonManager.java b/core/src/main/java/org/apache/accumulo/core/singletons/SingletonManager.java
index bb32253c34..4badba37ee 100644
--- a/core/src/main/java/org/apache/accumulo/core/singletons/SingletonManager.java
+++ b/core/src/main/java/org/apache/accumulo/core/singletons/SingletonManager.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/singletons/SingletonReservation.java b/core/src/main/java/org/apache/accumulo/core/singletons/SingletonReservation.java
index 31e38eaa09..e7448fd5f7 100644
--- a/core/src/main/java/org/apache/accumulo/core/singletons/SingletonReservation.java
+++ b/core/src/main/java/org/apache/accumulo/core/singletons/SingletonReservation.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/singletons/SingletonService.java b/core/src/main/java/org/apache/accumulo/core/singletons/SingletonService.java
index 5b54fe306c..5438c78bd6 100644
--- a/core/src/main/java/org/apache/accumulo/core/singletons/SingletonService.java
+++ b/core/src/main/java/org/apache/accumulo/core/singletons/SingletonService.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/spi/balancer/BalancerEnvironment.java b/core/src/main/java/org/apache/accumulo/core/spi/balancer/BalancerEnvironment.java
index 64d08925da..f307cda067 100644
--- a/core/src/main/java/org/apache/accumulo/core/spi/balancer/BalancerEnvironment.java
+++ b/core/src/main/java/org/apache/accumulo/core/spi/balancer/BalancerEnvironment.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/spi/balancer/GroupBalancer.java b/core/src/main/java/org/apache/accumulo/core/spi/balancer/GroupBalancer.java
index 3a87f261e7..3527ba6f4c 100644
--- a/core/src/main/java/org/apache/accumulo/core/spi/balancer/GroupBalancer.java
+++ b/core/src/main/java/org/apache/accumulo/core/spi/balancer/GroupBalancer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/spi/balancer/HostRegexTableLoadBalancer.java b/core/src/main/java/org/apache/accumulo/core/spi/balancer/HostRegexTableLoadBalancer.java
index 6a36dc9bb9..8d94c5b42f 100644
--- a/core/src/main/java/org/apache/accumulo/core/spi/balancer/HostRegexTableLoadBalancer.java
+++ b/core/src/main/java/org/apache/accumulo/core/spi/balancer/HostRegexTableLoadBalancer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/spi/balancer/RegexGroupBalancer.java b/core/src/main/java/org/apache/accumulo/core/spi/balancer/RegexGroupBalancer.java
index 8f8ae27cf7..8c762767fe 100644
--- a/core/src/main/java/org/apache/accumulo/core/spi/balancer/RegexGroupBalancer.java
+++ b/core/src/main/java/org/apache/accumulo/core/spi/balancer/RegexGroupBalancer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/spi/balancer/SimpleLoadBalancer.java b/core/src/main/java/org/apache/accumulo/core/spi/balancer/SimpleLoadBalancer.java
index 323f22cd01..7a0111c2c9 100644
--- a/core/src/main/java/org/apache/accumulo/core/spi/balancer/SimpleLoadBalancer.java
+++ b/core/src/main/java/org/apache/accumulo/core/spi/balancer/SimpleLoadBalancer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/spi/balancer/TableLoadBalancer.java b/core/src/main/java/org/apache/accumulo/core/spi/balancer/TableLoadBalancer.java
index c3fe6906b4..cb66ddf998 100644
--- a/core/src/main/java/org/apache/accumulo/core/spi/balancer/TableLoadBalancer.java
+++ b/core/src/main/java/org/apache/accumulo/core/spi/balancer/TableLoadBalancer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/spi/balancer/TabletBalancer.java b/core/src/main/java/org/apache/accumulo/core/spi/balancer/TabletBalancer.java
index b120ae7c39..a7dfcbdc2b 100644
--- a/core/src/main/java/org/apache/accumulo/core/spi/balancer/TabletBalancer.java
+++ b/core/src/main/java/org/apache/accumulo/core/spi/balancer/TabletBalancer.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TServerStatus.java b/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TServerStatus.java
index f14dfb7ed2..a5b9801ed5 100644
--- a/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TServerStatus.java
+++ b/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TServerStatus.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TableStatistics.java b/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TableStatistics.java
index 21df202599..4a258f860e 100644
--- a/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TableStatistics.java
+++ b/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TableStatistics.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TabletMigration.java b/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TabletMigration.java
index cd00d9a88d..304b46d115 100644
--- a/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TabletMigration.java
+++ b/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TabletMigration.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TabletServerId.java b/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TabletServerId.java
index 69d27db58e..6adcc803f1 100644
--- a/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TabletServerId.java
+++ b/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TabletServerId.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TabletStatistics.java b/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TabletStatistics.java
index af38c49f8a..99ac7a6251 100644
--- a/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TabletStatistics.java
+++ b/core/src/main/java/org/apache/accumulo/core/spi/balancer/data/TabletStatistics.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/spi/balancer/util/ThrottledBalancerProblemReporter.java b/core/src/main/java/org/apache/accumulo/core/spi/balancer/util/ThrottledBalancerProblemReporter.java
index 6a82dde4c6..41dd35f52c 100644
--- a/core/src/main/java/org/apache/accumulo/core/spi/balancer/util/ThrottledBalancerProblemReporter.java
+++ b/core/src/main/java/org/apache/accumulo/core/spi/balancer/util/ThrottledBalancerProblemReporter.java
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *   https://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
diff --git a/core/src/main/java/org/apache/accumulo/core/spi/cache/BlockCache.java b/core/src/main/java/org/apache/accumulo/core/spi/cache/BlockCache.java
index 2964295396..a11da67e86 100644
--- a/core/src/main/java/org/apache/accumulo/core/spi/cache/BlockCache.java
+++ b/core/src/main/java/org/apache/accumulo/core/spi/cache/BlockCache.java
... 25057 lines suppressed ...