You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by kt...@apache.org on 2018/12/18 19:09:22 UTC

[accumulo] branch master updated: Fix some codestyle issues that are not automated. (#838)

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

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


The following commit(s) were added to refs/heads/master by this push:
     new e56f2d3  Fix some codestyle issues that are not automated. (#838)
e56f2d3 is described below

commit e56f2d35653e3b5bc1e7366153f26f76e4045df3
Author: Christopher McTague <cj...@apache.org>
AuthorDate: Tue Dec 18 14:09:17 2018 -0500

    Fix some codestyle issues that are not automated. (#838)
    
    - Adjust the comparisons so that the constant is on the right side of
    of the comparison. This was the pattern found throughout the majority
    of the project. Also logically makes more sense.
    - Add missing @Override annotations
---
 .../accumulo/core/client/BatchWriterConfig.java    | 16 ++++++-------
 .../accumulo/core/client/ClientConfiguration.java  |  2 +-
 .../core/client/ClientSideIteratorScanner.java     |  2 +-
 .../accumulo/core/client/IsolatedScanner.java      |  2 +-
 .../accumulo/core/client/ZooKeeperInstance.java    |  2 +-
 .../core/client/admin/DelegationTokenConfig.java   |  2 +-
 .../core/client/mapred/AbstractInputFormat.java    | 18 +++++++-------
 .../core/client/mapred/AccumuloInputFormat.java    |  2 +-
 .../core/client/mapreduce/AbstractInputFormat.java | 18 +++++++-------
 .../core/client/mapreduce/AccumuloInputFormat.java |  2 +-
 .../core/client/mapreduce/RangeInputSplit.java     | 28 +++++++++++-----------
 .../client/replication/PeerExistsException.java    |  2 +-
 .../client/replication/PeerNotFoundException.java  |  2 +-
 .../accumulo/core/client/rfile/RFileScanner.java   |  8 +++----
 .../security/tokens/CredentialProviderToken.java   |  4 ++--
 .../core/client/security/tokens/KerberosToken.java |  6 ++---
 .../clientImpl/AuthenticationTokenIdentifier.java  | 12 +++++-----
 .../core/clientImpl/ClientConfConverter.java       | 12 +++++-----
 .../accumulo/core/clientImpl/ClientContext.java    |  3 ++-
 .../core/clientImpl/ConditionalWriterImpl.java     |  2 +-
 .../core/clientImpl/DelegationTokenImpl.java       |  2 +-
 .../accumulo/core/clientImpl/MasterClient.java     |  4 ++--
 .../core/clientImpl/MultiTableBatchWriterImpl.java |  2 +-
 .../core/clientImpl/ReplicationOperationsImpl.java |  4 ++--
 .../accumulo/core/clientImpl/ScannerImpl.java      |  2 +-
 .../accumulo/core/clientImpl/ScannerIterator.java  |  2 +-
 .../core/clientImpl/SecurityOperationsImpl.java    |  6 ++---
 .../core/clientImpl/TableOperationsImpl.java       |  2 +-
 .../apache/accumulo/core/clientImpl/Tables.java    |  2 +-
 .../core/clientImpl/TabletServerBatchWriter.java   |  4 ++--
 .../core/clientImpl/ThriftTransportKey.java        |  4 ++--
 .../core/clientImpl/mapreduce/BatchInputSplit.java |  2 +-
 .../mapreduce/lib/InputConfigurator.java           |  2 +-
 .../apache/accumulo/core/conf/ClientProperty.java  |  4 ++--
 .../core/conf/CredentialProviderFactoryShim.java   | 22 ++++++++---------
 .../accumulo/core/conf/SiteConfiguration.java      | 10 ++++----
 .../core/cryptoImpl/CryptoEnvironmentImpl.java     |  2 ++
 .../org/apache/accumulo/core/data/Mutation.java    | 10 ++++----
 .../java/org/apache/accumulo/core/data/Value.java  |  4 ++--
 .../core/file/blockfile/cache/lru/CachedBlock.java |  2 +-
 .../blockfile/cache/lru/LruBlockCacheManager.java  |  2 +-
 .../core/file/rfile/bcfile/Compression.java        |  6 ++---
 .../accumulo/core/iterators/DebugIterator.java     |  2 +-
 .../apache/accumulo/core/iterators/OrIterator.java |  6 ++---
 .../core/replication/ReplicationSchema.java        |  8 +++----
 .../core/replication/ReplicationTable.java         |  2 +-
 .../core/replication/ReplicationTarget.java        |  6 ++---
 .../rpc/ProtocolOverridingSSLSocketFactory.java    |  2 +-
 .../core/rpc/SaslClientDigestCallbackHandler.java  |  2 +-
 .../accumulo/core/rpc/SaslConnectionParams.java    |  6 ++---
 .../accumulo/core/rpc/SslConnectionParams.java     |  2 +-
 .../accumulo/core/rpc/TTimeoutTransport.java       |  6 ++---
 .../org/apache/accumulo/core/rpc/ThriftUtil.java   |  8 +++----
 .../accumulo/core/rpc/UGIAssumingTransport.java    |  2 +-
 .../org/apache/accumulo/core/util/AddressUtil.java |  4 ++--
 .../accumulo/core/volume/VolumeConfiguration.java  |  2 +-
 .../main/java/org/apache/accumulo/fate/Fate.java   |  2 +-
 .../apache/accumulo/fate/zookeeper/ZooUtil.java    | 14 +++++------
 .../hadoopImpl/mapred/AbstractInputFormat.java     | 18 +++++++-------
 .../hadoopImpl/mapreduce/AbstractInputFormat.java  | 18 +++++++-------
 .../hadoopImpl/mapreduce/BatchInputSplit.java      |  2 +-
 .../hadoopImpl/mapreduce/RangeInputSplit.java      | 24 +++++++++----------
 .../mapreduce/lib/InputConfigurator.java           |  2 +-
 .../accumulo/iteratortest/IteratorTestOutput.java  |  4 ++--
 .../accumulo/iteratortest/IteratorTestRunner.java  |  2 +-
 .../testcases/InstantiationTestCase.java           |  2 +-
 .../testcases/IsolatedDeepCopiesTestCase.java      |  2 +-
 .../org/apache/accumulo/cluster/ClusterUser.java   | 12 +++++-----
 .../accumulo/cluster/RemoteShellOptions.java       |  4 ++--
 .../standalone/StandaloneAccumuloCluster.java      |  4 ++--
 .../standalone/StandaloneClusterControl.java       | 12 +++++-----
 .../MiniAccumuloClusterControl.java                | 18 +++++++-------
 .../miniclusterImpl/MiniAccumuloClusterImpl.java   | 12 +++++-----
 .../miniclusterImpl/MiniAccumuloConfigImpl.java    |  2 +-
 .../org/apache/accumulo/proxy/ProxyServer.java     | 12 +++++-----
 .../org/apache/accumulo/server/ServerContext.java  |  2 +-
 .../server/client/ClientServiceHandler.java        |  2 +-
 .../server/conf/NamespaceConfiguration.java        |  2 +-
 .../server/conf/ServerConfigurationFactory.java    |  2 +-
 .../accumulo/server/conf/TableConfiguration.java   |  2 +-
 .../accumulo/server/fs/PerTableVolumeChooser.java  |  8 +++----
 .../accumulo/server/fs/PreferredVolumeChooser.java |  8 +++----
 .../accumulo/server/fs/VolumeManagerImpl.java      |  4 ++--
 .../apache/accumulo/server/init/Initialize.java    |  7 +++---
 .../accumulo/server/master/LiveTServerSet.java     |  6 ++---
 .../master/balancer/DefaultLoadBalancer.java       |  4 ++--
 .../balancer/HostRegexTableLoadBalancer.java       | 28 +++++++++++-----------
 .../server/metrics/AbstractMetricsImpl.java        | 14 +++++------
 .../server/metrics/MetricsConfiguration.java       | 12 +++++-----
 .../DistributedWorkQueueWorkAssignerHelper.java    |  6 ++---
 .../server/replication/ReplicaSystemFactory.java   |  4 ++--
 .../server/replication/ReplicationUtil.java        | 12 +++++-----
 .../server/replication/StatusCombiner.java         |  2 +-
 .../accumulo/server/replication/StatusUtil.java    |  4 ++--
 .../rpc/TCredentialsUpdatingInvocationHandler.java | 10 ++++----
 .../apache/accumulo/server/rpc/TServerUtils.java   | 12 +++++-----
 .../server/security/SecurityOperation.java         |  2 +-
 .../server/security/UserImpersonation.java         |  2 +-
 .../security/delegation/AuthenticationKey.java     |  8 +++----
 .../delegation/AuthenticationTokenKeyManager.java  |  2 +-
 .../AuthenticationTokenSecretManager.java          | 10 ++++----
 .../ZooAuthenticationKeyDistributor.java           |  4 ++--
 .../delegation/ZooAuthenticationKeyWatcher.java    | 10 ++++----
 .../security/handler/KerberosAuthenticator.java    |  2 +-
 .../tabletserver/LargestFirstMemoryManager.java    |  2 +-
 .../org/apache/accumulo/server/util/Admin.java     |  6 ++---
 .../accumulo/server/util/RandomizeVolumes.java     |  6 ++---
 .../accumulo/server/util/SystemPropUtil.java       |  2 +-
 .../apache/accumulo/gc/SimpleGarbageCollector.java |  2 +-
 .../replication/CloseWriteAheadLogReferences.java  |  6 ++---
 .../apache/accumulo/master/FateServiceHandler.java |  2 +-
 .../java/org/apache/accumulo/master/Master.java    | 12 +++++-----
 .../master/metrics/Metrics2ReplicationMetrics.java |  2 +-
 .../master/metrics/ReplicationMetrics.java         |  2 +-
 .../DistributedWorkQueueWorkAssigner.java          |  4 ++--
 .../master/replication/FinishedWorkUpdater.java    |  2 +-
 .../RemoveCompleteReplicationRecords.java          |  6 ++---
 .../master/replication/ReplicationDriver.java      |  2 +-
 .../master/replication/SequentialWorkAssigner.java | 22 ++++++++---------
 .../accumulo/master/replication/StatusMaker.java   |  4 ++--
 .../master/replication/UnorderedWorkAssigner.java  |  6 ++---
 .../accumulo/master/replication/WorkDriver.java    |  2 +-
 .../accumulo/master/replication/WorkMaker.java     |  4 ++--
 .../master/tableOps/bulkVer1/LoadFiles.java        |  4 ++--
 .../apache/accumulo/monitor/EmbeddedWebServer.java |  2 +-
 .../java/org/apache/accumulo/monitor/Monitor.java  |  6 ++---
 .../apache/accumulo/monitor/ZooKeeperStatus.java   |  6 ++---
 .../apache/accumulo/monitor/rest/XMLResource.java  |  2 +-
 .../monitor/rest/gc/GarbageCollectorResource.java  | 12 +++++-----
 .../monitor/rest/gc/GarbageCollectorStatus.java    |  2 +-
 .../monitor/rest/master/MasterResource.java        | 12 +++++-----
 .../rest/replication/ReplicationResource.java      | 10 ++++----
 .../monitor/rest/status/StatusResource.java        |  2 +-
 .../monitor/rest/tables/TableInformation.java      |  6 ++---
 .../monitor/rest/tables/TablesResource.java        |  2 +-
 .../monitor/rest/trace/TracesResource.java         | 12 +++++-----
 .../rest/tservers/TabletServerResource.java        |  4 ++--
 .../java/org/apache/accumulo/tracer/TraceDump.java |  2 +-
 .../org/apache/accumulo/tracer/TraceServer.java    |  8 +++----
 .../accumulo/tserver/ActiveAssignmentRunnable.java |  2 +-
 .../org/apache/accumulo/tserver/NativeMap.java     |  2 +-
 .../org/apache/accumulo/tserver/TabletServer.java  | 10 ++++----
 .../tserver/TabletServerResourceManager.java       |  2 +-
 .../org/apache/accumulo/tserver/log/DfsLogger.java |  4 ++--
 .../org/apache/accumulo/tserver/log/LogSorter.java |  2 +-
 .../accumulo/tserver/log/RecoveryLogReader.java    |  2 +-
 .../accumulo/tserver/log/TabletServerLogger.java   | 10 ++++----
 .../tserver/replication/AccumuloReplicaSystem.java | 22 ++++++++---------
 .../BatchWriterReplicationReplayer.java            |  6 ++---
 .../tserver/replication/ReplicationProcessor.java  |  2 +-
 .../replication/ReplicationServicerHandler.java    |  2 +-
 .../accumulo/tserver/tablet/CompactionRunner.java  |  2 +-
 .../accumulo/tserver/tablet/DatafileManager.java   |  2 +-
 .../apache/accumulo/tserver/tablet/Scanner.java    |  4 ++--
 .../org/apache/accumulo/tserver/tablet/Tablet.java |  4 ++--
 .../main/java/org/apache/accumulo/shell/Shell.java |  2 +-
 .../org/apache/accumulo/shell/ShellOptionsJC.java  |  6 ++---
 .../accumulo/shell/commands/ScanCommand.java       |  2 +-
 .../accumulo/shell/commands/ScriptCommand.java     | 10 ++++----
 .../accumulo/shell/commands/SetIterCommand.java    |  8 +++----
 .../start/classloader/AccumuloClassLoader.java     |  4 ++--
 .../classloader/vfs/AccumuloVFSClassLoader.java    |  6 ++---
 .../classloader/vfs/UniqueFileReplicator.java      |  2 +-
 .../accumulo/harness/AccumuloClusterHarness.java   | 14 +++++------
 .../accumulo/harness/MiniClusterHarness.java       |  2 +-
 .../accumulo/harness/SharedMiniClusterBase.java    | 10 ++++----
 .../conf/AccumuloClusterPropertyConfiguration.java | 16 ++++++-------
 .../conf/AccumuloMiniClusterConfiguration.java     |  6 ++---
 .../StandaloneAccumuloClusterConfiguration.java    | 18 +++++++-------
 .../org/apache/accumulo/test/AuditMessageIT.java   |  4 ++--
 .../accumulo/test/BadDeleteMarkersCreatedIT.java   | 12 +++++-----
 .../accumulo/test/BatchWriterInTabletServerIT.java |  2 +-
 .../java/org/apache/accumulo/test/CleanWalIT.java  |  2 +-
 .../apache/accumulo/test/ConditionalWriterIT.java  |  2 +-
 .../accumulo/test/DetectDeadTabletServersIT.java   |  4 ++--
 .../apache/accumulo/test/FairVolumeChooser.java    |  2 +-
 .../org/apache/accumulo/test/ImportExportIT.java   |  4 ++--
 .../org/apache/accumulo/test/LargeSplitRowIT.java  |  2 +-
 .../java/org/apache/accumulo/test/MetaSplitIT.java |  4 ++--
 .../accumulo/test/MultiTableBatchWriterIT.java     | 12 +++++-----
 .../org/apache/accumulo/test/NamespacesIT.java     | 10 ++++----
 .../org/apache/accumulo/test/ShellConfigIT.java    |  2 +-
 .../org/apache/accumulo/test/ShellServerIT.java    | 10 ++++----
 .../accumulo/test/TableConfigurationUpdateIT.java  |  2 +-
 .../apache/accumulo/test/TestRandomDeletes.java    |  2 +-
 .../ThriftServerBindsBeforeZooKeeperLockIT.java    | 16 ++++++-------
 .../apache/accumulo/test/TransportCachingIT.java   |  6 ++---
 .../accumulo/test/UserCompactionStrategyIT.java    |  2 +-
 .../test/constraints/AlphaNumKeyConstraint.java    |  2 +-
 .../accumulo/test/functional/BinaryStressIT.java   |  4 ++--
 .../apache/accumulo/test/functional/BulkIT.java    |  2 +-
 .../test/functional/BulkSplitOptimizationIT.java   |  2 +-
 .../accumulo/test/functional/CompactionIT.java     |  6 ++---
 .../apache/accumulo/test/functional/DeleteIT.java  |  8 +++----
 .../accumulo/test/functional/DurabilityIT.java     |  6 ++---
 .../accumulo/test/functional/KerberosIT.java       | 10 ++++----
 .../accumulo/test/functional/KerberosProxyIT.java  | 18 +++++++-------
 .../test/functional/KerberosRenewalIT.java         |  8 +++----
 .../accumulo/test/functional/LargeRowIT.java       |  2 +-
 .../apache/accumulo/test/functional/MaxOpenIT.java |  6 ++---
 .../accumulo/test/functional/MonitorSslIT.java     |  4 ++--
 .../accumulo/test/functional/PermissionsIT.java    |  2 +-
 .../accumulo/test/functional/ReadWriteIT.java      | 12 +++++-----
 .../apache/accumulo/test/functional/RestartIT.java | 14 +++++------
 .../accumulo/test/functional/RestartStressIT.java  |  2 +-
 .../apache/accumulo/test/functional/ScanIdIT.java  |  2 +-
 .../accumulo/test/functional/ScanIteratorIT.java   |  2 +-
 .../test/functional/ScanSessionTimeOutIT.java      |  2 +-
 .../accumulo/test/functional/ScannerContextIT.java |  8 +++----
 .../test/functional/SessionDurabilityIT.java       |  2 +-
 .../apache/accumulo/test/functional/SplitIT.java   |  6 ++---
 .../accumulo/test/functional/VisibilityIT.java     |  2 +-
 .../accumulo/test/proxy/SimpleProxyBase.java       | 18 +++++++-------
 .../accumulo/test/proxy/TestProxyClient.java       |  2 +-
 .../test/replication/CyclicReplicationIT.java      |  6 ++---
 .../test/replication/KerberosReplicationIT.java    | 10 ++++----
 .../replication/MultiInstanceReplicationIT.java    | 12 +++++-----
 .../accumulo/test/replication/ReplicationIT.java   |  8 +++----
 .../UnorderedWorkAssignerReplicationIT.java        | 12 +++++-----
 219 files changed, 667 insertions(+), 663 deletions(-)

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 a260921..27ad00d 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
@@ -288,42 +288,42 @@ public class BatchWriterConfig implements Writable {
     if (o instanceof BatchWriterConfig) {
       BatchWriterConfig other = (BatchWriterConfig) o;
 
-      if (null != maxMemory) {
+      if (maxMemory != null) {
         if (!maxMemory.equals(other.maxMemory)) {
           return false;
         }
       } else {
-        if (null != other.maxMemory) {
+        if (other.maxMemory != null) {
           return false;
         }
       }
 
-      if (null != maxLatency) {
+      if (maxLatency != null) {
         if (!maxLatency.equals(other.maxLatency)) {
           return false;
         }
       } else {
-        if (null != other.maxLatency) {
+        if (other.maxLatency != null) {
           return false;
         }
       }
 
-      if (null != maxWriteThreads) {
+      if (maxWriteThreads != null) {
         if (!maxWriteThreads.equals(other.maxWriteThreads)) {
           return false;
         }
       } else {
-        if (null != other.maxWriteThreads) {
+        if (other.maxWriteThreads != null) {
           return false;
         }
       }
 
-      if (null != timeout) {
+      if (timeout != null) {
         if (!timeout.equals(other.timeout)) {
           return false;
         }
       } else {
-        if (null != other.timeout) {
+        if (other.timeout != null) {
           return false;
         }
       }
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 a9d400d..e2de49f 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
@@ -266,7 +266,7 @@ public class ClientConfiguration {
   @SuppressFBWarnings(value = "PATH_TRAVERSAL_IN",
       justification = "process runs in same security context as user who provided path")
   static String getClientConfPath(String clientConfPath) {
-    if (null == clientConfPath) {
+    if (clientConfPath == null) {
       return null;
     }
     File filePath = new File(clientConfPath);
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 bb034d3..e37f4fe 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
@@ -328,7 +328,7 @@ public class ClientSideIteratorScanner extends ScannerOptions implements Scanner
 
   @Override
   public void setReadaheadThreshold(long batches) {
-    if (0 > batches) {
+    if (batches < 0) {
       throw new IllegalArgumentException(
           "Number of batches before read-ahead must be non-negative");
     }
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 8068ef9..c7e09ef 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
@@ -276,7 +276,7 @@ public class IsolatedScanner extends ScannerOptions implements Scanner {
 
   @Override
   public void setReadaheadThreshold(long batches) {
-    if (0 > batches) {
+    if (batches < 0) {
       throw new IllegalArgumentException(
           "Number of batches before read-ahead must be non-negative");
     }
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 50d2800..1aaec27 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
@@ -104,7 +104,7 @@ public class ZooKeeperInstance implements Instance {
     this.zooKeepersSessionTimeOut = (int) ConfigurationTypeHelper
         .getTimeInMillis(clientConf.get(ClientConfiguration.ClientProperty.INSTANCE_ZK_TIMEOUT));
     zooCache = zcf.getZooCache(zooKeepers, zooKeepersSessionTimeOut);
-    if (null != instanceName) {
+    if (instanceName != null) {
       // Validates that the provided instanceName actually exists
       getInstanceID();
     }
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 0f0f2f1..04a5660 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
@@ -42,7 +42,7 @@ public class DelegationTokenConfig {
    * @return this
    */
   public DelegationTokenConfig setTokenLifetime(long lifetime, TimeUnit unit) {
-    checkArgument(0 <= lifetime, "Lifetime must be non-negative");
+    checkArgument(lifetime >= 0, "Lifetime must be non-negative");
     requireNonNull(unit, "TimeUnit was null");
     this.lifetime = TimeUnit.MILLISECONDS.convert(lifetime, unit);
     return this;
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 8c20714..32af1a0 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
@@ -460,11 +460,11 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
         org.apache.accumulo.core.client.mapreduce.RangeInputSplit split) {
       List<IteratorSetting> iterators = null;
 
-      if (null == split) {
+      if (split == null) {
         iterators = jobIterators(job, tableName);
       } else {
         iterators = split.getIterators();
-        if (null == iterators) {
+        if (iterators == null) {
           iterators = jobIterators(job, tableName);
         }
       }
@@ -504,7 +504,7 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
             scanner = context.createBatchScanner(baseSplit.getTableName(), authorizations,
                 scanThreads);
             setupIterators(job, scanner, baseSplit.getTableName(), baseSplit);
-            if (null != classLoaderContext) {
+            if (classLoaderContext != null) {
               scanner.setClassLoaderContext(classLoaderContext);
             }
           } catch (Exception e) {
@@ -517,17 +517,17 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
         } else if (baseSplit instanceof RangeInputSplit) {
           split = (RangeInputSplit) baseSplit;
           Boolean isOffline = baseSplit.isOffline();
-          if (null == isOffline) {
+          if (isOffline == null) {
             isOffline = tableConfig.isOfflineScan();
           }
 
           Boolean isIsolated = baseSplit.isIsolatedScan();
-          if (null == isIsolated) {
+          if (isIsolated == null) {
             isIsolated = tableConfig.shouldUseIsolatedScanners();
           }
 
           Boolean usesLocalIterators = baseSplit.usesLocalIterators();
-          if (null == usesLocalIterators) {
+          if (usesLocalIterators == null) {
             usesLocalIterators = tableConfig.shouldUseLocalIterators();
           }
 
@@ -561,7 +561,7 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
         }
 
         Collection<Pair<Text,Text>> columns = baseSplit.getFetchedColumns();
-        if (null == columns) {
+        if (columns == null) {
           columns = tableConfig.getFetchedColumns();
         }
 
@@ -577,7 +577,7 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
         }
 
         SamplerConfiguration samplerConfig = baseSplit.getSamplerConfiguration();
-        if (null == samplerConfig) {
+        if (samplerConfig == null) {
           samplerConfig = tableConfig.getSamplerConfiguration();
         }
 
@@ -601,7 +601,7 @@ public abstract class AbstractInputFormat<K,V> implements InputFormat<K,V> {
 
     @Override
     public void close() {
-      if (null != scannerBase) {
+      if (scannerBase != null) {
         scannerBase.close();
       }
     }
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 f25ed8e..7d81884 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
@@ -59,7 +59,7 @@ public class AccumuloInputFormat extends InputFormatBase<Key,Value> {
         (org.apache.accumulo.core.client.mapreduce.RangeInputSplit) split;
       // @formatter:on
       Level level = accSplit.getLogLevel();
-      if (null != level) {
+      if (level != null) {
         log.setLevel(level);
       }
     } else {
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 9d79e57..fdb3c63 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
@@ -469,11 +469,11 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
         RangeInputSplit split) {
       List<IteratorSetting> iterators = null;
 
-      if (null == split) {
+      if (split == null) {
         iterators = contextIterators(context, tableName);
       } else {
         iterators = split.getIterators();
-        if (null == iterators) {
+        if (iterators == null) {
           iterators = contextIterators(context, tableName);
         }
       }
@@ -513,7 +513,7 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
           int scanThreads = 1;
           scanner = context.createBatchScanner(split.getTableName(), authorizations, scanThreads);
           setupIterators(attempt, scanner, split.getTableName(), split);
-          if (null != classLoaderContext) {
+          if (classLoaderContext != null) {
             scanner.setClassLoaderContext(classLoaderContext);
           }
         } catch (Exception e) {
@@ -527,17 +527,17 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
         Scanner scanner;
 
         Boolean isOffline = split.isOffline();
-        if (null == isOffline) {
+        if (isOffline == null) {
           isOffline = tableConfig.isOfflineScan();
         }
 
         Boolean isIsolated = split.isIsolatedScan();
-        if (null == isIsolated) {
+        if (isIsolated == null) {
           isIsolated = tableConfig.shouldUseIsolatedScanners();
         }
 
         Boolean usesLocalIterators = split.usesLocalIterators();
-        if (null == usesLocalIterators) {
+        if (usesLocalIterators == null) {
           usesLocalIterators = tableConfig.shouldUseLocalIterators();
         }
 
@@ -569,7 +569,7 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
       }
 
       Collection<Pair<Text,Text>> columns = split.getFetchedColumns();
-      if (null == columns) {
+      if (columns == null) {
         columns = tableConfig.getFetchedColumns();
       }
 
@@ -585,7 +585,7 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
       }
 
       SamplerConfiguration samplerConfig = split.getSamplerConfiguration();
-      if (null == samplerConfig) {
+      if (samplerConfig == null) {
         samplerConfig = tableConfig.getSamplerConfiguration();
       }
 
@@ -608,7 +608,7 @@ public abstract class AbstractInputFormat<K,V> extends InputFormat<K,V> {
 
     @Override
     public void close() {
-      if (null != scannerBase) {
+      if (scannerBase != null) {
         scannerBase.close();
       }
     }
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 057a453..f9e4468 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
@@ -59,7 +59,7 @@ public class AccumuloInputFormat extends InputFormatBase<Key,Value> {
         (org.apache.accumulo.core.client.mapreduce.RangeInputSplit) split;
       // @formatter:on
       Level level = accSplit.getLogLevel();
-      if (null != level) {
+      if (level != null) {
         log.setLevel(level);
       }
     } else {
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 9180807..867f552 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
@@ -192,23 +192,23 @@ public class RangeInputSplit extends InputSplit implements Writable {
     for (String location : locations)
       out.writeUTF(location);
 
-    out.writeBoolean(null != isolatedScan);
-    if (null != isolatedScan) {
+    out.writeBoolean(isolatedScan != null);
+    if (isolatedScan != null) {
       out.writeBoolean(isolatedScan);
     }
 
-    out.writeBoolean(null != offline);
-    if (null != offline) {
+    out.writeBoolean(offline != null);
+    if (offline != null) {
       out.writeBoolean(offline);
     }
 
-    out.writeBoolean(null != localIterators);
-    if (null != localIterators) {
+    out.writeBoolean(localIterators != null);
+    if (localIterators != null) {
       out.writeBoolean(localIterators);
     }
 
-    out.writeBoolean(null != fetchedColumns);
-    if (null != fetchedColumns) {
+    out.writeBoolean(fetchedColumns != null);
+    if (fetchedColumns != null) {
       String[] cols = InputConfigurator.serializeColumns(fetchedColumns);
       out.writeInt(cols.length);
       for (String col : cols) {
@@ -216,21 +216,21 @@ public class RangeInputSplit extends InputSplit implements Writable {
       }
     }
 
-    out.writeBoolean(null != iterators);
-    if (null != iterators) {
+    out.writeBoolean(iterators != null);
+    if (iterators != null) {
       out.writeInt(iterators.size());
       for (IteratorSetting iterator : iterators) {
         iterator.write(out);
       }
     }
 
-    out.writeBoolean(null != level);
-    if (null != level) {
+    out.writeBoolean(level != null);
+    if (level != null) {
       out.writeInt(level.toInt());
     }
 
-    out.writeBoolean(null != samplerConfig);
-    if (null != samplerConfig) {
+    out.writeBoolean(samplerConfig != null);
+    if (samplerConfig != null) {
       new SamplerConfigurationImpl(samplerConfig).write(out);
     }
 
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 9218bcf..c83f3ba 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
@@ -28,7 +28,7 @@ public class PeerExistsException extends Exception {
 
   public PeerExistsException(String peer, String message) {
     super("Peer '" + peer + "' already exists"
-        + (null == message || message.isEmpty() ? "" : message));
+        + (message == null || message.isEmpty() ? "" : message));
   }
 
   public PeerExistsException(String message, Throwable cause) {
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 4e02218..a5997e2 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
@@ -27,7 +27,7 @@ public class PeerNotFoundException extends Exception {
   }
 
   public PeerNotFoundException(String peer, String message) {
-    super("Peer '" + peer + "' not found " + (null == message || message.isEmpty() ? "" : message));
+    super("Peer '" + peer + "' not found " + (message == null || message.isEmpty() ? "" : message));
   }
 
   public PeerNotFoundException(String message, Throwable cause) {
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 9efd4e8..e7849c7 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
@@ -184,7 +184,7 @@ class RFileScanner extends ScannerOptions implements Scanner {
     }
 
     this.opts = opts;
-    if (null != opts.tableConfig && opts.tableConfig.size() > 0) {
+    if (opts.tableConfig != null && opts.tableConfig.size() > 0) {
       ConfigurationCopy tableCC = new ConfigurationCopy(DefaultConfiguration.getInstance());
       opts.tableConfig.forEach(tableCC::set);
       this.tableConf = tableCC;
@@ -212,10 +212,10 @@ class RFileScanner extends ScannerOptions implements Scanner {
         throw new RuntimeException(e);
       }
     }
-    if (null == indexCache) {
+    if (indexCache == null) {
       this.indexCache = new NoopCache();
     }
-    if (null == this.dataCache) {
+    if (this.dataCache == null) {
       this.dataCache = new NoopCache();
     }
     this.cryptoService = CryptoServiceFactory.newInstance(tableConf, ClassloaderType.JAVA);
@@ -397,7 +397,7 @@ class RFileScanner extends ScannerOptions implements Scanner {
       throw new RuntimeException(e);
     }
     try {
-      if (null != this.blockCacheManager) {
+      if (this.blockCacheManager != null) {
         this.blockCacheManager.stop();
       }
     } catch (Exception e1) {
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 320268c..ee2d60d 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
@@ -56,7 +56,7 @@ public class CredentialProviderToken extends PasswordToken {
 
     char[] password = CredentialProviderFactoryShim.getValueFromCredentialProvider(conf, name);
 
-    if (null == password) {
+    if (password == null) {
       throw new IOException(
           "No password could be extracted from CredentialProvider(s) with " + name);
     }
@@ -82,7 +82,7 @@ public class CredentialProviderToken extends PasswordToken {
   public void init(Properties properties) {
     char[] nameCharArray = properties.get(NAME_PROPERTY),
         credentialProvidersCharArray = properties.get(CREDENTIAL_PROVIDERS_PROPERTY);
-    if (null != nameCharArray && null != credentialProvidersCharArray) {
+    if (nameCharArray != null && credentialProvidersCharArray != null) {
       try {
         this.setWithCredentialProviders(new String(nameCharArray),
             new String(credentialProvidersCharArray));
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 94a178a..d12b209 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
@@ -69,7 +69,7 @@ public class KerberosToken implements AuthenticationToken {
   static void validateAuthMethod(AuthenticationMethod authMethod) {
     // There is also KERBEROS_SSL but that appears to be deprecated/OBE
     checkArgument(
-        AuthenticationMethod.KERBEROS == authMethod || AuthenticationMethod.PROXY == authMethod,
+        authMethod == AuthenticationMethod.KERBEROS || authMethod == AuthenticationMethod.PROXY,
         "KerberosToken expects KERBEROS or PROXY authentication for the current "
             + "UserGroupInformation user. Saw " + authMethod);
   }
@@ -151,7 +151,7 @@ public class KerberosToken implements AuthenticationToken {
   @Override
   public void readFields(DataInput in) throws IOException {
     int actualVersion = in.readInt();
-    if (VERSION != actualVersion) {
+    if (actualVersion != VERSION) {
       throw new IOException("Did not find expected version in serialized KerberosToken");
     }
   }
@@ -163,7 +163,7 @@ public class KerberosToken implements AuthenticationToken {
 
   @Override
   public boolean isDestroyed() {
-    return null == principal;
+    return principal == null;
   }
 
   @Override
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 0862c78..ed4fd95 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
@@ -129,7 +129,7 @@ public class AuthenticationTokenIdentifier extends TokenIdentifier {
 
   @Override
   public void write(DataOutput out) throws IOException {
-    if (null != impl) {
+    if (impl != null) {
       ThriftMessageUtil msgUtil = new ThriftMessageUtil();
       ByteBuffer serialized = msgUtil.serialize(impl);
       out.writeInt(serialized.limit());
@@ -158,7 +158,7 @@ public class AuthenticationTokenIdentifier extends TokenIdentifier {
 
   @Override
   public UserGroupInformation getUser() {
-    if (null != impl && impl.isSetPrincipal()) {
+    if (impl != null && impl.isSetPrincipal()) {
       return UserGroupInformation.createRemoteUser(impl.getPrincipal());
     }
     return null;
@@ -166,7 +166,7 @@ public class AuthenticationTokenIdentifier extends TokenIdentifier {
 
   @Override
   public int hashCode() {
-    if (null == impl) {
+    if (impl == null) {
       return 0;
     }
     HashCodeBuilder hcb = new HashCodeBuilder(7, 11);
@@ -197,13 +197,13 @@ public class AuthenticationTokenIdentifier extends TokenIdentifier {
 
   @Override
   public boolean equals(Object o) {
-    if (null == o) {
+    if (o == null) {
       return false;
     }
     if (o instanceof AuthenticationTokenIdentifier) {
       AuthenticationTokenIdentifier other = (AuthenticationTokenIdentifier) o;
-      if (null == impl) {
-        return null == other.impl;
+      if (impl == null) {
+        return other.impl == null;
       }
       return impl.equals(other.impl);
     }
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 651ff21..bb55d09 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
@@ -165,11 +165,11 @@ public class ClientConfConverter {
         // Attempt to load sensitive properties from a CredentialProvider, if configured
         if (property.isSensitive()) {
           org.apache.hadoop.conf.Configuration hadoopConf = getHadoopConfiguration();
-          if (null != hadoopConf) {
+          if (hadoopConf != null) {
             try {
               char[] value = CredentialProviderFactoryShim
                   .getValueFromCredentialProvider(hadoopConf, key);
-              if (null != value) {
+              if (value != null) {
                 log.trace("Loaded sensitive value for {} from CredentialProvider", key);
                 return new String(value);
               } else {
@@ -187,7 +187,7 @@ public class ClientConfConverter {
           return config.getString(key);
         else {
           // Reconstitute the server kerberos property from the client config
-          if (Property.GENERAL_KERBEROS_PRINCIPAL == property) {
+          if (property == Property.GENERAL_KERBEROS_PRINCIPAL) {
             if (config.containsKey(
                 org.apache.accumulo.core.client.ClientConfiguration.ClientProperty.KERBEROS_SERVER_PRIMARY
                     .getKey())) {
@@ -231,7 +231,7 @@ public class ClientConfConverter {
 
         // Attempt to load sensitive properties from a CredentialProvider, if configured
         org.apache.hadoop.conf.Configuration hadoopConf = getHadoopConfiguration();
-        if (null != hadoopConf) {
+        if (hadoopConf != null) {
           try {
             for (String key : CredentialProviderFactoryShim.getKeys(hadoopConf)) {
               if (!Property.isValidPropertyKey(key) || !Property.isSensitive(key)) {
@@ -241,7 +241,7 @@ public class ClientConfConverter {
               if (filter.test(key)) {
                 char[] value = CredentialProviderFactoryShim
                     .getValueFromCredentialProvider(hadoopConf, key);
-                if (null != value) {
+                if (value != null) {
                   props.put(key, new String(value));
                 }
               }
@@ -256,7 +256,7 @@ public class ClientConfConverter {
       private org.apache.hadoop.conf.Configuration getHadoopConfiguration() {
         String credProviderPaths = config
             .getString(Property.GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS.getKey());
-        if (null != credProviderPaths && !credProviderPaths.isEmpty()) {
+        if (credProviderPaths != null && !credProviderPaths.isEmpty()) {
           org.apache.hadoop.conf.Configuration hConf = new org.apache.hadoop.conf.Configuration();
           hConf.set(CredentialProviderFactoryShim.CREDENTIAL_PROVIDER_PATH, credProviderPaths);
           return hConf;
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 928a4d1..f5a6b5c 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
@@ -376,6 +376,7 @@ public class ClientContext implements AccumuloClient {
    *
    * @return a UUID
    */
+  @Override
   public String getInstanceID() {
     ensureOpen();
     final String instanceName = info.getInstanceName();
@@ -588,7 +589,7 @@ public class ClientContext implements AccumuloClient {
   @Override
   public synchronized ReplicationOperations replicationOperations() {
     ensureOpen();
-    if (null == replicationops) {
+    if (replicationops == null) {
       replicationops = new ReplicationOperationsImpl(this);
     }
 
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 c4b2221..697a5b7 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
@@ -274,7 +274,7 @@ class ConditionalWriterImpl implements ConditionalWriter {
           else
             toe = new TimedOutException("Conditional mutation timed out");
 
-          qcm.queueResult(new Result(toe, qcm, (null == server ? null : server.toString())));
+          qcm.queueResult(new Result(toe, qcm, (server == null ? null : server.toString())));
         } else {
           mutations2.add(qcm);
         }
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 0e8c28d..b0dc992 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
@@ -62,7 +62,7 @@ public class DelegationTokenImpl extends PasswordToken implements DelegationToke
     Credentials creds = user.getCredentials();
     Token<? extends TokenIdentifier> token = creds
         .getToken(new Text(SERVICE_NAME + "-" + instanceID));
-    if (null == token) {
+    if (token == null) {
       throw new IllegalArgumentException(
           "Did not find Accumulo delegation token in provided UserGroupInformation");
     }
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/MasterClient.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/MasterClient.java
index a425990..98473ee 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/MasterClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/MasterClient.java
@@ -62,7 +62,7 @@ public class MasterClient {
     }
 
     HostAndPort master = HostAndPort.fromString(locations.get(0));
-    if (0 == master.getPort())
+    if (master.getPort() == 0)
       return null;
 
     try {
@@ -71,7 +71,7 @@ public class MasterClient {
           context);
     } catch (TTransportException tte) {
       Throwable cause = tte.getCause();
-      if (null != cause && cause instanceof UnknownHostException) {
+      if (cause != null && cause instanceof UnknownHostException) {
         // do not expect to recover from this
         throw new RuntimeException(tte);
       }
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 c28bb73..2f1d93f 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
@@ -129,7 +129,7 @@ public class MultiTableBatchWriterImpl implements MultiTableBatchWriter {
 
       log.error("Unexpected exception when fetching table id for {}", tableName);
 
-      if (null == cause) {
+      if (cause == null) {
         throw new RuntimeException(e);
       } else if (cause instanceof TableNotFoundException) {
         throw (TableNotFoundException) cause;
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 308ad8b..8474a15 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
@@ -128,9 +128,9 @@ public class ReplicationOperationsImpl implements ReplicationOperations {
     }
 
     String tableId = null;
-    while (null == tableId) {
+    while (tableId == null) {
       tableId = tops.tableIdMap().get(tableName);
-      if (null == tableId) {
+      if (tableId == null) {
         sleepUninterruptibly(200, TimeUnit.MILLISECONDS);
       }
     }
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 7139108..3d38bb3 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
@@ -114,7 +114,7 @@ public class ScannerImpl extends ScannerOptions implements Scanner {
 
   @Override
   public synchronized void setReadaheadThreshold(long batches) {
-    if (0 > batches) {
+    if (batches < 0) {
       throw new IllegalArgumentException(
           "Number of batches before read-ahead must be non-negative");
     }
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 b72a1b1..011aa50 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
@@ -127,7 +127,7 @@ public class ScannerIterator implements Iterator<Entry<Key,Value>> {
         options.executionHints);
 
     // If we want to start readahead immediately, don't wait for hasNext to be called
-    if (0L == readaheadThreshold) {
+    if (readaheadThreshold == 0L) {
       initiateReadAhead();
     }
     iter = null;
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 481a695..9babdac 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
@@ -99,11 +99,11 @@ public class SecurityOperationsImpl implements SecurityOperations {
   public void createLocalUser(final String principal, final PasswordToken password)
       throws AccumuloException, AccumuloSecurityException {
     checkArgument(principal != null, "principal is null");
-    if (null == context.getSaslParams()) {
+    if (context.getSaslParams() == null) {
       checkArgument(password != null, "password is null");
     }
     executeVoid(client -> {
-      if (null == context.getSaslParams()) {
+      if (context.getSaslParams() == null) {
         client.createLocalUser(Tracer.traceInfo(), context.rpcCreds(), principal,
             ByteBuffer.wrap(password.getPassword()));
       } else {
@@ -277,7 +277,7 @@ public class SecurityOperationsImpl implements SecurityOperations {
   public DelegationToken getDelegationToken(DelegationTokenConfig cfg)
       throws AccumuloException, AccumuloSecurityException {
     final TDelegationTokenConfig tConfig;
-    if (null != cfg) {
+    if (cfg != null) {
       tConfig = DelegationTokenConfigSerializer.serialize(cfg);
     } else {
       tConfig = new TDelegationTokenConfig();
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 a435c68..bb9033b 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
@@ -567,7 +567,7 @@ public class TableOperationsImpl extends TableOperationsHelper {
         } catch (NotServingTabletException e) {
           // Do not silently spin when we repeatedly fail to get the location for a tablet
           locationFailures++;
-          if (5 == locationFailures || 0 == locationFailures % 50) {
+          if (locationFailures == 5 || locationFailures % 50 == 0) {
             log.warn("Having difficulty locating hosting tabletserver for split {} on table {}."
                 + " Seen {} failures.", split, tableName, locationFailures);
           }
diff --git a/core/src/main/java/org/apache/accumulo/core/clientImpl/Tables.java b/core/src/main/java/org/apache/accumulo/core/clientImpl/Tables.java
index f0e7af9..d539f98 100644
--- a/core/src/main/java/org/apache/accumulo/core/clientImpl/Tables.java
+++ b/core/src/main/java/org/apache/accumulo/core/clientImpl/Tables.java
@@ -314,7 +314,7 @@ public class Tables {
         + Constants.ZTABLE_NAMESPACE);
 
     // We might get null out of ZooCache if this tableID doesn't exist
-    if (null == n) {
+    if (n == null) {
       throw new TableNotFoundException(tableId.canonicalID(), null, null);
     }
 
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 56fc3af..7e693ea 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
@@ -724,10 +724,10 @@ public class TabletServerBatchWriter {
     }
 
     void queueMutations(final MutationSet mutationsToSend) throws InterruptedException {
-      if (null == mutationsToSend)
+      if (mutationsToSend == null)
         return;
       binningThreadPool.execute(Trace.wrap(() -> {
-        if (null != mutationsToSend) {
+        if (mutationsToSend != null) {
           try {
             log.trace("{} - binning {} mutations", Thread.currentThread().getName(),
                 mutationsToSend.size());
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 161b255..7a80b92 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
@@ -42,9 +42,9 @@ public class ThriftTransportKey {
     this.timeout = timeout;
     this.sslParams = context.getClientSslParams();
     this.saslParams = context.getSaslParams();
-    if (null != saslParams) {
+    if (saslParams != null) {
       // TSasl and TSSL transport factories don't play nicely together
-      if (null != sslParams) {
+      if (sslParams != null) {
         throw new RuntimeException("Cannot use both SSL and SASL thrift transports");
       }
     }
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 a544e18..ebd80f4 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
@@ -59,7 +59,7 @@ public class BatchInputSplit extends RangeInputSplit {
    */
   @Override
   public float getProgress(Key currentKey) {
-    if (null == rangeProgress)
+    if (rangeProgress == null)
       rangeProgress = new float[ranges.size()];
 
     float total = 0; // progress per range could be on different scales, this number is "fuzzy"
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 9897000..58cac6e 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
@@ -374,7 +374,7 @@ public class InputConfigurator extends ConfiguratorBase {
   public static Set<Pair<Text,Text>> deserializeFetchedColumns(Collection<String> serialized) {
     Set<Pair<Text,Text>> columns = new HashSet<>();
 
-    if (null == serialized) {
+    if (serialized == null) {
       return columns;
     }
 
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 83d3e42..66b27b8 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
@@ -220,13 +220,13 @@ public enum ClientProperty {
   }
 
   public void setBytes(Properties properties, Long bytes) {
-    checkState(PropertyType.BYTES == getType(), "Invalid type setting " + "bytes. Type must be "
+    checkState(getType() == PropertyType.BYTES, "Invalid type setting " + "bytes. Type must be "
         + PropertyType.BYTES + ", not " + getType());
     properties.setProperty(getKey(), bytes.toString());
   }
 
   public void setTimeInMillis(Properties properties, Long milliseconds) {
-    checkState(PropertyType.TIMEDURATION == getType(), "Invalid type setting "
+    checkState(getType() == PropertyType.TIMEDURATION, "Invalid type setting "
         + "time. Type must be " + PropertyType.TIMEDURATION + ", not " + getType());
     properties.setProperty(getKey(), milliseconds + "ms");
   }
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/CredentialProviderFactoryShim.java b/core/src/main/java/org/apache/accumulo/core/conf/CredentialProviderFactoryShim.java
index bff0bd7..c8ef29e 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/CredentialProviderFactoryShim.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/CredentialProviderFactoryShim.java
@@ -85,12 +85,12 @@ public class CredentialProviderFactoryShim {
    */
   public static synchronized boolean isHadoopCredentialProviderAvailable() {
     // If we already found the class
-    if (null != hadoopClassesAvailable) {
+    if (hadoopClassesAvailable != null) {
       // Make sure everything is initialized as expected
       // Otherwise we failed to load it
-      return hadoopClassesAvailable && null != getProvidersMethod
-          && null != hadoopCredProviderFactory && null != getCredentialEntryMethod
-          && null != getCredentialMethod;
+      return hadoopClassesAvailable && getProvidersMethod != null
+          && hadoopCredProviderFactory != null && getCredentialEntryMethod != null
+          && getCredentialMethod != null;
     }
 
     hadoopClassesAvailable = false;
@@ -245,7 +245,7 @@ public class CredentialProviderFactoryShim {
   protected static char[] getFromHadoopCredentialProvider(Configuration conf, String alias) {
     List<Object> providerObjList = getCredentialProviders(conf);
 
-    if (null == providerObjList) {
+    if (providerObjList == null) {
       return null;
     }
 
@@ -254,7 +254,7 @@ public class CredentialProviderFactoryShim {
         // Invoke CredentialProvider.getCredentialEntry(String)
         Object credEntryObj = getCredentialEntryMethod.invoke(providerObj, alias);
 
-        if (null == credEntryObj) {
+        if (credEntryObj == null) {
           continue;
         }
 
@@ -278,19 +278,19 @@ public class CredentialProviderFactoryShim {
   protected static List<String> getAliasesFromHadoopCredentialProvider(Configuration conf) {
     List<Object> providerObjList = getCredentialProviders(conf);
 
-    if (null == providerObjList) {
+    if (providerObjList == null) {
       log.debug("Failed to get CredProviders");
       return Collections.emptyList();
     }
 
     ArrayList<String> aliases = new ArrayList<>();
     for (Object providerObj : providerObjList) {
-      if (null != providerObj) {
+      if (providerObj != null) {
         Object aliasesObj;
         try {
           aliasesObj = getAliasesMethod.invoke(providerObj);
 
-          if (null != aliasesObj && aliasesObj instanceof List) {
+          if (aliasesObj != null && aliasesObj instanceof List) {
             try {
               aliases.addAll((List<String>) aliasesObj);
             } catch (ClassCastException e) {
@@ -410,12 +410,12 @@ public class CredentialProviderFactoryShim {
     }
 
     List<Object> providers = getCredentialProviders(conf);
-    if (null == providers) {
+    if (providers == null) {
       throw new IOException(
           "Could not fetch any CredentialProviders, is the implementation available?");
     }
 
-    if (1 != providers.size()) {
+    if (providers.size() != 1) {
       log.warn("Found more than one CredentialProvider. Using first provider found");
     }
 
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 474bc5e..df46dc2 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
@@ -204,12 +204,12 @@ public class SiteConfiguration extends AccumuloConfiguration {
 
   private String getSensitiveFromHadoop(Property property) {
     org.apache.hadoop.conf.Configuration hadoopConf = getHadoopConfiguration();
-    if (null != hadoopConf) {
+    if (hadoopConf != null) {
       // Try to find the sensitive value from the CredentialProvider
       try {
         char[] value = CredentialProviderFactoryShim.getValueFromCredentialProvider(hadoopConf,
             property.getKey());
-        if (null != value) {
+        if (value != null) {
           return new String(value);
         }
       } catch (IOException e) {
@@ -249,7 +249,7 @@ public class SiteConfiguration extends AccumuloConfiguration {
 
     // CredentialProvider should take precedence over site
     org.apache.hadoop.conf.Configuration hadoopConf = getHadoopConfiguration();
-    if (null != hadoopConf) {
+    if (hadoopConf != null) {
       try {
         for (String key : CredentialProviderFactoryShim.getKeys(hadoopConf)) {
           if (!Property.isValidPropertyKey(key) || !Property.isSensitive(key)) {
@@ -259,7 +259,7 @@ public class SiteConfiguration extends AccumuloConfiguration {
           if (filter.test(key)) {
             char[] value = CredentialProviderFactoryShim.getValueFromCredentialProvider(hadoopConf,
                 key);
-            if (null != value) {
+            if (value != null) {
               props.put(key, new String(value));
             }
           }
@@ -282,7 +282,7 @@ public class SiteConfiguration extends AccumuloConfiguration {
     String credProviderPathsKey = Property.GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS.getKey();
     String credProviderPathsValue = getConfiguration().getString(credProviderPathsKey);
 
-    if (null != credProviderPathsValue) {
+    if (credProviderPathsValue != null) {
       // We have configuration for a CredentialProvider
       // Try to pull the sensitive password from there
       org.apache.hadoop.conf.Configuration conf = new org.apache.hadoop.conf.Configuration(
diff --git a/core/src/main/java/org/apache/accumulo/core/cryptoImpl/CryptoEnvironmentImpl.java b/core/src/main/java/org/apache/accumulo/core/cryptoImpl/CryptoEnvironmentImpl.java
index 9667252..92fc316 100644
--- a/core/src/main/java/org/apache/accumulo/core/cryptoImpl/CryptoEnvironmentImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/cryptoImpl/CryptoEnvironmentImpl.java
@@ -31,10 +31,12 @@ public class CryptoEnvironmentImpl implements CryptoEnvironment {
     this.decryptionParams = decryptionParams;
   }
 
+  @Override
   public Scope getScope() {
     return this.scope;
   }
 
+  @Override
   public byte[] getDecryptionParams() {
     return decryptionParams;
   }
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 c4cc0f4..ee11ef3 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
@@ -1460,7 +1460,7 @@ public class Mutation implements Writable {
    * @since 1.7.0
    */
   public void addReplicationSource(String peer) {
-    if (null == replicationSources || replicationSources == EMPTY) {
+    if (replicationSources == null || replicationSources == EMPTY) {
       replicationSources = new HashSet<>();
     }
 
@@ -1485,7 +1485,7 @@ public class Mutation implements Writable {
    * @return An unmodifiable view of the replication sources
    */
   public Set<String> getReplicationSources() {
-    if (null == replicationSources) {
+    if (replicationSources == null) {
       return EMPTY;
     }
     return Collections.unmodifiableSet(replicationSources);
@@ -1531,7 +1531,7 @@ public class Mutation implements Writable {
       }
     }
 
-    if (0x02 == (first & 0x02)) {
+    if ((first & 0x02) == 0x02) {
       int numMutations = WritableUtils.readVInt(in);
       this.replicationSources = new HashSet<>();
       for (int i = 0; i < numMutations; i++) {
@@ -1621,14 +1621,14 @@ public class Mutation implements Writable {
     out.write(data);
     UnsynchronizedBuffer.writeVInt(out, integerBuffer, entries);
 
-    if (0x01 == (0x01 & hasValues)) {
+    if ((0x01 & hasValues) == 0x01) {
       UnsynchronizedBuffer.writeVInt(out, integerBuffer, values.size());
       for (byte[] val : values) {
         UnsynchronizedBuffer.writeVInt(out, integerBuffer, val.length);
         out.write(val);
       }
     }
-    if (0x02 == (0x02 & hasValues)) {
+    if ((0x02 & hasValues) == 0x02) {
       UnsynchronizedBuffer.writeVInt(out, integerBuffer, replicationSources.size());
       for (String source : replicationSources) {
         WritableUtils.writeString(out, source);
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 1e57987..a042850 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
@@ -148,7 +148,7 @@ public class Value implements WritableComparable<Object> {
    * @return the underlying byte array directly.
    */
   public byte[] get() {
-    assert (null != value);
+    assert (value != null);
     return this.value;
   }
 
@@ -182,7 +182,7 @@ public class Value implements WritableComparable<Object> {
    * @return size in bytes
    */
   public int getSize() {
-    assert (null != value);
+    assert (value != null);
     return this.value.length;
   }
 
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 14c71c3..81be8be 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
@@ -98,7 +98,7 @@ public class CachedBlock implements HeapSize, Comparable<CachedBlock> {
   @Override
   public boolean equals(Object obj) {
     return this == obj
-        || (obj != null && obj instanceof CachedBlock && 0 == compareTo((CachedBlock) obj));
+        || (obj != null && obj instanceof CachedBlock && compareTo((CachedBlock) obj) == 0);
   }
 
   @Override
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 c50a8fd..0051d82 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
@@ -38,7 +38,7 @@ public class LruBlockCacheManager extends BlockCacheManager {
   public void stop() {
     for (CacheType type : CacheType.values()) {
       LruBlockCache cache = ((LruBlockCache) this.getBlockCache(type));
-      if (null != cache) {
+      if (cache != null) {
         cache.shutdown();
       }
     }
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 d2a0d7b..6841613 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
@@ -265,7 +265,7 @@ public final class Compression {
         // Set the internal buffer size to read from down stream.
         CompressionCodec decomCodec = codec;
         // if we're not using the default, let's pull from the loading cache
-        if (DEFAULT_BUFFER_SIZE != downStreamBufferSize) {
+        if (downStreamBufferSize != DEFAULT_BUFFER_SIZE) {
           Entry<Algorithm,Integer> sizeOpt = Maps.immutableEntry(GZ, downStreamBufferSize);
           try {
             decomCodec = codecCache.get(sizeOpt);
@@ -431,7 +431,7 @@ public final class Compression {
 
         CompressionCodec decomCodec = snappyCodec;
         // if we're not using the same buffer size, we'll pull the codec from the loading cache
-        if (DEFAULT_BUFFER_SIZE != downStreamBufferSize) {
+        if (downStreamBufferSize != DEFAULT_BUFFER_SIZE) {
           Entry<Algorithm,Integer> sizeOpt = Maps.immutableEntry(SNAPPY, downStreamBufferSize);
           try {
             decomCodec = codecCache.get(sizeOpt);
@@ -547,7 +547,7 @@ public final class Compression {
 
         CompressionCodec decomCodec = zstdCodec;
         // if we're not using the same buffer size, we'll pull the codec from the loading cache
-        if (DEFAULT_BUFFER_SIZE != downStreamBufferSize) {
+        if (downStreamBufferSize != DEFAULT_BUFFER_SIZE) {
           Entry<Algorithm,Integer> sizeOpt = Maps.immutableEntry(ZSTANDARD, downStreamBufferSize);
           try {
             decomCodec = codecCache.get(sizeOpt);
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 ffd4a03..072ebc3 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
@@ -89,7 +89,7 @@ public class DebugIterator extends WrappingIterator implements OptionDescriber {
       IteratorEnvironment env) throws IOException {
     log.debug("init({}, {}, {})", source, options, env);
 
-    if (null == prefix) {
+    if (prefix == null) {
       prefix = String.format("0x%08X", this.hashCode());
     }
 
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 13c8d9d..20a01b0 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
@@ -117,7 +117,7 @@ public class OrIterator implements SortedKeyValueIterator<Key,Value>, OptionDesc
 
     @Override
     public boolean equals(Object obj) {
-      return obj == this || (obj instanceof TermSource && 0 == compareTo((TermSource) obj));
+      return obj == this || (obj instanceof TermSource && compareTo((TermSource) obj) == 0);
     }
 
     @Override
@@ -301,7 +301,7 @@ public class OrIterator implements SortedKeyValueIterator<Key,Value>, OptionDesc
       IteratorEnvironment env) throws IOException {
     LOG.trace("init()");
     String columnsValue = options.get(COLUMNS_KEY);
-    if (null == columnsValue) {
+    if (columnsValue == null) {
       throw new IllegalArgumentException(
           COLUMNS_KEY + " was not provided in the iterator configuration");
     }
@@ -321,6 +321,6 @@ public class OrIterator implements SortedKeyValueIterator<Key,Value>, OptionDesc
 
   @Override
   public boolean validateOptions(Map<String,String> options) {
-    return null != options.get(COLUMNS_KEY);
+    return options.get(COLUMNS_KEY) != null;
   }
 }
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 4bd5e31..21fa902 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
@@ -251,13 +251,13 @@ public class ReplicationSchema {
       // find the last offset
       while (true) {
         int nextOffset = buff.find(ROW_SEPARATOR.toString(), offset + 1);
-        if (-1 == nextOffset) {
+        if (nextOffset == -1) {
           break;
         }
         offset = nextOffset;
       }
 
-      if (-1 == offset) {
+      if (offset == -1) {
         throw new IllegalArgumentException(
             "Row does not contain expected separator for OrderSection");
       }
@@ -278,13 +278,13 @@ public class ReplicationSchema {
       // find the last offset
       while (true) {
         int nextOffset = buff.find(ROW_SEPARATOR.toString(), offset + 1);
-        if (-1 == nextOffset) {
+        if (nextOffset == -1) {
           break;
         }
         offset = nextOffset;
       }
 
-      if (-1 == offset) {
+      if (offset == -1) {
         throw new IllegalArgumentException(
             "Row does not contain expected separator for OrderSection");
       }
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 905ce3d..53fb248 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
@@ -91,7 +91,7 @@ public class ReplicationTable {
   }
 
   public static boolean isOnline(AccumuloClient client) {
-    return TableState.ONLINE == Tables.getTableState((ClientContext) client, ID);
+    return Tables.getTableState((ClientContext) client, ID) == TableState.ONLINE;
   }
 
   public static void setOnline(AccumuloClient client)
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 5743f5e..ae133db 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
@@ -72,21 +72,21 @@ public class ReplicationTarget implements Writable {
 
   @Override
   public void write(DataOutput out) throws IOException {
-    if (null == peerName) {
+    if (peerName == null) {
       out.writeBoolean(false);
     } else {
       out.writeBoolean(true);
       WritableUtils.writeString(out, peerName);
     }
 
-    if (null == remoteIdentifier) {
+    if (remoteIdentifier == null) {
       out.writeBoolean(false);
     } else {
       out.writeBoolean(true);
       WritableUtils.writeString(out, remoteIdentifier);
     }
 
-    if (null == sourceTableId) {
+    if (sourceTableId == null) {
       out.writeBoolean(false);
     } else {
       out.writeBoolean(true);
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 a58e0eb..7fe916d 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
@@ -45,7 +45,7 @@ class ProtocolOverridingSSLSocketFactory extends SSLSocketFactory {
   public ProtocolOverridingSSLSocketFactory(final SSLSocketFactory delegate,
       final String[] enabledProtocols) {
     requireNonNull(enabledProtocols);
-    checkArgument(0 != enabledProtocols.length, "Expected at least one protocol");
+    checkArgument(enabledProtocols.length != 0, "Expected at least one protocol");
     this.delegate = delegate;
     this.enabledProtocols = enabledProtocols;
   }
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 a0fbd97..7773b8e 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
@@ -103,7 +103,7 @@ public class SaslClientDigestCallbackHandler extends SaslDigestCallbackHandler {
 
   @Override
   public boolean equals(Object o) {
-    if (null == o) {
+    if (o == null) {
       return false;
     }
     if (o instanceof SaslClientDigestCallbackHandler) {
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 e5394f1..fad8812 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
@@ -177,7 +177,7 @@ public class SaslConnectionParams {
 
     // The full name is our principal
     this.principal = currentUser.getUserName();
-    if (null == this.principal) {
+    if (this.principal == null) {
       throw new RuntimeException("Got null username from " + currentUser);
     }
 
@@ -258,8 +258,8 @@ public class SaslConnectionParams {
       if (!mechanism.equals(other.mechanism)) {
         return false;
       }
-      if (null == callbackHandler) {
-        if (null != other.callbackHandler) {
+      if (callbackHandler == null) {
+        if (other.callbackHandler != null) {
           return false;
         }
       } else if (!callbackHandler.equals(other.callbackHandler)) {
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 b83f1e2..2fbfb55 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
@@ -79,7 +79,7 @@ public class SslConnectionParams {
     }
 
     String ciphers = conf.get(Property.RPC_SSL_CIPHER_SUITES);
-    if (null != ciphers && !ciphers.isEmpty()) {
+    if (ciphers != null && !ciphers.isEmpty()) {
       result.cipherSuites = StringUtils.split(ciphers, ',');
     }
 
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 66088be..52c6410 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
@@ -53,9 +53,9 @@ public class TTimeoutTransport {
   private TTimeoutTransport() {}
 
   private Method getNetUtilsInputStreamMethod() {
-    if (null == GET_INPUT_STREAM_METHOD) {
+    if (GET_INPUT_STREAM_METHOD == null) {
       synchronized (this) {
-        if (null == GET_INPUT_STREAM_METHOD) {
+        if (GET_INPUT_STREAM_METHOD == null) {
           try {
             GET_INPUT_STREAM_METHOD = NetUtils.class.getMethod("getInputStream", Socket.class,
                 Long.TYPE);
@@ -153,7 +153,7 @@ public class TTimeoutTransport {
     }
 
     // Should be non-null
-    assert null != socket;
+    assert socket != null;
 
     // Set up the streams
     try {
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 4ab6398..8640a83 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
@@ -252,7 +252,7 @@ public class ThriftUtil {
       if (sslParams != null) {
         // The check in AccumuloServerContext ensures that servers are brought up with sane
         // configurations, but we also want to validate clients
-        if (null != saslParams) {
+        if (saslParams != null) {
           throw new IllegalStateException("Cannot use both SSL and SASL");
         }
 
@@ -287,7 +287,7 @@ public class ThriftUtil {
         }
 
         transport = ThriftUtil.transportFactory().getTransport(transport);
-      } else if (null != saslParams) {
+      } else if (saslParams != null) {
         if (!UserGroupInformation.isSecurityEnabled()) {
           throw new IllegalStateException(
               "Expected Kerberos security to be enabled if SASL is in use");
@@ -307,7 +307,7 @@ public class ThriftUtil {
           // Log in via UGI, ensures we have logged in with our KRB credentials
           final UserGroupInformation currentUser = UserGroupInformation.getCurrentUser();
           final UserGroupInformation userForRpc;
-          if (AuthenticationMethod.PROXY == currentUser.getAuthenticationMethod()) {
+          if (currentUser.getAuthenticationMethod() == AuthenticationMethod.PROXY) {
             // A "proxy" user is when the real (Kerberos) credentials are for a user
             // other than the one we're acting as. When we make an RPC though, we need to make sure
             // that the current user is the user that has some credentials.
@@ -405,7 +405,7 @@ public class ThriftUtil {
   static void attemptClientReLogin() {
     try {
       UserGroupInformation loginUser = UserGroupInformation.getLoginUser();
-      if (null == loginUser || !loginUser.hasKerberosCredentials()) {
+      if (loginUser == null || !loginUser.hasKerberosCredentials()) {
         // We should have already checked that we're logged in and have credentials. A
         // precondition-like check.
         throw new RuntimeException("Expected to find Kerberos UGI credentials, but did not");
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 0ca77f2..83e53b1 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
@@ -62,7 +62,7 @@ public class UGIAssumingTransport extends FilterTransport {
 
     // Make sure the transport exception gets (re)thrown if it happened
     TTransportException tte = holder.get();
-    if (null != tte) {
+    if (tte != null) {
       throw tte;
     }
   }
diff --git a/core/src/main/java/org/apache/accumulo/core/util/AddressUtil.java b/core/src/main/java/org/apache/accumulo/core/util/AddressUtil.java
index 6bbdc06..2b6810f 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/AddressUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/AddressUtil.java
@@ -66,14 +66,14 @@ public class AddressUtil {
       log.warn("Failed to get JVM negative DNS response cache TTL due to security manager. "
           + "Falling back to default based on Oracle JVM 1.4+ (10s)", exception);
     }
-    if (-1 == negativeTtl) {
+    if (negativeTtl == -1) {
       log.error(
           "JVM negative DNS repsonse cache TTL is set to 'forever' and host lookup failed. "
               + "TTL can be changed with security property "
               + "'networkaddress.cache.negative.ttl', see java.net.InetAddress.",
           originalException);
       throw new IllegalArgumentException(originalException);
-    } else if (0 > negativeTtl) {
+    } else if (negativeTtl < 0) {
       log.warn("JVM specified negative DNS response cache TTL was negative (and not 'forever'). "
           + "Falling back to default based on Oracle JVM 1.4+ (10s)");
       negativeTtl = 10;
diff --git a/core/src/main/java/org/apache/accumulo/core/volume/VolumeConfiguration.java b/core/src/main/java/org/apache/accumulo/core/volume/VolumeConfiguration.java
index 8558438..05badeb 100644
--- a/core/src/main/java/org/apache/accumulo/core/volume/VolumeConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/volume/VolumeConfiguration.java
@@ -150,7 +150,7 @@ public class VolumeConfiguration {
   public static <T extends FileSystem> Volume create(T fs, AccumuloConfiguration acuconf) {
     String dfsDir = acuconf.get(Property.INSTANCE_DFS_DIR);
     return new VolumeImpl(fs,
-        null == dfsDir ? Property.INSTANCE_DFS_DIR.getDefaultValue() : dfsDir);
+        dfsDir == null ? Property.INSTANCE_DFS_DIR.getDefaultValue() : dfsDir);
   }
 
   public static <T extends FileSystem> Volume create(T fs, String basePath) {
diff --git a/core/src/main/java/org/apache/accumulo/fate/Fate.java b/core/src/main/java/org/apache/accumulo/fate/Fate.java
index e51b2c4..466585d 100644
--- a/core/src/main/java/org/apache/accumulo/fate/Fate.java
+++ b/core/src/main/java/org/apache/accumulo/fate/Fate.java
@@ -100,7 +100,7 @@ public class Fate<T> {
         } catch (Exception e) {
           runnerLog.error("Uncaught exception in FATE runner thread.", e);
         } finally {
-          if (null != tid) {
+          if (tid != null) {
             store.unreserve(tid, deferTime);
           }
         }
diff --git a/core/src/main/java/org/apache/accumulo/fate/zookeeper/ZooUtil.java b/core/src/main/java/org/apache/accumulo/fate/zookeeper/ZooUtil.java
index 01b76e8..308e53c 100644
--- a/core/src/main/java/org/apache/accumulo/fate/zookeeper/ZooUtil.java
+++ b/core/src/main/java/org/apache/accumulo/fate/zookeeper/ZooUtil.java
@@ -123,10 +123,10 @@ public class ZooUtil {
     public int hashCode() {
       final HashCodeBuilder hcb = new HashCodeBuilder(31, 47);
       hcb.append(keepers).append(timeout);
-      if (null != scheme) {
+      if (scheme != null) {
         hcb.append(scheme);
       }
-      if (null != auth) {
+      if (auth != null) {
         hcb.append(auth);
       }
       return hcb.toHashCode();
@@ -140,8 +140,8 @@ public class ZooUtil {
           return false;
         }
 
-        if (null != scheme) {
-          if (null == other.scheme) {
+        if (scheme != null) {
+          if (other.scheme == null) {
             // Ours is non-null, theirs is null
             return false;
           } else if (!scheme.equals(other.scheme)) {
@@ -150,8 +150,8 @@ public class ZooUtil {
           }
         }
 
-        if (null != auth) {
-          if (null == other.auth) {
+        if (auth != null) {
+          if (other.auth == null) {
             return false;
           } else {
             return Arrays.equals(auth, other.auth);
@@ -170,7 +170,7 @@ public class ZooUtil {
       sb.append("zookeepers=").append(keepers);
       sb.append(", timeout=").append(timeout);
       sb.append(", scheme=").append(scheme);
-      sb.append(", auth=").append(null == auth ? "null" : "REDACTED");
+      sb.append(", auth=").append(auth == null ? "null" : "REDACTED");
       return sb.toString();
     }
   }
diff --git a/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapred/AbstractInputFormat.java b/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapred/AbstractInputFormat.java
index cf2bc04..fc34f3f 100644
--- a/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapred/AbstractInputFormat.java
+++ b/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapred/AbstractInputFormat.java
@@ -277,11 +277,11 @@ public abstract class AbstractInputFormat {
         org.apache.accumulo.hadoopImpl.mapreduce.RangeInputSplit split) {
       List<IteratorSetting> iterators = null;
 
-      if (null == split) {
+      if (split == null) {
         iterators = jobIterators(job, tableName);
       } else {
         iterators = split.getIterators();
-        if (null == iterators) {
+        if (iterators == null) {
           iterators = jobIterators(job, tableName);
         }
       }
@@ -322,7 +322,7 @@ public abstract class AbstractInputFormat {
           scanner = context.createBatchScanner(baseSplit.getTableName(), authorizations,
               scanThreads);
           setupIterators(job, scanner, baseSplit.getTableName(), baseSplit);
-          if (null != classLoaderContext) {
+          if (classLoaderContext != null) {
             scanner.setClassLoaderContext(classLoaderContext);
           }
         } catch (Exception e) {
@@ -335,17 +335,17 @@ public abstract class AbstractInputFormat {
       } else if (baseSplit instanceof RangeInputSplit) {
         split = (RangeInputSplit) baseSplit;
         Boolean isOffline = baseSplit.isOffline();
-        if (null == isOffline) {
+        if (isOffline == null) {
           isOffline = tableConfig.isOfflineScan();
         }
 
         Boolean isIsolated = baseSplit.isIsolatedScan();
-        if (null == isIsolated) {
+        if (isIsolated == null) {
           isIsolated = tableConfig.shouldUseIsolatedScanners();
         }
 
         Boolean usesLocalIterators = baseSplit.usesLocalIterators();
-        if (null == usesLocalIterators) {
+        if (usesLocalIterators == null) {
           usesLocalIterators = tableConfig.shouldUseLocalIterators();
         }
 
@@ -378,7 +378,7 @@ public abstract class AbstractInputFormat {
       }
 
       Collection<IteratorSetting.Column> columns = baseSplit.getFetchedColumns();
-      if (null == columns) {
+      if (columns == null) {
         columns = tableConfig.getFetchedColumns();
       }
 
@@ -394,7 +394,7 @@ public abstract class AbstractInputFormat {
       }
 
       SamplerConfiguration samplerConfig = baseSplit.getSamplerConfiguration();
-      if (null == samplerConfig) {
+      if (samplerConfig == null) {
         samplerConfig = tableConfig.getSamplerConfiguration();
       }
 
@@ -417,7 +417,7 @@ public abstract class AbstractInputFormat {
 
     @Override
     public void close() {
-      if (null != scannerBase) {
+      if (scannerBase != null) {
         scannerBase.close();
       }
       if (client != null) {
diff --git a/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/AbstractInputFormat.java b/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/AbstractInputFormat.java
index 0529c6d..c6702b6 100644
--- a/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/AbstractInputFormat.java
+++ b/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/AbstractInputFormat.java
@@ -282,11 +282,11 @@ public abstract class AbstractInputFormat {
         RangeInputSplit split) {
       List<IteratorSetting> iterators = null;
 
-      if (null == split) {
+      if (split == null) {
         iterators = contextIterators(context, tableName);
       } else {
         iterators = split.getIterators();
-        if (null == iterators) {
+        if (iterators == null) {
           iterators = contextIterators(context, tableName);
         }
       }
@@ -326,7 +326,7 @@ public abstract class AbstractInputFormat {
           int scanThreads = 1;
           scanner = context.createBatchScanner(split.getTableName(), authorizations, scanThreads);
           setupIterators(attempt, scanner, split.getTableName(), split);
-          if (null != classLoaderContext) {
+          if (classLoaderContext != null) {
             scanner.setClassLoaderContext(classLoaderContext);
           }
         } catch (Exception e) {
@@ -340,17 +340,17 @@ public abstract class AbstractInputFormat {
         Scanner scanner;
 
         Boolean isOffline = split.isOffline();
-        if (null == isOffline) {
+        if (isOffline == null) {
           isOffline = tableConfig.isOfflineScan();
         }
 
         Boolean isIsolated = split.isIsolatedScan();
-        if (null == isIsolated) {
+        if (isIsolated == null) {
           isIsolated = tableConfig.shouldUseIsolatedScanners();
         }
 
         Boolean usesLocalIterators = split.usesLocalIterators();
-        if (null == usesLocalIterators) {
+        if (usesLocalIterators == null) {
           usesLocalIterators = tableConfig.shouldUseLocalIterators();
         }
 
@@ -382,7 +382,7 @@ public abstract class AbstractInputFormat {
       }
 
       Collection<IteratorSetting.Column> columns = split.getFetchedColumns();
-      if (null == columns) {
+      if (columns == null) {
         columns = tableConfig.getFetchedColumns();
       }
 
@@ -398,7 +398,7 @@ public abstract class AbstractInputFormat {
       }
 
       SamplerConfiguration samplerConfig = split.getSamplerConfiguration();
-      if (null == samplerConfig) {
+      if (samplerConfig == null) {
         samplerConfig = tableConfig.getSamplerConfiguration();
       }
 
@@ -421,7 +421,7 @@ public abstract class AbstractInputFormat {
 
     @Override
     public void close() {
-      if (null != scannerBase) {
+      if (scannerBase != null) {
         scannerBase.close();
       }
       if (client != null) {
diff --git a/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/BatchInputSplit.java b/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/BatchInputSplit.java
index 562ae12..89ec405 100644
--- a/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/BatchInputSplit.java
+++ b/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/BatchInputSplit.java
@@ -58,7 +58,7 @@ public class BatchInputSplit extends RangeInputSplit {
    */
   @Override
   public float getProgress(Key currentKey) {
-    if (null == rangeProgress)
+    if (rangeProgress == null)
       rangeProgress = new float[ranges.size()];
 
     float total = 0; // progress per range could be on different scales, this number is "fuzzy"
diff --git a/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/RangeInputSplit.java b/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/RangeInputSplit.java
index 3fcc881..f029aff 100644
--- a/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/RangeInputSplit.java
+++ b/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/RangeInputSplit.java
@@ -183,23 +183,23 @@ public class RangeInputSplit extends InputSplit implements Writable {
     for (String location : locations)
       out.writeUTF(location);
 
-    out.writeBoolean(null != isolatedScan);
-    if (null != isolatedScan) {
+    out.writeBoolean(isolatedScan != null);
+    if (isolatedScan != null) {
       out.writeBoolean(isolatedScan);
     }
 
-    out.writeBoolean(null != offline);
-    if (null != offline) {
+    out.writeBoolean(offline != null);
+    if (offline != null) {
       out.writeBoolean(offline);
     }
 
-    out.writeBoolean(null != localIterators);
-    if (null != localIterators) {
+    out.writeBoolean(localIterators != null);
+    if (localIterators != null) {
       out.writeBoolean(localIterators);
     }
 
-    out.writeBoolean(null != fetchedColumns);
-    if (null != fetchedColumns) {
+    out.writeBoolean(fetchedColumns != null);
+    if (fetchedColumns != null) {
       String[] cols = InputConfigurator.serializeColumns(fetchedColumns);
       out.writeInt(cols.length);
       for (String col : cols) {
@@ -207,16 +207,16 @@ public class RangeInputSplit extends InputSplit implements Writable {
       }
     }
 
-    out.writeBoolean(null != iterators);
-    if (null != iterators) {
+    out.writeBoolean(iterators != null);
+    if (iterators != null) {
       out.writeInt(iterators.size());
       for (IteratorSetting iterator : iterators) {
         iterator.write(out);
       }
     }
 
-    out.writeBoolean(null != samplerConfig);
-    if (null != samplerConfig) {
+    out.writeBoolean(samplerConfig != null);
+    if (samplerConfig != null) {
       new SamplerConfigurationImpl(samplerConfig).write(out);
     }
 
diff --git a/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/lib/InputConfigurator.java b/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/lib/InputConfigurator.java
index 3fb28f4..f52b427 100644
--- a/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/lib/InputConfigurator.java
+++ b/hadoop-mapreduce/src/main/java/org/apache/accumulo/hadoopImpl/mapreduce/lib/InputConfigurator.java
@@ -350,7 +350,7 @@ public class InputConfigurator extends ConfiguratorBase {
       Collection<String> serialized) {
     Set<IteratorSetting.Column> columns = new HashSet<>();
 
-    if (null == serialized) {
+    if (serialized == null) {
       return columns;
     }
 
diff --git a/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/IteratorTestOutput.java b/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/IteratorTestOutput.java
index 7b74204..78c02f8 100644
--- a/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/IteratorTestOutput.java
+++ b/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/IteratorTestOutput.java
@@ -104,7 +104,7 @@ public class IteratorTestOutput {
    * @return True if there is output, false if the output is null.
    */
   public boolean hasOutput() {
-    return null != output;
+    return output != null;
   }
 
   /**
@@ -121,7 +121,7 @@ public class IteratorTestOutput {
    *         pairs.
    */
   public boolean hasException() {
-    return null != exception;
+    return exception != null;
   }
 
   @Override
diff --git a/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/IteratorTestRunner.java b/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/IteratorTestRunner.java
index 8be2295..f2890c9 100644
--- a/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/IteratorTestRunner.java
+++ b/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/IteratorTestRunner.java
@@ -85,7 +85,7 @@ public class IteratorTestRunner {
       }
 
       // Sanity-check on the IteratorTestCase implementation.
-      if (null == actualOutput) {
+      if (actualOutput == null) {
         throw new IllegalStateException(
             "IteratorTestCase implementations should always return a non-null IteratorTestOutput. "
                 + testCase.getClass().getName() + " did not!");
diff --git a/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/testcases/InstantiationTestCase.java b/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/testcases/InstantiationTestCase.java
index a36650c..e9341d5 100644
--- a/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/testcases/InstantiationTestCase.java
+++ b/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/testcases/InstantiationTestCase.java
@@ -47,7 +47,7 @@ public class InstantiationTestCase implements IteratorTestCase {
   public boolean verify(IteratorTestOutput expected, IteratorTestOutput actual) {
     // Ignore what the user provided as expected output, just check that we instantiated the
     // iterator successfully.
-    return TestOutcome.PASSED == actual.getTestOutcome();
+    return actual.getTestOutcome() == TestOutcome.PASSED;
   }
 
 }
diff --git a/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/testcases/IsolatedDeepCopiesTestCase.java b/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/testcases/IsolatedDeepCopiesTestCase.java
index 69fd588..7376fd8 100644
--- a/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/testcases/IsolatedDeepCopiesTestCase.java
+++ b/iterator-test-harness/src/main/java/org/apache/accumulo/iteratortest/testcases/IsolatedDeepCopiesTestCase.java
@@ -155,7 +155,7 @@ public class IsolatedDeepCopiesTestCase extends OutputVerifyingTestCase {
     }
 
     // Copy the value
-    if (null == topValue) {
+    if (topValue == null) {
       throw new IllegalStateException(
           "Should always find a non-null Value from the iterator being tested.");
     }
diff --git a/minicluster/src/main/java/org/apache/accumulo/cluster/ClusterUser.java b/minicluster/src/main/java/org/apache/accumulo/cluster/ClusterUser.java
index c8b0d82..7304f25 100644
--- a/minicluster/src/main/java/org/apache/accumulo/cluster/ClusterUser.java
+++ b/minicluster/src/main/java/org/apache/accumulo/cluster/ClusterUser.java
@@ -80,9 +80,9 @@ public class ClusterUser {
    *           if performing necessary login failed
    */
   public AuthenticationToken getToken() throws IOException {
-    if (null != password) {
+    if (password != null) {
       return new PasswordToken(password);
-    } else if (null != keytab) {
+    } else if (keytab != null) {
       UserGroupInformation.loginUserFromKeytab(principal, keytab.getAbsolutePath());
       return new KerberosToken();
     }
@@ -118,16 +118,16 @@ public class ClusterUser {
 
     if (obj instanceof ClusterUser) {
       ClusterUser other = (ClusterUser) obj;
-      if (null == keytab) {
-        if (null != other.keytab) {
+      if (keytab == null) {
+        if (other.keytab != null) {
           return false;
         }
       } else if (!keytab.equals(other.keytab)) {
         return false;
       }
 
-      if (null == password) {
-        if (null != other.password) {
+      if (password == null) {
+        if (other.password != null) {
           return false;
         }
       } else if (!password.equals(other.password)) {
diff --git a/minicluster/src/main/java/org/apache/accumulo/cluster/RemoteShellOptions.java b/minicluster/src/main/java/org/apache/accumulo/cluster/RemoteShellOptions.java
index 15f90eb..61e044c 100644
--- a/minicluster/src/main/java/org/apache/accumulo/cluster/RemoteShellOptions.java
+++ b/minicluster/src/main/java/org/apache/accumulo/cluster/RemoteShellOptions.java
@@ -62,7 +62,7 @@ public class RemoteShellOptions {
     String propertyFile = systemProperties.getProperty(SSH_PROPERTIES_FILE);
 
     // Load properties from the specified file
-    if (null != propertyFile) {
+    if (propertyFile != null) {
       // Check for properties provided in a file
       File f = new File(propertyFile);
       if (f.exists() && f.isFile() && f.canRead()) {
@@ -73,7 +73,7 @@ public class RemoteShellOptions {
           log.warn("Could not read properties from specified file: {}", propertyFile, e);
         }
 
-        if (null != reader) {
+        if (reader != null) {
           try {
             properties.load(reader);
           } catch (IOException e) {
diff --git a/minicluster/src/main/java/org/apache/accumulo/cluster/standalone/StandaloneAccumuloCluster.java b/minicluster/src/main/java/org/apache/accumulo/cluster/standalone/StandaloneAccumuloCluster.java
index 8160e28..3bee50b 100644
--- a/minicluster/src/main/java/org/apache/accumulo/cluster/standalone/StandaloneAccumuloCluster.java
+++ b/minicluster/src/main/java/org/apache/accumulo/cluster/standalone/StandaloneAccumuloCluster.java
@@ -107,10 +107,10 @@ public class StandaloneAccumuloCluster implements AccumuloCluster {
   }
 
   public String getHadoopConfDir() {
-    if (null == hadoopConfDir) {
+    if (hadoopConfDir == null) {
       hadoopConfDir = System.getenv("HADOOP_CONF_DIR");
     }
-    if (null == hadoopConfDir) {
+    if (hadoopConfDir == null) {
       throw new IllegalArgumentException("Cannot determine HADOOP_CONF_DIR for standalone cluster");
     }
     return hadoopConfDir;
diff --git a/minicluster/src/main/java/org/apache/accumulo/cluster/standalone/StandaloneClusterControl.java b/minicluster/src/main/java/org/apache/accumulo/cluster/standalone/StandaloneClusterControl.java
index 9bca414..c374e86 100644
--- a/minicluster/src/main/java/org/apache/accumulo/cluster/standalone/StandaloneClusterControl.java
+++ b/minicluster/src/main/java/org/apache/accumulo/cluster/standalone/StandaloneClusterControl.java
@@ -150,7 +150,7 @@ public class StandaloneClusterControl implements ClusterControl {
 
   String getJarFromClass(Class<?> clz) {
     CodeSource source = clz.getProtectionDomain().getCodeSource();
-    if (null == source) {
+    if (source == null) {
       throw new RuntimeException("Could not get CodeSource for class");
     }
     URL jarUrl = source.getLocation();
@@ -167,7 +167,7 @@ public class StandaloneClusterControl implements ClusterControl {
     String[] cmd = {serverCmdPrefix, accumuloPath, Admin.class.getName(), "stopAll"};
     // Directly invoke the RemoteShell
     Entry<Integer,String> pair = exec(master, cmd);
-    if (0 != pair.getKey()) {
+    if (pair.getKey() != 0) {
       throw new IOException("stopAll did not finish successfully, retcode=" + pair.getKey()
           + ", stdout=" + pair.getValue());
     }
@@ -187,7 +187,7 @@ public class StandaloneClusterControl implements ClusterControl {
     String master = getHosts(MASTER_HOSTS_FILE).get(0);
     String[] cmd = {serverCmdPrefix, accumuloPath, SetGoalState.class.getName(), goalState};
     Entry<Integer,String> pair = exec(master, cmd);
-    if (0 != pair.getKey()) {
+    if (pair.getKey() != 0) {
       throw new IOException("SetGoalState did not finish successfully, retcode=" + pair.getKey()
           + ", stdout=" + pair.getValue());
     }
@@ -239,7 +239,7 @@ public class StandaloneClusterControl implements ClusterControl {
   public void start(ServerType server, String hostname) throws IOException {
     String[] cmd = {serverCmdPrefix, accumuloServicePath, getProcessString(server), "start"};
     Entry<Integer,String> pair = exec(hostname, cmd);
-    if (0 != pair.getKey()) {
+    if (pair.getKey() != 0) {
       throw new IOException(
           "Start " + server + " on " + hostname + " failed for execute successfully");
     }
@@ -311,7 +311,7 @@ public class StandaloneClusterControl implements ClusterControl {
     }
 
     Entry<Integer,String> pair = exec(hostname, stopCmd);
-    if (0 != pair.getKey()) {
+    if (pair.getKey() != 0) {
       throw new IOException("Signal " + signal + " to " + server + " on " + hostname
           + " failed for execute successfully. stdout=" + pair.getValue());
     }
@@ -336,7 +336,7 @@ public class StandaloneClusterControl implements ClusterControl {
       throws IOException {
     String[] getPidCommand = getPidCommand(server, accumuloHome);
     Entry<Integer,String> ret = exec(hostname, getPidCommand);
-    if (0 != ret.getKey()) {
+    if (ret.getKey() != 0) {
       throw new IOException(
           "Could not locate PID for " + getProcessString(server) + " on " + hostname);
     }
diff --git a/minicluster/src/main/java/org/apache/accumulo/miniclusterImpl/MiniAccumuloClusterControl.java b/minicluster/src/main/java/org/apache/accumulo/miniclusterImpl/MiniAccumuloClusterControl.java
index 2893d70..3b2e33e 100644
--- a/minicluster/src/main/java/org/apache/accumulo/miniclusterImpl/MiniAccumuloClusterControl.java
+++ b/minicluster/src/main/java/org/apache/accumulo/miniclusterImpl/MiniAccumuloClusterControl.java
@@ -123,7 +123,7 @@ public class MiniAccumuloClusterControl implements ClusterControl {
       Thread.currentThread().interrupt();
       throw new IOException(e);
     }
-    if (0 != p.exitValue()) {
+    if (p.exitValue() != 0) {
       throw new IOException("Failed to run `accumulo admin stopAll`");
     }
   }
@@ -155,28 +155,28 @@ public class MiniAccumuloClusterControl implements ClusterControl {
         }
         break;
       case MASTER:
-        if (null == masterProcess) {
+        if (masterProcess == null) {
           masterProcess = cluster._exec(Master.class, server, configOverrides);
         }
         break;
       case ZOOKEEPER:
-        if (null == zooKeeperProcess) {
+        if (zooKeeperProcess == null) {
           zooKeeperProcess = cluster._exec(ZooKeeperServerMain.class, server, configOverrides,
               cluster.getZooCfgFile().getAbsolutePath());
         }
         break;
       case GARBAGE_COLLECTOR:
-        if (null == gcProcess) {
+        if (gcProcess == null) {
           gcProcess = cluster._exec(SimpleGarbageCollector.class, server, configOverrides);
         }
         break;
       case MONITOR:
-        if (null == monitor) {
+        if (monitor == null) {
           monitor = cluster._exec(Monitor.class, server, configOverrides);
         }
         break;
       case TRACER:
-        if (null == tracer) {
+        if (tracer == null) {
           tracer = cluster._exec(TraceServer.class, server, configOverrides);
         }
         break;
@@ -198,7 +198,7 @@ public class MiniAccumuloClusterControl implements ClusterControl {
   public synchronized void stop(ServerType server, String hostname) throws IOException {
     switch (server) {
       case MASTER:
-        if (null != masterProcess) {
+        if (masterProcess != null) {
           try {
             cluster.stopProcessWithTimeout(masterProcess, 30, TimeUnit.SECONDS);
           } catch (ExecutionException | TimeoutException e) {
@@ -211,7 +211,7 @@ public class MiniAccumuloClusterControl implements ClusterControl {
         }
         break;
       case GARBAGE_COLLECTOR:
-        if (null != gcProcess) {
+        if (gcProcess != null) {
           try {
             cluster.stopProcessWithTimeout(gcProcess, 30, TimeUnit.SECONDS);
           } catch (ExecutionException | TimeoutException e) {
@@ -224,7 +224,7 @@ public class MiniAccumuloClusterControl implements ClusterControl {
         }
         break;
       case ZOOKEEPER:
-        if (null != zooKeeperProcess) {
+        if (zooKeeperProcess != null) {
           try {
             cluster.stopProcessWithTimeout(zooKeeperProcess, 30, TimeUnit.SECONDS);
           } catch (ExecutionException | TimeoutException e) {
diff --git a/minicluster/src/main/java/org/apache/accumulo/miniclusterImpl/MiniAccumuloClusterImpl.java b/minicluster/src/main/java/org/apache/accumulo/miniclusterImpl/MiniAccumuloClusterImpl.java
index d55549f..0a5e9b0 100644
--- a/minicluster/src/main/java/org/apache/accumulo/miniclusterImpl/MiniAccumuloClusterImpl.java
+++ b/minicluster/src/main/java/org/apache/accumulo/miniclusterImpl/MiniAccumuloClusterImpl.java
@@ -626,7 +626,7 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
         // If we aren't using SASL, add in the root password
         final String saslEnabled = config.getSiteConfig()
             .get(Property.INSTANCE_RPC_SASL_ENABLED.getKey());
-        if (null == saslEnabled || !Boolean.parseBoolean(saslEnabled)) {
+        if (saslEnabled == null || !Boolean.parseBoolean(saslEnabled)) {
           args.add("--password");
           args.add(config.getRootPassword());
         }
@@ -662,7 +662,7 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
     control.start(ServerType.MASTER);
     control.start(ServerType.GARBAGE_COLLECTOR);
 
-    if (null == executor) {
+    if (executor == null) {
       executor = Executors.newSingleThreadExecutor();
     }
   }
@@ -694,10 +694,10 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
     result.put(ServerType.MASTER, references(control.masterProcess));
     result.put(ServerType.TABLET_SERVER,
         references(control.tabletServerProcesses.toArray(new Process[0])));
-    if (null != control.zooKeeperProcess) {
+    if (control.zooKeeperProcess != null) {
       result.put(ServerType.ZOOKEEPER, references(control.zooKeeperProcess));
     }
-    if (null != control.gcProcess) {
+    if (control.gcProcess != null) {
       result.put(ServerType.GARBAGE_COLLECTOR, references(control.gcProcess));
     }
     return result;
@@ -733,7 +733,7 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
    */
   @Override
   public synchronized void stop() throws IOException, InterruptedException {
-    if (null == executor) {
+    if (executor == null) {
       // keep repeated calls to stop() from failing
       return;
     }
@@ -750,7 +750,7 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
     control.stop(ServerType.ZOOKEEPER, null);
 
     // ACCUMULO-2985 stop the ExecutorService after we finished using it to stop accumulo procs
-    if (null != executor) {
+    if (executor != null) {
       List<Runnable> tasksRemaining = executor.shutdownNow();
 
       // the single thread executor shouldn't have any pending tasks, but check anyways
diff --git a/minicluster/src/main/java/org/apache/accumulo/miniclusterImpl/MiniAccumuloConfigImpl.java b/minicluster/src/main/java/org/apache/accumulo/miniclusterImpl/MiniAccumuloConfigImpl.java
index cde3ee8..f69c80e 100644
--- a/minicluster/src/main/java/org/apache/accumulo/miniclusterImpl/MiniAccumuloConfigImpl.java
+++ b/minicluster/src/main/java/org/apache/accumulo/miniclusterImpl/MiniAccumuloConfigImpl.java
@@ -190,7 +190,7 @@ public class MiniAccumuloConfigImpl {
 
   private void updateConfigForCredentialProvider() {
     String cpPaths = siteConfig.get(Property.GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS.getKey());
-    if (null != cpPaths
+    if (cpPaths != null
         && !Property.GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS.getDefaultValue().equals(cpPaths)) {
       // Already configured
       return;
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java b/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java
index fedb986..0e147d7 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java
@@ -261,7 +261,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
       throw ex;
     } catch (AccumuloException e) {
       Throwable cause = e.getCause();
-      if (null != cause && TableNotFoundException.class.equals(cause.getClass())) {
+      if (cause != null && TableNotFoundException.class.equals(cause.getClass())) {
         throw new org.apache.accumulo.proxy.thrift.TableNotFoundException(cause.toString());
       }
       handleAccumuloException(e);
@@ -322,7 +322,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
       throw ex;
     } catch (AccumuloException e) {
       Throwable cause = e.getCause();
-      if (null != cause && NamespaceNotFoundException.class.equals(cause.getClass())) {
+      if (cause != null && NamespaceNotFoundException.class.equals(cause.getClass())) {
         throw new org.apache.accumulo.proxy.thrift.NamespaceNotFoundException(cause.toString());
       }
       handleAccumuloException(e);
@@ -1383,7 +1383,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
     } catch (Exception e) {
       handleExceptionMRE(e);
     } finally {
-      if (null != bwpe) {
+      if (bwpe != null) {
         try {
           bwpe.writer.close();
         } catch (MutationsRejectedException e) {
@@ -1936,7 +1936,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
       org.apache.accumulo.proxy.thrift.AccumuloSecurityException,
       org.apache.accumulo.proxy.thrift.NamespaceNotFoundException, TException {
     try {
-      if (null != scopes && scopes.size() > 0) {
+      if (scopes != null && scopes.size() > 0) {
         getConnector(login).namespaceOperations().attachIterator(namespaceName,
             getIteratorSetting(setting), getIteratorScopes(scopes));
       } else {
@@ -2081,9 +2081,9 @@ public class ProxyServer implements AccumuloProxy.Iface {
   @Override
   public ByteBuffer login(String principal, Map<String,String> loginProperties)
       throws org.apache.accumulo.proxy.thrift.AccumuloSecurityException, TException {
-    if (ThriftServerType.SASL == serverType) {
+    if (serverType == ThriftServerType.SASL) {
       String remoteUser = UGIAssumingProcessor.rpcPrincipal();
-      if (null == remoteUser || !remoteUser.equals(principal)) {
+      if (remoteUser == null || !remoteUser.equals(principal)) {
         logger.error("Denying login from user {} who attempted to log in as {}", remoteUser,
             principal);
         throw new org.apache.accumulo.proxy.thrift.AccumuloSecurityException(
diff --git a/server/base/src/main/java/org/apache/accumulo/server/ServerContext.java b/server/base/src/main/java/org/apache/accumulo/server/ServerContext.java
index 4dffaa3..ebb2baa 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/ServerContext.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/ServerContext.java
@@ -101,7 +101,7 @@ public class ServerContext extends ClientContext {
     MetricsSystemHelper.configure(applicationClassName);
     DistributedTrace.enable(hostname, applicationName,
         getServerConfFactory().getSystemConfiguration());
-    if (null != getSaslParams()) {
+    if (getSaslParams() != null) {
       // Server-side "client" check to make sure we're logged in as a user we expect to be
       enforceKerberosLogin();
     }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/client/ClientServiceHandler.java b/server/base/src/main/java/org/apache/accumulo/server/client/ClientServiceHandler.java
index 33448e6..e6a1399 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/client/ClientServiceHandler.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/client/ClientServiceHandler.java
@@ -176,7 +176,7 @@ public class ClientServiceHandler implements ClientService.Iface {
   public void createLocalUser(TInfo tinfo, TCredentials credentials, String principal,
       ByteBuffer password) throws ThriftSecurityException {
     AuthenticationToken token;
-    if (null != context.getSaslParams()) {
+    if (context.getSaslParams() != null) {
       try {
         token = new KerberosToken();
       } catch (IOException e) {
diff --git a/server/base/src/main/java/org/apache/accumulo/server/conf/NamespaceConfiguration.java b/server/base/src/main/java/org/apache/accumulo/server/conf/NamespaceConfiguration.java
index 795e6e9..f9aaad5 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/conf/NamespaceConfiguration.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/conf/NamespaceConfiguration.java
@@ -142,7 +142,7 @@ public class NamespaceConfiguration extends ObservableConfiguration {
 
   @Override
   public synchronized void invalidateCache() {
-    if (null != propCacheAccessor) {
+    if (propCacheAccessor != null) {
       propCacheAccessor.invalidateCache();
     }
     // Else, if the accessor is null, we could lock and double-check
diff --git a/server/base/src/main/java/org/apache/accumulo/server/conf/ServerConfigurationFactory.java b/server/base/src/main/java/org/apache/accumulo/server/conf/ServerConfigurationFactory.java
index fb99364..f655a4d 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/conf/ServerConfigurationFactory.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/conf/ServerConfigurationFactory.java
@@ -153,7 +153,7 @@ public class ServerConfigurationFactory extends ServerConfiguration {
       synchronized (tableConfigs) {
         Map<Table.ID,TableConfiguration> configs = tableConfigs.get(instanceID);
         TableConfiguration existingConf = configs.get(tableId);
-        if (null == existingConf) {
+        if (existingConf == null) {
           // Configuration doesn't exist yet
           configs.put(tableId, conf);
         } else {
diff --git a/server/base/src/main/java/org/apache/accumulo/server/conf/TableConfiguration.java b/server/base/src/main/java/org/apache/accumulo/server/conf/TableConfiguration.java
index 6576862..3c433a1 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/conf/TableConfiguration.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/conf/TableConfiguration.java
@@ -150,7 +150,7 @@ public class TableConfiguration extends ObservableConfiguration {
 
   @Override
   public synchronized void invalidateCache() {
-    if (null != propCacheAccessor) {
+    if (propCacheAccessor != null) {
       propCacheAccessor.invalidateCache();
     }
     // Else, if the accessor is null, we could lock and double-check
diff --git a/server/base/src/main/java/org/apache/accumulo/server/fs/PerTableVolumeChooser.java b/server/base/src/main/java/org/apache/accumulo/server/fs/PerTableVolumeChooser.java
index f792add..5aab9d2 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/fs/PerTableVolumeChooser.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/fs/PerTableVolumeChooser.java
@@ -90,11 +90,11 @@ public class PerTableVolumeChooser implements VolumeChooser {
 
     // fall back to global default scope, so setting only one default is necessary, rather than a
     // separate default for TABLE scope than other scopes
-    if (null == clazz || clazz.isEmpty()) {
+    if (clazz == null || clazz.isEmpty()) {
       clazz = confFactory.getSystemConfiguration().get(DEFAULT_SCOPED_VOLUME_CHOOSER);
     }
 
-    if (null == clazz || clazz.isEmpty()) {
+    if (clazz == null || clazz.isEmpty()) {
       String msg = "Property " + TABLE_VOLUME_CHOOSER + " or " + DEFAULT_SCOPED_VOLUME_CHOOSER
           + " must be a valid " + VolumeChooser.class.getSimpleName() + " to use the "
           + getClass().getSimpleName();
@@ -122,11 +122,11 @@ public class PerTableVolumeChooser implements VolumeChooser {
 
     // fall back to global default scope if this scope isn't configured (and not already default
     // scope)
-    if ((null == clazz || clazz.isEmpty()) && scope != ChooserScope.DEFAULT) {
+    if ((clazz == null || clazz.isEmpty()) && scope != ChooserScope.DEFAULT) {
       log.debug("{} not found; using {}", property, DEFAULT_SCOPED_VOLUME_CHOOSER);
       clazz = systemConfiguration.get(DEFAULT_SCOPED_VOLUME_CHOOSER);
 
-      if (null == clazz || clazz.isEmpty()) {
+      if (clazz == null || clazz.isEmpty()) {
         String msg = "Property " + property + " or " + DEFAULT_SCOPED_VOLUME_CHOOSER
             + " must be a valid " + VolumeChooser.class.getSimpleName() + " to use the "
             + getClass().getSimpleName();
diff --git a/server/base/src/main/java/org/apache/accumulo/server/fs/PreferredVolumeChooser.java b/server/base/src/main/java/org/apache/accumulo/server/fs/PreferredVolumeChooser.java
index b9e0539..452acf6 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/fs/PreferredVolumeChooser.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/fs/PreferredVolumeChooser.java
@@ -90,12 +90,12 @@ public class PreferredVolumeChooser extends RandomVolumeChooser {
 
     // fall back to global default scope, so setting only one default is necessary, rather than a
     // separate default for TABLE scope than other scopes
-    if (null == preferredVolumes || preferredVolumes.isEmpty()) {
+    if (preferredVolumes == null || preferredVolumes.isEmpty()) {
       preferredVolumes = confFactory.getSystemConfiguration().get(DEFAULT_SCOPED_PREFERRED_VOLUMES);
     }
 
     // throw an error if volumes not specified or empty
-    if (null == preferredVolumes || preferredVolumes.isEmpty()) {
+    if (preferredVolumes == null || preferredVolumes.isEmpty()) {
       String msg = "Property " + TABLE_PREFERRED_VOLUMES + " or " + DEFAULT_SCOPED_PREFERRED_VOLUMES
           + " must be a subset of " + Arrays.toString(options) + " to use the "
           + getClass().getSimpleName();
@@ -116,13 +116,13 @@ public class PreferredVolumeChooser extends RandomVolumeChooser {
 
     // fall back to global default scope if this scope isn't configured (and not already default
     // scope)
-    if ((null == preferredVolumes || preferredVolumes.isEmpty()) && scope != ChooserScope.DEFAULT) {
+    if ((preferredVolumes == null || preferredVolumes.isEmpty()) && scope != ChooserScope.DEFAULT) {
       log.debug("{} not found; using {}", property, DEFAULT_SCOPED_PREFERRED_VOLUMES);
       preferredVolumes = systemConfiguration.get(DEFAULT_SCOPED_PREFERRED_VOLUMES);
 
       // only if the custom property is not set to we fall back to the default scoped preferred
       // volumes
-      if (null == preferredVolumes || preferredVolumes.isEmpty()) {
+      if (preferredVolumes == null || preferredVolumes.isEmpty()) {
         String msg = "Property " + property + " or " + DEFAULT_SCOPED_PREFERRED_VOLUMES
             + " must be a subset of " + Arrays.toString(options) + " to use the "
             + getClass().getSimpleName();
diff --git a/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeManagerImpl.java b/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeManagerImpl.java
index eed7ad2..a361f9d 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeManagerImpl.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeManagerImpl.java
@@ -264,7 +264,7 @@ public class VolumeManagerImpl implements VolumeManager {
         FileSystem desiredFs = path.getFileSystem(CachedConfiguration.getInstance());
         URI desiredFsUri = desiredFs.getUri();
         Collection<Volume> candidateVolumes = volumesByFileSystemUri.get(desiredFsUri);
-        if (null != candidateVolumes) {
+        if (candidateVolumes != null) {
           for (Volume candidateVolume : candidateVolumes) {
             if (candidateVolume.isValidPath(path)) {
               return candidateVolume;
@@ -454,7 +454,7 @@ public class VolumeManagerImpl implements VolumeManager {
     // ACCUMULO-2974 To ensure that a proper absolute path is created, the caller needs to include
     // the table ID
     // in the relative path. Fail when this doesn't appear to happen.
-    if (FileType.TABLE == fileType) {
+    if (fileType == FileType.TABLE) {
       // Trailing slash doesn't create an additional element
       String[] pathComponents = StringUtils.split(path, Path.SEPARATOR_CHAR);
 
diff --git a/server/base/src/main/java/org/apache/accumulo/server/init/Initialize.java b/server/base/src/main/java/org/apache/accumulo/server/init/Initialize.java
index 5ef502b..64889f6 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/init/Initialize.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/init/Initialize.java
@@ -718,7 +718,7 @@ public class Initialize implements KeywordExecutable {
     ConsoleReader c = getConsoleReader();
     c.println("Running against secured HDFS");
 
-    if (null != opts.rootUser) {
+    if (opts.rootUser != null) {
       return opts.rootUser;
     }
 
@@ -872,8 +872,9 @@ public class Initialize implements KeywordExecutable {
             aBasePath, Property.INSTANCE_VOLUMES_REPLACEMENTS, Property.INSTANCE_VOLUMES);
     }
 
-    if (ServerConstants.DATA_VERSION != ServerUtil.getAccumuloPersistentVersion(
-        versionPath.getFileSystem(CachedConfiguration.getInstance()), versionPath)) {
+    if (ServerUtil.getAccumuloPersistentVersion(
+        versionPath.getFileSystem(CachedConfiguration.getInstance()),
+        versionPath) != ServerConstants.DATA_VERSION) {
       throw new IOException("Accumulo " + Constants.VERSION + " cannot initialize data version "
           + ServerUtil.getAccumuloPersistentVersion(fs));
     }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/master/LiveTServerSet.java b/server/base/src/main/java/org/apache/accumulo/server/master/LiveTServerSet.java
index 8781de6..c7ad9ef 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/master/LiveTServerSet.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/master/LiveTServerSet.java
@@ -397,9 +397,9 @@ public class LiveTServerSet implements Watcher {
   TServerInstance find(Map<String,TServerInfo> servers, String tabletServer) {
     HostAndPort addr;
     String sessionId = null;
-    if (']' == tabletServer.charAt(tabletServer.length() - 1)) {
+    if (tabletServer.charAt(tabletServer.length() - 1) == ']') {
       int index = tabletServer.indexOf('[');
-      if (-1 == index) {
+      if (index == -1) {
         throw new IllegalArgumentException("Could not parse tabletserver '" + tabletServer + "'");
       }
       addr = AddressUtil.parseAddress(tabletServer.substring(0, index), false);
@@ -411,7 +411,7 @@ public class LiveTServerSet implements Watcher {
     for (Entry<String,TServerInfo> entry : servers.entrySet()) {
       if (entry.getValue().instance.getLocation().equals(addr)) {
         // Return the instance if we have no desired session ID, or we match the desired session ID
-        if (null == sessionId || sessionId.equals(entry.getValue().instance.getSession()))
+        if (sessionId == null || sessionId.equals(entry.getValue().instance.getSession()))
           return entry.getValue().instance;
       }
     }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/master/balancer/DefaultLoadBalancer.java b/server/base/src/main/java/org/apache/accumulo/server/master/balancer/DefaultLoadBalancer.java
index 20ef687..64b88a8 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/master/balancer/DefaultLoadBalancer.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/master/balancer/DefaultLoadBalancer.java
@@ -108,7 +108,7 @@ public class DefaultLoadBalancer extends TabletBalancer {
     @Override
     public boolean equals(Object obj) {
       return obj == this
-          || (obj != null && obj instanceof ServerCounts && 0 == compareTo((ServerCounts) obj));
+          || (obj != null && obj instanceof ServerCounts && compareTo((ServerCounts) obj) == 0);
     }
 
     @Override
@@ -245,7 +245,7 @@ public class DefaultLoadBalancer extends TabletBalancer {
         if (onlineTabletsForTable == null) {
           onlineTabletsForTable = new HashMap<>();
           List<TabletStats> stats = getOnlineTabletsForTable(tooMuch.server, table);
-          if (null == stats) {
+          if (stats == null) {
             log.warn("Unable to find tablets to move");
             return result;
           }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancer.java b/server/base/src/main/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancer.java
index 7a18072..5310333 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancer.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancer.java
@@ -136,7 +136,7 @@ public class HostRegexTableLoadBalancer extends TableLoadBalancer implements Con
       List<String> poolNames = getPoolNamesForHost(e.getKey().host());
       for (String pool : poolNames) {
         SortedMap<TServerInstance,TabletServerStatus> np = newPools.get(pool);
-        if (null == np) {
+        if (np == null) {
           np = new TreeMap<>(current.comparator());
           newPools.put(pool, np);
         }
@@ -204,7 +204,7 @@ public class HostRegexTableLoadBalancer extends TableLoadBalancer implements Con
    * @return tablet server pool name (table name or DEFAULT_POOL)
    */
   protected String getPoolNameForTable(String tableName) {
-    if (null == tableName) {
+    if (tableName == null) {
       return DEFAULT_POOL;
     }
     return poolNameToRegexPattern.containsKey(tableName) ? tableName : DEFAULT_POOL;
@@ -218,7 +218,7 @@ public class HostRegexTableLoadBalancer extends TableLoadBalancer implements Con
    */
   protected void parseConfiguration(ServerConfiguration conf) {
     TableOperations t = getTableOperations();
-    if (null == t) {
+    if (t == null) {
       throw new RuntimeException("Table Operations cannot be null");
     }
     tableIdToTableName = new HashMap<>();
@@ -229,7 +229,7 @@ public class HostRegexTableLoadBalancer extends TableLoadBalancer implements Con
       conf.getTableConfiguration(tableId).addObserver(this);
       Map<String,String> customProps = conf.getTableConfiguration(tableId)
           .getAllPropertiesWithPrefix(Property.TABLE_ARBITRARY_PROP_PREFIX);
-      if (null != customProps && customProps.size() > 0) {
+      if (customProps != null && customProps.size() > 0) {
         for (Entry<String,String> customProp : customProps.entrySet()) {
           if (customProp.getKey().startsWith(HOST_BALANCER_PREFIX)) {
             if (customProp.getKey().equals(HOST_BALANCER_OOB_CHECK_KEY)
@@ -246,20 +246,20 @@ public class HostRegexTableLoadBalancer extends TableLoadBalancer implements Con
       }
     }
     String oobProperty = conf.getSystemConfiguration().get(HOST_BALANCER_OOB_CHECK_KEY);
-    if (null != oobProperty) {
+    if (oobProperty != null) {
       oobCheckMillis = ConfigurationTypeHelper.getTimeInMillis(oobProperty);
     }
     String ipBased = conf.getSystemConfiguration().get(HOST_BALANCER_REGEX_USING_IPS_KEY);
-    if (null != ipBased) {
+    if (ipBased != null) {
       isIpBasedRegex = Boolean.parseBoolean(ipBased);
     }
     String migrations = conf.getSystemConfiguration().get(HOST_BALANCER_REGEX_MAX_MIGRATIONS_KEY);
-    if (null != migrations) {
+    if (migrations != null) {
       maxTServerMigrations = Integer.parseInt(migrations);
     }
     String outstanding = conf.getSystemConfiguration()
         .get(HOST_BALANCER_OUTSTANDING_MIGRATIONS_KEY);
-    if (null != outstanding) {
+    if (outstanding != null) {
       this.maxOutstandingMigrations = Integer.parseInt(outstanding);
     }
     LOG.info("{}", this);
@@ -331,10 +331,10 @@ public class HostRegexTableLoadBalancer extends TableLoadBalancer implements Con
       String tableName = tableIdToTableName.get(e.getKey());
       String poolName = getPoolNameForTable(tableName);
       SortedMap<TServerInstance,TabletServerStatus> currentView = pools.get(poolName);
-      if (null == currentView || currentView.size() == 0) {
+      if (currentView == null || currentView.size() == 0) {
         LOG.warn("No tablet servers online for table {}, assigning within default pool", tableName);
         currentView = pools.get(DEFAULT_POOL);
-        if (null == currentView) {
+        if (currentView == null) {
           LOG.error(
               "No tablet servers exist in the default pool, unable to assign tablets for table {}",
               tableName);
@@ -376,7 +376,7 @@ public class HostRegexTableLoadBalancer extends TableLoadBalancer implements Con
               continue;
             }
             String tid = tableIdMap.get(table);
-            if (null == tid) {
+            if (tid == null) {
               LOG.warn("Unable to check for out of bounds tablets for table {},"
                   + " it may have been deleted or renamed.", table);
               continue;
@@ -384,7 +384,7 @@ public class HostRegexTableLoadBalancer extends TableLoadBalancer implements Con
             try {
               List<TabletStats> outOfBoundsTablets = getOnlineTabletsForTable(e.getKey(),
                   Table.ID.of(tid));
-              if (null == outOfBoundsTablets) {
+              if (outOfBoundsTablets == null) {
                 continue;
               }
               Random random = new SecureRandom();
@@ -397,7 +397,7 @@ public class HostRegexTableLoadBalancer extends TableLoadBalancer implements Con
                 String poolName = getPoolNameForTable(table);
                 SortedMap<TServerInstance,TabletServerStatus> currentView = currentGrouped
                     .get(poolName);
-                if (null != currentView) {
+                if (currentView != null) {
                   int skip = random.nextInt(currentView.size());
                   Iterator<TServerInstance> iter = currentView.keySet().iterator();
                   for (int i = 0; i < skip; i++) {
@@ -472,7 +472,7 @@ public class HostRegexTableLoadBalancer extends TableLoadBalancer implements Con
       String regexTableName = getPoolNameForTable(tableName);
       SortedMap<TServerInstance,TabletServerStatus> currentView = currentGrouped
           .get(regexTableName);
-      if (null == currentView) {
+      if (currentView == null) {
         LOG.warn("Skipping balance for table {} as no tablet servers are online.", tableName);
         continue;
       }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/metrics/AbstractMetricsImpl.java b/server/base/src/main/java/org/apache/accumulo/server/metrics/AbstractMetricsImpl.java
index 0e76fa0..a1962ce 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/metrics/AbstractMetricsImpl.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/metrics/AbstractMetricsImpl.java
@@ -126,7 +126,7 @@ public abstract class AbstractMetricsImpl implements Metrics {
   public void register(StandardMBean mbean) throws Exception {
     // Register this object with the MBeanServer
     MBeanServer mbs = ManagementFactory.getPlatformMBeanServer();
-    if (null == getObjectName())
+    if (getObjectName() == null)
       throw new IllegalArgumentException("MBean object name must be set.");
     mbs.registerMBean(mbean, getObjectName());
 
@@ -140,7 +140,7 @@ public abstract class AbstractMetricsImpl implements Metrics {
   public void register() throws Exception {
     // Register this object with the MBeanServer
     MBeanServer mbs = ManagementFactory.getPlatformMBeanServer();
-    if (null == getObjectName())
+    if (getObjectName() == null)
       throw new IllegalArgumentException("MBean object name must be set.");
     mbs.registerMBean(this, getObjectName());
     setupLogging();
@@ -168,14 +168,14 @@ public abstract class AbstractMetricsImpl implements Metrics {
 
   @SuppressFBWarnings(value = "PATH_TRAVERSAL_IN", justification = "path provided by admin")
   private void setupLogging() throws IOException {
-    if (null == config.getMetricsConfiguration())
+    if (config.getMetricsConfiguration() == null)
       return;
     // If we are already logging, then return
     if (!currentlyLogging
         && config.getMetricsConfiguration().getBoolean(metricsPrefix + ".logging", false)) {
       // Check to see if directory exists, else make it
       String mDir = config.getMetricsConfiguration().getString("logging.dir");
-      if (null != mDir) {
+      if (mDir != null) {
         File dir = new File(mDir);
         if (!dir.isDirectory())
           if (!dir.mkdir())
@@ -190,7 +190,7 @@ public abstract class AbstractMetricsImpl implements Metrics {
 
   @SuppressFBWarnings(value = "PATH_TRAVERSAL_IN", justification = "path provided by admin")
   private void startNewLog() throws IOException {
-    if (null != logWriter) {
+    if (logWriter != null) {
       logWriter.flush();
       logWriter.close();
     }
@@ -206,7 +206,7 @@ public abstract class AbstractMetricsImpl implements Metrics {
   }
 
   private void writeToLog(String name) throws IOException {
-    if (null == logWriter)
+    if (logWriter == null)
       return;
     // Increment the date if we have to
     Date now = new Date();
@@ -267,7 +267,7 @@ public abstract class AbstractMetricsImpl implements Metrics {
 
   @Override
   protected void finalize() {
-    if (null != logWriter) {
+    if (logWriter != null) {
       try {
         logWriter.close();
       } catch (Exception e) {
diff --git a/server/base/src/main/java/org/apache/accumulo/server/metrics/MetricsConfiguration.java b/server/base/src/main/java/org/apache/accumulo/server/metrics/MetricsConfiguration.java
index 4203480..3f2ee7c 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/metrics/MetricsConfiguration.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/metrics/MetricsConfiguration.java
@@ -109,7 +109,7 @@ public class MetricsConfiguration {
 
   public Configuration getEnvironmentConfiguration() {
     synchronized (MetricsConfiguration.class) {
-      if (null == envConfig)
+      if (envConfig == null)
         envConfig = new EnvironmentConfiguration();
       return envConfig;
     }
@@ -117,7 +117,7 @@ public class MetricsConfiguration {
 
   public Configuration getSystemConfiguration() {
     synchronized (MetricsConfiguration.class) {
-      if (null == sysConfig)
+      if (sysConfig == null)
         sysConfig = new SystemConfiguration();
       return sysConfig;
     }
@@ -136,11 +136,11 @@ public class MetricsConfiguration {
         notFoundCount++;
       }
     }
-    if (null == config || needsReloading) {
+    if (config == null || needsReloading) {
       synchronized (lock) {
         if (needsReloading) {
           loadConfiguration();
-        } else if (null == config) {
+        } else if (config == null) {
           loadConfiguration();
         }
         needsReloading = false;
@@ -169,7 +169,7 @@ public class MetricsConfiguration {
 
       // Start a background Thread that checks a property from the XMLConfiguration
       // every so often to force the FileChangedReloadingStrategy to fire.
-      if (null == watcher || !watcher.isAlive()) {
+      if (watcher == null || !watcher.isAlive()) {
         watcher = new MetricsConfigWatcher();
         watcher.start();
       }
@@ -195,7 +195,7 @@ public class MetricsConfiguration {
 
   public boolean isEnabled() {
     // Force reload if necessary
-    if (null == getMetricsConfiguration())
+    if (getMetricsConfiguration() == null)
       return false;
     return enabled;
   }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/replication/DistributedWorkQueueWorkAssignerHelper.java b/server/base/src/main/java/org/apache/accumulo/server/replication/DistributedWorkQueueWorkAssignerHelper.java
index 868bcf2..4877ff1 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/replication/DistributedWorkQueueWorkAssignerHelper.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/replication/DistributedWorkQueueWorkAssignerHelper.java
@@ -54,7 +54,7 @@ public class DistributedWorkQueueWorkAssignerHelper {
     requireNonNull(queueKey);
 
     int index = queueKey.indexOf(KEY_SEPARATOR);
-    if (-1 == index) {
+    if (index == -1) {
       throw new IllegalArgumentException(
           "Could not find expected separator in queue key '" + queueKey + "'");
     }
@@ -62,13 +62,13 @@ public class DistributedWorkQueueWorkAssignerHelper {
     String filename = queueKey.substring(0, index);
 
     int secondIndex = queueKey.indexOf(KEY_SEPARATOR, index + 1);
-    if (-1 == secondIndex) {
+    if (secondIndex == -1) {
       throw new IllegalArgumentException(
           "Could not find expected separator in queue key '" + queueKey + "'");
     }
 
     int thirdIndex = queueKey.indexOf(KEY_SEPARATOR, secondIndex + 1);
-    if (-1 == thirdIndex) {
+    if (thirdIndex == -1) {
       throw new IllegalArgumentException(
           "Could not find expected seperator in queue key '" + queueKey + "'");
     }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicaSystemFactory.java b/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicaSystemFactory.java
index accaf4e..493e8ee 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicaSystemFactory.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicaSystemFactory.java
@@ -68,7 +68,7 @@ public class ReplicaSystemFactory {
     requireNonNull(value);
 
     int index = value.indexOf(',');
-    if (-1 == index) {
+    if (index == -1) {
       throw new IllegalArgumentException(
           "Expected comma separator between replication system name and configuration");
     }
@@ -90,7 +90,7 @@ public class ReplicaSystemFactory {
   public static String getPeerConfigurationValue(Class<? extends ReplicaSystem> system,
       String configuration) {
     String systemName = system.getName() + ",";
-    if (null == configuration) {
+    if (configuration == null) {
       return systemName;
     }
 
diff --git a/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicationUtil.java b/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicationUtil.java
index 5caf15d..8589807 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicationUtil.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicationUtil.java
@@ -130,13 +130,13 @@ public class ReplicationUtil {
       }
 
       Table.ID localId = tableNameToId.get(table);
-      if (null == localId) {
+      if (localId == null) {
         log.trace("Could not determine ID for {}", table);
         continue;
       }
 
       TableConfiguration tableConf = context.getServerConfFactory().getTableConfiguration(localId);
-      if (null == tableConf) {
+      if (tableConf == null) {
         log.trace("Could not get configuration for table {} (it no longer exists)", table);
         continue;
       }
@@ -179,7 +179,7 @@ public class ReplicationUtil {
         // TODO ACCUMULO-2835 once explicit lengths are tracked, we can give size-based estimates
         // instead of just file-based
         Long count = counts.get(target);
-        if (null == count) {
+        if (count == null) {
           counts.put(target, 1L);
         } else {
           counts.put(target, count + 1);
@@ -233,7 +233,7 @@ public class ReplicationUtil {
    */
   public String getAbsolutePath(AccumuloClient client, String workQueuePath, String queueKey) {
     byte[] data = zooCache.get(workQueuePath + "/" + queueKey);
-    if (null != data) {
+    if (data != null) {
       return new String(data, UTF_8);
     }
 
@@ -255,7 +255,7 @@ public class ReplicationUtil {
     // We could try to grep over the table, but without knowing the full file path, we
     // can't find the status quickly
     String status = "Unknown";
-    if (null != path) {
+    if (path != null) {
       Scanner s;
       try {
         s = ReplicationTable.getScanner(client);
@@ -279,7 +279,7 @@ public class ReplicationUtil {
       }
 
       // If we found the work entry for it, try to compute some progress
-      if (null != kv) {
+      if (kv != null) {
         try {
           Status stat = Status.parseFrom(kv.getValue().get());
           if (StatusUtil.isFullyReplicated(stat)) {
diff --git a/server/base/src/main/java/org/apache/accumulo/server/replication/StatusCombiner.java b/server/base/src/main/java/org/apache/accumulo/server/replication/StatusCombiner.java
index 4f3a958..7c7bf8c 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/replication/StatusCombiner.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/replication/StatusCombiner.java
@@ -110,7 +110,7 @@ public class StatusCombiner extends TypedValueCombiner<Status> {
 
       // Avoid creation of a new builder and message when we only have one
       // message to reduce
-      if (null == combined) {
+      if (combined == null) {
         if (!iter.hasNext()) {
           if (log.isTraceEnabled()) {
             log.trace("Returned single value: {} {}", key.toStringNoTruncate(),
diff --git a/server/base/src/main/java/org/apache/accumulo/server/replication/StatusUtil.java b/server/base/src/main/java/org/apache/accumulo/server/replication/StatusUtil.java
index 577ff88..8823b21 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/replication/StatusUtil.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/replication/StatusUtil.java
@@ -211,7 +211,7 @@ public class StatusUtil {
    */
   public static boolean isFullyReplicated(Status status) {
     if (status.getInfiniteEnd()) {
-      return Long.MAX_VALUE == status.getBegin();
+      return status.getBegin() == Long.MAX_VALUE;
     } else {
       return status.getBegin() >= status.getEnd();
     }
@@ -226,7 +226,7 @@ public class StatusUtil {
    */
   public static boolean isWorkRequired(Status status) {
     if (status.getInfiniteEnd()) {
-      return Long.MAX_VALUE != status.getBegin();
+      return status.getBegin() != Long.MAX_VALUE;
     } else {
       return status.getBegin() < status.getEnd();
     }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/rpc/TCredentialsUpdatingInvocationHandler.java b/server/base/src/main/java/org/apache/accumulo/server/rpc/TCredentialsUpdatingInvocationHandler.java
index b649d4b..c3da71a 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/rpc/TCredentialsUpdatingInvocationHandler.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/rpc/TCredentialsUpdatingInvocationHandler.java
@@ -81,7 +81,7 @@ public class TCredentialsUpdatingInvocationHandler<I> implements InvocationHandl
     }
 
     // If we don't find a tcredentials in the first two positions
-    if (null == tcreds) {
+    if (tcreds == null) {
       // Not all calls require authentication (e.g. closeMultiScan). We need to let these pass
       // through.
       log.trace("Did not find a TCredentials object in the first two positions"
@@ -96,7 +96,7 @@ public class TCredentialsUpdatingInvocationHandler<I> implements InvocationHandl
 
     // If we authenticated the user over DIGEST-MD5 and they have a DelegationToken, the principals
     // should match
-    if (SaslMechanism.DIGEST_MD5 == UGIAssumingProcessor.rpcMechanism()
+    if (UGIAssumingProcessor.rpcMechanism() == SaslMechanism.DIGEST_MD5
         && DelegationTokenImpl.class.isAssignableFrom(tokenClass)) {
       if (!principal.equals(tcreds.principal)) {
         log.warn("{} issued RPC with delegation token over DIGEST-MD5 as the"
@@ -117,7 +117,7 @@ public class TCredentialsUpdatingInvocationHandler<I> implements InvocationHandl
           SecurityErrorCode.BAD_CREDENTIALS);
     }
 
-    if (null == principal) {
+    if (principal == null) {
       log.debug(
           "Found KerberosToken in TCredentials, but did not receive principal from SASL processor");
       throw new ThriftSecurityException("Did not extract principal from Thrift SASL processor",
@@ -128,7 +128,7 @@ public class TCredentialsUpdatingInvocationHandler<I> implements InvocationHandl
     // principal
     if (!principal.equals(tcreds.principal)) {
       UsersWithHosts usersWithHosts = impersonation.get(principal);
-      if (null == usersWithHosts) {
+      if (usersWithHosts == null) {
         principalMismatch(principal, tcreds.principal);
       }
       if (!usersWithHosts.getUsers().contains(tcreds.principal)) {
@@ -153,7 +153,7 @@ public class TCredentialsUpdatingInvocationHandler<I> implements InvocationHandl
 
   protected Class<? extends AuthenticationToken> getTokenClassFromName(String tokenClassName) {
     Class<? extends AuthenticationToken> typedClz = TOKEN_CLASS_CACHE.get(tokenClassName);
-    if (null == typedClz) {
+    if (typedClz == null) {
       Class<?> clz;
       try {
         clz = Class.forName(tokenClassName);
diff --git a/server/base/src/main/java/org/apache/accumulo/server/rpc/TServerUtils.java b/server/base/src/main/java/org/apache/accumulo/server/rpc/TServerUtils.java
index af2871e..30c238f 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/rpc/TServerUtils.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/rpc/TServerUtils.java
@@ -143,7 +143,7 @@ public class TServerUtils {
         .getCount(Property.GENERAL_SIMPLETIMER_THREADPOOL_SIZE);
     final ThriftServerType serverType = service.getThriftServerType();
 
-    if (ThriftServerType.SASL == serverType) {
+    if (serverType == ThriftServerType.SASL) {
       processor = updateSaslProcessor(serverType, processor);
     }
 
@@ -329,7 +329,7 @@ public class TServerUtils {
     options.protocolFactory(protocolFactory);
     options.transportFactory(transportFactory);
     options.processorFactory(new ClientInfoProcessorFactory(clientAddress, processor));
-    if (null != service) {
+    if (service != null) {
       options.executorService(service);
     }
     return new TThreadPoolServer(options);
@@ -488,7 +488,7 @@ public class TServerUtils {
     saslTransportFactory.addServerDefinition(ThriftUtil.GSSAPI, params.getKerberosServerPrimary(),
         hostname, params.getSaslProperties(), new SaslRpcServer.SaslGssCallbackHandler());
 
-    if (null != params.getSecretManager()) {
+    if (params.getSecretManager() != null) {
       log.info("Adding DIGEST-MD5 server definition for delegation tokens");
       saslTransportFactory.addServerDefinition(ThriftUtil.DIGEST_MD5,
           params.getKerberosServerPrimary(), hostname, params.getSaslProperties(),
@@ -523,7 +523,7 @@ public class TServerUtils {
       SaslServerConnectionParams saslParams, long serverSocketTimeout, HostAndPort... addresses)
       throws TTransportException {
 
-    if (ThriftServerType.SASL == serverType) {
+    if (serverType == ThriftServerType.SASL) {
       processor = updateSaslProcessor(serverType, processor);
     }
 
@@ -599,7 +599,7 @@ public class TServerUtils {
         log.warn("Error attempting to create server at {}. Error: {}", address, e.getMessage());
       }
     }
-    if (null == serverAddress) {
+    if (serverAddress == null) {
       throw new TTransportException(
           "Unable to create server on addresses: " + Arrays.toString(addresses));
     }
@@ -662,7 +662,7 @@ public class TServerUtils {
    * @return A {@link UGIAssumingProcessor} which wraps the provided processor
    */
   private static TProcessor updateSaslProcessor(ThriftServerType serverType, TProcessor processor) {
-    checkArgument(ThriftServerType.SASL == serverType);
+    checkArgument(serverType == ThriftServerType.SASL);
 
     // Wrap the provided processor in our special processor which proxies the provided UGI on the
     // logged-in UGI
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java b/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java
index a569018..510ae7e 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java
@@ -200,7 +200,7 @@ public class SecurityOperation {
             try {
               _createUser(credentials, creds, Authorizations.EMPTY);
             } catch (ThriftSecurityException e) {
-              if (SecurityErrorCode.USER_EXISTS != e.getCode()) {
+              if (e.getCode() != SecurityErrorCode.USER_EXISTS) {
                 // For Kerberos, a user acct is automatically created because there is no notion of
                 // a password
                 // in the traditional sense of Accumulo users. As such, if a user acct already
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/UserImpersonation.java b/server/base/src/main/java/org/apache/accumulo/server/security/UserImpersonation.java
index a5ac0d5..77a33b9 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/UserImpersonation.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/UserImpersonation.java
@@ -204,7 +204,7 @@ public class UserImpersonation {
       final String hostConfig = hostConfigs[i];
 
       final String[] splitUserConfig = StringUtils.split(userConfig, ':');
-      if (2 != splitUserConfig.length) {
+      if (splitUserConfig.length != 2) {
         throw new IllegalArgumentException(
             "Expect a single colon-separated pair, but found '" + userConfig + "'");
       }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/delegation/AuthenticationKey.java b/server/base/src/main/java/org/apache/accumulo/server/security/delegation/AuthenticationKey.java
index a04fad0..9bc1bae 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/delegation/AuthenticationKey.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/delegation/AuthenticationKey.java
@@ -91,7 +91,7 @@ public class AuthenticationKey implements Writable {
 
   @Override
   public int hashCode() {
-    if (null == authKey) {
+    if (authKey == null) {
       return 1;
     }
     HashCodeBuilder hcb = new HashCodeBuilder(29, 31);
@@ -110,7 +110,7 @@ public class AuthenticationKey implements Writable {
   public String toString() {
     StringBuilder buf = new StringBuilder();
     buf.append("AuthenticationKey[");
-    if (null == authKey) {
+    if (authKey == null) {
       buf.append("null]");
     } else {
       buf.append("id=").append(authKey.getKeyId()).append(", expiration=")
@@ -122,7 +122,7 @@ public class AuthenticationKey implements Writable {
 
   @Override
   public void write(DataOutput out) throws IOException {
-    if (null == authKey) {
+    if (authKey == null) {
       WritableUtils.writeVInt(out, 0);
       return;
     }
@@ -135,7 +135,7 @@ public class AuthenticationKey implements Writable {
   @Override
   public void readFields(DataInput in) throws IOException {
     int length = WritableUtils.readVInt(in);
-    if (0 == length) {
+    if (length == 0) {
       return;
     }
 
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/delegation/AuthenticationTokenKeyManager.java b/server/base/src/main/java/org/apache/accumulo/server/security/delegation/AuthenticationTokenKeyManager.java
index 5cef9e1..9e53082 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/delegation/AuthenticationTokenKeyManager.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/delegation/AuthenticationTokenKeyManager.java
@@ -115,7 +115,7 @@ public class AuthenticationTokenKeyManager extends Daemon {
         // expected
         // functionality if the active master happens to die for some reason
         AuthenticationKey currentKey = secretManager.getCurrentKey();
-        if (null != currentKey) {
+        if (currentKey != null) {
           log.info("Updating last key update to {} from current secret manager key",
               currentKey.getCreationDate());
           lastKeyUpdate = currentKey.getCreationDate();
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/delegation/AuthenticationTokenSecretManager.java b/server/base/src/main/java/org/apache/accumulo/server/security/delegation/AuthenticationTokenSecretManager.java
index bddd325..ffbe2f9 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/delegation/AuthenticationTokenSecretManager.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/delegation/AuthenticationTokenSecretManager.java
@@ -96,9 +96,9 @@ public class AuthenticationTokenSecretManager extends SecretManager<Authenticati
     identifier.setExpirationDate(expiration);
 
     // Limit the lifetime if the user requests it
-    if (null != cfg) {
+    if (cfg != null) {
       long requestedLifetime = cfg.getTokenLifetime(TimeUnit.MILLISECONDS);
-      if (0 < requestedLifetime) {
+      if (requestedLifetime > 0) {
         long requestedExpirationDate = identifier.getIssueDate() + requestedLifetime;
         // Catch overflow again
         if (requestedExpirationDate < identifier.getIssueDate()) {
@@ -158,7 +158,7 @@ public class AuthenticationTokenSecretManager extends SecretManager<Authenticati
     final AuthenticationTokenIdentifier id = new AuthenticationTokenIdentifier(username, cfg);
 
     final StringBuilder svcName = new StringBuilder(DelegationTokenImpl.SERVICE_NAME);
-    if (null != id.getInstanceId()) {
+    if (id.getInstanceId() != null) {
       svcName.append("-").append(id.getInstanceId());
     }
     // Create password will update the state on the identifier given currentKey. Need to call this
@@ -206,7 +206,7 @@ public class AuthenticationTokenSecretManager extends SecretManager<Authenticati
 
     log.debug("Removing AuthenticatioKey with keyId {}", keyId);
 
-    return null != allKeys.remove(keyId);
+    return allKeys.remove(keyId) != null;
   }
 
   /**
@@ -255,7 +255,7 @@ public class AuthenticationTokenSecretManager extends SecretManager<Authenticati
   }
 
   synchronized boolean isCurrentKeySet() {
-    return null != currentKey;
+    return currentKey != null;
   }
 
   /**
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/delegation/ZooAuthenticationKeyDistributor.java b/server/base/src/main/java/org/apache/accumulo/server/security/delegation/ZooAuthenticationKeyDistributor.java
index e822f13..71f22c1 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/delegation/ZooAuthenticationKeyDistributor.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/delegation/ZooAuthenticationKeyDistributor.java
@@ -72,7 +72,7 @@ public class ZooAuthenticationKeyDistributor {
       }
     } else {
       List<ACL> acls = zk.getACL(baseNode, new Stat());
-      if (1 == acls.size()) {
+      if (acls.size() == 1) {
         ACL actualAcl = acls.get(0), expectedAcl = ZooUtil.PRIVATE.get(0);
         Id actualId = actualAcl.getId();
         // The expected outcome from ZooUtil.PRIVATE
@@ -112,7 +112,7 @@ public class ZooAuthenticationKeyDistributor {
     List<AuthenticationKey> keys = new ArrayList<>(children.size());
     for (String child : children) {
       byte[] data = zk.getData(qualifyPath(child), null);
-      if (null != data) {
+      if (data != null) {
         AuthenticationKey key = new AuthenticationKey();
         try {
           key.readFields(new DataInputStream(new ByteArrayInputStream(data)));
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/delegation/ZooAuthenticationKeyWatcher.java b/server/base/src/main/java/org/apache/accumulo/server/security/delegation/ZooAuthenticationKeyWatcher.java
index 8f944d1..4df829b 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/delegation/ZooAuthenticationKeyWatcher.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/delegation/ZooAuthenticationKeyWatcher.java
@@ -49,7 +49,7 @@ public class ZooAuthenticationKeyWatcher implements Watcher {
 
   @Override
   public void process(WatchedEvent event) {
-    if (EventType.None == event.getType()) {
+    if (event.getType() == EventType.None) {
       switch (event.getState()) {
         case Disconnected: // Intentional fall through of case
         case Expired: // ZooReader is handling the Expiration of the original ZooKeeper object for
@@ -74,7 +74,7 @@ public class ZooAuthenticationKeyWatcher implements Watcher {
     }
 
     String path = event.getPath();
-    if (null == path) {
+    if (path == null) {
       return;
     }
 
@@ -161,7 +161,7 @@ public class ZooAuthenticationKeyWatcher implements Watcher {
     switch (event.getType()) {
       case NodeDeleted:
         // Key expired
-        if (null == path) {
+        if (path == null) {
           log.error("Got null path for NodeDeleted event");
           return;
         }
@@ -175,7 +175,7 @@ public class ZooAuthenticationKeyWatcher implements Watcher {
         break;
       case NodeCreated:
         // New key created
-        if (null == path) {
+        if (path == null) {
           log.error("Got null path for NodeCreated event");
           return;
         }
@@ -186,7 +186,7 @@ public class ZooAuthenticationKeyWatcher implements Watcher {
         break;
       case NodeDataChanged:
         // Key changed, could happen on restart after not running Accumulo.
-        if (null == path) {
+        if (path == null) {
           log.error("Got null path for NodeDataChanged event");
           return;
         }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java b/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java
index 088232d..2783536 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java
@@ -121,7 +121,7 @@ public class KerberosAuthenticator implements Authenticator {
       // doesn't contain the actual credentials
       // Double check that the rpc user can impersonate as the requested user.
       UsersWithHosts usersWithHosts = impersonation.get(rpcPrincipal);
-      if (null == usersWithHosts) {
+      if (usersWithHosts == null) {
         throw new AccumuloSecurityException(principal, SecurityErrorCode.AUTHENTICATOR_FAILED);
       }
       if (!usersWithHosts.getUsers().contains(principal)) {
diff --git a/server/base/src/main/java/org/apache/accumulo/server/tabletserver/LargestFirstMemoryManager.java b/server/base/src/main/java/org/apache/accumulo/server/tabletserver/LargestFirstMemoryManager.java
index dea14a2..a7d8af8 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/tabletserver/LargestFirstMemoryManager.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/tabletserver/LargestFirstMemoryManager.java
@@ -196,7 +196,7 @@ public class LargestFirstMemoryManager implements MemoryManager {
           }
         } catch (IllegalArgumentException e) {
           Throwable cause = e.getCause();
-          if (null != cause && cause instanceof TableNotFoundException) {
+          if (cause != null && cause instanceof TableNotFoundException) {
             log.trace("Ignoring extent for deleted table: {}", ts.getExtent());
 
             // The table might have been deleted during the iteration of the tablets
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/Admin.java b/server/base/src/main/java/org/apache/accumulo/server/util/Admin.java
index 962324f..d982d89 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/Admin.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/Admin.java
@@ -398,7 +398,7 @@ public class Admin implements KeywordExecutable {
       String hostAndPort) {
     try {
       long sessionId = ZooLock.getSessionId(zooCache, zTServerRoot + "/" + hostAndPort);
-      if (0 == sessionId) {
+      if (sessionId == 0) {
         return hostAndPort;
       }
       return hostAndPort + "[" + Long.toHexString(sessionId) + "]";
@@ -491,13 +491,13 @@ public class Admin implements KeywordExecutable {
   }
 
   private String getDefaultConfigValue(String key) {
-    if (null == key)
+    if (key == null)
       return null;
 
     String defaultValue = null;
     try {
       Property p = Property.getPropertyByKey(key);
-      if (null == p)
+      if (p == null)
         return defaultValue;
       defaultValue = defaultConfig.get(p);
     } catch (IllegalArgumentException e) {
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/RandomizeVolumes.java b/server/base/src/main/java/org/apache/accumulo/server/util/RandomizeVolumes.java
index 8be3815..b186304 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/RandomizeVolumes.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/RandomizeVolumes.java
@@ -70,13 +70,13 @@ public class RandomizeVolumes {
       return 1;
     }
     String tblStr = context.tableOperations().tableIdMap().get(tableName);
-    if (null == tblStr) {
+    if (tblStr == null) {
       log.error("Could not determine the table ID for table {}", tableName);
       return 2;
     }
     Table.ID tableId = Table.ID.of(tblStr);
     TableState tableState = context.getTableManager().getTableState(tableId);
-    if (TableState.OFFLINE != tableState) {
+    if (tableState != TableState.OFFLINE) {
       log.info("Taking {} offline", tableName);
       context.tableOperations().offline(tableName, true);
       log.info("{} offline", tableName);
@@ -136,7 +136,7 @@ public class RandomizeVolumes {
       }
     }
     log.info("Updated {} entries for table {}", count, tableName);
-    if (TableState.OFFLINE != tableState) {
+    if (tableState != TableState.OFFLINE) {
       context.tableOperations().online(tableName, true);
       log.info("table {} back online", tableName);
     }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/SystemPropUtil.java b/server/base/src/main/java/org/apache/accumulo/server/util/SystemPropUtil.java
index 82b2502..40180fa 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/SystemPropUtil.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/SystemPropUtil.java
@@ -44,7 +44,7 @@ public class SystemPropUtil {
     // Find the property taking prefix into account
     Property foundProp = null;
     for (Property prop : Property.values()) {
-      if (PropertyType.PREFIX == prop.getType() && property.startsWith(prop.getKey())
+      if (prop.getType() == PropertyType.PREFIX && property.startsWith(prop.getKey())
           || prop.getKey().equals(property)) {
         foundProp = prop;
         break;
diff --git a/server/gc/src/main/java/org/apache/accumulo/gc/SimpleGarbageCollector.java b/server/gc/src/main/java/org/apache/accumulo/gc/SimpleGarbageCollector.java
index a078ba7..9eab1c8 100644
--- a/server/gc/src/main/java/org/apache/accumulo/gc/SimpleGarbageCollector.java
+++ b/server/gc/src/main/java/org/apache/accumulo/gc/SimpleGarbageCollector.java
@@ -667,7 +667,7 @@ public class SimpleGarbageCollector implements Iface {
   private HostAndPort startStatsService() throws UnknownHostException {
     Iface rpcProxy = TraceWrap.service(this);
     final Processor<Iface> processor;
-    if (ThriftServerType.SASL == context.getThriftServerType()) {
+    if (context.getThriftServerType() == ThriftServerType.SASL) {
       Iface tcProxy = TCredentialsUpdatingWrapper.service(rpcProxy, getClass(), getConfiguration());
       processor = new Processor<>(tcProxy);
     } else {
diff --git a/server/gc/src/main/java/org/apache/accumulo/gc/replication/CloseWriteAheadLogReferences.java b/server/gc/src/main/java/org/apache/accumulo/gc/replication/CloseWriteAheadLogReferences.java
index 5d217c8..97d2af7 100644
--- a/server/gc/src/main/java/org/apache/accumulo/gc/replication/CloseWriteAheadLogReferences.java
+++ b/server/gc/src/main/java/org/apache/accumulo/gc/replication/CloseWriteAheadLogReferences.java
@@ -189,11 +189,11 @@ public class CloseWriteAheadLogReferences implements Runnable {
     } catch (TableNotFoundException e) {
       log.error("Replication table was deleted", e);
     } finally {
-      if (null != bs) {
+      if (bs != null) {
         bs.close();
       }
 
-      if (null != bw) {
+      if (bw != null) {
         try {
           bw.close();
         } catch (MutationsRejectedException e) {
@@ -264,7 +264,7 @@ public class CloseWriteAheadLogReferences implements Runnable {
       // on every tserver
       // node. The master is already tracking all of this info, so hopefully this is less overall
       // work.
-      if (null != client) {
+      if (client != null) {
         tservers = client.getActiveTservers(tinfo, context.rpcCreds());
       }
     } catch (TException e) {
diff --git a/server/master/src/main/java/org/apache/accumulo/master/FateServiceHandler.java b/server/master/src/main/java/org/apache/accumulo/master/FateServiceHandler.java
index 18da6be..7ffe888 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/FateServiceHandler.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/FateServiceHandler.java
@@ -606,7 +606,7 @@ class FateServiceHandler implements FateService.Iface {
   private void throwIfTableMissingSecurityException(ThriftSecurityException e, Table.ID tableId,
       String tableName, TableOperation op) throws ThriftTableOperationException {
     // ACCUMULO-3135 Table can be deleted after we get table ID but before we can check permission
-    if (e.isSetCode() && SecurityErrorCode.TABLE_DOESNT_EXIST == e.getCode()) {
+    if (e.isSetCode() && e.getCode() == SecurityErrorCode.TABLE_DOESNT_EXIST) {
       throw new ThriftTableOperationException(tableId.canonicalID(), tableName, op,
           TableOperationExceptionType.NOTFOUND, "Table no longer exists");
     }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/Master.java b/server/master/src/main/java/org/apache/accumulo/master/Master.java
index 7fc1639..53f3eb2 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/Master.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/Master.java
@@ -335,7 +335,7 @@ public class Master
       // This Master hasn't started Fate yet, so any outstanding transactions must be from before
       // the upgrade.
       // Change to Guava's Verify once we use Guava 17.
-      if (null != fate) {
+      if (fate != null) {
         throw new IllegalStateException("Access to Fate should not have been"
             + " initialized prior to the Master transitioning to active. Please"
             + " save all logs and file a bug.");
@@ -503,7 +503,7 @@ public class Master
               + " Accumulo's metadata table if we've already upgraded ZooKeeper."
               + " Please save all logs and file a bug.");
         }
-        if (null != fate) {
+        if (fate != null) {
           throw new IllegalStateException("Access to Fate should not have been"
               + " initialized prior to the Master finishing upgrades. Please save"
               + " all logs and file a bug.");
@@ -966,7 +966,7 @@ public class Master
       TableManager manager = context.getTableManager();
       for (Table.ID tableId : Tables.getIdToNameMap(context).keySet()) {
         TableState state = manager.getTableState(tableId);
-        if (TableState.OFFLINE == state) {
+        if (state == TableState.OFFLINE) {
           clearMigrations(tableId);
         }
       }
@@ -1253,7 +1253,7 @@ public class Master
     Iface haProxy = HighlyAvailableServiceWrapper.service(clientHandler, this);
     Iface rpcProxy = TraceWrap.service(haProxy);
     final Processor<Iface> processor;
-    if (ThriftServerType.SASL == context.getThriftServerType()) {
+    if (context.getThriftServerType() == ThriftServerType.SASL) {
       Iface tcredsProxy = TCredentialsUpdatingWrapper.service(rpcProxy, clientHandler.getClass(),
           getConfiguration());
       processor = new Processor<>(tcredsProxy);
@@ -1371,7 +1371,7 @@ public class Master
 
     // Make sure that we have a secret key (either a new one or an old one from ZK) before we start
     // the master client service.
-    if (null != authenticationTokenKeyManager && null != keyDistributor) {
+    if (authenticationTokenKeyManager != null && keyDistributor != null) {
       log.info("Starting delegation-token key manager");
       keyDistributor.initialize();
       authenticationTokenKeyManager.start();
@@ -1647,7 +1647,7 @@ public class Master
   @Override
   public void stateChanged(Table.ID tableId, TableState state) {
     nextEvent.event("Table state in zookeeper changed for %s to %s", tableId, state);
-    if (TableState.OFFLINE == state) {
+    if (state == TableState.OFFLINE) {
       clearMigrations(tableId);
     }
   }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/metrics/Metrics2ReplicationMetrics.java b/server/master/src/main/java/org/apache/accumulo/master/metrics/Metrics2ReplicationMetrics.java
index d83654f..bda9ae6 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/metrics/Metrics2ReplicationMetrics.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/metrics/Metrics2ReplicationMetrics.java
@@ -130,7 +130,7 @@ public class Metrics2ReplicationMetrics implements Metrics, MetricsSource {
     for (ReplicationTarget configuredTarget : allConfiguredTargets) {
       Long numFiles = targetCounts.get(configuredTarget);
 
-      if (null != numFiles) {
+      if (numFiles != null) {
         filesPending += numFiles;
       }
     }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/metrics/ReplicationMetrics.java b/server/master/src/main/java/org/apache/accumulo/master/metrics/ReplicationMetrics.java
index 982e053..db7f11f 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/metrics/ReplicationMetrics.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/metrics/ReplicationMetrics.java
@@ -82,7 +82,7 @@ public class ReplicationMetrics extends AbstractMetricsImpl implements Replicati
     for (ReplicationTarget configuredTarget : allConfiguredTargets) {
       Long numFiles = targetCounts.get(configuredTarget);
 
-      if (null != numFiles) {
+      if (numFiles != null) {
         filesPending += numFiles;
       }
     }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/replication/DistributedWorkQueueWorkAssigner.java b/server/master/src/main/java/org/apache/accumulo/master/replication/DistributedWorkQueueWorkAssigner.java
index bf0e0d4..2b34cfe 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/replication/DistributedWorkQueueWorkAssigner.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/replication/DistributedWorkQueueWorkAssigner.java
@@ -126,13 +126,13 @@ public abstract class DistributedWorkQueueWorkAssigner implements WorkAssigner {
 
   @Override
   public void assignWork() {
-    if (null == workQueue) {
+    if (workQueue == null) {
       initializeWorkQueue(conf);
     }
 
     initializeQueuedWork();
 
-    if (null == zooCache) {
+    if (zooCache == null) {
       zooCache = new ZooCache(workQueue.getZooReaderWriter());
     }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/replication/FinishedWorkUpdater.java b/server/master/src/main/java/org/apache/accumulo/master/replication/FinishedWorkUpdater.java
index b03b0bb..9eb749a 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/replication/FinishedWorkUpdater.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/replication/FinishedWorkUpdater.java
@@ -137,7 +137,7 @@ public class FinishedWorkUpdater implements Runnable {
         for (Entry<Table.ID,Long> entry : tableIdToProgress.entrySet()) {
           // If the progress is 0, then no one has replicated anything, and we don't need to update
           // anything
-          if (0 == entry.getValue()) {
+          if (entry.getValue() == 0) {
             continue;
           }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/replication/RemoveCompleteReplicationRecords.java b/server/master/src/main/java/org/apache/accumulo/master/replication/RemoveCompleteReplicationRecords.java
index 840ab1d..47bc64d 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/replication/RemoveCompleteReplicationRecords.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/replication/RemoveCompleteReplicationRecords.java
@@ -92,10 +92,10 @@ public class RemoveCompleteReplicationRecords implements Runnable {
       sw.start();
       recordsRemoved = removeCompleteRecords(client, bs, bw);
     } finally {
-      if (null != bs) {
+      if (bs != null) {
         bs.close();
       }
-      if (null != bw) {
+      if (bw != null) {
         try {
           bw.close();
         } catch (MutationsRejectedException e) {
@@ -190,7 +190,7 @@ public class RemoveCompleteReplicationRecords implements Runnable {
 
       if (status.hasCreatedTime()) {
         Long timeClosed = tableToTimeCreated.get(tableId);
-        if (null == timeClosed) {
+        if (timeClosed == null) {
           tableToTimeCreated.put(tableId, status.getCreatedTime());
         } else if (timeClosed != status.getCreatedTime()) {
           log.warn("Found multiple values for timeClosed for {}: {} and {}", row, timeClosed,
diff --git a/server/master/src/main/java/org/apache/accumulo/master/replication/ReplicationDriver.java b/server/master/src/main/java/org/apache/accumulo/master/replication/ReplicationDriver.java
index d2d2bc1..99e0d3f 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/replication/ReplicationDriver.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/replication/ReplicationDriver.java
@@ -62,7 +62,7 @@ public class ReplicationDriver extends Daemon {
     log.debug("Starting replication loop");
 
     while (master.stillMaster()) {
-      if (null == workMaker) {
+      if (workMaker == null) {
         client = master.getContext();
         statusMaker = new StatusMaker(client, master.getFileSystem());
         workMaker = new WorkMaker(master.getContext(), client);
diff --git a/server/master/src/main/java/org/apache/accumulo/master/replication/SequentialWorkAssigner.java b/server/master/src/main/java/org/apache/accumulo/master/replication/SequentialWorkAssigner.java
index 6555b9b..61524f5 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/replication/SequentialWorkAssigner.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/replication/SequentialWorkAssigner.java
@@ -82,7 +82,7 @@ public class SequentialWorkAssigner extends DistributedWorkQueueWorkAssigner {
    */
   @Override
   protected void initializeQueuedWork() {
-    if (null != queuedWorkByPeerName) {
+    if (queuedWorkByPeerName != null) {
       return;
     }
 
@@ -107,7 +107,7 @@ public class SequentialWorkAssigner extends DistributedWorkQueueWorkAssigner {
           sourceTableId, peerName);
 
       Map<Table.ID,String> replicationForPeer = queuedWorkByPeerName.get(peerName);
-      if (null == replicationForPeer) {
+      if (replicationForPeer == null) {
         replicationForPeer = new HashMap<>();
         queuedWorkByPeerName.put(peerName, replicationForPeer);
       }
@@ -141,8 +141,8 @@ public class SequentialWorkAssigner extends DistributedWorkQueueWorkAssigner {
         // tableID -> workKey
         Entry<Table.ID,String> entry = iter.next();
         // Null equates to the work for this target was finished
-        if (null == zooCache.get(ZooUtil.getRoot(instanceId) + ReplicationConstants.ZOO_WORK_QUEUE
-            + "/" + entry.getValue())) {
+        if (zooCache.get(ZooUtil.getRoot(instanceId) + ReplicationConstants.ZOO_WORK_QUEUE + "/"
+            + entry.getValue()) == null) {
           log.debug("Removing {} from work assignment state", entry.getValue());
           iter.remove();
           elementsRemoved++;
@@ -162,27 +162,27 @@ public class SequentialWorkAssigner extends DistributedWorkQueueWorkAssigner {
   @Override
   protected boolean shouldQueueWork(ReplicationTarget target) {
     Map<Table.ID,String> queuedWorkForPeer = this.queuedWorkByPeerName.get(target.getPeerName());
-    if (null == queuedWorkForPeer) {
+    if (queuedWorkForPeer == null) {
       return true;
     }
 
     String queuedWork = queuedWorkForPeer.get(target.getSourceTableId());
 
     // If we have no work for the local table to the given peer, submit some!
-    return null == queuedWork;
+    return queuedWork == null;
   }
 
   @Override
   protected boolean queueWork(Path path, ReplicationTarget target) {
     String queueKey = DistributedWorkQueueWorkAssignerHelper.getQueueKey(path.getName(), target);
     Map<Table.ID,String> workForPeer = this.queuedWorkByPeerName.get(target.getPeerName());
-    if (null == workForPeer) {
+    if (workForPeer == null) {
       workForPeer = new HashMap<>();
       this.queuedWorkByPeerName.put(target.getPeerName(), workForPeer);
     }
 
     String queuedWork = workForPeer.get(target.getSourceTableId());
-    if (null == queuedWork) {
+    if (queuedWork == null) {
       try {
         workQueue.addWork(queueKey, path.toString());
         workForPeer.put(target.getSourceTableId(), queueKey);
@@ -206,12 +206,12 @@ public class SequentialWorkAssigner extends DistributedWorkQueueWorkAssigner {
   @Override
   protected Set<String> getQueuedWork(ReplicationTarget target) {
     Map<Table.ID,String> queuedWorkForPeer = this.queuedWorkByPeerName.get(target.getPeerName());
-    if (null == queuedWorkForPeer) {
+    if (queuedWorkForPeer == null) {
       return Collections.emptySet();
     }
 
     String queuedWork = queuedWorkForPeer.get(target.getSourceTableId());
-    if (null == queuedWork) {
+    if (queuedWork == null) {
       return Collections.emptySet();
     } else {
       return Collections.singleton(queuedWork);
@@ -221,7 +221,7 @@ public class SequentialWorkAssigner extends DistributedWorkQueueWorkAssigner {
   @Override
   protected void removeQueuedWork(ReplicationTarget target, String queueKey) {
     Map<Table.ID,String> queuedWorkForPeer = this.queuedWorkByPeerName.get(target.getPeerName());
-    if (null == queuedWorkForPeer) {
+    if (queuedWorkForPeer == null) {
       log.warn("removeQueuedWork called when no work was queued for {}", target.getPeerName());
       return;
     }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/replication/StatusMaker.java b/server/master/src/main/java/org/apache/accumulo/master/replication/StatusMaker.java
index c19acd2..f82e707 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/replication/StatusMaker.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/replication/StatusMaker.java
@@ -99,7 +99,7 @@ public class StatusMaker {
       Text file = new Text();
       for (Entry<Key,Value> entry : s) {
         // Get a writer to the replication table
-        if (null == replicationWriter) {
+        if (replicationWriter == null) {
           // Ensures table is online
           try {
             ReplicationTable.setOnline(client);
@@ -261,7 +261,7 @@ public class StatusMaker {
    */
   protected void deleteStatusRecord(Key k) {
     log.debug("Deleting {} from metadata table as it's no longer needed", k.toStringNoTruncate());
-    if (null == metadataWriter) {
+    if (metadataWriter == null) {
       try {
         metadataWriter = client.createBatchWriter(sourceTableName, new BatchWriterConfig());
       } catch (TableNotFoundException e) {
diff --git a/server/master/src/main/java/org/apache/accumulo/master/replication/UnorderedWorkAssigner.java b/server/master/src/main/java/org/apache/accumulo/master/replication/UnorderedWorkAssigner.java
index 73ddc3b..a1cb36e 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/replication/UnorderedWorkAssigner.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/replication/UnorderedWorkAssigner.java
@@ -76,7 +76,7 @@ public class UnorderedWorkAssigner extends DistributedWorkQueueWorkAssigner {
    */
   @Override
   protected void initializeQueuedWork() {
-    if (null != queuedWork) {
+    if (queuedWork != null) {
       return;
     }
 
@@ -141,8 +141,8 @@ public class UnorderedWorkAssigner extends DistributedWorkQueueWorkAssigner {
     while (work.hasNext()) {
       String filename = work.next();
       // Null equates to the work was finished
-      if (null == zooCache.get(
-          ZooUtil.getRoot(instanceId) + ReplicationConstants.ZOO_WORK_QUEUE + "/" + filename)) {
+      if (zooCache.get(ZooUtil.getRoot(instanceId) + ReplicationConstants.ZOO_WORK_QUEUE + "/"
+          + filename) == null) {
         work.remove();
       }
     }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/replication/WorkDriver.java b/server/master/src/main/java/org/apache/accumulo/master/replication/WorkDriver.java
index b9e9e60..94937e1 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/replication/WorkDriver.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/replication/WorkDriver.java
@@ -55,7 +55,7 @@ public class WorkDriver extends Daemon {
   protected void configureWorkAssigner() {
     String workAssignerClass = conf.get(Property.REPLICATION_WORK_ASSIGNER);
 
-    if (null == assigner || !assigner.getClass().getName().equals(workAssignerClass)) {
+    if (assigner == null || !assigner.getClass().getName().equals(workAssignerClass)) {
       log.info("Initializing work assigner implementation of {}", workAssignerClass);
 
       try {
diff --git a/server/master/src/main/java/org/apache/accumulo/master/replication/WorkMaker.java b/server/master/src/main/java/org/apache/accumulo/master/replication/WorkMaker.java
index e64757a..309378f 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/replication/WorkMaker.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/replication/WorkMaker.java
@@ -77,7 +77,7 @@ public class WorkMaker {
       final Scanner s;
       try {
         s = ReplicationTable.getScanner(client);
-        if (null == writer) {
+        if (writer == null) {
           setBatchWriter(ReplicationTable.getBatchWriter(client));
         }
       } catch (ReplicationTableOfflineException e) {
@@ -117,7 +117,7 @@ public class WorkMaker {
         tableConf = context.getServerConfFactory().getTableConfiguration(tableId);
 
         // getTableConfiguration(String) returns null if the table no longer exists
-        if (null == tableConf) {
+        if (tableConf == null) {
           continue;
         }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer1/LoadFiles.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer1/LoadFiles.java
index de036a1..2b6b81a 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer1/LoadFiles.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer1/LoadFiles.java
@@ -140,7 +140,7 @@ class LoadFiles extends MasterRepo {
       final Random random = new SecureRandom();
       final TServerInstance[] servers;
       String prop = conf.get(Property.MASTER_BULK_TSERVER_REGEX);
-      if (null == prop || "".equals(prop)) {
+      if (prop == null || "".equals(prop)) {
         servers = master.onlineTabletServers().toArray(new TServerInstance[0]);
       } else {
         Pattern regex = Pattern.compile(prop);
@@ -150,7 +150,7 @@ class LoadFiles extends MasterRepo {
             subset.add(t);
           }
         });
-        if (0 == subset.size()) {
+        if (subset.size() == 0) {
           log.warn("There are no tablet servers online that match supplied regex: {}",
               conf.get(Property.MASTER_BULK_TSERVER_REGEX));
         }
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/EmbeddedWebServer.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/EmbeddedWebServer.java
index 69222ab..18cde9f 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/EmbeddedWebServer.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/EmbeddedWebServer.java
@@ -89,7 +89,7 @@ public class EmbeddedWebServer {
       }
 
       final String includeProtocols = conf.get(Property.MONITOR_SSL_INCLUDE_PROTOCOLS);
-      if (null != includeProtocols && !includeProtocols.isEmpty()) {
+      if (includeProtocols != null && !includeProtocols.isEmpty()) {
         sslContextFactory.setIncludeProtocols(StringUtils.split(includeProtocols, ','));
       }
 
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/Monitor.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/Monitor.java
index 65944d7..3c3d6af 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/Monitor.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/Monitor.java
@@ -255,7 +255,7 @@ public class Monitor implements HighlyAvailableService {
             synchronized (Monitor.class) {
               if (cachedInstanceName.get().equals(DEFAULT_INSTANCE_NAME)) {
                 final String instanceName = context.getInstanceName();
-                if (null != instanceName) {
+                if (instanceName != null) {
                   cachedInstanceName.set(instanceName);
                 }
               }
@@ -496,7 +496,7 @@ public class Monitor implements HighlyAvailableService {
       log.error("Unable to set monitor HTTP address in zookeeper", ex);
     }
 
-    if (null != advertiseHost) {
+    if (advertiseHost != null) {
       LogService.startLogListener(context, advertiseHost);
     } else {
       log.warn("Not starting log4j listener as we could not determine address to use");
@@ -632,7 +632,7 @@ public class Monitor implements HighlyAvailableService {
     if (zoo.exists(monitorPath)) {
       byte[] data = zoo.getData(monitorPath, null);
       // If the node isn't empty, it's from a previous install (has hostname:port for HTTP server)
-      if (0 != data.length) {
+      if (data.length != 0) {
         // Recursively delete from that parent node
         zoo.recursiveDelete(monitorPath, NodeMissingPolicy.SKIP);
 
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/ZooKeeperStatus.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/ZooKeeperStatus.java
index 25ae353..3ebb9ac 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/ZooKeeperStatus.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/ZooKeeperStatus.java
@@ -64,7 +64,7 @@ public class ZooKeeperStatus implements Runnable {
     @Override
     public boolean equals(Object obj) {
       return obj == this
-          || (obj != null && obj instanceof ZooKeeperState && 0 == compareTo((ZooKeeperState) obj));
+          || (obj != null && obj instanceof ZooKeeperState && compareTo((ZooKeeperState) obj) == 0);
     }
 
     @Override
@@ -76,9 +76,9 @@ public class ZooKeeperStatus implements Runnable {
       } else {
         if (this.keeper == other.keeper) {
           return 0;
-        } else if (null == this.keeper) {
+        } else if (this.keeper == null) {
           return -1;
-        } else if (null == other.keeper) {
+        } else if (other.keeper == null) {
           return 1;
         } else {
           return this.keeper.compareTo(other.keeper);
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/XMLResource.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/XMLResource.java
index d821707..c8cf7a4 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/XMLResource.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/XMLResource.java
@@ -47,7 +47,7 @@ public class XMLResource {
   public SummaryInformation getInformation() {
 
     MasterMonitorInfo mmi = Monitor.getMmi();
-    if (null == mmi) {
+    if (mmi == null) {
       throw new WebApplicationException(Status.INTERNAL_SERVER_ERROR);
     }
 
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/gc/GarbageCollectorResource.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/gc/GarbageCollectorResource.java
index ef612fa..5cdc58a 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/gc/GarbageCollectorResource.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/gc/GarbageCollectorResource.java
@@ -52,7 +52,7 @@ public class GarbageCollectorResource {
   @GET
   public GarbageCollection getFileStatus() {
     GCStatus gcStatus = Monitor.getGcStatus();
-    if (null == gcStatus) {
+    if (gcStatus == null) {
       return GarbageCollection.getEmpty();
     }
     return new GarbageCollection(gcStatus.last, gcStatus.current);
@@ -67,7 +67,7 @@ public class GarbageCollectorResource {
   @GET
   public GarbageCollectorCycle getLastCycle() {
     GCStatus status = Monitor.getGcStatus();
-    if (null == status) {
+    if (status == null) {
       return GarbageCollectorCycle.getEmpty();
     }
     return new GarbageCollectorCycle(status.last);
@@ -82,7 +82,7 @@ public class GarbageCollectorResource {
   @GET
   public GarbageCollectorCycle getCurrentCycle() {
     GCStatus status = Monitor.getGcStatus();
-    if (null == status) {
+    if (status == null) {
       return GarbageCollectorCycle.getEmpty();
     }
     return new GarbageCollectorCycle(status.current);
@@ -97,7 +97,7 @@ public class GarbageCollectorResource {
   @GET
   public GarbageCollection getWalStatus() {
     GCStatus gcStatus = Monitor.getGcStatus();
-    if (null == gcStatus) {
+    if (gcStatus == null) {
       return GarbageCollection.getEmpty();
     }
     return new GarbageCollection(gcStatus.lastLog, gcStatus.currentLog);
@@ -112,7 +112,7 @@ public class GarbageCollectorResource {
   @GET
   public GarbageCollectorCycle getLastWalCycle() {
     GCStatus status = Monitor.getGcStatus();
-    if (null == status) {
+    if (status == null) {
       return GarbageCollectorCycle.getEmpty();
     }
     return new GarbageCollectorCycle(status.lastLog);
@@ -127,7 +127,7 @@ public class GarbageCollectorResource {
   @GET
   public GarbageCollectorCycle getCurrentWalCycle() {
     GCStatus status = Monitor.getGcStatus();
-    if (null == status) {
+    if (status == null) {
       return GarbageCollectorCycle.getEmpty();
     }
     return new GarbageCollectorCycle(status.currentLog);
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/gc/GarbageCollectorStatus.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/gc/GarbageCollectorStatus.java
index df16848..0282838 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/gc/GarbageCollectorStatus.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/gc/GarbageCollectorStatus.java
@@ -40,7 +40,7 @@ public class GarbageCollectorStatus {
    *          garbage collector status
    */
   public GarbageCollectorStatus(GCStatus status) {
-    if (null != status) {
+    if (status != null) {
       files = new GarbageCollection(status.last, status.current);
       wals = new GarbageCollection(status.lastLog, status.currentLog);
     }
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/master/MasterResource.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/master/MasterResource.java
index d28a7e0..252a4d1 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/master/MasterResource.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/master/MasterResource.java
@@ -135,7 +135,7 @@ public class MasterResource {
    */
   public static String getState() {
     MasterMonitorInfo mmi = getMmi();
-    if (null == mmi) {
+    if (mmi == null) {
       return NO_MASTERS;
     }
     return mmi.state.toString();
@@ -148,7 +148,7 @@ public class MasterResource {
    */
   public static String getGoalState() {
     MasterMonitorInfo mmi = getMmi();
-    if (null == mmi) {
+    if (mmi == null) {
       return NO_MASTERS;
     }
     return mmi.goalState.name();
@@ -161,7 +161,7 @@ public class MasterResource {
    */
   public static DeadServerList getDeadTservers() {
     MasterMonitorInfo mmi = getMmi();
-    if (null == mmi) {
+    if (mmi == null) {
       return new DeadServerList();
     }
 
@@ -181,7 +181,7 @@ public class MasterResource {
    */
   public static DeadLoggerList getDeadLoggers() {
     MasterMonitorInfo mmi = getMmi();
-    if (null == mmi) {
+    if (mmi == null) {
       return new DeadLoggerList();
     }
 
@@ -201,13 +201,13 @@ public class MasterResource {
    */
   public static BadTabletServers getNumBadTservers() {
     MasterMonitorInfo mmi = getMmi();
-    if (null == mmi) {
+    if (mmi == null) {
       return new BadTabletServers();
     }
 
     Map<String,Byte> badServers = mmi.getBadTServers();
 
-    if (null == badServers || badServers.isEmpty()) {
+    if (badServers == null || badServers.isEmpty()) {
       return new BadTabletServers();
     }
 
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/replication/ReplicationResource.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/replication/ReplicationResource.java
index 03f134a..9e25d39 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/replication/ReplicationResource.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/replication/ReplicationResource.java
@@ -120,7 +120,7 @@ public class ReplicationResource {
         continue;
       }
       Table.ID localId = tableNameToId.get(table);
-      if (null == localId) {
+      if (localId == null) {
         log.trace("Could not determine ID for {}", table);
         continue;
       }
@@ -165,7 +165,7 @@ public class ReplicationResource {
         // TODO ACCUMULO-2835 once explicit lengths are tracked, we can give size-based estimates
         // instead of just file-based
         Long count = targetCounts.get(target);
-        if (null == count) {
+        if (count == null) {
           targetCounts.put(target, 1L);
         } else {
           targetCounts.put(target, count + 1);
@@ -178,13 +178,13 @@ public class ReplicationResource {
     List<ReplicationInformation> replicationInformation = new ArrayList<>();
     for (ReplicationTarget configuredTarget : allConfiguredTargets) {
       String tableName = tableIdToName.get(configuredTarget.getSourceTableId());
-      if (null == tableName) {
+      if (tableName == null) {
         log.trace("Could not determine table name from id {}", configuredTarget.getSourceTableId());
         continue;
       }
 
       String replicaSystemClass = peers.get(configuredTarget.getPeerName());
-      if (null == replicaSystemClass) {
+      if (replicaSystemClass == null) {
         log.trace("Could not determine configured ReplicaSystem for {}",
             configuredTarget.getPeerName());
         continue;
@@ -194,7 +194,7 @@ public class ReplicationResource {
 
       replicationInformation.add(new ReplicationInformation(tableName,
           configuredTarget.getPeerName(), configuredTarget.getRemoteIdentifier(),
-          replicaSystemClass, (null == numFiles) ? 0 : numFiles));
+          replicaSystemClass, (numFiles == null) ? 0 : numFiles));
     }
 
     return replicationInformation;
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/status/StatusResource.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/status/StatusResource.java
index 4bde31d..03b6750 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/status/StatusResource.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/status/StatusResource.java
@@ -93,7 +93,7 @@ public class StatusResource {
       }
     } else {
       masterStatus = Status.ERROR;
-      if (null == Monitor.getGcStatus()) {
+      if (Monitor.getGcStatus() == null) {
         gcStatus = Status.ERROR;
       } else {
         gcStatus = Status.OK;
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/tables/TableInformation.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/tables/TableInformation.java
index 8f6f062..c862088 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/tables/TableInformation.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/tables/TableInformation.java
@@ -145,7 +145,7 @@ public class TableInformation {
 
     this.holdTime = holdTime;
 
-    if (null != info.scans) {
+    if (info.scans != null) {
       this.queuedScans = info.scans.queued;
       this.runningScans = info.scans.running;
       this.scansCombo = info.scans.running + "(" + info.scans.queued + ")";
@@ -155,7 +155,7 @@ public class TableInformation {
       this.scansCombo = ZERO_COMBO;
     }
 
-    if (null != info.minors) {
+    if (info.minors != null) {
       this.queuedMinorCompactions = info.minors.queued;
       this.runningMinorCompactions = info.minors.running;
       this.minorCombo = info.minors.running + "(" + info.minors.queued + ")";
@@ -165,7 +165,7 @@ public class TableInformation {
       this.minorCombo = ZERO_COMBO;
     }
 
-    if (null != info.majors) {
+    if (info.majors != null) {
       this.queuedMajorCompactions = info.majors.queued;
       this.runningMajorCompactions = info.majors.running;
       this.majorCombo = info.majors.running + "(" + info.majors.queued + ")";
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/tables/TablesResource.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/tables/TablesResource.java
index a01dca2..53ed37b 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/tables/TablesResource.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/tables/TablesResource.java
@@ -89,7 +89,7 @@ public class TablesResource {
       TableInfo tableInfo = tableStats.get(tableId);
       TableState tableState = tableManager.getTableState(tableId);
 
-      if (null != tableInfo && !tableState.equals(TableState.OFFLINE)) {
+      if (tableInfo != null && !tableState.equals(TableState.OFFLINE)) {
         Double holdTime = compactingByTable.get(tableId.canonicalID());
         if (holdTime == null)
           holdTime = 0.;
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/trace/TracesResource.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/trace/TracesResource.java
index 76ee863..7d83ea1 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/trace/TracesResource.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/trace/TracesResource.java
@@ -105,7 +105,7 @@ public class TracesResource {
       scanner.setRange(range);
 
       final Map<String,RecentTracesInformation> summary = new TreeMap<>();
-      if (null != pair.getSecond()) {
+      if (pair.getSecond() != null) {
         pair.getSecond().doAs((PrivilegedAction<Void>) () -> {
           parseSpans(scanner, summary);
           return null;
@@ -157,7 +157,7 @@ public class TracesResource {
 
       scanner.setRange(range);
 
-      if (null != pair.getSecond()) {
+      if (pair.getSecond() != null) {
         pair.getSecond().doAs((PrivilegedAction<Void>) () -> {
           for (Entry<Key,Value> entry : scanner) {
             RemoteSpan span = TraceFormatter.getRemoteSpan(entry);
@@ -213,7 +213,7 @@ public class TracesResource {
       final SpanTree tree = new SpanTree();
       long start;
 
-      if (null != pair.getSecond()) {
+      if (pair.getSecond() != null) {
         start = pair.getSecond()
             .doAs((PrivilegedAction<Long>) () -> addSpans(scanner, tree, Long.MAX_VALUE));
       } else {
@@ -307,7 +307,7 @@ public class TracesResource {
       keytab = conf.getPath(Property.GENERAL_KERBEROS_KEYTAB);
     }
 
-    if (saslEnabled && null != keytab) {
+    if (saslEnabled && keytab != null) {
       principal = SecurityUtil.getServerPrincipal(conf.get(Property.TRACE_USER));
       try {
         traceUgi = UserGroupInformation.loginUserFromKeytabAndReturnUGI(principal, keytab);
@@ -340,7 +340,7 @@ public class TracesResource {
 
     java.util.Properties props = Monitor.getContext().getProperties();
     AccumuloClient client;
-    if (null != traceUgi) {
+    if (traceUgi != null) {
       try {
         client = traceUgi.doAs((PrivilegedExceptionAction<AccumuloClient>) () -> {
           // Make the KerberosToken inside the doAs
@@ -351,7 +351,7 @@ public class TracesResource {
         throw new RuntimeException("Failed to obtain scanner", e);
       }
     } else {
-      if (null == at) {
+      if (at == null) {
         throw new AssertionError("AuthenticationToken should not be null");
       }
       client = Accumulo.newClient().from(props).as(principal, at).build();
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/tservers/TabletServerResource.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/tservers/TabletServerResource.java
index 3df217b..23a0e25 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/tservers/TabletServerResource.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/tservers/TabletServerResource.java
@@ -78,7 +78,7 @@ public class TabletServerResource {
   @GET
   public TabletServers getTserverSummary() {
     MasterMonitorInfo mmi = Monitor.getMmi();
-    if (null == mmi) {
+    if (mmi == null) {
       throw new WebApplicationException(Status.INTERNAL_SERVER_ERROR);
     }
 
@@ -118,7 +118,7 @@ public class TabletServerResource {
     TabletServersRecovery recoveryList = new TabletServersRecovery();
 
     MasterMonitorInfo mmi = Monitor.getMmi();
-    if (null == mmi) {
+    if (mmi == null) {
       throw new WebApplicationException(Status.INTERNAL_SERVER_ERROR);
     }
 
diff --git a/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceDump.java b/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceDump.java
index c26d761..6596fca 100644
--- a/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceDump.java
+++ b/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceDump.java
@@ -129,7 +129,7 @@ public class TraceDump {
       if (span.parentId == Span.ROOT_SPAN_ID)
         count++;
     }
-    if (Long.MAX_VALUE == start) {
+    if (start == Long.MAX_VALUE) {
       out.print("Did not find any traces!");
       return 0;
     }
diff --git a/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceServer.java b/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceServer.java
index 99d3e4e..eac6d30 100644
--- a/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceServer.java
+++ b/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceServer.java
@@ -167,7 +167,7 @@ public class TraceServer implements Watcher, AutoCloseable {
          * Check for null, because we expect spans to come in much faster than flush calls. In the
          * case of failure, we'd rather avoid logging tons of NPEs.
          */
-        if (null == writer) {
+        if (writer == null) {
           log.warn("writer is not ready; discarding span.");
           return;
         }
@@ -216,7 +216,7 @@ public class TraceServer implements Watcher, AutoCloseable {
         log.warn("Unable to start trace server on port {}", port);
       }
     }
-    if (null == sock) {
+    if (sock == null) {
       throw new RuntimeException(
           "Unable to start trace server on configured ports: " + Arrays.toString(ports));
     }
@@ -312,7 +312,7 @@ public class TraceServer implements Watcher, AutoCloseable {
   private void flush() {
     try {
       final BatchWriter writer = this.writer.get();
-      if (null != writer) {
+      if (writer != null) {
         writer.flush();
       } else {
         // We don't have a writer. If the table exists, try to make a new writer.
@@ -342,7 +342,7 @@ public class TraceServer implements Watcher, AutoCloseable {
       /* Trade in the new writer (even if null) for the one we need to close. */
       writer = this.writer.getAndSet(writer);
       try {
-        if (null != writer) {
+        if (writer != null) {
           writer.close();
         }
       } catch (Exception ex) {
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/ActiveAssignmentRunnable.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/ActiveAssignmentRunnable.java
index a42e6e5..30b012c 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/ActiveAssignmentRunnable.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/ActiveAssignmentRunnable.java
@@ -73,7 +73,7 @@ public class ActiveAssignmentRunnable implements Runnable {
 
   public Exception getException() {
     final Exception e = new Exception("Assignment of " + extent);
-    if (null != executingThread) {
+    if (executingThread != null) {
       e.setStackTrace(executingThread.getStackTrace());
     }
     return e;
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/NativeMap.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/NativeMap.java
index 15fc4c3..1023bd0 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/NativeMap.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/NativeMap.java
@@ -350,7 +350,7 @@ public class NativeMap implements Iterable<Map.Entry<Key,Value>> {
           source.delete();
           source = new NMIterator(ret.getKey());
           fill();
-          if (0 < end && nextEntries.get(0).getKey().equals(ret.getKey())) {
+          if (end > 0 && nextEntries.get(0).getKey().equals(ret.getKey())) {
             index++;
             if (index == end) {
               fill();
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
index 97cdc9b..6d80347 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
@@ -1999,7 +1999,7 @@ public class TabletServer implements Runnable {
     public List<String> getActiveLogs(TInfo tinfo, TCredentials credentials) throws TException {
       String log = logger.getLogFile();
       // Might be null if there no active logger
-      if (null == log) {
+      if (log == null) {
         return Collections.emptyList();
       }
       return Collections.singletonList(log);
@@ -2653,7 +2653,7 @@ public class TabletServer implements Runnable {
     clientHandler = new ThriftClientHandler();
     Iface rpcProxy = TraceWrap.service(clientHandler);
     final Processor<Iface> processor;
-    if (ThriftServerType.SASL == context.getThriftServerType()) {
+    if (context.getThriftServerType() == ThriftServerType.SASL) {
       Iface tcredProxy = TCredentialsUpdatingWrapper.service(rpcProxy, ThriftClientHandler.class,
           getConfiguration());
       processor = new Processor<>(tcredProxy);
@@ -2714,7 +2714,7 @@ public class TabletServer implements Runnable {
       try {
         zoo.putPersistentData(zPath, new byte[] {}, NodeExistsPolicy.SKIP);
       } catch (KeeperException e) {
-        if (KeeperException.Code.NOAUTH == e.code()) {
+        if (e.code() == KeeperException.Code.NOAUTH) {
           log.error("Failed to write to ZooKeeper. Ensure that"
               + " accumulo.properties, specifically instance.secret, is consistent.");
         }
@@ -2799,7 +2799,7 @@ public class TabletServer implements Runnable {
       log.error("Error registering with JMX", e);
     }
 
-    if (null != authKeyWatcher) {
+    if (authKeyWatcher != null) {
       log.info("Seeding ZooKeeper watcher for authentication keys");
       try {
         authKeyWatcher.updateAuthKeys();
@@ -3139,7 +3139,7 @@ public class TabletServer implements Runnable {
   }
 
   public String getReplicationAddressSTring() {
-    if (null == replicationAddress) {
+    if (replicationAddress == null) {
       return null;
     }
     return replicationAddress.getHost() + ":" + replicationAddress.getPort();
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServerResourceManager.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServerResourceManager.java
index 6c26931..f7dc2e4 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServerResourceManager.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServerResourceManager.java
@@ -729,7 +729,7 @@ public class TabletServerResourceManager {
       executorService.shutdown();
     }
 
-    if (null != this.cacheManager) {
+    if (this.cacheManager != null) {
       try {
         this.cacheManager.stop();
       } catch (Exception ex) {
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/DfsLogger.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/DfsLogger.java
index a0bebab..522cc70 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/DfsLogger.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/DfsLogger.java
@@ -485,7 +485,7 @@ public class DfsLogger implements Comparable<DfsLogger> {
    * get the cq needed to reference this logger's entry in +r/!0
    */
   public String getMeta() {
-    if (null == metaReference) {
+    if (metaReference == null) {
       throw new IllegalStateException("logger doesn't have meta reference. " + this);
     }
     return metaReference;
@@ -664,7 +664,7 @@ public class DfsLogger implements Comparable<DfsLogger> {
    * @return non-null array of DatanodeInfo
    */
   DatanodeInfo[] getPipeLine() {
-    if (null != logFile) {
+    if (logFile != null) {
       OutputStream os = logFile.getWrappedStream();
       if (os instanceof DFSOutputStream) {
         return ((DFSOutputStream) os).getPipeline();
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/LogSorter.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/LogSorter.java
index 8c90930..51379e1 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/LogSorter.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/LogSorter.java
@@ -193,7 +193,7 @@ public class LogSorter {
     synchronized void close() throws IOException {
       // If we receive an empty or malformed-header WAL, we won't
       // have input streams that need closing. Avoid the NPE.
-      if (null != input) {
+      if (input != null) {
         bytesCopied = input.getPos();
         input.close();
         decryptingInput.close();
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/RecoveryLogReader.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/RecoveryLogReader.java
index 718fa98..fb8e0d8 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/RecoveryLogReader.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/RecoveryLogReader.java
@@ -88,7 +88,7 @@ public class RecoveryLogReader implements CloseableIterator<Entry<LogFileKey,Log
 
     @Override
     public boolean equals(Object obj) {
-      return this == obj || (obj != null && obj instanceof Index && 0 == compareTo((Index) obj));
+      return this == obj || (obj != null && obj instanceof Index && compareTo((Index) obj) == 0);
     }
 
     @Override
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/TabletServerLogger.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/TabletServerLogger.java
index 1a1bfa2..101521f 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/TabletServerLogger.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/TabletServerLogger.java
@@ -195,7 +195,7 @@ public class TabletServerLogger {
   public String getLogFile() {
     logIdLock.readLock().lock();
     try {
-      if (null == currentLog) {
+      if (currentLog == null) {
         return null;
       }
       return currentLog.getFileName();
@@ -225,7 +225,7 @@ public class TabletServerLogger {
         log.info("Using next log {}", currentLog.getFileName());
 
         // When we successfully create a WAL, make sure to reset the Retry.
-        if (null != createRetry) {
+        if (createRetry != null) {
           createRetry = null;
         }
 
@@ -235,7 +235,7 @@ public class TabletServerLogger {
         throw new RuntimeException("Error: unexpected type seen: " + next);
       }
     } catch (Exception t) {
-      if (null == createRetry) {
+      if (createRetry == null) {
         createRetry = createRetryFactory.createRetry();
       }
 
@@ -286,7 +286,7 @@ public class TabletServerLogger {
             }
           } catch (Exception t) {
             log.error("Failed to open WAL", t);
-            if (null != alog) {
+            if (alog != null) {
               // It's possible that the sync of the header and OPEN record to the WAL failed
               // We want to make sure that clean up the resources/thread inside the DfsLogger
               // object before trying to create a new one.
@@ -321,7 +321,7 @@ public class TabletServerLogger {
       throw new IllegalStateException("close should be called with write lock held!");
     }
     try {
-      if (null != currentLog) {
+      if (currentLog != null) {
         try {
           currentLog.close();
         } catch (DfsLogger.LogClosedException ex) {
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystem.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystem.java
index 4a4ea0e..b89e04a 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystem.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystem.java
@@ -138,7 +138,7 @@ public class AccumuloReplicaSystem implements ReplicaSystem {
 
     // instance_name,zookeepers
     int index = configuration.indexOf(',');
-    if (-1 == index) {
+    if (index == -1) {
       try {
         Thread.sleep(1000);
       } catch (InterruptedException e) {
@@ -184,7 +184,7 @@ public class AccumuloReplicaSystem implements ReplicaSystem {
       password = getPassword(localConf, target);
     }
 
-    if (null != keytab) {
+    if (keytab != null) {
       try {
         final UserGroupInformation accumuloUgi = UserGroupInformation.getCurrentUser();
         // Get a UGI with the principal + keytab
@@ -270,7 +270,7 @@ public class AccumuloReplicaSystem implements ReplicaSystem {
           span.stop();
         }
 
-        if (null == peerTserverStr) {
+        if (peerTserverStr == null) {
           // Something went wrong, and we didn't get a valid tserver from the remote for some reason
           log.warn("Did not receive tserver from master at {}, cannot proceed"
               + " with replication. Will retry.", target);
@@ -441,7 +441,7 @@ public class AccumuloReplicaSystem implements ReplicaSystem {
         if (!currentStatus.equals(lastStatus)) {
           span = Trace.start("Update replication table");
           try {
-            if (null != accumuloUgi) {
+            if (accumuloUgi != null) {
               final Status copy = currentStatus;
               accumuloUgi.doAs(new PrivilegedAction<Void>() {
                 @Override
@@ -455,7 +455,7 @@ public class AccumuloReplicaSystem implements ReplicaSystem {
                 }
               });
               Exception e = exceptionRef.get();
-              if (null != e) {
+              if (e != null) {
                 if (e instanceof TableNotFoundException) {
                   throw (TableNotFoundException) e;
                 } else if (e instanceof AccumuloSecurityException) {
@@ -558,11 +558,11 @@ public class AccumuloReplicaSystem implements ReplicaSystem {
 
       log.debug(
           "Read {} WAL entries and retained {} bytes of WAL entries for replication to peer '{}'",
-          (Long.MAX_VALUE == edits.entriesConsumed) ? "all remaining" : edits.entriesConsumed,
+          (edits.entriesConsumed == Long.MAX_VALUE) ? "all remaining" : edits.entriesConsumed,
           edits.sizeInBytes, p);
 
       // If we have some edits to send
-      if (0 < edits.walEdits.getEditsSize()) {
+      if (edits.walEdits.getEditsSize() > 0) {
         log.debug("Sending {} edits", edits.walEdits.getEditsSize());
         long entriesReplicated = client.replicateLog(remoteTableId, edits.walEdits, tcreds);
         if (entriesReplicated != edits.numUpdates) {
@@ -613,7 +613,7 @@ public class AccumuloReplicaSystem implements ReplicaSystem {
     @Override
     public ReplicationStats execute(Client client) throws Exception {
       RFileReplication kvs = getKeyValues(target, input, p, status, sizeLimit);
-      if (0 < kvs.keyValues.getKeyValuesSize()) {
+      if (kvs.keyValues.getKeyValuesSize() > 0) {
         long entriesReplicated = client.replicateKeyValues(remoteTableId, kvs.keyValues, tcreds);
         if (entriesReplicated != kvs.keyValues.getKeyValuesSize()) {
           log.warn(
@@ -638,7 +638,7 @@ public class AccumuloReplicaSystem implements ReplicaSystem {
         .getAllPropertiesWithPrefix(Property.REPLICATION_PEER_PASSWORD);
     String password = peerPasswords
         .get(Property.REPLICATION_PEER_PASSWORD.getKey() + target.getPeerName());
-    if (null == password) {
+    if (password == null) {
       throw new IllegalArgumentException("Cannot get password for " + target.getPeerName());
     }
     return password;
@@ -652,7 +652,7 @@ public class AccumuloReplicaSystem implements ReplicaSystem {
         .getAllPropertiesWithPrefix(Property.REPLICATION_PEER_KEYTAB);
     String keytab = peerKeytabs
         .get(Property.REPLICATION_PEER_KEYTAB.getKey() + target.getPeerName());
-    if (null == keytab) {
+    if (keytab == null) {
       throw new IllegalArgumentException("Cannot get keytab for " + target.getPeerName());
     }
     return keytab;
@@ -668,7 +668,7 @@ public class AccumuloReplicaSystem implements ReplicaSystem {
         .getAllPropertiesWithPrefix(Property.REPLICATION_PEER_USER);
 
     String user = peerUsers.get(userKey);
-    if (null == user) {
+    if (user == null) {
       throw new IllegalArgumentException("Cannot get user for " + target.getPeerName());
     }
     return user;
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/BatchWriterReplicationReplayer.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/BatchWriterReplicationReplayer.java
index f707260..d011213 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/BatchWriterReplicationReplayer.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/BatchWriterReplicationReplayer.java
@@ -79,7 +79,7 @@ public class BatchWriterReplicationReplayer implements AccumuloReplicationReplay
         }
 
         // Create the batchScanner if we don't already have one.
-        if (null == bw) {
+        if (bw == null) {
           BatchWriterConfig bwConfig = new BatchWriterConfig();
           bwConfig.setMaxMemory(memoryInBytes);
           try {
@@ -127,7 +127,7 @@ public class BatchWriterReplicationReplayer implements AccumuloReplicationReplay
 
             // We also need to preserve the replicationSource information to prevent cycles
             Set<String> replicationSources = orig.getReplicationSources();
-            if (null != replicationSources && !replicationSources.isEmpty()) {
+            if (replicationSources != null && !replicationSources.isEmpty()) {
               for (String replicationSource : replicationSources) {
                 copy.addReplicationSource(replicationSource);
               }
@@ -155,7 +155,7 @@ public class BatchWriterReplicationReplayer implements AccumuloReplicationReplay
         mutationsApplied += mutationsCopy.size();
       }
     } finally {
-      if (null != bw) {
+      if (bw != null) {
         try {
           bw.close();
         } catch (MutationsRejectedException e) {
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/ReplicationProcessor.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/ReplicationProcessor.java
index 7498520..9758c04 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/ReplicationProcessor.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/ReplicationProcessor.java
@@ -157,7 +157,7 @@ public class ReplicationProcessor implements Processor {
     Map<String,String> configuredPeers = conf
         .getAllPropertiesWithPrefix(Property.REPLICATION_PEERS);
     String peerType = configuredPeers.get(Property.REPLICATION_PEERS.getKey() + peerName);
-    if (null == peerType) {
+    if (peerType == null) {
       String msg = "Cannot process replication for unknown peer: " + peerName;
       log.warn(msg);
       throw new IllegalArgumentException(msg);
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/ReplicationServicerHandler.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/ReplicationServicerHandler.java
index fc15a14..b0d6592 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/ReplicationServicerHandler.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/ReplicationServicerHandler.java
@@ -74,7 +74,7 @@ public class ReplicationServicerHandler implements Iface {
     String propertyForHandlerTable = Property.TSERV_REPLICATION_REPLAYERS.getKey() + tableId;
 
     String handlerClassForTable = replicationHandlers.get(propertyForHandlerTable);
-    if (null == handlerClassForTable) {
+    if (handlerClassForTable == null) {
       if (!replicationHandlers.isEmpty()) {
         log.debug("Could not find replication replayer for {}", tableId);
       }
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/CompactionRunner.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/CompactionRunner.java
index 5b127d5..ee540a3 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/CompactionRunner.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/CompactionRunner.java
@@ -68,7 +68,7 @@ final class CompactionRunner implements Runnable, Comparable<CompactionRunner> {
   @Override
   public boolean equals(Object obj) {
     return this == obj || (obj != null && obj instanceof CompactionRunner
-        && 0 == compareTo((CompactionRunner) obj));
+        && compareTo((CompactionRunner) obj) == 0);
   }
 
   @Override
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/DatafileManager.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/DatafileManager.java
index 86eea1f..ae5201d 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/DatafileManager.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/DatafileManager.java
@@ -409,7 +409,7 @@ class DatafileManager {
       logFileOnly = new HashSet<>();
       for (String unusedWalLog : unusedWalLogs) {
         int index = unusedWalLog.indexOf('/');
-        if (-1 == index) {
+        if (index == -1) {
           log.warn("Could not find host component to strip from DFSLogger representation of WAL");
         } else {
           unusedWalLog = unusedWalLog.substring(index + 1);
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Scanner.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Scanner.java
index e24c331..3e5e118 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Scanner.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Scanner.java
@@ -133,9 +133,9 @@ public class Scanner {
     } finally {
       // code in finally block because always want
       // to return mapfiles, even when exception is thrown
-      if (null != dataSource && !options.isIsolated()) {
+      if (dataSource != null && !options.isIsolated()) {
         dataSource.close(false);
-      } else if (null != dataSource) {
+      } else if (dataSource != null) {
         dataSource.detachFileManager();
       }
 
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java
index 19d9bb2..facf55d 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java
@@ -341,7 +341,7 @@ public class Tablet implements TabletCommitter {
     this.logId = tabletServer.createLogId();
 
     TableConfiguration tblConf = tabletServer.getTableConfiguration(extent);
-    if (null == tblConf) {
+    if (tblConf == null) {
       Tables.clearCache(tabletServer.getContext());
       tblConf = tabletServer.getTableConfiguration(extent);
       requireNonNull(tblConf, "Could not get table configuration for " + extent.getTableId());
@@ -1648,7 +1648,7 @@ public class Tablet implements TabletCommitter {
 
       // We expect to get a midPoint for this set of files. If we don't get one, we have a problem.
       final Key mid = keys.get(.5);
-      if (null == mid) {
+      if (mid == null) {
         throw new IllegalStateException("Could not determine midpoint for files");
       }
 
diff --git a/shell/src/main/java/org/apache/accumulo/shell/Shell.java b/shell/src/main/java/org/apache/accumulo/shell/Shell.java
index 83eb1193..7f29210 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/Shell.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/Shell.java
@@ -1204,7 +1204,7 @@ public class Shell extends ShellOptions implements KeywordExecutable {
   public Class<? extends Formatter> getFormatter(String tableName) {
     Class<? extends Formatter> formatter = FormatterCommand.getCurrentFormatter(tableName, this);
 
-    if (null == formatter) {
+    if (formatter == null) {
       logError("Could not load the specified formatter. Using the DefaultFormatter");
       return this.defaultFormatterClass;
     } else {
diff --git a/shell/src/main/java/org/apache/accumulo/shell/ShellOptionsJC.java b/shell/src/main/java/org/apache/accumulo/shell/ShellOptionsJC.java
index a1c54b2..8946d77 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/ShellOptionsJC.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/ShellOptionsJC.java
@@ -193,7 +193,7 @@ public class ShellOptionsJC {
   private List<String> unrecognizedOptions;
 
   public String getUsername() throws Exception {
-    if (null == username) {
+    if (username == null) {
       username = getClientProperties().getProperty(ClientProperty.AUTH_PRINCIPAL.getKey());
       if (username == null || username.isEmpty()) {
         if (ClientProperty.SASL_ENABLED.getBoolean(getClientProperties())) {
@@ -297,10 +297,10 @@ public class ShellOptionsJC {
       props.setProperty(ClientProperty.INSTANCE_NAME.getKey(), instanceName);
     }
     // If the user provided the hosts, set the ZK for tracing too
-    if (null != zooKeeperHosts && !zooKeeperHosts.isEmpty()) {
+    if (zooKeeperHosts != null && !zooKeeperHosts.isEmpty()) {
       props.setProperty(ClientProperty.INSTANCE_ZOOKEEPERS.getKey(), zooKeeperHosts);
     }
-    if (null != zooKeeperInstanceName && !zooKeeperInstanceName.isEmpty()) {
+    if (zooKeeperInstanceName != null && !zooKeeperInstanceName.isEmpty()) {
       props.setProperty(ClientProperty.INSTANCE_NAME.getKey(), zooKeeperInstanceName);
     }
     return props;
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/ScanCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/ScanCommand.java
index 3e1d15d..327a1b1 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/ScanCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/ScanCommand.java
@@ -101,7 +101,7 @@ public class ScanCommand extends Command {
       // scan with
       final Authorizations auths = getAuths(cl, shellState);
       final Scanner scanner = shellState.getAccumuloClient().createScanner(tableName, auths);
-      if (null != classLoaderContext) {
+      if (classLoaderContext != null) {
         scanner.setClassLoaderContext(classLoaderContext);
       }
       // handle session-specific scan iterators
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/ScriptCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/ScriptCommand.java
index 3d08661..784439b 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/ScriptCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/ScriptCommand.java
@@ -74,7 +74,7 @@ public class ScriptCommand extends Command {
         engineName = cl.getOptionValue(engine.getOpt());
       }
       ScriptEngine engine = mgr.getEngineByName(engineName);
-      if (null == engine) {
+      if (engine == null) {
         shellState.printException(new Exception(engineName + " not found"));
         return 1;
       }
@@ -126,7 +126,7 @@ public class ScriptCommand extends Command {
       if (cl.hasOption(file.getOpt())) {
         File f = new File(cl.getOptionValue(file.getOpt()));
         if (!f.exists()) {
-          if (null != writer) {
+          if (writer != null) {
             writer.close();
           }
           shellState.printException(new Exception(f.getAbsolutePath() + " not found"));
@@ -143,7 +143,7 @@ public class ScriptCommand extends Command {
           return 1;
         } finally {
           reader.close();
-          if (null != writer) {
+          if (writer != null) {
             writer.close();
           }
         }
@@ -167,12 +167,12 @@ public class ScriptCommand extends Command {
           shellState.printException(ex);
           return 1;
         } finally {
-          if (null != writer) {
+          if (writer != null) {
             writer.close();
           }
         }
       }
-      if (null != writer) {
+      if (writer != null) {
         writer.close();
       }
 
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/SetIterCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/SetIterCommand.java
index 8848d14..d66d88b 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/SetIterCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/SetIterCommand.java
@@ -111,9 +111,9 @@ public class SetIterCommand extends Command {
     String name = cl.getOptionValue(nameOpt.getOpt(), null);
 
     // Cannot continue if no name is provided
-    if (null == name && null == configuredName) {
+    if (name == null && configuredName == null) {
       throw new IllegalArgumentException("No provided or default name for iterator");
-    } else if (null == name) {
+    } else if (name == null) {
       // Fall back to the name from OptionDescriber or user input if none is provided on setiter
       // option
       name = configuredName;
@@ -239,7 +239,7 @@ public class SetIterCommand extends Command {
     }
 
     String iteratorName;
-    if (null != iterOptions) {
+    if (iterOptions != null) {
       final IteratorOptions itopts = iterOptions.describeOptions();
       iteratorName = itopts.getName();
 
@@ -315,7 +315,7 @@ public class SetIterCommand extends Command {
       reader.println("The iterator class does not implement OptionDescriber."
           + " Consider this for better iterator configuration using this setiter" + " command.");
       iteratorName = reader.readLine("Name for iterator (enter to skip): ");
-      if (null == iteratorName) {
+      if (iteratorName == null) {
         reader.println();
         throw new IOException("Input stream closed");
       } else if (StringUtils.isWhitespace(iteratorName)) {
diff --git a/start/src/main/java/org/apache/accumulo/start/classloader/AccumuloClassLoader.java b/start/src/main/java/org/apache/accumulo/start/classloader/AccumuloClassLoader.java
index bd8a46f..ba9d3f3 100644
--- a/start/src/main/java/org/apache/accumulo/start/classloader/AccumuloClassLoader.java
+++ b/start/src/main/java/org/apache/accumulo/start/classloader/AccumuloClassLoader.java
@@ -135,8 +135,8 @@ public class AccumuloClassLoader {
       // Not a valid URI
     }
 
-    if (null == uri || !uri.isAbsolute()
-        || (null != uri.getScheme() && uri.getScheme().equals("file://"))) {
+    if (uri == null || !uri.isAbsolute()
+        || (uri.getScheme() != null && uri.getScheme().equals("file://"))) {
       // Then treat this URI as a File.
       // This checks to see if the url string is a dir if it expand and get all jars in that
       // directory
diff --git a/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java b/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
index cb2e342..5af8c3b 100644
--- a/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
+++ b/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
@@ -197,14 +197,14 @@ public class AccumuloVFSClassLoader {
 
   public static ClassLoader getClassLoader() throws IOException {
     ReloadingClassLoader localLoader = loader;
-    while (null == localLoader) {
+    while (localLoader == null) {
       synchronized (lock) {
-        if (null == loader) {
+        if (loader == null) {
 
           FileSystemManager vfs = generateVfs();
 
           // Set up the 2nd tier class loader
-          if (null == parent) {
+          if (parent == null) {
             parent = AccumuloClassLoader.getClassLoader();
           }
 
diff --git a/start/src/main/java/org/apache/accumulo/start/classloader/vfs/UniqueFileReplicator.java b/start/src/main/java/org/apache/accumulo/start/classloader/vfs/UniqueFileReplicator.java
index fa93664..578d59d 100644
--- a/start/src/main/java/org/apache/accumulo/start/classloader/vfs/UniqueFileReplicator.java
+++ b/start/src/main/java/org/apache/accumulo/start/classloader/vfs/UniqueFileReplicator.java
@@ -99,7 +99,7 @@ public class UniqueFileReplicator implements VfsComponent, FileReplicator {
     if (tempDir.exists()) {
       String[] list = tempDir.list();
       int numChildren = list == null ? 0 : list.length;
-      if (0 == numChildren && !tempDir.delete())
+      if (numChildren == 0 && !tempDir.delete())
         log.warn("Cannot delete empty directory: {}", tempDir);
     }
   }
diff --git a/test/src/main/java/org/apache/accumulo/harness/AccumuloClusterHarness.java b/test/src/main/java/org/apache/accumulo/harness/AccumuloClusterHarness.java
index 831a6ee..3f6749b 100644
--- a/test/src/main/java/org/apache/accumulo/harness/AccumuloClusterHarness.java
+++ b/test/src/main/java/org/apache/accumulo/harness/AccumuloClusterHarness.java
@@ -86,7 +86,7 @@ public abstract class AccumuloClusterHarness extends AccumuloITBase
     clusterConf = AccumuloClusterPropertyConfiguration.get();
     type = clusterConf.getClusterType();
 
-    if (ClusterType.MINI == type
+    if (type == ClusterType.MINI
         && TRUE.equals(System.getProperty(MiniClusterHarness.USE_KERBEROS_FOR_IT_OPTION))) {
       krb = new TestingKdc();
       krb.start();
@@ -98,7 +98,7 @@ public abstract class AccumuloClusterHarness extends AccumuloITBase
 
   @AfterClass
   public static void tearDownHarness() throws Exception {
-    if (null != krb) {
+    if (krb != null) {
       krb.stop();
     }
   }
@@ -123,7 +123,7 @@ public abstract class AccumuloClusterHarness extends AccumuloITBase
         // core-site.xml
         cluster = miniClusterHarness.create(this, getAdminToken(), krb);
         // Login as the "root" user
-        if (null != krb) {
+        if (krb != null) {
           ClusterUser rootUser = krb.getRootUser();
           // Log in the 'client' user
           UserGroupInformation.loginUserFromKeytab(rootUser.getPrincipal(),
@@ -171,7 +171,7 @@ public abstract class AccumuloClusterHarness extends AccumuloITBase
 
     switch (type) {
       case MINI:
-        if (null != krb) {
+        if (krb != null) {
           final String traceTable = Property.TRACE_TABLE.getDefaultValue();
           final ClusterUser systemUser = krb.getAccumuloServerUser(), rootUser = krb.getRootUser();
 
@@ -239,7 +239,7 @@ public abstract class AccumuloClusterHarness extends AccumuloITBase
 
   @After
   public void teardownCluster() throws Exception {
-    if (null != cluster) {
+    if (cluster != null) {
       if (type.isDynamic()) {
         cluster.stop();
       } else {
@@ -301,7 +301,7 @@ public abstract class AccumuloClusterHarness extends AccumuloITBase
   public ClusterUser getAdminUser() {
     switch (type) {
       case MINI:
-        if (null == krb) {
+        if (krb == null) {
           PasswordToken passwordToken = (PasswordToken) getAdminToken();
           return new ClusterUser(getAdminPrincipal(),
               new String(passwordToken.getPassword(), UTF_8));
@@ -319,7 +319,7 @@ public abstract class AccumuloClusterHarness extends AccumuloITBase
   public ClusterUser getUser(int offset) {
     switch (type) {
       case MINI:
-        if (null != krb) {
+        if (krb != null) {
           // Defer to the TestingKdc when kerberos is on so we can get the keytab instead of a
           // password
           return krb.getClientPrincipal(offset);
diff --git a/test/src/main/java/org/apache/accumulo/harness/MiniClusterHarness.java b/test/src/main/java/org/apache/accumulo/harness/MiniClusterHarness.java
index 23e2bc9..84f359f 100644
--- a/test/src/main/java/org/apache/accumulo/harness/MiniClusterHarness.java
+++ b/test/src/main/java/org/apache/accumulo/harness/MiniClusterHarness.java
@@ -250,7 +250,7 @@ public class MiniClusterHarness {
       return;
     }
 
-    if (null == kdc) {
+    if (kdc == null) {
       throw new IllegalStateException("MiniClusterKdc was null");
     }
 
diff --git a/test/src/main/java/org/apache/accumulo/harness/SharedMiniClusterBase.java b/test/src/main/java/org/apache/accumulo/harness/SharedMiniClusterBase.java
index 254fe4a..a88da08 100644
--- a/test/src/main/java/org/apache/accumulo/harness/SharedMiniClusterBase.java
+++ b/test/src/main/java/org/apache/accumulo/harness/SharedMiniClusterBase.java
@@ -109,7 +109,7 @@ public abstract class SharedMiniClusterBase extends AccumuloITBase implements Cl
         miniClusterCallback, krb);
     cluster.start();
 
-    if (null != krb) {
+    if (krb != null) {
       final String traceTable = Property.TRACE_TABLE.getDefaultValue();
       final ClusterUser systemUser = krb.getAccumuloServerUser(), rootUser = krb.getRootUser();
       // Login as the trace user
@@ -147,14 +147,14 @@ public abstract class SharedMiniClusterBase extends AccumuloITBase implements Cl
    * Stops the MiniAccumuloCluster and related services if they are running.
    */
   public static void stopMiniCluster() throws Exception {
-    if (null != cluster) {
+    if (cluster != null) {
       try {
         cluster.stop();
       } catch (Exception e) {
         log.error("Failed to stop minicluster", e);
       }
     }
-    if (null != krb) {
+    if (krb != null) {
       try {
         krb.stop();
       } catch (Exception e) {
@@ -201,7 +201,7 @@ public abstract class SharedMiniClusterBase extends AccumuloITBase implements Cl
 
   @Override
   public ClusterUser getAdminUser() {
-    if (null == krb) {
+    if (krb == null) {
       return new ClusterUser(getPrincipal(), getRootPassword());
     } else {
       return krb.getRootUser();
@@ -210,7 +210,7 @@ public abstract class SharedMiniClusterBase extends AccumuloITBase implements Cl
 
   @Override
   public ClusterUser getUser(int offset) {
-    if (null == krb) {
+    if (krb == null) {
       String user = SharedMiniClusterBase.class.getName() + "_" + testName.getMethodName() + "_"
           + offset;
       // Password is the username
diff --git a/test/src/main/java/org/apache/accumulo/harness/conf/AccumuloClusterPropertyConfiguration.java b/test/src/main/java/org/apache/accumulo/harness/conf/AccumuloClusterPropertyConfiguration.java
index d2aac5e..b778987 100644
--- a/test/src/main/java/org/apache/accumulo/harness/conf/AccumuloClusterPropertyConfiguration.java
+++ b/test/src/main/java/org/apache/accumulo/harness/conf/AccumuloClusterPropertyConfiguration.java
@@ -55,7 +55,7 @@ public abstract class AccumuloClusterPropertyConfiguration implements AccumuloCl
     String clusterTypeValue = null, clientConf = null;
     String propertyFile = systemProperties.getProperty(ACCUMULO_IT_PROPERTIES_FILE);
 
-    if (null != propertyFile) {
+    if (propertyFile != null) {
       // Check for properties provided in a file
       File f = new File(propertyFile);
       if (f.exists() && f.isFile() && f.canRead()) {
@@ -67,7 +67,7 @@ public abstract class AccumuloClusterPropertyConfiguration implements AccumuloCl
           log.warn("Could not read properties from specified file: {}", propertyFile, e);
         }
 
-        if (null != reader) {
+        if (reader != null) {
           try {
             fileProperties.load(reader);
           } catch (IOException e) {
@@ -90,16 +90,16 @@ public abstract class AccumuloClusterPropertyConfiguration implements AccumuloCl
       log.debug("No properties file found in {}", ACCUMULO_IT_PROPERTIES_FILE);
     }
 
-    if (null == clusterTypeValue) {
+    if (clusterTypeValue == null) {
       clusterTypeValue = systemProperties.getProperty(ACCUMULO_CLUSTER_TYPE_KEY);
     }
 
-    if (null == clientConf) {
+    if (clientConf == null) {
       clientConf = systemProperties.getProperty(ACCUMULO_CLUSTER_CLIENT_CONF_KEY);
     }
 
     ClusterType type;
-    if (null == clusterTypeValue) {
+    if (clusterTypeValue == null) {
       type = ClusterType.MINI;
     } else {
       type = ClusterType.valueOf(clusterTypeValue);
@@ -113,7 +113,7 @@ public abstract class AccumuloClusterPropertyConfiguration implements AccumuloCl
         // started
         return new AccumuloMiniClusterConfiguration();
       case STANDALONE:
-        if (null == clientConf) {
+        if (clientConf == null) {
           throw new RuntimeException(
               "Expected client configuration to be provided: " + ACCUMULO_CLUSTER_CLIENT_CONF_KEY);
         }
@@ -152,7 +152,7 @@ public abstract class AccumuloClusterPropertyConfiguration implements AccumuloCl
     String propertyFile = systemProperties.getProperty(ACCUMULO_IT_PROPERTIES_FILE);
 
     // Check for properties provided in a file
-    if (null != propertyFile) {
+    if (propertyFile != null) {
       File f = new File(propertyFile);
       if (f.exists() && f.isFile() && f.canRead()) {
         Properties fileProperties = new Properties();
@@ -163,7 +163,7 @@ public abstract class AccumuloClusterPropertyConfiguration implements AccumuloCl
           log.warn("Could not read properties from specified file: {}", propertyFile, e);
         }
 
-        if (null != reader) {
+        if (reader != null) {
           try {
             fileProperties.load(reader);
             loadFromProperties(prefix, fileProperties, configuration);
diff --git a/test/src/main/java/org/apache/accumulo/harness/conf/AccumuloMiniClusterConfiguration.java b/test/src/main/java/org/apache/accumulo/harness/conf/AccumuloMiniClusterConfiguration.java
index c985813..e4695ed 100644
--- a/test/src/main/java/org/apache/accumulo/harness/conf/AccumuloMiniClusterConfiguration.java
+++ b/test/src/main/java/org/apache/accumulo/harness/conf/AccumuloMiniClusterConfiguration.java
@@ -49,7 +49,7 @@ public class AccumuloMiniClusterConfiguration extends AccumuloClusterPropertyCon
 
   public AccumuloMiniClusterConfiguration() {
     ClusterType type = getClusterType();
-    if (ClusterType.MINI != type) {
+    if (type != ClusterType.MINI) {
       throw new IllegalStateException("Expected only to see mini cluster state");
     }
 
@@ -65,7 +65,7 @@ public class AccumuloMiniClusterConfiguration extends AccumuloClusterPropertyCon
       return AccumuloClusterHarness.getKdc().getRootUser().getPrincipal();
     } else {
       String principal = conf.get(ACCUMULO_MINI_PRINCIPAL_KEY);
-      if (null == principal) {
+      if (principal == null) {
         principal = ACCUMULO_MINI_PRINCIPAL_DEFAULT;
       }
 
@@ -91,7 +91,7 @@ public class AccumuloMiniClusterConfiguration extends AccumuloClusterPropertyCon
       }
     } else {
       String password = conf.get(ACCUMULO_MINI_PASSWORD_KEY);
-      if (null == password) {
+      if (password == null) {
         password = ACCUMULO_MINI_PASSWORD_DEFAULT;
       }
 
diff --git a/test/src/main/java/org/apache/accumulo/harness/conf/StandaloneAccumuloClusterConfiguration.java b/test/src/main/java/org/apache/accumulo/harness/conf/StandaloneAccumuloClusterConfiguration.java
index 2b30a7c..9b9fa31 100644
--- a/test/src/main/java/org/apache/accumulo/harness/conf/StandaloneAccumuloClusterConfiguration.java
+++ b/test/src/main/java/org/apache/accumulo/harness/conf/StandaloneAccumuloClusterConfiguration.java
@@ -98,7 +98,7 @@ public class StandaloneAccumuloClusterConfiguration extends AccumuloClusterPrope
   @SuppressFBWarnings(value = "PATH_TRAVERSAL_IN", justification = "path provided by test")
   public StandaloneAccumuloClusterConfiguration(File clientPropsFile) {
     ClusterType type = getClusterType();
-    if (ClusterType.STANDALONE != type) {
+    if (type != ClusterType.STANDALONE) {
       throw new IllegalStateException("Expected only to see standalone cluster state");
     }
 
@@ -109,7 +109,7 @@ public class StandaloneAccumuloClusterConfiguration extends AccumuloClusterPrope
 
     // The user Accumulo is running as
     serverUser = conf.get(ACCUMULO_STANDALONE_SERVER_USER);
-    if (null == serverUser) {
+    if (serverUser == null) {
       serverUser = ACCUMULO_STANDALONE_SERVER_USER_DEFAULT;
     }
 
@@ -119,14 +119,14 @@ public class StandaloneAccumuloClusterConfiguration extends AccumuloClusterPrope
       if (key.startsWith(ACCUMULO_STANDALONE_USER_KEY)) {
         String suffix = key.substring(ACCUMULO_STANDALONE_USER_KEY.length());
         String keytab = conf.get(ACCUMULO_STANDALONE_USER_KEYTABS_KEY + suffix);
-        if (null != keytab) {
+        if (keytab != null) {
           File keytabFile = new File(keytab);
           assertTrue("Keytab doesn't exist: " + keytabFile,
               keytabFile.exists() && keytabFile.isFile());
           clusterUsers.add(new ClusterUser(entry.getValue(), keytabFile));
         } else {
           String password = conf.get(ACCUMULO_STANDALONE_USER_PASSWORDS_KEY + suffix);
-          if (null == password) {
+          if (password == null) {
             throw new IllegalArgumentException(
                 "Missing password or keytab configuration for user with offset " + suffix);
           }
@@ -140,7 +140,7 @@ public class StandaloneAccumuloClusterConfiguration extends AccumuloClusterPrope
   @Override
   public String getAdminPrincipal() {
     String principal = conf.get(ACCUMULO_STANDALONE_ADMIN_PRINCIPAL_KEY);
-    if (null == principal) {
+    if (principal == null) {
       principal = ACCUMULO_STANDALONE_ADMIN_PRINCIPAL_DEFAULT;
     }
     return principal;
@@ -152,7 +152,7 @@ public class StandaloneAccumuloClusterConfiguration extends AccumuloClusterPrope
 
   public String getPassword() {
     String password = conf.get(ACCUMULO_STANDALONE_PASSWORD_KEY);
-    if (null == password) {
+    if (password == null) {
       password = ACCUMULO_STANDALONE_PASSWORD_DEFAULT;
     }
     return password;
@@ -189,7 +189,7 @@ public class StandaloneAccumuloClusterConfiguration extends AccumuloClusterPrope
 
   public String getZooKeepers() {
     String zookeepers = conf.get(ACCUMULO_STANDALONE_ZOOKEEPERS_KEY);
-    if (null == zookeepers) {
+    if (zookeepers == null) {
       zookeepers = ACCUMULO_STANDALONE_ZOOKEEPERS_DEFAULT;
     }
     return zookeepers;
@@ -197,7 +197,7 @@ public class StandaloneAccumuloClusterConfiguration extends AccumuloClusterPrope
 
   public String getInstanceName() {
     String instanceName = conf.get(ACCUMULO_STANDALONE_INSTANCE_NAME_KEY);
-    if (null == instanceName) {
+    if (instanceName == null) {
       instanceName = ACCUMULO_STANDALONE_INSTANCE_NAME_DEFAULT;
     }
     return instanceName;
@@ -238,7 +238,7 @@ public class StandaloneAccumuloClusterConfiguration extends AccumuloClusterPrope
 
   public Path getTmpDirectory() {
     String tmpDir = conf.get(ACCUMULO_STANDALONE_TMP_DIR_KEY);
-    if (null == tmpDir) {
+    if (tmpDir == null) {
       tmpDir = ACCUMULO_STANDALONE_TMP_DIR_DEFAULT;
     }
     return new Path(tmpDir);
diff --git a/test/src/main/java/org/apache/accumulo/test/AuditMessageIT.java b/test/src/main/java/org/apache/accumulo/test/AuditMessageIT.java
index fa9bbad..523f928 100644
--- a/test/src/main/java/org/apache/accumulo/test/AuditMessageIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/AuditMessageIT.java
@@ -431,9 +431,9 @@ public class AuditMessageIT extends ConfigurableMacBase {
 
     ArrayList<String> auditMessages = getAuditMessages("testDataOperationsAudits");
     assertTrue(
-        1 <= findAuditMessage(auditMessages, "action: scan; targetTable: " + OLD_TEST_TABLE_NAME));
+        findAuditMessage(auditMessages, "action: scan; targetTable: " + OLD_TEST_TABLE_NAME) >= 1);
     assertTrue(
-        1 <= findAuditMessage(auditMessages, "action: scan; targetTable: " + OLD_TEST_TABLE_NAME));
+        findAuditMessage(auditMessages, "action: scan; targetTable: " + OLD_TEST_TABLE_NAME) >= 1);
     assertEquals(1,
         findAuditMessage(auditMessages,
             String.format(AuditedSecurityOperation.CAN_DELETE_RANGE_AUDIT_TEMPLATE,
diff --git a/test/src/main/java/org/apache/accumulo/test/BadDeleteMarkersCreatedIT.java b/test/src/main/java/org/apache/accumulo/test/BadDeleteMarkersCreatedIT.java
index 0a21de7..afe937b 100644
--- a/test/src/main/java/org/apache/accumulo/test/BadDeleteMarkersCreatedIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/BadDeleteMarkersCreatedIT.java
@@ -104,11 +104,11 @@ public class BadDeleteMarkersCreatedIT extends AccumuloClusterHarness {
       byte[] gcLockData;
       do {
         gcLockData = ZooLock.getLockData(zcache, path, null);
-        if (null != gcLockData) {
+        if (gcLockData != null) {
           log.info("Waiting for GC ZooKeeper lock to expire");
           Thread.sleep(2000);
         }
-      } while (null != gcLockData);
+      } while (gcLockData != null);
 
       log.info("GC lock was lost");
 
@@ -118,11 +118,11 @@ public class BadDeleteMarkersCreatedIT extends AccumuloClusterHarness {
       gcLockData = null;
       do {
         gcLockData = ZooLock.getLockData(zcache, path, null);
-        if (null == gcLockData) {
+        if (gcLockData == null) {
           log.info("Waiting for GC ZooKeeper lock to be acquired");
           Thread.sleep(2000);
         }
-      } while (null == gcLockData);
+      } while (gcLockData == null);
 
       log.info("GC lock was acquired");
     }
@@ -132,10 +132,10 @@ public class BadDeleteMarkersCreatedIT extends AccumuloClusterHarness {
   public void restoreConfig() throws Exception {
     try (AccumuloClient c = createAccumuloClient()) {
       InstanceOperations iops = c.instanceOperations();
-      if (null != gcCycleDelay) {
+      if (gcCycleDelay != null) {
         iops.setProperty(Property.GC_CYCLE_DELAY.getKey(), gcCycleDelay);
       }
-      if (null != gcCycleStart) {
+      if (gcCycleStart != null) {
         iops.setProperty(Property.GC_CYCLE_START.getKey(), gcCycleStart);
       }
       log.info("Restarting garbage collector");
diff --git a/test/src/main/java/org/apache/accumulo/test/BatchWriterInTabletServerIT.java b/test/src/main/java/org/apache/accumulo/test/BatchWriterInTabletServerIT.java
index 857dddb..8d85f0b 100644
--- a/test/src/main/java/org/apache/accumulo/test/BatchWriterInTabletServerIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/BatchWriterInTabletServerIT.java
@@ -50,7 +50,7 @@ public class BatchWriterInTabletServerIT extends AccumuloClusterHarness {
 
   @Override
   public boolean canRunTest(ClusterType type) {
-    return ClusterType.MINI == type;
+    return type == ClusterType.MINI;
   }
 
   /**
diff --git a/test/src/main/java/org/apache/accumulo/test/CleanWalIT.java b/test/src/main/java/org/apache/accumulo/test/CleanWalIT.java
index 5d06cc7..631d579 100644
--- a/test/src/main/java/org/apache/accumulo/test/CleanWalIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/CleanWalIT.java
@@ -79,7 +79,7 @@ public class CleanWalIT extends AccumuloClusterHarness {
 
   @After
   public void onlineTraceTable() throws Exception {
-    if (null != cluster) {
+    if (cluster != null) {
       try (AccumuloClient client = createAccumuloClient()) {
         String traceTable = client.instanceOperations().getSystemConfiguration()
             .get(Property.TRACE_TABLE.getKey());
diff --git a/test/src/main/java/org/apache/accumulo/test/ConditionalWriterIT.java b/test/src/main/java/org/apache/accumulo/test/ConditionalWriterIT.java
index 265b227..cd8c605 100644
--- a/test/src/main/java/org/apache/accumulo/test/ConditionalWriterIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ConditionalWriterIT.java
@@ -1585,7 +1585,7 @@ public class ConditionalWriterIT extends AccumuloClusterHarness {
             for (String part : parts) {
               log.info("Looking in trace output for '" + part + "'");
               int pos = traceOutput.indexOf(part);
-              if (-1 == pos) {
+              if (pos == -1) {
                 log.info("Trace output doesn't contain '" + part + "'");
                 Thread.sleep(1000);
                 break loop;
diff --git a/test/src/main/java/org/apache/accumulo/test/DetectDeadTabletServersIT.java b/test/src/main/java/org/apache/accumulo/test/DetectDeadTabletServersIT.java
index 5fc1a33..b11d02d 100644
--- a/test/src/main/java/org/apache/accumulo/test/DetectDeadTabletServersIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/DetectDeadTabletServersIT.java
@@ -65,7 +65,7 @@ public class DetectDeadTabletServersIT extends ConfigurableMacBase {
 
       while (true) {
         stats = getStats(c);
-        if (2 != stats.tServerInfo.size()) {
+        if (stats.tServerInfo.size() != 2) {
           break;
         }
         UtilWaitThread.sleep(500);
@@ -74,7 +74,7 @@ public class DetectDeadTabletServersIT extends ConfigurableMacBase {
       assertEquals(1, stats.badTServers.size() + stats.deadTabletServers.size());
       while (true) {
         stats = getStats(c);
-        if (0 != stats.deadTabletServers.size()) {
+        if (stats.deadTabletServers.size() != 0) {
           break;
         }
         UtilWaitThread.sleep(500);
diff --git a/test/src/main/java/org/apache/accumulo/test/FairVolumeChooser.java b/test/src/main/java/org/apache/accumulo/test/FairVolumeChooser.java
index 7c94004..561bffd 100644
--- a/test/src/main/java/org/apache/accumulo/test/FairVolumeChooser.java
+++ b/test/src/main/java/org/apache/accumulo/test/FairVolumeChooser.java
@@ -32,7 +32,7 @@ public class FairVolumeChooser implements VolumeChooser {
   public String choose(VolumeChooserEnvironment env, String[] options) {
     int currentChoice;
     Integer lastChoice = optionLengthToLastChoice.get(options.length);
-    if (null == lastChoice) {
+    if (lastChoice == null) {
       currentChoice = 0;
     } else {
       currentChoice = lastChoice + 1;
diff --git a/test/src/main/java/org/apache/accumulo/test/ImportExportIT.java b/test/src/main/java/org/apache/accumulo/test/ImportExportIT.java
index cd7491b..87db97f 100644
--- a/test/src/main/java/org/apache/accumulo/test/ImportExportIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ImportExportIT.java
@@ -122,7 +122,7 @@ public class ImportExportIT extends AccumuloClusterHarness {
 
       // Copy each file that was exported to the import directory
       String line;
-      while (null != (line = reader.readLine())) {
+      while ((line = reader.readLine()) != null) {
         Path p = new Path(line.substring(5));
         assertTrue("File doesn't exist: " + p, fs.exists(p));
 
@@ -194,7 +194,7 @@ public class ImportExportIT extends AccumuloClusterHarness {
 
   private boolean looksLikeRelativePath(String uri) {
     if (uri.startsWith("/" + Constants.BULK_PREFIX)) {
-      return '/' == uri.charAt(10);
+      return uri.charAt(10) == '/';
     } else {
       return uri.startsWith("/" + Constants.CLONE_PREFIX);
     }
diff --git a/test/src/main/java/org/apache/accumulo/test/LargeSplitRowIT.java b/test/src/main/java/org/apache/accumulo/test/LargeSplitRowIT.java
index d527ecf..3908e51 100644
--- a/test/src/main/java/org/apache/accumulo/test/LargeSplitRowIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/LargeSplitRowIT.java
@@ -240,7 +240,7 @@ public class LargeSplitRowIT extends ConfigurableMacBase {
         Thread.sleep(250);
       }
 
-      assertTrue(0 < client.tableOperations().listSplits(tableName).size());
+      assertTrue(client.tableOperations().listSplits(tableName).size() > 0);
     }
   }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/MetaSplitIT.java b/test/src/main/java/org/apache/accumulo/test/MetaSplitIT.java
index 7c185db..1247a8f 100644
--- a/test/src/main/java/org/apache/accumulo/test/MetaSplitIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/MetaSplitIT.java
@@ -51,7 +51,7 @@ public class MetaSplitIT extends AccumuloClusterHarness {
 
   @Before
   public void saveMetadataSplits() throws Exception {
-    if (ClusterType.STANDALONE == getClusterType()) {
+    if (getClusterType() == ClusterType.STANDALONE) {
       try (AccumuloClient client = createAccumuloClient()) {
         Collection<Text> splits = client.tableOperations().listSplits(MetadataTable.NAME);
         // We expect a single split
@@ -69,7 +69,7 @@ public class MetaSplitIT extends AccumuloClusterHarness {
 
   @After
   public void restoreMetadataSplits() throws Exception {
-    if (null != metadataSplits) {
+    if (metadataSplits != null) {
       log.info("Restoring split on metadata table");
       try (AccumuloClient client = createAccumuloClient()) {
         client.tableOperations().merge(MetadataTable.NAME, null, null);
diff --git a/test/src/main/java/org/apache/accumulo/test/MultiTableBatchWriterIT.java b/test/src/main/java/org/apache/accumulo/test/MultiTableBatchWriterIT.java
index 007ed4d..d5aedaf 100644
--- a/test/src/main/java/org/apache/accumulo/test/MultiTableBatchWriterIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/MultiTableBatchWriterIT.java
@@ -130,7 +130,7 @@ public class MultiTableBatchWriterIT extends AccumuloClusterHarness {
       }
 
     } finally {
-      if (null != mtbw) {
+      if (mtbw != null) {
         mtbw.close();
       }
     }
@@ -187,7 +187,7 @@ public class MultiTableBatchWriterIT extends AccumuloClusterHarness {
         }
       }
     } finally {
-      if (null != mtbw) {
+      if (mtbw != null) {
         mtbw.close();
       }
     }
@@ -264,7 +264,7 @@ public class MultiTableBatchWriterIT extends AccumuloClusterHarness {
         }
       }
     } finally {
-      if (null != mtbw) {
+      if (mtbw != null) {
         mtbw.close();
       }
     }
@@ -308,7 +308,7 @@ public class MultiTableBatchWriterIT extends AccumuloClusterHarness {
         // Pass
       }
     } finally {
-      if (null != mtbw) {
+      if (mtbw != null) {
         mtbw.close();
       }
     }
@@ -351,7 +351,7 @@ public class MultiTableBatchWriterIT extends AccumuloClusterHarness {
       }
 
     } finally {
-      if (null != mtbw) {
+      if (mtbw != null) {
         try {
           // Mutations might have flushed before the table offline occurred
           mtbw.close();
@@ -401,7 +401,7 @@ public class MultiTableBatchWriterIT extends AccumuloClusterHarness {
         mutationsRejected = true;
       }
     } finally {
-      if (null != mtbw) {
+      if (mtbw != null) {
         try {
           mtbw.close();
         } catch (MutationsRejectedException e) {
diff --git a/test/src/main/java/org/apache/accumulo/test/NamespacesIT.java b/test/src/main/java/org/apache/accumulo/test/NamespacesIT.java
index 05c6766..9b38252 100644
--- a/test/src/main/java/org/apache/accumulo/test/NamespacesIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/NamespacesIT.java
@@ -103,7 +103,7 @@ public class NamespacesIT extends AccumuloClusterHarness {
 
   @Before
   public void setupConnectorAndNamespace() throws Exception {
-    Assume.assumeTrue(ClusterType.MINI == getClusterType());
+    Assume.assumeTrue(getClusterType() == ClusterType.MINI);
 
     // prepare a unique namespace and get a new root client for each test
     c = createAccumuloClient();
@@ -112,7 +112,7 @@ public class NamespacesIT extends AccumuloClusterHarness {
 
   @After
   public void swingMjölnir() throws Exception {
-    if (null == c) {
+    if (c == null) {
       return;
     }
     // clean up any added tables, namespaces, and users, after each test
@@ -518,12 +518,12 @@ public class NamespacesIT extends AccumuloClusterHarness {
     Integer namespaceNum = null;
     for (int i = 0; i < 5; i++) {
       namespaceNum = c.namespaceOperations().listConstraints(namespace).get(constraintClassName);
-      if (null == namespaceNum) {
+      if (namespaceNum == null) {
         Thread.sleep(500);
         continue;
       }
       Integer tableNum = c.tableOperations().listConstraints(t1).get(constraintClassName);
-      if (null == tableNum) {
+      if (tableNum == null) {
         Thread.sleep(500);
         continue;
       }
@@ -663,7 +663,7 @@ public class NamespacesIT extends AccumuloClusterHarness {
     ClusterUser user1 = getUser(0), user2 = getUser(1), root = getAdminUser();
     String u1 = user1.getPrincipal();
     String u2 = user2.getPrincipal();
-    PasswordToken pass = (null != user1.getPassword() ? new PasswordToken(user1.getPassword())
+    PasswordToken pass = (user1.getPassword() != null ? new PasswordToken(user1.getPassword())
         : null);
 
     String n1 = namespace;
diff --git a/test/src/main/java/org/apache/accumulo/test/ShellConfigIT.java b/test/src/main/java/org/apache/accumulo/test/ShellConfigIT.java
index aa9d956..d13dc31 100644
--- a/test/src/main/java/org/apache/accumulo/test/ShellConfigIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ShellConfigIT.java
@@ -62,7 +62,7 @@ public class ShellConfigIT extends AccumuloClusterHarness {
 
   @After
   public void resetProperty() throws Exception {
-    if (null != origPropValue) {
+    if (origPropValue != null) {
       try (AccumuloClient client = createAccumuloClient()) {
         client.instanceOperations().setProperty(PerTableVolumeChooser.TABLE_VOLUME_CHOOSER,
             origPropValue);
diff --git a/test/src/main/java/org/apache/accumulo/test/ShellServerIT.java b/test/src/main/java/org/apache/accumulo/test/ShellServerIT.java
index 6196518..2fdbaff 100644
--- a/test/src/main/java/org/apache/accumulo/test/ShellServerIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ShellServerIT.java
@@ -245,7 +245,7 @@ public class ShellServerIT extends SharedMiniClusterBase {
 
     void assertGoodExit(String s, boolean stringPresent, ErrorMessageCallback callback) {
       shellLog.debug("Shell Output: '{}'", output.get());
-      if (0 != shell.getExitCode()) {
+      if (shell.getExitCode() != 0) {
         String errorMsg = callback.getErrorMessage();
         assertEquals(errorMsg, 0, shell.getExitCode());
       }
@@ -257,7 +257,7 @@ public class ShellServerIT extends SharedMiniClusterBase {
 
     void assertBadExit(String s, boolean stringPresent, ErrorMessageCallback callback) {
       shellLog.debug(output.get());
-      if (0 == shell.getExitCode()) {
+      if (shell.getExitCode() == 0) {
         String errorMsg = callback.getErrorMessage();
         assertTrue(errorMsg, shell.getExitCode() > 0);
       }
@@ -322,7 +322,7 @@ public class ShellServerIT extends SharedMiniClusterBase {
 
   @AfterClass
   public static void tearDownAfterClass() throws Exception {
-    if (null != traceProcess) {
+    if (traceProcess != null) {
       traceProcess.destroy();
     }
 
@@ -1189,7 +1189,7 @@ public class ShellServerIT extends SharedMiniClusterBase {
     // 2nd file for that tablet
     // If we notice this, compact and then move on.
     List<String> files = getFiles(tableId);
-    if (3 < files.size()) {
+    if (files.size() > 3) {
       log.info("More than 3 files were found, compacting before proceeding");
       ts.exec("compact -w -t " + table);
       files = getFiles(tableId);
@@ -2000,7 +2000,7 @@ public class ShellServerIT extends SharedMiniClusterBase {
     String[] lines = StringUtils.split(ts.output.get(), "\n");
     ts.output.clear();
 
-    if (0 == lines.length) {
+    if (lines.length == 0) {
       return Collections.emptyList();
     }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/TableConfigurationUpdateIT.java b/test/src/main/java/org/apache/accumulo/test/TableConfigurationUpdateIT.java
index 43cb80f..593bb32 100644
--- a/test/src/main/java/org/apache/accumulo/test/TableConfigurationUpdateIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/TableConfigurationUpdateIT.java
@@ -85,7 +85,7 @@ public class TableConfigurationUpdateIT extends AccumuloClusterHarness {
 
       for (Future<Exception> fut : futures) {
         Exception e = fut.get();
-        if (null != e) {
+        if (e != null) {
           fail("Thread failed with exception " + e);
         }
       }
diff --git a/test/src/main/java/org/apache/accumulo/test/TestRandomDeletes.java b/test/src/main/java/org/apache/accumulo/test/TestRandomDeletes.java
index eab9096..e943ca9 100644
--- a/test/src/main/java/org/apache/accumulo/test/TestRandomDeletes.java
+++ b/test/src/main/java/org/apache/accumulo/test/TestRandomDeletes.java
@@ -62,7 +62,7 @@ public class TestRandomDeletes {
     @Override
     public boolean equals(Object obj) {
       return this == obj
-          || (obj != null && obj instanceof RowColumn && 0 == compareTo((RowColumn) obj));
+          || (obj != null && obj instanceof RowColumn && compareTo((RowColumn) obj) == 0);
     }
 
     @Override
diff --git a/test/src/main/java/org/apache/accumulo/test/ThriftServerBindsBeforeZooKeeperLockIT.java b/test/src/main/java/org/apache/accumulo/test/ThriftServerBindsBeforeZooKeeperLockIT.java
index 57c18bf..1e59ccb 100644
--- a/test/src/main/java/org/apache/accumulo/test/ThriftServerBindsBeforeZooKeeperLockIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ThriftServerBindsBeforeZooKeeperLockIT.java
@@ -58,7 +58,7 @@ public class ThriftServerBindsBeforeZooKeeperLockIT extends AccumuloClusterHarne
 
   @Override
   public boolean canRunTest(ClusterType type) {
-    return ClusterType.MINI == type;
+    return type == ClusterType.MINI;
   }
 
   @Test
@@ -66,7 +66,7 @@ public class ThriftServerBindsBeforeZooKeeperLockIT extends AccumuloClusterHarne
     final MiniAccumuloClusterImpl cluster = (MiniAccumuloClusterImpl) getCluster();
     Collection<ProcessReference> monitors = cluster.getProcesses().get(ServerType.MONITOR);
     // Need to start one monitor and let it become active.
-    if (null == monitors || 0 == monitors.size()) {
+    if (monitors == null || monitors.size() == 0) {
       getClusterControl().start(ServerType.MONITOR, "localhost");
     }
 
@@ -97,7 +97,7 @@ public class ThriftServerBindsBeforeZooKeeperLockIT extends AccumuloClusterHarne
             final int responseCode = cnxn.getResponseCode();
             String errorText;
             // This is our "assertion", but we want to re-check it if it's not what we expect
-            if (HttpURLConnection.HTTP_OK == responseCode) {
+            if (responseCode == HttpURLConnection.HTTP_OK) {
               return;
             } else {
               errorText = FunctionalTestUtils.readAll(cnxn.getErrorStream());
@@ -120,7 +120,7 @@ public class ThriftServerBindsBeforeZooKeeperLockIT extends AccumuloClusterHarne
           }
         }
       } finally {
-        if (null != monitor) {
+        if (monitor != null) {
           monitor.destroyForcibly();
         }
       }
@@ -170,7 +170,7 @@ public class ThriftServerBindsBeforeZooKeeperLockIT extends AccumuloClusterHarne
             } catch (Exception e) {
               LOG.debug("Caught exception trying to connect to Master", e);
             } finally {
-              if (null != s) {
+              if (s != null) {
                 s.close();
               }
             }
@@ -187,7 +187,7 @@ public class ThriftServerBindsBeforeZooKeeperLockIT extends AccumuloClusterHarne
             }
           }
         } finally {
-          if (null != master) {
+          if (master != null) {
             master.destroyForcibly();
           }
         }
@@ -238,7 +238,7 @@ public class ThriftServerBindsBeforeZooKeeperLockIT extends AccumuloClusterHarne
             } catch (Exception e) {
               LOG.debug("Caught exception trying to connect to GC", e);
             } finally {
-              if (null != s) {
+              if (s != null) {
                 s.close();
               }
             }
@@ -255,7 +255,7 @@ public class ThriftServerBindsBeforeZooKeeperLockIT extends AccumuloClusterHarne
             }
           }
         } finally {
-          if (null != master) {
+          if (master != null) {
             master.destroyForcibly();
           }
         }
diff --git a/test/src/main/java/org/apache/accumulo/test/TransportCachingIT.java b/test/src/main/java/org/apache/accumulo/test/TransportCachingIT.java
index 2bb5b84..3196ac0 100644
--- a/test/src/main/java/org/apache/accumulo/test/TransportCachingIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/TransportCachingIT.java
@@ -83,7 +83,7 @@ public class TransportCachingIT extends AccumuloClusterHarness {
 
       ThriftTransportPool pool = ThriftTransportPool.getInstance();
       TTransport first = null;
-      while (null == first) {
+      while (first == null) {
         try {
           // Get a transport (cached or not)
           first = pool.getAnyTransport(servers, true).getSecond();
@@ -97,7 +97,7 @@ public class TransportCachingIT extends AccumuloClusterHarness {
       pool.returnTransport(first);
 
       TTransport second = null;
-      while (null == second) {
+      while (second == null) {
         try {
           // Get a cached transport (should be the first)
           second = pool.getAnyTransport(servers, true).getSecond();
@@ -112,7 +112,7 @@ public class TransportCachingIT extends AccumuloClusterHarness {
       pool.returnTransport(second);
 
       TTransport third = null;
-      while (null == third) {
+      while (third == null) {
         try {
           // Get a non-cached transport
           third = pool.getAnyTransport(servers, false).getSecond();
diff --git a/test/src/main/java/org/apache/accumulo/test/UserCompactionStrategyIT.java b/test/src/main/java/org/apache/accumulo/test/UserCompactionStrategyIT.java
index 1f7aeef..2c25dce 100644
--- a/test/src/main/java/org/apache/accumulo/test/UserCompactionStrategyIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/UserCompactionStrategyIT.java
@@ -151,7 +151,7 @@ public class UserCompactionStrategyIT extends AccumuloClusterHarness {
   @Test
   public void testPerTableClasspath() throws Exception {
     // Can't assume that a test-resource will be on the server's classpath
-    Assume.assumeTrue(ClusterType.MINI == getClusterType());
+    Assume.assumeTrue(getClusterType() == ClusterType.MINI);
 
     // test per-table classpath + user specified compaction strategy
 
diff --git a/test/src/main/java/org/apache/accumulo/test/constraints/AlphaNumKeyConstraint.java b/test/src/main/java/org/apache/accumulo/test/constraints/AlphaNumKeyConstraint.java
index 14fa82d..6ab8ce2 100644
--- a/test/src/main/java/org/apache/accumulo/test/constraints/AlphaNumKeyConstraint.java
+++ b/test/src/main/java/org/apache/accumulo/test/constraints/AlphaNumKeyConstraint.java
@@ -75,7 +75,7 @@ public class AlphaNumKeyConstraint implements Constraint {
         violations = addViolation(violations, NON_ALPHA_NUM_COLQ);
     }
 
-    return null == violations ? null : new ArrayList<>(violations);
+    return violations == null ? null : new ArrayList<>(violations);
   }
 
   @Override
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/BinaryStressIT.java b/test/src/main/java/org/apache/accumulo/test/functional/BinaryStressIT.java
index 9b07900..d5d159c 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/BinaryStressIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/BinaryStressIT.java
@@ -59,7 +59,7 @@ public class BinaryStressIT extends AccumuloClusterHarness {
 
   @Before
   public void alterConfig() throws Exception {
-    if (ClusterType.MINI == getClusterType()) {
+    if (getClusterType() == ClusterType.MINI) {
       return;
     }
     try (AccumuloClient client = createAccumuloClient()) {
@@ -78,7 +78,7 @@ public class BinaryStressIT extends AccumuloClusterHarness {
 
   @After
   public void resetConfig() throws Exception {
-    if (null != majcDelay) {
+    if (majcDelay != null) {
       try (AccumuloClient client = createAccumuloClient()) {
         InstanceOperations iops = client.instanceOperations();
         iops.setProperty(Property.TSERV_MAJC_DELAY.getKey(), majcDelay);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/BulkIT.java b/test/src/main/java/org/apache/accumulo/test/functional/BulkIT.java
index 4c80b70..e223346 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/BulkIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/BulkIT.java
@@ -58,7 +58,7 @@ public class BulkIT extends AccumuloClusterHarness {
 
   @After
   public void restoreConf() {
-    if (null != origConf) {
+    if (origConf != null) {
       CachedConfiguration.setInstance(origConf);
     }
   }
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/BulkSplitOptimizationIT.java b/test/src/main/java/org/apache/accumulo/test/functional/BulkSplitOptimizationIT.java
index d67b183..ddd2d6b 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/BulkSplitOptimizationIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/BulkSplitOptimizationIT.java
@@ -68,7 +68,7 @@ public class BulkSplitOptimizationIT extends AccumuloClusterHarness {
 
   @After
   public void resetConfig() throws Exception {
-    if (null != majcDelay) {
+    if (majcDelay != null) {
       try (AccumuloClient client = createAccumuloClient()) {
         client.instanceOperations().setProperty(Property.TSERV_MAJC_DELAY.getKey(), majcDelay);
         getClusterControl().stopAllServers(ServerType.TABLET_SERVER);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/CompactionIT.java b/test/src/main/java/org/apache/accumulo/test/functional/CompactionIT.java
index f24dc37..980ad11 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/CompactionIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/CompactionIT.java
@@ -72,7 +72,7 @@ public class CompactionIT extends AccumuloClusterHarness {
 
   @Before
   public void alterConfig() throws Exception {
-    if (ClusterType.STANDALONE == getClusterType()) {
+    if (getClusterType() == ClusterType.STANDALONE) {
       try (AccumuloClient client = createAccumuloClient()) {
         InstanceOperations iops = client.instanceOperations();
         Map<String,String> config = iops.getSystemConfiguration();
@@ -93,7 +93,7 @@ public class CompactionIT extends AccumuloClusterHarness {
   @After
   public void resetConfig() throws Exception {
     // We set the values..
-    if (null != majcThreadMaxOpen) {
+    if (majcThreadMaxOpen != null) {
       try (AccumuloClient client = createAccumuloClient()) {
         InstanceOperations iops = client.instanceOperations();
 
@@ -162,7 +162,7 @@ public class CompactionIT extends AccumuloClusterHarness {
       } finally {
         // Make sure the internal state in the cluster is reset (e.g. processes in MAC)
         getCluster().stop();
-        if (ClusterType.STANDALONE == getClusterType()) {
+        if (getClusterType() == ClusterType.STANDALONE) {
           // Then restart things for the next test if it's a standalone
           getCluster().start();
         }
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/DeleteIT.java b/test/src/main/java/org/apache/accumulo/test/functional/DeleteIT.java
index 5615184..279991b 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/DeleteIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/DeleteIT.java
@@ -68,7 +68,7 @@ public class DeleteIT extends AccumuloClusterHarness {
     vopts.cols = opts.cols = 1;
     vopts.random = opts.random = 56;
 
-    assertTrue("Expected one of password or keytab", null != password || null != keytab);
+    assertTrue("Expected one of password or keytab", password != null || keytab != null);
     opts.setClientProperties(getClientProperties());
     vopts.setClientProperties(getClientProperties());
 
@@ -77,13 +77,13 @@ public class DeleteIT extends AccumuloClusterHarness {
 
     String[] args = null;
 
-    assertTrue("Expected one of password or keytab", null != password || null != keytab);
-    if (null != password) {
+    assertTrue("Expected one of password or keytab", password != null || keytab != null);
+    if (password != null) {
       assertNull("Given password, expected null keytab", keytab);
       args = new String[] {"-u", user, "-p", password, "-i", cluster.getInstanceName(), "-z",
           cluster.getZooKeepers(), "--table", tableName};
     }
-    if (null != keytab) {
+    if (keytab != null) {
       assertNull("Given keytab, expect null password", password);
       args = new String[] {"-u", user, "-i", cluster.getInstanceName(), "-z",
           cluster.getZooKeepers(), "--table", tableName, "--keytab", keytab};
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/DurabilityIT.java b/test/src/main/java/org/apache/accumulo/test/functional/DurabilityIT.java
index 8b21d1e..475e94b 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/DurabilityIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/DurabilityIT.java
@@ -148,7 +148,7 @@ public class DurabilityIT extends ConfigurableMacBase {
       writeSome(client, tableNames[2], N);
       restartTServer();
       long numResults = readSome(client, tableNames[2]);
-      assertTrue("Expected " + N + " >= " + numResults, N >= numResults);
+      assertTrue("Expected " + N + " >= " + numResults, numResults <= N);
       cleanup(client, tableNames);
     }
   }
@@ -161,7 +161,7 @@ public class DurabilityIT extends ConfigurableMacBase {
       writeSome(client, tableNames[3], N);
       restartTServer();
       long numResults = readSome(client, tableNames[3]);
-      assertTrue("Expected " + N + " >= " + numResults, N >= numResults);
+      assertTrue("Expected " + N + " >= " + numResults, numResults <= N);
       cleanup(client, tableNames);
     }
   }
@@ -175,7 +175,7 @@ public class DurabilityIT extends ConfigurableMacBase {
       writeSome(c, tableName, N);
       restartTServer();
       long numResults = readSome(c, tableName);
-      assertTrue("Expected " + N + " >= " + numResults, N >= numResults);
+      assertTrue("Expected " + N + " >= " + numResults, numResults <= N);
       c.tableOperations().setProperty(tableName, Property.TABLE_DURABILITY.getKey(), "sync");
       writeSome(c, tableName, N);
       restartTServer();
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/KerberosIT.java b/test/src/main/java/org/apache/accumulo/test/functional/KerberosIT.java
index 98f98b8..6deb0b7 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/KerberosIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/KerberosIT.java
@@ -104,7 +104,7 @@ public class KerberosIT extends AccumuloITBase {
     kdc = new TestingKdc();
     kdc.start();
     krbEnabledForITs = System.getProperty(MiniClusterHarness.USE_KERBEROS_FOR_IT_OPTION);
-    if (null == krbEnabledForITs || !Boolean.parseBoolean(krbEnabledForITs)) {
+    if (krbEnabledForITs == null || !Boolean.parseBoolean(krbEnabledForITs)) {
       System.setProperty(MiniClusterHarness.USE_KERBEROS_FOR_IT_OPTION, "true");
     }
     rootUser = kdc.getRootUser();
@@ -112,10 +112,10 @@ public class KerberosIT extends AccumuloITBase {
 
   @AfterClass
   public static void stopKdc() throws Exception {
-    if (null != kdc) {
+    if (kdc != null) {
       kdc.stop();
     }
-    if (null != krbEnabledForITs) {
+    if (krbEnabledForITs != null) {
       System.setProperty(MiniClusterHarness.USE_KERBEROS_FOR_IT_OPTION, krbEnabledForITs);
     }
     UserGroupInformation.setConfiguration(new Configuration(false));
@@ -153,7 +153,7 @@ public class KerberosIT extends AccumuloITBase {
 
   @After
   public void stopMac() throws Exception {
-    if (null != mac) {
+    if (mac != null) {
       mac.stop();
     }
   }
@@ -598,7 +598,7 @@ public class KerberosIT extends AccumuloITBase {
       });
     } catch (UndeclaredThrowableException e) {
       Throwable cause = e.getCause();
-      if (null != cause) {
+      if (cause != null) {
         throw cause;
       } else {
         throw e;
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/KerberosProxyIT.java b/test/src/main/java/org/apache/accumulo/test/functional/KerberosProxyIT.java
index 7e2c693..3d4c63f 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/KerberosProxyIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/KerberosProxyIT.java
@@ -119,7 +119,7 @@ public class KerberosProxyIT extends AccumuloITBase {
     kdc = new TestingKdc();
     kdc.start();
     krbEnabledForITs = System.getProperty(MiniClusterHarness.USE_KERBEROS_FOR_IT_OPTION);
-    if (null == krbEnabledForITs || !Boolean.parseBoolean(krbEnabledForITs)) {
+    if (krbEnabledForITs == null || !Boolean.parseBoolean(krbEnabledForITs)) {
       System.setProperty(MiniClusterHarness.USE_KERBEROS_FOR_IT_OPTION, "true");
     }
 
@@ -137,10 +137,10 @@ public class KerberosProxyIT extends AccumuloITBase {
 
   @AfterClass
   public static void stopKdc() throws Exception {
-    if (null != kdc) {
+    if (kdc != null) {
       kdc.stop();
     }
-    if (null != krbEnabledForITs) {
+    if (krbEnabledForITs != null) {
       System.setProperty(MiniClusterHarness.USE_KERBEROS_FOR_IT_OPTION, krbEnabledForITs);
     }
     UserGroupInformation.setConfiguration(new Configuration(false));
@@ -209,14 +209,14 @@ public class KerberosProxyIT extends AccumuloITBase {
         success = true;
       } catch (TTransportException e) {
         Throwable cause = e.getCause();
-        if (null != cause && cause instanceof ConnectException) {
+        if (cause != null && cause instanceof ConnectException) {
           log.info("Proxy not yet up, waiting");
           Thread.sleep(3000);
           proxyProcess = checkProxyAndRestart(proxyProcess, cfg);
           continue;
         }
       } finally {
-        if (null != ugiTransport) {
+        if (ugiTransport != null) {
           ugiTransport.close();
         }
       }
@@ -329,14 +329,14 @@ public class KerberosProxyIT extends AccumuloITBase {
 
   @After
   public void stopMac() throws Exception {
-    if (null != proxyProcess) {
+    if (proxyProcess != null) {
       log.info("Destroying proxy process");
       proxyProcess.destroy();
       log.info("Waiting for proxy termination");
       proxyProcess.waitFor();
       log.info("Proxy terminated");
     }
-    if (null != mac) {
+    if (mac != null) {
       mac.stop();
     }
   }
@@ -469,7 +469,7 @@ public class KerberosProxyIT extends AccumuloITBase {
     try {
       client.login(kdc.qualifyUser(user), Collections.<String,String> emptyMap());
     } finally {
-      if (null != ugiTransport) {
+      if (ugiTransport != null) {
         ugiTransport.close();
       }
     }
@@ -518,7 +518,7 @@ public class KerberosProxyIT extends AccumuloITBase {
     try {
       client.login(rootUser.getPrincipal(), Collections.<String,String> emptyMap());
     } finally {
-      if (null != ugiTransport) {
+      if (ugiTransport != null) {
         ugiTransport.close();
       }
     }
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/KerberosRenewalIT.java b/test/src/main/java/org/apache/accumulo/test/functional/KerberosRenewalIT.java
index ad35191..e27baac 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/KerberosRenewalIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/KerberosRenewalIT.java
@@ -86,7 +86,7 @@ public class KerberosRenewalIT extends AccumuloITBase {
         TICKET_LIFETIME);
     kdc.start();
     krbEnabledForITs = System.getProperty(MiniClusterHarness.USE_KERBEROS_FOR_IT_OPTION);
-    if (null == krbEnabledForITs || !Boolean.parseBoolean(krbEnabledForITs)) {
+    if (krbEnabledForITs == null || !Boolean.parseBoolean(krbEnabledForITs)) {
       System.setProperty(MiniClusterHarness.USE_KERBEROS_FOR_IT_OPTION, "true");
     }
     rootUser = kdc.getRootUser();
@@ -94,10 +94,10 @@ public class KerberosRenewalIT extends AccumuloITBase {
 
   @AfterClass
   public static void stopKdc() throws Exception {
-    if (null != kdc) {
+    if (kdc != null) {
       kdc.stop();
     }
-    if (null != krbEnabledForITs) {
+    if (krbEnabledForITs != null) {
       System.setProperty(MiniClusterHarness.USE_KERBEROS_FOR_IT_OPTION, krbEnabledForITs);
     }
   }
@@ -136,7 +136,7 @@ public class KerberosRenewalIT extends AccumuloITBase {
 
   @After
   public void stopMac() throws Exception {
-    if (null != mac) {
+    if (mac != null) {
       mac.stop();
     }
   }
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/LargeRowIT.java b/test/src/main/java/org/apache/accumulo/test/functional/LargeRowIT.java
index 2857968..f28a22b 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/LargeRowIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/LargeRowIT.java
@@ -103,7 +103,7 @@ public class LargeRowIT extends AccumuloClusterHarness {
 
   @After
   public void resetMajcDelay() throws Exception {
-    if (null != tservMajcDelay) {
+    if (tservMajcDelay != null) {
       try (AccumuloClient client = createAccumuloClient()) {
         client.instanceOperations().setProperty(Property.TSERV_MAJC_DELAY.getKey(), tservMajcDelay);
       }
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/MaxOpenIT.java b/test/src/main/java/org/apache/accumulo/test/functional/MaxOpenIT.java
index 5ad2e65..c4f493d 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/MaxOpenIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/MaxOpenIT.java
@@ -78,13 +78,13 @@ public class MaxOpenIT extends AccumuloClusterHarness {
   public void restoreConfig() throws Exception {
     try (AccumuloClient client = createAccumuloClient()) {
       InstanceOperations iops = client.instanceOperations();
-      if (null != scanMaxOpenFiles) {
+      if (scanMaxOpenFiles != null) {
         iops.setProperty(Property.TSERV_SCAN_MAX_OPENFILES.getKey(), scanMaxOpenFiles);
       }
-      if (null != majcConcurrent) {
+      if (majcConcurrent != null) {
         iops.setProperty(Property.TSERV_MAJC_MAXCONCURRENT.getKey(), majcConcurrent);
       }
-      if (null != majcThreadMaxOpen) {
+      if (majcThreadMaxOpen != null) {
         iops.setProperty(Property.TSERV_MAJC_THREAD_MAXOPEN.getKey(), majcThreadMaxOpen);
       }
     }
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/MonitorSslIT.java b/test/src/main/java/org/apache/accumulo/test/functional/MonitorSslIT.java
index ce2b752..ddda7e2 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/MonitorSslIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/MonitorSslIT.java
@@ -129,13 +129,13 @@ public class MonitorSslIT extends ConfigurableMacBase {
     cluster.getClusterControl().startAllServers(ServerType.MONITOR);
     String monitorLocation = null;
     try (AccumuloClient client = createClient()) {
-      while (null == monitorLocation) {
+      while (monitorLocation == null) {
         try {
           monitorLocation = MonitorUtil.getLocation((ClientContext) client);
         } catch (Exception e) {
           // ignored
         }
-        if (null == monitorLocation) {
+        if (monitorLocation == null) {
           log.debug("Could not fetch monitor HTTP address from zookeeper");
           Thread.sleep(2000);
         }
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/PermissionsIT.java b/test/src/main/java/org/apache/accumulo/test/functional/PermissionsIT.java
index 5b7e249..39db95e 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/PermissionsIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/PermissionsIT.java
@@ -77,7 +77,7 @@ public class PermissionsIT extends AccumuloClusterHarness {
 
   @Before
   public void limitToMini() throws Exception {
-    Assume.assumeTrue(ClusterType.MINI == getClusterType());
+    Assume.assumeTrue(getClusterType() == ClusterType.MINI);
     try (AccumuloClient c = createAccumuloClient()) {
       Set<String> users = c.securityOperations().listLocalUsers();
       ClusterUser user = getUser(0);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ReadWriteIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ReadWriteIT.java
index ed42344..508c111 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ReadWriteIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ReadWriteIT.java
@@ -148,9 +148,9 @@ public class ReadWriteIT extends AccumuloClusterHarness {
       ingest(accumuloClient, getClientInfo(), ROWS, COLS, 50, 0, tableName);
       verify(accumuloClient, getClientInfo(), ROWS, COLS, 50, 0, tableName);
       String monitorLocation = null;
-      while (null == monitorLocation) {
+      while (monitorLocation == null) {
         monitorLocation = MonitorUtil.getLocation((ClientContext) accumuloClient);
-        if (null == monitorLocation) {
+        if (monitorLocation == null) {
           log.debug("Could not fetch monitor HTTP address from zookeeper");
           Thread.sleep(2000);
         }
@@ -164,7 +164,7 @@ public class ReadWriteIT extends AccumuloClusterHarness {
           Configuration conf = new Configuration(false);
           conf.addResource(new Path(accumuloProps.toURI()));
           String monitorSslKeystore = conf.get(Property.MONITOR_SSL_KEYSTORE.getKey());
-          if (null != monitorSslKeystore) {
+          if (monitorSslKeystore != null) {
             log.info("Using HTTPS since monitor ssl keystore configuration was observed in {}",
                 accumuloProps);
             scheme = "https://";
@@ -194,11 +194,11 @@ public class ReadWriteIT extends AccumuloClusterHarness {
       do {
         masterLockData = ZooLock.getLockData(zcache,
             ZooUtil.getRoot(accumuloClient.getInstanceID()) + Constants.ZMASTER_LOCK, null);
-        if (null != masterLockData) {
+        if (masterLockData != null) {
           log.info("Master lock is still held");
           Thread.sleep(1000);
         }
-      } while (null != masterLockData);
+      } while (masterLockData != null);
 
       control.stopAllServers(ServerType.GARBAGE_COLLECTOR);
       control.stopAllServers(ServerType.MONITOR);
@@ -466,7 +466,7 @@ public class ReadWriteIT extends AccumuloClusterHarness {
           args.add(entry.getKey().getColumnQualifier().toString());
           args.add("--props");
           args.add(getCluster().getAccumuloPropertiesPath());
-          if (ClusterType.STANDALONE == getClusterType() && saslEnabled()) {
+          if (getClusterType() == ClusterType.STANDALONE && saslEnabled()) {
             args.add("--config");
             StandaloneAccumuloCluster sac = (StandaloneAccumuloCluster) cluster;
             String hadoopConfDir = sac.getHadoopConfDir();
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/RestartIT.java b/test/src/main/java/org/apache/accumulo/test/functional/RestartIT.java
index 26be49c..12d925e 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/RestartIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/RestartIT.java
@@ -92,7 +92,7 @@ public class RestartIT extends AccumuloClusterHarness {
 
   @After
   public void teardown() throws Exception {
-    if (null == svc) {
+    if (svc == null) {
       return;
     }
 
@@ -174,11 +174,11 @@ public class RestartIT extends AccumuloClusterHarness {
       do {
         masterLockData = ZooLock.getLockData(zcache,
             ZooUtil.getRoot(c.getInstanceID()) + Constants.ZMASTER_LOCK, null);
-        if (null != masterLockData) {
+        if (masterLockData != null) {
           log.info("Master lock is still held");
           Thread.sleep(1000);
         }
-      } while (null != masterLockData);
+      } while (masterLockData != null);
 
       cluster.start();
       sleepUninterruptibly(5, TimeUnit.MILLISECONDS);
@@ -188,11 +188,11 @@ public class RestartIT extends AccumuloClusterHarness {
       do {
         masterLockData = ZooLock.getLockData(zcache,
             ZooUtil.getRoot(c.getInstanceID()) + Constants.ZMASTER_LOCK, null);
-        if (null != masterLockData) {
+        if (masterLockData != null) {
           log.info("Master lock is still held");
           Thread.sleep(1000);
         }
-      } while (null != masterLockData);
+      } while (masterLockData != null);
       cluster.start();
       VerifyIngest.verifyIngest(c, VOPTS, SOPTS);
     }
@@ -243,11 +243,11 @@ public class RestartIT extends AccumuloClusterHarness {
       do {
         masterLockData = ZooLock.getLockData(zcache,
             ZooUtil.getRoot(c.getInstanceID()) + Constants.ZMASTER_LOCK, null);
-        if (null != masterLockData) {
+        if (masterLockData != null) {
           log.info("Master lock is still held");
           Thread.sleep(1000);
         }
-      } while (null != masterLockData);
+      } while (masterLockData != null);
 
       cluster.start();
       assertEquals(0, ret.get().intValue());
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/RestartStressIT.java b/test/src/main/java/org/apache/accumulo/test/functional/RestartStressIT.java
index e707c80..fa54510 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/RestartStressIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/RestartStressIT.java
@@ -76,7 +76,7 @@ public class RestartStressIT extends AccumuloClusterHarness {
 
   @After
   public void teardown() throws Exception {
-    if (null == svc) {
+    if (svc == null) {
       return;
     }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ScanIdIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ScanIdIT.java
index 2c8d602..6785a69 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ScanIdIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ScanIdIT.java
@@ -182,7 +182,7 @@ public class ScanIdIT extends AccumuloClusterHarness {
       }
 
       assertTrue("Expected at least " + NUM_SCANNERS + " scanIds, but saw " + scanIds.size(),
-          NUM_SCANNERS <= scanIds.size());
+          scanIds.size() >= NUM_SCANNERS);
 
     }
   }
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ScanIteratorIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ScanIteratorIT.java
index 7003476..24d853b 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ScanIteratorIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ScanIteratorIT.java
@@ -95,7 +95,7 @@ public class ScanIteratorIT extends AccumuloClusterHarness {
 
   @After
   public void tearDown() throws Exception {
-    if (null != user) {
+    if (user != null) {
       if (saslEnabled) {
         ClusterUser rootUser = getAdminUser();
         UserGroupInformation.loginUserFromKeytab(rootUser.getPrincipal(),
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ScanSessionTimeOutIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ScanSessionTimeOutIT.java
index 8fbf11d..2c48388 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ScanSessionTimeOutIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ScanSessionTimeOutIT.java
@@ -85,7 +85,7 @@ public class ScanSessionTimeOutIT extends AccumuloClusterHarness {
 
   @After
   public void resetSessionIdle() throws Exception {
-    if (null != sessionIdle) {
+    if (sessionIdle != null) {
       try (AccumuloClient client = createAccumuloClient()) {
         client.instanceOperations().setProperty(Property.TSERV_SESSION_MAXIDLE.getKey(),
             sessionIdle);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ScannerContextIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ScannerContextIT.java
index e3c9cfe..888cc0e 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ScannerContextIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ScannerContextIT.java
@@ -284,10 +284,10 @@ public class ScannerContextIT extends AccumuloClusterHarness {
   private void scanCheck(AccumuloClient c, String tableName, IteratorSetting cfg, String context,
       String expected) throws Exception {
     try (Scanner bs = c.createScanner(tableName, Authorizations.EMPTY)) {
-      if (null != context) {
+      if (context != null) {
         bs.setClassLoaderContext(context);
       }
-      if (null != cfg) {
+      if (cfg != null) {
         bs.addScanIterator(cfg);
       }
       Iterator<Entry<Key,Value>> iterator = bs.iterator();
@@ -304,10 +304,10 @@ public class ScannerContextIT extends AccumuloClusterHarness {
       String expected) throws Exception {
     try (BatchScanner bs = c.createBatchScanner(tableName, Authorizations.EMPTY, 1)) {
       bs.setRanges(Collections.singleton(new Range()));
-      if (null != context) {
+      if (context != null) {
         bs.setClassLoaderContext(context);
       }
-      if (null != cfg) {
+      if (cfg != null) {
         bs.addScanIterator(cfg);
       }
       Iterator<Entry<Key,Value>> iterator = bs.iterator();
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/SessionDurabilityIT.java b/test/src/main/java/org/apache/accumulo/test/functional/SessionDurabilityIT.java
index 208e301..7141b14 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/SessionDurabilityIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/SessionDurabilityIT.java
@@ -80,7 +80,7 @@ public class SessionDurabilityIT extends ConfigurableMacBase {
       writeSome(c, tableName, 10, cfg);
       // verify writes are lost on restart
       restartTServer();
-      assertTrue(10 > count(c, tableName));
+      assertTrue(count(c, tableName) < 10);
     }
   }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/SplitIT.java b/test/src/main/java/org/apache/accumulo/test/functional/SplitIT.java
index 35b4ba3..80b3969 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/SplitIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/SplitIT.java
@@ -73,7 +73,7 @@ public class SplitIT extends AccumuloClusterHarness {
 
   @Before
   public void alterConfig() throws Exception {
-    Assume.assumeTrue(ClusterType.MINI == getClusterType());
+    Assume.assumeTrue(getClusterType() == ClusterType.MINI);
     try (AccumuloClient client = createAccumuloClient()) {
       InstanceOperations iops = client.instanceOperations();
       Map<String,String> config = iops.getSystemConfiguration();
@@ -106,14 +106,14 @@ public class SplitIT extends AccumuloClusterHarness {
   @After
   public void resetConfig() throws Exception {
     try (AccumuloClient client = createAccumuloClient()) {
-      if (null != tservMaxMem) {
+      if (tservMaxMem != null) {
         log.info("Resetting {}={}", Property.TSERV_MAXMEM.getKey(), tservMaxMem);
         client.instanceOperations().setProperty(Property.TSERV_MAXMEM.getKey(), tservMaxMem);
         tservMaxMem = null;
         getCluster().getClusterControl().stopAllServers(ServerType.TABLET_SERVER);
         getCluster().getClusterControl().startAllServers(ServerType.TABLET_SERVER);
       }
-      if (null != tservMajcDelay) {
+      if (tservMajcDelay != null) {
         log.info("Resetting {}={}", Property.TSERV_MAJC_DELAY.getKey(), tservMajcDelay);
         client.instanceOperations().setProperty(Property.TSERV_MAJC_DELAY.getKey(), tservMajcDelay);
         tservMajcDelay = null;
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/VisibilityIT.java b/test/src/main/java/org/apache/accumulo/test/functional/VisibilityIT.java
index 094c063..ecdb7de 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/VisibilityIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/VisibilityIT.java
@@ -70,7 +70,7 @@ public class VisibilityIT extends AccumuloClusterHarness {
   @After
   public void resetAuths() throws Exception {
     try (AccumuloClient c = createAccumuloClient()) {
-      if (null != origAuths) {
+      if (origAuths != null) {
         c.securityOperations().changeUserAuthorizations(getAdminPrincipal(), origAuths);
       }
     }
diff --git a/test/src/main/java/org/apache/accumulo/test/proxy/SimpleProxyBase.java b/test/src/main/java/org/apache/accumulo/test/proxy/SimpleProxyBase.java
index a7aba98..a72d7b7 100644
--- a/test/src/main/java/org/apache/accumulo/test/proxy/SimpleProxyBase.java
+++ b/test/src/main/java/org/apache/accumulo/test/proxy/SimpleProxyBase.java
@@ -239,7 +239,7 @@ public abstract class SimpleProxyBase extends SharedMiniClusterBase {
 
   @AfterClass
   public static void tearDownProxy() throws Exception {
-    if (null != proxyServer) {
+    if (proxyServer != null) {
       proxyServer.stop();
     }
 
@@ -312,7 +312,7 @@ public abstract class SimpleProxyBase extends SharedMiniClusterBase {
 
   @After
   public void teardown() throws Exception {
-    if (null != tableName) {
+    if (tableName != null) {
       if (isKerberosEnabled()) {
         UserGroupInformation.loginUserFromKeytab(clientPrincipal, clientKeytab.getAbsolutePath());
       }
@@ -325,7 +325,7 @@ public abstract class SimpleProxyBase extends SharedMiniClusterBase {
       }
     }
 
-    if (null != namespaceName) {
+    if (namespaceName != null) {
       try {
         if (client.namespaceExists(creds, namespaceName)) {
           client.deleteNamespace(creds, namespaceName);
@@ -336,7 +336,7 @@ public abstract class SimpleProxyBase extends SharedMiniClusterBase {
     }
 
     // Close the transport after the test
-    if (null != proxyClient) {
+    if (proxyClient != null) {
       proxyClient.close();
     }
   }
@@ -1274,7 +1274,7 @@ public abstract class SimpleProxyBase extends SharedMiniClusterBase {
         } catch (Exception e) {
           throw new RuntimeException(e);
         } finally {
-          if (null != proxyClient2) {
+          if (proxyClient2 != null) {
             proxyClient2.close();
           }
         }
@@ -1360,7 +1360,7 @@ public abstract class SimpleProxyBase extends SharedMiniClusterBase {
         } catch (Exception e) {
           throw new RuntimeException(e);
         } finally {
-          if (null != proxyClient2) {
+          if (proxyClient2 != null) {
             proxyClient2.close();
           }
         }
@@ -1472,7 +1472,7 @@ public abstract class SimpleProxyBase extends SharedMiniClusterBase {
         otherProxyClient = new TestProxyClient(hostname, proxyPort, factory, proxyPrimary, ugi);
         otherProxyClient.proxy().login(user, Collections.<String,String> emptyMap());
       } finally {
-        if (null != otherProxyClient) {
+        if (otherProxyClient != null) {
           otherProxyClient.close();
         }
       }
@@ -2391,7 +2391,7 @@ public abstract class SimpleProxyBase extends SharedMiniClusterBase {
 
       assertEquals(1, results.size());
       status = results.get(s2bb("00347"));
-      if (ConditionalStatus.VIOLATED != status) {
+      if (status != ConditionalStatus.VIOLATED) {
         log.info("ConditionalUpdate was not rejected by server due to table"
             + " constraint. Sleeping and retrying");
         Thread.sleep(5000);
@@ -2626,7 +2626,7 @@ public abstract class SimpleProxyBase extends SharedMiniClusterBase {
     } finally {
       if (isKerberosEnabled()) {
         // Close the other client
-        if (null != cwuserProxyClient) {
+        if (cwuserProxyClient != null) {
           cwuserProxyClient.close();
         }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/proxy/TestProxyClient.java b/test/src/main/java/org/apache/accumulo/test/proxy/TestProxyClient.java
index 657a0a9..87eab25 100644
--- a/test/src/main/java/org/apache/accumulo/test/proxy/TestProxyClient.java
+++ b/test/src/main/java/org/apache/accumulo/test/proxy/TestProxyClient.java
@@ -85,7 +85,7 @@ public class TestProxyClient {
   }
 
   public synchronized void close() {
-    if (null != transport) {
+    if (transport != null) {
       transport.close();
       transport = null;
     }
diff --git a/test/src/main/java/org/apache/accumulo/test/replication/CyclicReplicationIT.java b/test/src/main/java/org/apache/accumulo/test/replication/CyclicReplicationIT.java
index 3df1ee8..5649c88 100644
--- a/test/src/main/java/org/apache/accumulo/test/replication/CyclicReplicationIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/replication/CyclicReplicationIT.java
@@ -133,12 +133,12 @@ public class CyclicReplicationIT {
 
       // Passwords might be stored in CredentialProvider
       String keystorePassword = primarySiteConfig.get(Property.RPC_SSL_KEYSTORE_PASSWORD.getKey());
-      if (null != keystorePassword) {
+      if (keystorePassword != null) {
         peerSiteConfig.put(Property.RPC_SSL_KEYSTORE_PASSWORD.getKey(), keystorePassword);
       }
       String truststorePassword = primarySiteConfig
           .get(Property.RPC_SSL_TRUSTSTORE_PASSWORD.getKey());
-      if (null != truststorePassword) {
+      if (truststorePassword != null) {
         peerSiteConfig.put(Property.RPC_SSL_TRUSTSTORE_PASSWORD.getKey(), truststorePassword);
       }
 
@@ -149,7 +149,7 @@ public class CyclicReplicationIT {
     // Use the CredentialProvider if the primary also uses one
     String credProvider = primarySiteConfig
         .get(Property.GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS.getKey());
-    if (null != credProvider) {
+    if (credProvider != null) {
       Map<String,String> peerSiteConfig = peerCfg.getSiteConfig();
       peerSiteConfig.put(Property.GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS.getKey(),
           credProvider);
diff --git a/test/src/main/java/org/apache/accumulo/test/replication/KerberosReplicationIT.java b/test/src/main/java/org/apache/accumulo/test/replication/KerberosReplicationIT.java
index a7bed3a6..3655fb6 100644
--- a/test/src/main/java/org/apache/accumulo/test/replication/KerberosReplicationIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/replication/KerberosReplicationIT.java
@@ -83,7 +83,7 @@ public class KerberosReplicationIT extends AccumuloITBase {
     kdc = new TestingKdc();
     kdc.start();
     krbEnabledForITs = System.getProperty(MiniClusterHarness.USE_KERBEROS_FOR_IT_OPTION);
-    if (null == krbEnabledForITs || !Boolean.parseBoolean(krbEnabledForITs)) {
+    if (krbEnabledForITs == null || !Boolean.parseBoolean(krbEnabledForITs)) {
       System.setProperty(MiniClusterHarness.USE_KERBEROS_FOR_IT_OPTION, "true");
     }
     rootUser = kdc.getRootUser();
@@ -91,10 +91,10 @@ public class KerberosReplicationIT extends AccumuloITBase {
 
   @AfterClass
   public static void stopKdc() throws Exception {
-    if (null != kdc) {
+    if (kdc != null) {
       kdc.stop();
     }
-    if (null != krbEnabledForITs) {
+    if (krbEnabledForITs != null) {
       System.setProperty(MiniClusterHarness.USE_KERBEROS_FOR_IT_OPTION, krbEnabledForITs);
     }
   }
@@ -150,10 +150,10 @@ public class KerberosReplicationIT extends AccumuloITBase {
 
   @After
   public void teardown() throws Exception {
-    if (null != peer) {
+    if (peer != null) {
       peer.stop();
     }
-    if (null != primary) {
+    if (primary != null) {
       primary.stop();
     }
     UserGroupInformation.setConfiguration(new Configuration(false));
diff --git a/test/src/main/java/org/apache/accumulo/test/replication/MultiInstanceReplicationIT.java b/test/src/main/java/org/apache/accumulo/test/replication/MultiInstanceReplicationIT.java
index 68c93ae..e1ae809 100644
--- a/test/src/main/java/org/apache/accumulo/test/replication/MultiInstanceReplicationIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/replication/MultiInstanceReplicationIT.java
@@ -94,7 +94,7 @@ public class MultiInstanceReplicationIT extends ConfigurableMacBase {
 
   @After
   public void stopExecutor() {
-    if (null != executor) {
+    if (executor != null) {
       executor.shutdownNow();
     }
   }
@@ -136,12 +136,12 @@ public class MultiInstanceReplicationIT extends ConfigurableMacBase {
 
       // Passwords might be stored in CredentialProvider
       String keystorePassword = primarySiteConfig.get(Property.RPC_SSL_KEYSTORE_PASSWORD.getKey());
-      if (null != keystorePassword) {
+      if (keystorePassword != null) {
         peerSiteConfig.put(Property.RPC_SSL_KEYSTORE_PASSWORD.getKey(), keystorePassword);
       }
       String truststorePassword = primarySiteConfig
           .get(Property.RPC_SSL_TRUSTSTORE_PASSWORD.getKey());
-      if (null != truststorePassword) {
+      if (truststorePassword != null) {
         peerSiteConfig.put(Property.RPC_SSL_TRUSTSTORE_PASSWORD.getKey(), truststorePassword);
       }
 
@@ -152,7 +152,7 @@ public class MultiInstanceReplicationIT extends ConfigurableMacBase {
     // Use the CredentialProvider if the primary also uses one
     String credProvider = primarySiteConfig
         .get(Property.GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS.getKey());
-    if (null != credProvider) {
+    if (credProvider != null) {
       Map<String,String> peerSiteConfig = peerCfg.getSiteConfig();
       peerSiteConfig.put(Property.GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS.getKey(),
           credProvider);
@@ -762,7 +762,7 @@ public class MultiInstanceReplicationIT extends ConfigurableMacBase {
 
         log.info("Found {} records in {}", countTable, peerTable1);
 
-        if (0L == countTable) {
+        if (countTable == 0L) {
           Thread.sleep(5000);
         } else {
           break;
@@ -784,7 +784,7 @@ public class MultiInstanceReplicationIT extends ConfigurableMacBase {
 
         log.info("Found {} records in {}", countTable, peerTable2);
 
-        if (0L == countTable) {
+        if (countTable == 0L) {
           Thread.sleep(5000);
         } else {
           break;
diff --git a/test/src/main/java/org/apache/accumulo/test/replication/ReplicationIT.java b/test/src/main/java/org/apache/accumulo/test/replication/ReplicationIT.java
index 176511d..6ae7569 100644
--- a/test/src/main/java/org/apache/accumulo/test/replication/ReplicationIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/replication/ReplicationIT.java
@@ -205,7 +205,7 @@ public class ReplicationIT extends ConfigurableMacBase {
     String zkPath = ZooUtil.getRoot(client.getInstanceID()) + Constants.ZGC_LOCK;
     log.info("Looking for GC lock at {}", zkPath);
     byte[] data = ZooLock.getLockData(zcache, zkPath, null);
-    while (null == data) {
+    while (data == null) {
       log.info("Waiting for GC ZooKeeper lock to be acquired");
       Thread.sleep(1000);
       data = ZooLock.getLockData(zcache, zkPath, null);
@@ -926,7 +926,7 @@ public class ReplicationIT extends ConfigurableMacBase {
         Status expectedStatus = StatusUtil.openWithUnknownLength();
         attempts = 10;
         // This record will move from new to new with infinite length because of the minc (flush)
-        while (null == entry && attempts > 0) {
+        while (entry == null && attempts > 0) {
           try {
             entry = Iterables.getOnlyElement(s);
             Status actual = Status.parseFrom(entry.getValue().get());
@@ -964,7 +964,7 @@ public class ReplicationIT extends ConfigurableMacBase {
           try (Scanner s2 = ReplicationTable.getScanner(client)) {
             WorkSection.limit(s2);
             int elementsFound = Iterables.size(s2);
-            if (0 < elementsFound) {
+            if (elementsFound > 0) {
               assertEquals(1, elementsFound);
               notFound = false;
             }
@@ -1014,7 +1014,7 @@ public class ReplicationIT extends ConfigurableMacBase {
           try (Scanner s2 = ReplicationTable.getScanner(client)) {
             WorkSection.limit(s2);
             int elementsFound = Iterables.size(s2);
-            if (2 == elementsFound) {
+            if (elementsFound == 2) {
               notFound = false;
             }
             Thread.sleep(500);
diff --git a/test/src/main/java/org/apache/accumulo/test/replication/UnorderedWorkAssignerReplicationIT.java b/test/src/main/java/org/apache/accumulo/test/replication/UnorderedWorkAssignerReplicationIT.java
index bb20092..1ad2e9c 100644
--- a/test/src/main/java/org/apache/accumulo/test/replication/UnorderedWorkAssignerReplicationIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/replication/UnorderedWorkAssignerReplicationIT.java
@@ -96,7 +96,7 @@ public class UnorderedWorkAssignerReplicationIT extends ConfigurableMacBase {
 
   @After
   public void stopExecutor() {
-    if (null != executor) {
+    if (executor != null) {
       executor.shutdownNow();
     }
   }
@@ -143,12 +143,12 @@ public class UnorderedWorkAssignerReplicationIT extends ConfigurableMacBase {
 
       // Passwords might be stored in CredentialProvider
       String keystorePassword = primarySiteConfig.get(Property.RPC_SSL_KEYSTORE_PASSWORD.getKey());
-      if (null != keystorePassword) {
+      if (keystorePassword != null) {
         peerSiteConfig.put(Property.RPC_SSL_KEYSTORE_PASSWORD.getKey(), keystorePassword);
       }
       String truststorePassword = primarySiteConfig
           .get(Property.RPC_SSL_TRUSTSTORE_PASSWORD.getKey());
-      if (null != truststorePassword) {
+      if (truststorePassword != null) {
         peerSiteConfig.put(Property.RPC_SSL_TRUSTSTORE_PASSWORD.getKey(), truststorePassword);
       }
 
@@ -159,7 +159,7 @@ public class UnorderedWorkAssignerReplicationIT extends ConfigurableMacBase {
     // Use the CredentialProvider if the primary also uses one
     String credProvider = primarySiteConfig
         .get(Property.GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS.getKey());
-    if (null != credProvider) {
+    if (credProvider != null) {
       Map<String,String> peerSiteConfig = peerCfg.getSiteConfig();
       peerSiteConfig.put(Property.GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS.getKey(),
           credProvider);
@@ -769,7 +769,7 @@ public class UnorderedWorkAssignerReplicationIT extends ConfigurableMacBase {
               + entry.getValue(), entry.getKey().getRow().toString().startsWith(masterTable1));
         }
         log.info("Found {} records in {}", countTable, peerTable1);
-        if (0 < countTable) {
+        if (countTable > 0) {
           break;
         }
         Thread.sleep(2000);
@@ -786,7 +786,7 @@ public class UnorderedWorkAssignerReplicationIT extends ConfigurableMacBase {
         }
 
         log.info("Found {} records in {}", countTable, peerTable2);
-        if (0 < countTable) {
+        if (countTable > 0) {
           break;
         }
         Thread.sleep(2000);