You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@accumulo.apache.org by GitBox <gi...@apache.org> on 2018/05/09 18:49:04 UTC

[GitHub] mikewalch closed pull request #479: More intellij automated fixes

mikewalch closed pull request #479: More intellij automated fixes
URL: https://github.com/apache/accumulo/pull/479
 
 
   

This is a PR merged from a forked repository.
As GitHub hides the original diff on merge, it is displayed below for
the sake of provenance:

As this is a foreign pull request (from a fork), the diff is supplied
below (as it won't show otherwise due to GitHub magic):

diff --git a/client/mapreduce/src/test/java/org/apache/accumulo/core/client/mapreduce/impl/BatchInputSplitTest.java b/client/mapreduce/src/test/java/org/apache/accumulo/core/client/mapreduce/impl/BatchInputSplitTest.java
index a9fd63c1ab..a5fb3bbc5f 100644
--- a/client/mapreduce/src/test/java/org/apache/accumulo/core/client/mapreduce/impl/BatchInputSplitTest.java
+++ b/client/mapreduce/src/test/java/org/apache/accumulo/core/client/mapreduce/impl/BatchInputSplitTest.java
@@ -23,7 +23,9 @@
 import java.io.IOException;
 import java.util.ArrayList;
 import java.util.Arrays;
+import java.util.Collections;
 import java.util.HashSet;
+import java.util.List;
 import java.util.Set;
 
 import org.apache.accumulo.core.client.IteratorSetting;
@@ -44,8 +46,8 @@
 
   @Test
   public void testSimpleWritable() throws IOException {
-    Range[] ranges = new Range[] {new Range(new Key("a"), new Key("b"))};
-    BatchInputSplit split = new BatchInputSplit("table", Table.ID.of("1"), Arrays.asList(ranges),
+    List<Range> ranges = Collections.singletonList(new Range(new Key("a"), new Key("b")));
+    BatchInputSplit split = new BatchInputSplit("table", Table.ID.of("1"), ranges,
         new String[] {"localhost"});
 
     ByteArrayOutputStream baos = new ByteArrayOutputStream();
@@ -66,8 +68,8 @@ public void testSimpleWritable() throws IOException {
 
   @Test
   public void testAllFieldsWritable() throws IOException {
-    Range[] ranges = new Range[] {new Range(new Key("a"), new Key("b"))};
-    BatchInputSplit split = new BatchInputSplit("table", Table.ID.of("1"), Arrays.asList(ranges),
+    List<Range> ranges = Collections.singletonList(new Range(new Key("a"), new Key("b")));
+    BatchInputSplit split = new BatchInputSplit("table", Table.ID.of("1"), ranges,
         new String[] {"localhost"});
 
     Set<Pair<Text,Text>> fetchedColumns = new HashSet<>();
diff --git a/client/mapreduce/src/test/java/org/apache/accumulo/core/client/mapreduce/lib/partition/RangePartitionerTest.java b/client/mapreduce/src/test/java/org/apache/accumulo/core/client/mapreduce/lib/partition/RangePartitionerTest.java
index e194a7624a..90e58d2b18 100644
--- a/client/mapreduce/src/test/java/org/apache/accumulo/core/client/mapreduce/lib/partition/RangePartitionerTest.java
+++ b/client/mapreduce/src/test/java/org/apache/accumulo/core/client/mapreduce/lib/partition/RangePartitionerTest.java
@@ -26,7 +26,7 @@
 
 public class RangePartitionerTest {
 
-  private static Text[] cutArray = new Text[] {new Text("A"), new Text("B"), new Text("C")};
+  private static Text[] cutArray = {new Text("A"), new Text("B"), new Text("C")};
 
   @Test
   public void testNoSubBins() throws IOException {
diff --git a/core/src/main/java/org/apache/accumulo/core/Constants.java b/core/src/main/java/org/apache/accumulo/core/Constants.java
index bf057e5397..f8cf8e270c 100644
--- a/core/src/main/java/org/apache/accumulo/core/Constants.java
+++ b/core/src/main/java/org/apache/accumulo/core/Constants.java
@@ -33,7 +33,7 @@
   public static final String ZINSTANCES = "/instances";
 
   public static final String ZTABLES = "/tables";
-  public static final byte[] ZTABLES_INITIAL_ID = new byte[] {'0'};
+  public static final byte[] ZTABLES_INITIAL_ID = {'0'};
   public static final String ZTABLE_NAME = "/name";
   public static final String ZTABLE_CONF = "/conf";
   public static final String ZTABLE_STATE = "/state";
diff --git a/core/src/main/java/org/apache/accumulo/core/bloomfilter/BloomFilter.java b/core/src/main/java/org/apache/accumulo/core/bloomfilter/BloomFilter.java
index 4d704f3897..50f035e3a7 100644
--- a/core/src/main/java/org/apache/accumulo/core/bloomfilter/BloomFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/bloomfilter/BloomFilter.java
@@ -87,8 +87,8 @@
  */
 public class BloomFilter extends Filter {
   private static final Logger log = LoggerFactory.getLogger(BloomFilter.class);
-  private static final byte[] bitvalues = new byte[] {(byte) 0x01, (byte) 0x02, (byte) 0x04,
-      (byte) 0x08, (byte) 0x10, (byte) 0x20, (byte) 0x40, (byte) 0x80};
+  private static final byte[] bitvalues = {(byte) 0x01, (byte) 0x02, (byte) 0x04, (byte) 0x08,
+      (byte) 0x10, (byte) 0x20, (byte) 0x40, (byte) 0x80};
 
   /** The bit vector. */
   BitSet bits;
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchReaderIterator.java b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchReaderIterator.java
index 4c87dca565..0ccf8653b9 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchReaderIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchReaderIterator.java
@@ -121,9 +121,8 @@ public TabletServerBatchReaderIterator(ClientContext context, Table.ID tableId,
 
     this.locator = new TimeoutTabletLocator(timeout, context, tableId);
 
-    timeoutTrackers = Collections
-        .synchronizedMap(new HashMap<String,TabletServerBatchReaderIterator.TimeoutTracker>());
-    timedoutServers = Collections.synchronizedSet(new HashSet<String>());
+    timeoutTrackers = Collections.synchronizedMap(new HashMap<>());
+    timedoutServers = Collections.synchronizedSet(new HashSet<>());
     this.timeout = timeout;
 
     if (options.fetchedColumns.size() > 0) {
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java
index 868d70425d..1be64ea794 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java
@@ -123,7 +123,7 @@
   // latency timers
   private final Timer jtimer = new Timer("BatchWriterLatencyTimer", true);
   private final Map<String,TimeoutTracker> timeoutTrackers = Collections
-      .synchronizedMap(new HashMap<String,TabletServerBatchWriter.TimeoutTracker>());
+      .synchronizedMap(new HashMap<>());
 
   // stats
   private long totalMemUsed = 0;
diff --git a/core/src/main/java/org/apache/accumulo/core/client/summary/CountingSummarizer.java b/core/src/main/java/org/apache/accumulo/core/client/summary/CountingSummarizer.java
index 3837d5abb5..b39b0c7457 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/summary/CountingSummarizer.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/summary/CountingSummarizer.java
@@ -153,8 +153,8 @@
   // this default can not be changed as persisted summary data depends on it
   public static final String INGNORE_DELETES_DEFAULT = "true";
 
-  private static final String[] ALL_STATS = new String[] {TOO_LONG_STAT, TOO_MANY_STAT,
-      EMITTED_STAT, SEEN_STAT, DELETES_IGNORED_STAT};
+  private static final String[] ALL_STATS = {TOO_LONG_STAT, TOO_MANY_STAT, EMITTED_STAT, SEEN_STAT,
+      DELETES_IGNORED_STAT};
 
   private int maxCounters;
   private int maxCounterKeyLen;
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationCopy.java b/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationCopy.java
index d08f66d93c..8e082b7ade 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationCopy.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationCopy.java
@@ -28,7 +28,7 @@
  */
 public class ConfigurationCopy extends AccumuloConfiguration {
   private long updateCount = 0;
-  final Map<String,String> copy = Collections.synchronizedMap(new HashMap<String,String>());
+  final Map<String,String> copy = Collections.synchronizedMap(new HashMap<>());
 
   /**
    * Creates a new configuration.
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationTypeHelper.java b/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationTypeHelper.java
index def6e5f78c..b4686edddd 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationTypeHelper.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/ConfigurationTypeHelper.java
@@ -150,8 +150,7 @@ public static double getFraction(String str) {
   }
 
   // This is not a cache for loaded classes, just a way to avoid spamming the debug log
-  private static Map<String,Class<?>> loaded = Collections
-      .synchronizedMap(new HashMap<String,Class<?>>());
+  private static Map<String,Class<?>> loaded = Collections.synchronizedMap(new HashMap<>());
 
   /**
    * Loads a class in the given classloader context, suppressing any exceptions, and optionally
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/ObservableConfiguration.java b/core/src/main/java/org/apache/accumulo/core/conf/ObservableConfiguration.java
index 79115135b5..8790bdb567 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/ObservableConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/ObservableConfiguration.java
@@ -33,7 +33,7 @@
    * Creates a new observable configuration.
    */
   public ObservableConfiguration() {
-    observers = Collections.synchronizedSet(new java.util.HashSet<ConfigurationObserver>());
+    observers = Collections.synchronizedSet(new java.util.HashSet<>());
   }
 
   /**
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/KeyShortener.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/KeyShortener.java
index 590659dd9a..74bd0e3b7c 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/KeyShortener.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/KeyShortener.java
@@ -34,8 +34,8 @@
 public class KeyShortener {
 
   private static final byte[] EMPTY = new byte[0];
-  private static final byte[] B00 = new byte[] {(byte) 0x00};
-  private static final byte[] BFF = new byte[] {(byte) 0xff};
+  private static final byte[] B00 = {(byte) 0x00};
+  private static final byte[] BFF = {(byte) 0xff};
 
   private static final Logger log = LoggerFactory.getLogger(KeyShortener.class);
 
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/conf/ColumnSet.java b/core/src/main/java/org/apache/accumulo/core/iterators/conf/ColumnSet.java
index a219e4f8ca..f182757822 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/conf/ColumnSet.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/conf/ColumnSet.java
@@ -146,7 +146,7 @@ static Text decode(String s) {
       if (sb[i] != '%') {
         t.append(new byte[] {sb[i]}, 0, 1);
       } else {
-        byte hex[] = new byte[] {sb[++i], sb[++i]};
+        byte hex[] = {sb[++i], sb[++i]};
         String hs = new String(hex, UTF_8);
         int b = Integer.parseInt(hs, 16);
         t.append(new byte[] {(byte) b}, 0, 1);
diff --git a/core/src/main/java/org/apache/accumulo/core/util/format/HexFormatter.java b/core/src/main/java/org/apache/accumulo/core/util/format/HexFormatter.java
index 4f11ce5538..418a9ed720 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/format/HexFormatter.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/format/HexFormatter.java
@@ -29,8 +29,8 @@
  */
 public class HexFormatter implements Formatter, ScanInterpreter {
 
-  private char chars[] = new char[] {'0', '1', '2', '3', '4', '5', '6', '7', '8', '9', 'a', 'b',
-      'c', 'd', 'e', 'f'};
+  private char chars[] = {'0', '1', '2', '3', '4', '5', '6', '7', '8', '9', 'a', 'b', 'c', 'd', 'e',
+      'f'};
   private Iterator<Entry<Key,Value>> iter;
   private FormatterConfig config;
 
diff --git a/core/src/test/java/org/apache/accumulo/core/data/KeyBuilderTest.java b/core/src/test/java/org/apache/accumulo/core/data/KeyBuilderTest.java
index ec324b939a..5a3d613d66 100644
--- a/core/src/test/java/org/apache/accumulo/core/data/KeyBuilderTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/data/KeyBuilderTest.java
@@ -256,7 +256,7 @@ public void testKeyBuildingFromRowTimestampText() {
 
   @Test
   public void testKeyBuildingReusingBytes() {
-    byte[] reuse = new byte[] {1, 2, 3};
+    byte[] reuse = {1, 2, 3};
     KeyBuilder.Build keyBuilder = Key.builder(false).row(reuse);
     Key keyBuilt = keyBuilder.build();
     assertSame(reuse, keyBuilt.getRowBytes());
@@ -264,7 +264,7 @@ public void testKeyBuildingReusingBytes() {
 
   @Test
   public void testKeyBuildingCopyBytes() {
-    byte[] reuse = new byte[] {1, 2, 3};
+    byte[] reuse = {1, 2, 3};
     KeyBuilder.Build keyBuilder = Key.builder(true).row(reuse);
     Key keyBuilt = keyBuilder.build();
     assertNotEquals(reuse, keyBuilt.getRowBytes());
diff --git a/core/src/test/java/org/apache/accumulo/core/data/KeyTest.java b/core/src/test/java/org/apache/accumulo/core/data/KeyTest.java
index 188409a9ad..57051745c6 100644
--- a/core/src/test/java/org/apache/accumulo/core/data/KeyTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/data/KeyTest.java
@@ -170,22 +170,22 @@ public void testCompressDecompress() {
 
   @Test
   public void testBytesText() {
-    byte[] row = new byte[] {1};
+    byte[] row = {1};
     Key bytesRowKey = new Key(row);
     Key textRowKey = new Key(new Text(row));
     assertEquals(bytesRowKey, textRowKey);
 
-    byte[] colFamily = new byte[] {0, 1};
+    byte[] colFamily = {0, 1};
     Key bytesColFamilyKey = new Key(row, colFamily);
     Key textColFamilyKey = new Key(new Text(row), new Text(colFamily));
     assertEquals(bytesColFamilyKey, textColFamilyKey);
 
-    byte[] colQualifier = new byte[] {0, 0, 1};
+    byte[] colQualifier = {0, 0, 1};
     Key bytesColQualifierKey = new Key(row, colFamily, colQualifier);
     Key textColQualifierKey = new Key(new Text(row), new Text(colFamily), new Text(colQualifier));
     assertEquals(bytesColQualifierKey, textColQualifierKey);
 
-    byte[] colVisibility = new byte[] {0, 0, 0, 1};
+    byte[] colVisibility = {0, 0, 0, 1};
     Key bytesColVisibilityKey = new Key(row, colFamily, colQualifier, colVisibility);
     Key textColVisibilityKey = new Key(new Text(row), new Text(colFamily), new Text(colQualifier),
         new Text(colVisibility));
diff --git a/core/src/test/java/org/apache/accumulo/core/data/MutationTest.java b/core/src/test/java/org/apache/accumulo/core/data/MutationTest.java
index 9d751ee94c..8206e622b0 100644
--- a/core/src/test/java/org/apache/accumulo/core/data/MutationTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/data/MutationTest.java
@@ -564,7 +564,7 @@ public void testInitialBufferSizesEquals() {
     // m8 uses a different buffer size
     Mutation m8 = new Mutation(r1Bytes, 0, r1Bytes.length, 4242);
 
-    Mutation[] muts = new Mutation[] {m1, m2, m3, m4, m5, m6, m7, m8};
+    Mutation[] muts = {m1, m2, m3, m4, m5, m6, m7, m8};
     populate(muts);
 
     for (Mutation m : muts) {
diff --git a/core/src/test/java/org/apache/accumulo/core/file/rfile/KeyShortenerTest.java b/core/src/test/java/org/apache/accumulo/core/file/rfile/KeyShortenerTest.java
index 821e3382b2..854c642041 100644
--- a/core/src/test/java/org/apache/accumulo/core/file/rfile/KeyShortenerTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/file/rfile/KeyShortenerTest.java
@@ -26,7 +26,7 @@
 public class KeyShortenerTest {
 
   private static final byte[] E = new byte[0];
-  private static final byte[] FF = new byte[] {(byte) 0xff};
+  private static final byte[] FF = {(byte) 0xff};
 
   private void assertBetween(Key p, Key s, Key c) {
     Assert.assertTrue(p.compareTo(s) < 0);
diff --git a/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileMetricsTest.java b/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileMetricsTest.java
index ec8a499f29..482e1617cf 100644
--- a/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileMetricsTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileMetricsTest.java
@@ -532,7 +532,7 @@ public void testManyFamiliesInDefaultLocGroup() throws IOException {
 
     trf.writer.startDefaultLocalityGroup();
 
-    String vis[] = new String[] {"A", "A&B", "A|C", "B&C", "Boo"};
+    String vis[] = {"A", "A&B", "A|C", "B&C", "Boo"};
 
     int fam = 0;
     for (int row = 0; row < 1000; row++) {
diff --git a/core/src/test/java/org/apache/accumulo/core/file/rfile/RolllingStatsTest.java b/core/src/test/java/org/apache/accumulo/core/file/rfile/RolllingStatsTest.java
index 5d9fec3ef3..afbb71d1f9 100644
--- a/core/src/test/java/org/apache/accumulo/core/file/rfile/RolllingStatsTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/file/rfile/RolllingStatsTest.java
@@ -91,7 +91,7 @@ void check() {
   @Test
   public void testFewSizes() {
     StatTester st = new StatTester(1019);
-    int[] keySizes = new int[] {103, 113, 123, 2345};
+    int[] keySizes = {103, 113, 123, 2345};
     Random rand = new Random(42);
     for (int i = 0; i < 10000; i++) {
       st.addValue(keySizes[rand.nextInt(keySizes.length)]);
diff --git a/core/src/test/java/org/apache/accumulo/core/util/format/DefaultFormatterTest.java b/core/src/test/java/org/apache/accumulo/core/util/format/DefaultFormatterTest.java
index 5b97bbf6af..bf3bed13ee 100644
--- a/core/src/test/java/org/apache/accumulo/core/util/format/DefaultFormatterTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/util/format/DefaultFormatterTest.java
@@ -57,7 +57,7 @@ public void testNextBeforeInitialize() {
   @Test
   public void testAppendBytes() {
     StringBuilder sb = new StringBuilder();
-    byte[] data = new byte[] {0, '\\', 'x', -0x01};
+    byte[] data = {0, '\\', 'x', -0x01};
 
     DefaultFormatter.appendValue(sb, new Value());
     assertEquals("", sb.toString());
diff --git a/core/src/test/java/org/apache/accumulo/fate/zookeeper/ZooReaderWriterTest.java b/core/src/test/java/org/apache/accumulo/fate/zookeeper/ZooReaderWriterTest.java
index b1e05313b9..f2e5e37cd5 100644
--- a/core/src/test/java/org/apache/accumulo/fate/zookeeper/ZooReaderWriterTest.java
+++ b/core/src/test/java/org/apache/accumulo/fate/zookeeper/ZooReaderWriterTest.java
@@ -99,7 +99,7 @@ public void testDeleteFailOnRetry() throws Exception {
   @Test(expected = SessionExpiredException.class)
   public void testMutateNodeCreationFails() throws Exception {
     final String path = "/foo";
-    final byte[] value = new byte[] {0};
+    final byte[] value = {0};
     final List<ACL> acls = Collections.emptyList();
     Mutator mutator = new Mutator() {
       @Override
@@ -121,9 +121,9 @@ public void testMutateNodeCreationFails() throws Exception {
   @Test
   public void testMutateWithBadVersion() throws Exception {
     final String path = "/foo";
-    final byte[] value = new byte[] {0};
+    final byte[] value = {0};
     final List<ACL> acls = Collections.emptyList();
-    final byte[] mutatedBytes = new byte[] {1};
+    final byte[] mutatedBytes = {1};
     Mutator mutator = new Mutator() {
       @Override
       public byte[] mutate(byte[] currentValue) throws Exception {
@@ -159,9 +159,9 @@ public void testMutateWithBadVersion() throws Exception {
   @Test
   public void testMutateWithRetryOnSetData() throws Exception {
     final String path = "/foo";
-    final byte[] value = new byte[] {0};
+    final byte[] value = {0};
     final List<ACL> acls = Collections.emptyList();
-    final byte[] mutatedBytes = new byte[] {1};
+    final byte[] mutatedBytes = {1};
     Mutator mutator = new Mutator() {
       @Override
       public byte[] mutate(byte[] currentValue) throws Exception {
diff --git a/maven-plugin/src/main/java/org/apache/accumulo/maven/plugin/StartMojo.java b/maven-plugin/src/main/java/org/apache/accumulo/maven/plugin/StartMojo.java
index 6c504ef9c3..aad6a21973 100644
--- a/maven-plugin/src/main/java/org/apache/accumulo/maven/plugin/StartMojo.java
+++ b/maven-plugin/src/main/java/org/apache/accumulo/maven/plugin/StartMojo.java
@@ -60,7 +60,7 @@
   private String miniClasspath;
 
   static Set<MiniAccumuloClusterImpl> runningClusters = Collections
-      .synchronizedSet(new HashSet<MiniAccumuloClusterImpl>());
+      .synchronizedSet(new HashSet<>());
 
   @Override
   public void execute() throws MojoExecutionException {
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 28c17b1b15..403a944cda 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
@@ -152,7 +152,7 @@ String getJarFromClass(Class<?> clz) {
   @Override
   public void adminStopAll() throws IOException {
     String master = getHosts(MASTER_HOSTS_FILE).get(0);
-    String[] cmd = new String[] {serverCmdPrefix, accumuloPath, Admin.class.getName(), "stopAll"};
+    String[] cmd = {serverCmdPrefix, accumuloPath, Admin.class.getName(), "stopAll"};
     // Directly invoke the RemoteShell
     Entry<Integer,String> pair = exec(master, cmd);
     if (0 != pair.getKey()) {
@@ -173,8 +173,7 @@ public void setGoalState(String goalState) throws IOException {
     requireNonNull(goalState, "Goal state must not be null");
     checkArgument(MasterGoalState.valueOf(goalState) != null, "Unknown goal state: " + goalState);
     String master = getHosts(MASTER_HOSTS_FILE).get(0);
-    String[] cmd = new String[] {serverCmdPrefix, accumuloPath, SetGoalState.class.getName(),
-        goalState};
+    String[] cmd = {serverCmdPrefix, accumuloPath, SetGoalState.class.getName(), goalState};
     Entry<Integer,String> pair = exec(master, cmd);
     if (0 != pair.getKey()) {
       throw new IOException("SetGoalState did not finish successfully, retcode=" + pair.getKey()
@@ -226,8 +225,7 @@ public void startAllServers(ServerType server) throws IOException {
 
   @Override
   public void start(ServerType server, String hostname) throws IOException {
-    String[] cmd = new String[] {serverCmdPrefix, accumuloServicePath, getProcessString(server),
-        "start"};
+    String[] cmd = {serverCmdPrefix, accumuloServicePath, getProcessString(server), "start"};
     Entry<Integer,String> pair = exec(hostname, cmd);
     if (0 != pair.getKey()) {
       throw new IOException(
diff --git a/minicluster/src/test/java/org/apache/accumulo/cluster/standalone/StandaloneClusterControlTest.java b/minicluster/src/test/java/org/apache/accumulo/cluster/standalone/StandaloneClusterControlTest.java
index 05123c17ba..1c31f897d6 100644
--- a/minicluster/src/test/java/org/apache/accumulo/cluster/standalone/StandaloneClusterControlTest.java
+++ b/minicluster/src/test/java/org/apache/accumulo/cluster/standalone/StandaloneClusterControlTest.java
@@ -58,7 +58,7 @@ public void mapreduceLaunchesLocally() throws Exception {
         .addMockedMethod("getAccumuloUtilPath").addMockedMethod("getJarFromClass", Class.class)
         .createMock();
 
-    final String[] toolArgs = new String[] {"-u", "user", "-p", "password"};
+    final String[] toolArgs = {"-u", "user", "-p", "password"};
     final String[] expectedCommands = new String[4 + toolArgs.length];
 
     int i = 0;
diff --git a/server/base/src/main/java/org/apache/accumulo/server/Accumulo.java b/server/base/src/main/java/org/apache/accumulo/server/Accumulo.java
index aaff32c379..7f3920b667 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/Accumulo.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/Accumulo.java
@@ -267,7 +267,7 @@ public static void waitForZookeeperAndHdfs(VolumeManager fs) {
   public static void abortIfFateTransactions() {
     try {
       final ReadOnlyTStore<Accumulo> fate = new ReadOnlyStore<>(
-          new ZooStore<Accumulo>(ZooUtil.getRoot(HdfsZooInstance.getInstance()) + Constants.ZFATE,
+          new ZooStore<>(ZooUtil.getRoot(HdfsZooInstance.getInstance()) + Constants.ZFATE,
               ZooReaderWriter.getInstance()));
       if (!(fate.list().isEmpty())) {
         throw new AccumuloException("Aborting upgrade because there are"
diff --git a/server/base/src/main/java/org/apache/accumulo/server/client/deprecated/BulkImporter.java b/server/base/src/main/java/org/apache/accumulo/server/client/deprecated/BulkImporter.java
index 37cb82fd23..80428c6837 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/client/deprecated/BulkImporter.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/client/deprecated/BulkImporter.java
@@ -132,14 +132,14 @@ public AssignmentStats importFiles(List<String> files, Path failureDir) throws I
     AssignmentStats assignmentStats = new AssignmentStats(paths.size());
 
     final Map<Path,List<KeyExtent>> completeFailures = Collections
-        .synchronizedSortedMap(new TreeMap<Path,List<KeyExtent>>());
+        .synchronizedSortedMap(new TreeMap<>());
 
     ClientService.Client client = null;
     final TabletLocator locator = TabletLocator.getLocator(context, Table.ID.of(tableId));
 
     try {
       final Map<Path,List<TabletLocation>> assignments = Collections
-          .synchronizedSortedMap(new TreeMap<Path,List<TabletLocation>>());
+          .synchronizedSortedMap(new TreeMap<>());
 
       timer.start(Timers.EXAMINE_MAP_FILES);
       ExecutorService threadPool = Executors.newFixedThreadPool(numThreads,
@@ -367,8 +367,7 @@ public AssignmentInfo(KeyExtent keyExtent, Long estSize) {
       throw new RuntimeException(e);
     }
 
-    final Map<Path,List<AssignmentInfo>> ais = Collections
-        .synchronizedMap(new TreeMap<Path,List<AssignmentInfo>>());
+    final Map<Path,List<AssignmentInfo>> ais = Collections.synchronizedMap(new TreeMap<>());
 
     ExecutorService threadPool = Executors.newFixedThreadPool(numThreads,
         new NamingThreadFactory("estimateSizes"));
@@ -553,8 +552,7 @@ public String toString() {
 
     // group assignments by tabletserver
 
-    Map<Path,List<KeyExtent>> assignmentFailures = Collections
-        .synchronizedMap(new TreeMap<Path,List<KeyExtent>>());
+    Map<Path,List<KeyExtent>> assignmentFailures = Collections.synchronizedMap(new TreeMap<>());
 
     TreeMap<String,Map<KeyExtent,List<PathSize>>> assignmentsPerTabletServer = new TreeMap<>();
 
diff --git a/server/base/src/main/java/org/apache/accumulo/server/conf/ZooConfiguration.java b/server/base/src/main/java/org/apache/accumulo/server/conf/ZooConfiguration.java
index a7531440e1..1973fd8e24 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/conf/ZooConfiguration.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/conf/ZooConfiguration.java
@@ -37,8 +37,7 @@
 
   private final ZooCache propCache;
   private final AccumuloConfiguration parent;
-  private final Map<String,String> fixedProps = Collections
-      .synchronizedMap(new HashMap<String,String>());
+  private final Map<String,String> fixedProps = Collections.synchronizedMap(new HashMap<>());
   private final String propPathPrefix;
 
   protected ZooConfiguration(String instanceId, ZooCache propCache, AccumuloConfiguration parent) {
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 6f97106c8d..9ca5ed1fdd 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
@@ -607,7 +607,8 @@ private static void initZooKeeper(Opts opts, String uuid, String instanceNamePat
       zoo.recursiveDelete(instanceNamePath, NodeMissingPolicy.SKIP);
     zoo.putPersistentData(instanceNamePath, uuid.getBytes(UTF_8), NodeExistsPolicy.FAIL);
 
-    final byte[] EMPTY_BYTE_ARRAY = new byte[0], ZERO_CHAR_ARRAY = new byte[] {'0'};
+    final byte[] EMPTY_BYTE_ARRAY = new byte[0];
+    final byte[] ZERO_CHAR_ARRAY = {'0'};
 
     // setup the instance
     String zkInstanceRoot = Constants.ZROOT + "/" + uuid;
diff --git a/server/base/src/main/java/org/apache/accumulo/server/tables/TableManager.java b/server/base/src/main/java/org/apache/accumulo/server/tables/TableManager.java
index 82439fd373..4a8c8d1575 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/tables/TableManager.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/tables/TableManager.java
@@ -53,11 +53,10 @@
 public class TableManager {
 
   private static final Logger log = LoggerFactory.getLogger(TableManager.class);
-  private static final Set<TableObserver> observers = Collections
-      .synchronizedSet(new HashSet<TableObserver>());
+  private static final Set<TableObserver> observers = Collections.synchronizedSet(new HashSet<>());
   private static final Map<Table.ID,TableState> tableStateCache = Collections
       .synchronizedMap(new HashMap<>());
-  private static final byte[] ZERO_BYTE = new byte[] {'0'};
+  private static final byte[] ZERO_BYTE = {'0'};
 
   private static TableManager tableManager = null;
 
diff --git a/server/base/src/test/java/org/apache/accumulo/server/fs/PreferredVolumeChooserTest.java b/server/base/src/test/java/org/apache/accumulo/server/fs/PreferredVolumeChooserTest.java
index f9bac25561..0b4a5dabab 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/fs/PreferredVolumeChooserTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/fs/PreferredVolumeChooserTest.java
@@ -41,7 +41,7 @@
 
 public class PreferredVolumeChooserTest {
 
-  private static final String[] ALL_OPTIONS = new String[] {"1", "2", "3"};
+  private static final String[] ALL_OPTIONS = {"1", "2", "3"};
 
   private ServerConfigurationFactory confFactory;
   private TableConfiguration tableConf;
diff --git a/server/base/src/test/java/org/apache/accumulo/server/master/balancer/GroupBalancerTest.java b/server/base/src/test/java/org/apache/accumulo/server/master/balancer/GroupBalancerTest.java
index 4c881b71dc..82e6a1ee0b 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/master/balancer/GroupBalancerTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/master/balancer/GroupBalancerTest.java
@@ -193,9 +193,8 @@ void checkBalance() {
   @Test
   public void testSingleGroup() {
 
-    String tests[][] = new String[][] {new String[] {"a", "b", "c", "d"},
-        new String[] {"a", "b", "c"}, new String[] {"a", "b", "c", "d", "e"},
-        new String[] {"a", "b", "c", "d", "e", "f", "g"},
+    String tests[][] = {new String[] {"a", "b", "c", "d"}, new String[] {"a", "b", "c"},
+        new String[] {"a", "b", "c", "d", "e"}, new String[] {"a", "b", "c", "d", "e", "f", "g"},
         new String[] {"a", "b", "c", "d", "e", "f", "g", "h"},
         new String[] {"a", "b", "c", "d", "e", "f", "g", "h", "i"}, new String[] {"a"}};
 
@@ -217,9 +216,8 @@ public void testSingleGroup() {
 
   @Test
   public void testTwoGroups() {
-    String tests[][] = new String[][] {new String[] {"a", "b", "c", "d"},
-        new String[] {"a", "b", "c"}, new String[] {"a", "b", "c", "d", "e"},
-        new String[] {"a", "b", "c", "d", "e", "f", "g"},
+    String tests[][] = {new String[] {"a", "b", "c", "d"}, new String[] {"a", "b", "c"},
+        new String[] {"a", "b", "c", "d", "e"}, new String[] {"a", "b", "c", "d", "e", "f", "g"},
         new String[] {"a", "b", "c", "d", "e", "f", "g", "h"},
         new String[] {"a", "b", "c", "d", "e", "f", "g", "h", "i"}, new String[] {"a"}};
 
@@ -247,9 +245,8 @@ public void testTwoGroups() {
 
   @Test
   public void testThreeGroups() {
-    String tests[][] = new String[][] {new String[] {"a", "b", "c", "d"},
-        new String[] {"a", "b", "c"}, new String[] {"a", "b", "c", "d", "e"},
-        new String[] {"a", "b", "c", "d", "e", "f", "g"},
+    String tests[][] = {new String[] {"a", "b", "c", "d"}, new String[] {"a", "b", "c"},
+        new String[] {"a", "b", "c", "d", "e"}, new String[] {"a", "b", "c", "d", "e", "f", "g"},
         new String[] {"a", "b", "c", "d", "e", "f", "g", "h"},
         new String[] {"a", "b", "c", "d", "e", "f", "g", "h", "i"}, new String[] {"a"}};
 
diff --git a/server/base/src/test/java/org/apache/accumulo/server/util/FileSystemMonitorTest.java b/server/base/src/test/java/org/apache/accumulo/server/util/FileSystemMonitorTest.java
index dac2673cf8..8d76039159 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/util/FileSystemMonitorTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/util/FileSystemMonitorTest.java
@@ -37,7 +37,7 @@
 
   @Test
   public void testFilteredMountEntries() throws Exception {
-    String[] mountEntries = new String[] {"rootfs / rootfs rw 0 0",
+    String[] mountEntries = {"rootfs / rootfs rw 0 0",
         "proc /proc proc rw,nosuid,nodev,noexec,relatime 0 0",
         "sysfs /sys sysfs rw,seclabel,nosuid,nodev,noexec,relatime 0 0",
         "devtmpfs /dev devtmpfs rw,seclabel,nosuid,size=8119336k,nr_inodes=2029834,mode=755 0 0",
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 6fc40f8d22..d4fe20a2e4 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
@@ -197,11 +197,10 @@
   final private List<TabletGroupWatcher> watchers = new ArrayList<>();
   final SecurityOperation security;
   final Map<TServerInstance,AtomicInteger> badServers = Collections
-      .synchronizedMap(new DefaultMap<TServerInstance,AtomicInteger>(new AtomicInteger()));
-  final Set<TServerInstance> serversToShutdown = Collections
-      .synchronizedSet(new HashSet<TServerInstance>());
+      .synchronizedMap(new DefaultMap<>(new AtomicInteger()));
+  final Set<TServerInstance> serversToShutdown = Collections.synchronizedSet(new HashSet<>());
   final SortedMap<KeyExtent,TServerInstance> migrations = Collections
-      .synchronizedSortedMap(new TreeMap<KeyExtent,TServerInstance>());
+      .synchronizedSortedMap(new TreeMap<>());
   final EventCoordinator nextEvent = new EventCoordinator();
   final private Object mergeLock = new Object();
   private ReplicationDriver replicationWorkDriver;
@@ -223,7 +222,7 @@
   Fate<Master> fate;
 
   volatile SortedMap<TServerInstance,TabletServerStatus> tserverStatus = Collections
-      .unmodifiableSortedMap(new TreeMap<TServerInstance,TabletServerStatus>());
+      .unmodifiableSortedMap(new TreeMap<>());
   final ServerBulkImportStatus bulkImportStatus = new ServerBulkImportStatus();
 
   private final AtomicBoolean masterInitialized = new AtomicBoolean(false);
@@ -352,7 +351,7 @@ private void upgradeZookeeper() {
         zoo.recursiveDelete(zooRoot + "/loggers", NodeMissingPolicy.SKIP);
         zoo.recursiveDelete(zooRoot + "/dead/loggers", NodeMissingPolicy.SKIP);
 
-        final byte[] zero = new byte[] {'0'};
+        final byte[] zero = {'0'};
         log.debug("Initializing recovery area.");
         zoo.putPersistentData(zooRoot + Constants.ZRECOVERY, zero, NodeExistsPolicy.SKIP);
 
@@ -1314,8 +1313,8 @@ boolean canSuspendTablets() {
 
     try {
       final AgeOffStore<Master> store = new AgeOffStore<>(
-          new org.apache.accumulo.fate.ZooStore<Master>(
-              ZooUtil.getRoot(getInstance()) + Constants.ZFATE, ZooReaderWriter.getInstance()),
+          new org.apache.accumulo.fate.ZooStore<>(ZooUtil.getRoot(getInstance()) + Constants.ZFATE,
+              ZooReaderWriter.getInstance()),
           1000 * 60 * 60 * 8);
 
       int threads = getConfiguration().getCount(Property.MASTER_FATE_THREADPOOL_SIZE);
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/Utils.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/Utils.java
index 72dbde4090..5626978eb3 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/Utils.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/Utils.java
@@ -46,7 +46,7 @@
 import org.slf4j.LoggerFactory;
 
 public class Utils {
-  private static final byte[] ZERO_BYTE = new byte[] {'0'};
+  private static final byte[] ZERO_BYTE = {'0'};
   private static final Logger log = LoggerFactory.getLogger(Utils.class);
 
   static void checkTableDoesNotExist(Instance instance, String tableName, Table.ID tableId,
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 526380db14..5492b619d2 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
@@ -119,7 +119,7 @@ private static synchronized ExecutorService getThreadPool(Master master) {
     }
     fs.delete(writable);
 
-    final Set<String> filesToLoad = Collections.synchronizedSet(new HashSet<String>());
+    final Set<String> filesToLoad = Collections.synchronizedSet(new HashSet<>());
     for (FileStatus f : files)
       filesToLoad.add(f.getPath().toString());
 
@@ -135,7 +135,7 @@ private static synchronized ExecutorService getThreadPool(Master master) {
       }
 
       // Use the threadpool to assign files one-at-a-time to the server
-      final List<String> loaded = Collections.synchronizedList(new ArrayList<String>());
+      final List<String> loaded = Collections.synchronizedList(new ArrayList<>());
       final Random random = new Random();
       final TServerInstance[] servers;
       String prop = conf.get(Property.MASTER_BULK_TSERVER_REGEX);
diff --git a/server/master/src/test/java/org/apache/accumulo/master/state/RootTabletStateStoreTest.java b/server/master/src/test/java/org/apache/accumulo/master/state/RootTabletStateStoreTest.java
index f48a54789d..a473e2b3f8 100644
--- a/server/master/src/test/java/org/apache/accumulo/master/state/RootTabletStateStoreTest.java
+++ b/server/master/src/test/java/org/apache/accumulo/master/state/RootTabletStateStoreTest.java
@@ -50,7 +50,7 @@
 
     List<Node> children = new ArrayList<>();
     String name;
-    byte[] value = new byte[] {};
+    byte[] value = {};
 
     Node find(String name) {
       for (Node node : children)
diff --git a/server/master/src/test/java/org/apache/accumulo/master/tableOps/ImportTableTest.java b/server/master/src/test/java/org/apache/accumulo/master/tableOps/ImportTableTest.java
index 1414bf8e47..38f13a06bd 100644
--- a/server/master/src/test/java/org/apache/accumulo/master/tableOps/ImportTableTest.java
+++ b/server/master/src/test/java/org/apache/accumulo/master/tableOps/ImportTableTest.java
@@ -37,7 +37,7 @@ public void testTabletDir() {
     iti.tableId = Table.ID.of("5");
 
     // Different volumes with different paths
-    String[] tableDirs = new String[] {"hdfs://nn1:8020/apps/accumulo1/tables",
+    String[] tableDirs = {"hdfs://nn1:8020/apps/accumulo1/tables",
         "hdfs://nn2:8020/applications/accumulo/tables"};
     // This needs to be unique WRT the importtable command
     String tabletDir = "/c-00000001";
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 5f0d1e4db7..42b8959dbe 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
@@ -140,27 +140,27 @@ public boolean add(Pair<Long,T> obj) {
 
   private static final int MAX_TIME_PERIOD = 60 * 60 * 1000;
   private static final List<Pair<Long,Double>> loadOverTime = Collections
-      .synchronizedList(new MaxList<Double>(MAX_TIME_PERIOD));
+      .synchronizedList(new MaxList<>(MAX_TIME_PERIOD));
   private static final List<Pair<Long,Double>> ingestRateOverTime = Collections
-      .synchronizedList(new MaxList<Double>(MAX_TIME_PERIOD));
+      .synchronizedList(new MaxList<>(MAX_TIME_PERIOD));
   private static final List<Pair<Long,Double>> ingestByteRateOverTime = Collections
-      .synchronizedList(new MaxList<Double>(MAX_TIME_PERIOD));
+      .synchronizedList(new MaxList<>(MAX_TIME_PERIOD));
   private static final List<Pair<Long,Integer>> minorCompactionsOverTime = Collections
-      .synchronizedList(new MaxList<Integer>(MAX_TIME_PERIOD));
+      .synchronizedList(new MaxList<>(MAX_TIME_PERIOD));
   private static final List<Pair<Long,Integer>> majorCompactionsOverTime = Collections
-      .synchronizedList(new MaxList<Integer>(MAX_TIME_PERIOD));
+      .synchronizedList(new MaxList<>(MAX_TIME_PERIOD));
   private static final List<Pair<Long,Double>> lookupsOverTime = Collections
-      .synchronizedList(new MaxList<Double>(MAX_TIME_PERIOD));
+      .synchronizedList(new MaxList<>(MAX_TIME_PERIOD));
   private static final List<Pair<Long,Integer>> queryRateOverTime = Collections
-      .synchronizedList(new MaxList<Integer>(MAX_TIME_PERIOD));
+      .synchronizedList(new MaxList<>(MAX_TIME_PERIOD));
   private static final List<Pair<Long,Integer>> scanRateOverTime = Collections
-      .synchronizedList(new MaxList<Integer>(MAX_TIME_PERIOD));
+      .synchronizedList(new MaxList<>(MAX_TIME_PERIOD));
   private static final List<Pair<Long,Double>> queryByteRateOverTime = Collections
-      .synchronizedList(new MaxList<Double>(MAX_TIME_PERIOD));
+      .synchronizedList(new MaxList<>(MAX_TIME_PERIOD));
   private static final List<Pair<Long,Double>> indexCacheHitRateOverTime = Collections
-      .synchronizedList(new MaxList<Double>(MAX_TIME_PERIOD));
+      .synchronizedList(new MaxList<>(MAX_TIME_PERIOD));
   private static final List<Pair<Long,Double>> dataCacheHitRateOverTime = Collections
-      .synchronizedList(new MaxList<Double>(MAX_TIME_PERIOD));
+      .synchronizedList(new MaxList<>(MAX_TIME_PERIOD));
   private static EventCounter lookupRateTracker = new EventCounter();
   private static EventCounter indexCacheHitTracker = new EventCounter();
   private static EventCounter indexCacheRequestTracker = new EventCounter();
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/trace/RecentTracesInformation.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/trace/RecentTracesInformation.java
index 822e9f7ce8..e6a7f2d73c 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/trace/RecentTracesInformation.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/rest/trace/RecentTracesInformation.java
@@ -37,7 +37,7 @@
   public long max = Long.MIN_VALUE;
 
   private long totalMS = 0L;
-  public long histogram[] = new long[] {0L, 0L, 0L, 0L, 0L, 0L};
+  public long histogram[] = {0L, 0L, 0L, 0L, 0L, 0L};
 
   public RecentTracesInformation() {}
 
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/InMemoryMap.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/InMemoryMap.java
index ab7fa747bf..6a693baa8b 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/InMemoryMap.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/InMemoryMap.java
@@ -569,8 +569,7 @@ public synchronized long getNumEntries() {
     return map.size();
   }
 
-  private final Set<MemoryIterator> activeIters = Collections
-      .synchronizedSet(new HashSet<MemoryIterator>());
+  private final Set<MemoryIterator> activeIters = Collections.synchronizedSet(new HashSet<>());
 
   class MemoryDataSource implements DataSource {
 
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 187d8d1c3e..8b541d93a6 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
@@ -384,7 +384,7 @@ public TabletStateImpl clone() throws CloneNotSupportedException {
     private final Thread minorCompactionInitiatorThread;
 
     MemoryManagementFramework() {
-      tabletReports = Collections.synchronizedMap(new HashMap<KeyExtent,TabletStateImpl>());
+      tabletReports = Collections.synchronizedMap(new HashMap<>());
       memUsageReports = new LinkedBlockingQueue<>();
       maxMem = conf.getSystemConfiguration().getAsBytes(Property.TSERV_MAXMEM);
 
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletStatsKeeper.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletStatsKeeper.java
index e8d8aec5d2..fb0c297370 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletStatsKeeper.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletStatsKeeper.java
@@ -31,7 +31,7 @@
     MAJOR, SPLIT, MINOR
   }
 
-  private ActionStats[] map = new ActionStats[] {major, split, minor};
+  private ActionStats[] map = {major, split, minor};
 
   public void updateTime(Operation operation, long queued, long start, long count, boolean failed) {
     try {
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 57f25430bd..f8f3d495f8 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
@@ -61,8 +61,7 @@
   VolumeManager fs;
   AccumuloConfiguration conf;
 
-  private final Map<String,LogProcessor> currentWork = Collections
-      .synchronizedMap(new HashMap<String,LogProcessor>());
+  private final Map<String,LogProcessor> currentWork = Collections.synchronizedMap(new HashMap<>());
 
   class LogProcessor implements Processor {
 
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Compactor.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Compactor.java
index 548f046fca..b9e553bc76 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Compactor.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Compactor.java
@@ -131,7 +131,7 @@ private void clearStats() {
   }
 
   protected static final Set<Compactor> runningCompactions = Collections
-      .synchronizedSet(new HashSet<Compactor>());
+      .synchronizedSet(new HashSet<>());
 
   public static List<CompactionInfo> getRunningCompactions() {
     ArrayList<CompactionInfo> compactions = new ArrayList<>();
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 63397ff3b9..c9c85f0419 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
@@ -58,7 +58,7 @@
   private final Logger log = LoggerFactory.getLogger(DatafileManager.class);
   // access to datafilesizes needs to be synchronized: see CompactionRunner#getNumFiles
   private final Map<FileRef,DataFileValue> datafileSizes = Collections
-      .synchronizedMap(new TreeMap<FileRef,DataFileValue>());
+      .synchronizedMap(new TreeMap<>());
   private final Tablet tablet;
   private Long maxMergingMinorCompactionFileSize;
 
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/log/LogEventsTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/log/LogEventsTest.java
index f3bc9049d1..addb5ddb91 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/log/LogEventsTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/log/LogEventsTest.java
@@ -25,9 +25,8 @@
   public void testOrdinals() {
     // Ordinals are used for persistence, so its important they are stable.
 
-    LogEvents[] expectedOrder = new LogEvents[] {LogEvents.OPEN, LogEvents.DEFINE_TABLET,
-        LogEvents.MUTATION, LogEvents.MANY_MUTATIONS, LogEvents.COMPACTION_START,
-        LogEvents.COMPACTION_FINISH};
+    LogEvents[] expectedOrder = {LogEvents.OPEN, LogEvents.DEFINE_TABLET, LogEvents.MUTATION,
+        LogEvents.MANY_MUTATIONS, LogEvents.COMPACTION_START, LogEvents.COMPACTION_FINISH};
 
     for (int i = 0; i < expectedOrder.length; i++) {
       Assert.assertEquals(i, expectedOrder[i].ordinal());
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/log/SortedLogRecoveryTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/log/SortedLogRecoveryTest.java
index 708f843703..fa178e381c 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/log/SortedLogRecoveryTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/log/SortedLogRecoveryTest.java
@@ -178,22 +178,22 @@ public void testCompactionCrossesLogs() throws IOException {
     m.put(cf, cq, value);
     Mutation m2 = new ServerMutation(new Text("row2"));
     m2.put(cf, cq, value);
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, 1, "2"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, 1, "2"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),
         createKeyValue(COMPACTION_START, 3, 1, "/t1/f1"), createKeyValue(MUTATION, 2, 1, ignored),
         createKeyValue(MUTATION, 4, 1, ignored),};
-    KeyValue entries2[] = new KeyValue[] {createKeyValue(OPEN, 0, 1, "2"),
+    KeyValue entries2[] = {createKeyValue(OPEN, 0, 1, "2"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),
         createKeyValue(COMPACTION_START, 4, 1, "/t1/f1"), createKeyValue(MUTATION, 7, 1, m),};
-    KeyValue entries3[] = new KeyValue[] {createKeyValue(OPEN, 0, 2, "23"),
+    KeyValue entries3[] = {createKeyValue(OPEN, 0, 2, "23"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),
         createKeyValue(COMPACTION_START, 5, 1, "/t1/f2"),
         createKeyValue(COMPACTION_FINISH, 6, 1, null), createKeyValue(MUTATION, 3, 1, ignored),
         createKeyValue(MUTATION, 4, 1, ignored),};
-    KeyValue entries4[] = new KeyValue[] {createKeyValue(OPEN, 0, 3, "69"),
+    KeyValue entries4[] = {createKeyValue(OPEN, 0, 3, "69"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent), createKeyValue(MUTATION, 2, 1, ignored),
         createKeyValue(MUTATION, 3, 1, ignored), createKeyValue(MUTATION, 4, 1, ignored),};
-    KeyValue entries5[] = new KeyValue[] {createKeyValue(OPEN, 0, 4, "70"),
+    KeyValue entries5[] = {createKeyValue(OPEN, 0, 4, "70"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),
         createKeyValue(COMPACTION_START, 3, 1, "/t1/f3"), createKeyValue(MUTATION, 2, 1, ignored),
         createKeyValue(MUTATION, 6, 1, m2),};
@@ -227,13 +227,14 @@ public void testCompactionCrossesLogs5() throws IOException {
     m3.put(cf, cq, value);
     Mutation m4 = new ServerMutation(new Text("row4"));
     m4.put(cf, cq, value);
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),
         createKeyValue(COMPACTION_START, 3, 1, "/t1/f1"), createKeyValue(MUTATION, 2, 1, ignored),
         createKeyValue(MUTATION, 4, 1, ignored),};
-    KeyValue entries2[] = new KeyValue[] {createKeyValue(OPEN, 5, -1, "2"),
+    KeyValue entries2[] = {createKeyValue(OPEN, 5, -1, "2"),
         createKeyValue(DEFINE_TABLET, 6, 1, extent), createKeyValue(MUTATION, 7, 1, ignored),};
-    KeyValue entries3[] = new KeyValue[] {createKeyValue(OPEN, 8, -1, "3"),
+    // createKeyValue(COMPACTION_FINISH, 14, 1, null),
+    KeyValue entries3[] = {createKeyValue(OPEN, 8, -1, "3"),
         createKeyValue(DEFINE_TABLET, 9, 1, extent),
         createKeyValue(COMPACTION_FINISH, 10, 1, "/t1/f1"),
         createKeyValue(COMPACTION_START, 12, 1, "/t1/f2"),
@@ -241,7 +242,7 @@ public void testCompactionCrossesLogs5() throws IOException {
         // createKeyValue(COMPACTION_FINISH, 14, 1, null),
         createKeyValue(MUTATION, 11, 1, ignored), createKeyValue(MUTATION, 15, 1, m),
         createKeyValue(MUTATION, 16, 1, m2),};
-    KeyValue entries4[] = new KeyValue[] {createKeyValue(OPEN, 17, -1, "4"),
+    KeyValue entries4[] = {createKeyValue(OPEN, 17, -1, "4"),
         createKeyValue(DEFINE_TABLET, 18, 1, extent),
         createKeyValue(COMPACTION_START, 20, 1, "/t1/f3"), createKeyValue(MUTATION, 19, 1, m3),
         createKeyValue(MUTATION, 21, 1, m4),};
@@ -275,10 +276,10 @@ public void testCompactionCrossesLogs6() throws IOException {
     m4.put(cf, cq, value);
     Mutation m5 = new ServerMutation(new Text("row5"));
     m5.put(cf, cq, value);
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, 1, "2"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, 1, "2"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent), createKeyValue(MUTATION, 1, 1, ignored),
         createKeyValue(MUTATION, 3, 1, m),};
-    KeyValue entries2[] = new KeyValue[] {createKeyValue(OPEN, 0, 1, "2"),
+    KeyValue entries2[] = {createKeyValue(OPEN, 0, 1, "2"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),
         createKeyValue(COMPACTION_START, 2, 1, "/t1/f1"),
         createKeyValue(COMPACTION_FINISH, 3, 1, "/t1/f1"), createKeyValue(MUTATION, 3, 1, m2),};
@@ -299,7 +300,7 @@ public void testCompactionCrossesLogs6() throws IOException {
   @Test
   public void testEmpty() throws IOException {
     // Create a test log
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),};
     Map<String,KeyValue[]> logs = new TreeMap<>();
     logs.put("testlog", entries);
@@ -313,7 +314,7 @@ public void testEmpty() throws IOException {
   @Test
   public void testMissingDefinition() {
     // Create a test log
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),};
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),};
     Map<String,KeyValue[]> logs = new TreeMap<>();
     logs.put("testlog", entries);
     // Recover
@@ -328,7 +329,7 @@ public void testSimple() throws IOException {
     // Create a test log
     Mutation m = new ServerMutation(new Text("row1"));
     m.put(cf, cq, value);
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent), createKeyValue(MUTATION, 2, 1, m),};
     Map<String,KeyValue[]> logs = new TreeMap<>();
     logs.put("testlog", entries);
@@ -346,7 +347,7 @@ public void testSkipSuccessfulCompaction() throws IOException {
     ignored.put(cf, cq, value);
     Mutation m = new ServerMutation(new Text("row1"));
     m.put(cf, cq, value);
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),
         createKeyValue(COMPACTION_START, 3, 1, "/t1/f1"),
         createKeyValue(COMPACTION_FINISH, 4, 1, null), createKeyValue(MUTATION, 2, 1, ignored),
@@ -367,10 +368,10 @@ public void testSkipSuccessfulCompactionAcrossFiles() throws IOException {
     ignored.put(cf, cq, value);
     Mutation m = new ServerMutation(new Text("row1"));
     m.put(cf, cq, value);
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),
         createKeyValue(COMPACTION_START, 3, 1, "/t1/f1"), createKeyValue(MUTATION, 2, 1, ignored),};
-    KeyValue entries2[] = new KeyValue[] {createKeyValue(OPEN, 4, -1, "1"),
+    KeyValue entries2[] = {createKeyValue(OPEN, 4, -1, "1"),
         createKeyValue(DEFINE_TABLET, 5, 1, extent), createKeyValue(COMPACTION_FINISH, 6, 1, null),
         createKeyValue(MUTATION, 7, 1, m),};
     Map<String,KeyValue[]> logs = new TreeMap<>();
@@ -392,11 +393,11 @@ public void testGetMutationsAfterCompactionStart() throws IOException {
     m.put(cf, cq, value);
     Mutation m2 = new ServerMutation(new Text("row2"));
     m2.put(cf, cq, new Value("123".getBytes()));
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),
         createKeyValue(COMPACTION_START, 3, 1, "/t1/f1"), createKeyValue(MUTATION, 2, 1, ignored),
         createKeyValue(MUTATION, 4, 1, m),};
-    KeyValue entries2[] = new KeyValue[] {createKeyValue(OPEN, 5, -1, "1"),
+    KeyValue entries2[] = {createKeyValue(OPEN, 5, -1, "1"),
         createKeyValue(DEFINE_TABLET, 6, 1, extent), createKeyValue(COMPACTION_FINISH, 7, 1, null),
         createKeyValue(MUTATION, 8, 1, m2),};
     Map<String,KeyValue[]> logs = new TreeMap<>();
@@ -419,7 +420,7 @@ public void testDoubleFinish() throws IOException {
     m.put(cf, cq, value);
     Mutation m2 = new ServerMutation(new Text("row2"));
     m2.put(cf, cq, new Value("123".getBytes()));
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent), createKeyValue(COMPACTION_FINISH, 2, 1, null),
         createKeyValue(COMPACTION_START, 4, 1, "/t1/f1"),
         createKeyValue(COMPACTION_FINISH, 6, 1, null), createKeyValue(MUTATION, 3, 1, ignored),
@@ -445,13 +446,13 @@ public void testCompactionCrossesLogs2() throws IOException {
     m2.put(cf, cq, value);
     Mutation m3 = new ServerMutation(new Text("row3"));
     m3.put(cf, cq, value);
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),
         createKeyValue(COMPACTION_START, 3, 1, "/t1/f1"), createKeyValue(MUTATION, 2, 1, ignored),
         createKeyValue(MUTATION, 4, 1, m),};
-    KeyValue entries2[] = new KeyValue[] {createKeyValue(OPEN, 5, -1, "1"),
+    KeyValue entries2[] = {createKeyValue(OPEN, 5, -1, "1"),
         createKeyValue(DEFINE_TABLET, 6, 1, extent), createKeyValue(MUTATION, 7, 1, m2),};
-    KeyValue entries3[] = new KeyValue[] {createKeyValue(OPEN, 8, -1, "1"),
+    KeyValue entries3[] = {createKeyValue(OPEN, 8, -1, "1"),
         createKeyValue(DEFINE_TABLET, 9, 1, extent), createKeyValue(COMPACTION_FINISH, 10, 1, null),
         createKeyValue(MUTATION, 11, 1, m3),};
     Map<String,KeyValue[]> logs = new TreeMap<>();
@@ -474,7 +475,7 @@ public void testBug1() throws IOException {
     m1.put(cf, cq, value);
     Mutation m2 = new ServerMutation(new Text("row2"));
     m2.put(cf, cq, value);
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),
         createKeyValue(COMPACTION_START, 30, 1, "/t1/f1"),
         createKeyValue(COMPACTION_FINISH, 32, 1, "/t1/f1"), createKeyValue(MUTATION, 29, 1, m1),
@@ -498,11 +499,11 @@ public void testBug2() throws IOException {
     m2.put(cf, cq, value);
     Mutation m3 = new ServerMutation(new Text("row3"));
     m3.put(cf, cq, value);
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),
         createKeyValue(COMPACTION_START, 2, 1, "/t1/f1"),
         createKeyValue(COMPACTION_FINISH, 4, 1, null), createKeyValue(MUTATION, 3, 1, m),};
-    KeyValue entries2[] = new KeyValue[] {createKeyValue(OPEN, 5, -1, "1"),
+    KeyValue entries2[] = {createKeyValue(OPEN, 5, -1, "1"),
         createKeyValue(DEFINE_TABLET, 6, 1, extent),
         createKeyValue(COMPACTION_START, 8, 1, "/t1/f1"), createKeyValue(MUTATION, 7, 1, m2),
         createKeyValue(MUTATION, 9, 1, m3),};
@@ -535,15 +536,22 @@ public void testCompactionCrossesLogs4() throws IOException {
     m5.put(cf, cq, value);
     Mutation m6 = new ServerMutation(new Text("row6"));
     m6.put(cf, cq, value);
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    // createKeyValue(COMPACTION_FINISH, 5, 1, null),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),
         createKeyValue(COMPACTION_START, 4, 1, "/t1/f1"),
         // createKeyValue(COMPACTION_FINISH, 5, 1, null),
         createKeyValue(MUTATION, 2, 1, m), createKeyValue(MUTATION, 3, 1, m2),};
-    KeyValue entries2[] = new KeyValue[] {createKeyValue(OPEN, 5, -1, "2"),
+    KeyValue entries2[] = {createKeyValue(OPEN, 5, -1, "2"),
         createKeyValue(DEFINE_TABLET, 6, 1, extent), createKeyValue(MUTATION, 7, 1, m3),
         createKeyValue(MUTATION, 8, 1, m4),};
-    KeyValue entries3[] = new KeyValue[] {createKeyValue(OPEN, 9, -1, "3"),
+    // createKeyValue(COMPACTION_FINISH, 11, 1, null),
+    // createKeyValue(COMPACTION_FINISH, 14, 1, null),
+    // createKeyValue(COMPACTION_START, 15, 1, "somefile"),
+    // createKeyValue(COMPACTION_FINISH, 17, 1, null),
+    // createKeyValue(COMPACTION_START, 18, 1, "somefile"),
+    // createKeyValue(COMPACTION_FINISH, 19, 1, null),
+    KeyValue entries3[] = {createKeyValue(OPEN, 9, -1, "3"),
         createKeyValue(DEFINE_TABLET, 10, 1, extent),
         // createKeyValue(COMPACTION_FINISH, 11, 1, null),
         createKeyValue(COMPACTION_START, 12, 1, "/t1/f1"),
@@ -585,13 +593,13 @@ public void testLookingForBug3() throws IOException {
     m4.put(cf, cq, value);
     Mutation m5 = new ServerMutation(new Text("row5"));
     m5.put(cf, cq, value);
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),
         createKeyValue(COMPACTION_START, 2, 1, "/t1/f1"),
         createKeyValue(COMPACTION_FINISH, 3, 1, null), createKeyValue(MUTATION, 1, 1, ignored),
         createKeyValue(MUTATION, 3, 1, m), createKeyValue(MUTATION, 3, 1, m2),
         createKeyValue(MUTATION, 3, 1, m3),};
-    KeyValue entries2[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "2"),
+    KeyValue entries2[] = {createKeyValue(OPEN, 0, -1, "2"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent),
         createKeyValue(COMPACTION_START, 2, 1, "/t1/f12"), createKeyValue(MUTATION, 3, 1, m4),
         createKeyValue(MUTATION, 3, 1, m5),};
@@ -620,7 +628,7 @@ public void testMultipleTabletDefinition() throws Exception {
     Mutation m = new ServerMutation(new Text("row1"));
     m.put("foo", "bar", "v1");
 
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 1, extent), createKeyValue(DEFINE_TABLET, 1, 2, extent),
         createKeyValue(MUTATION, 2, 2, ignored), createKeyValue(COMPACTION_START, 3, 2, "/t1/f1"),
         createKeyValue(MUTATION, 4, 2, m), createKeyValue(COMPACTION_FINISH, 6, 2, null),};
@@ -644,7 +652,7 @@ public void testNoFinish0() throws Exception {
     Mutation ignored = new ServerMutation(new Text("row1"));
     ignored.put("foo", "bar", "v1");
 
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 2, extent), createKeyValue(MUTATION, 2, 2, ignored),
         createKeyValue(COMPACTION_START, 3, 2, "/t/f1")};
 
@@ -667,7 +675,7 @@ public void testNoFinish1() throws Exception {
     Mutation m = new ServerMutation(new Text("row1"));
     m.put("foo", "bar", "v2");
 
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 2, extent), createKeyValue(MUTATION, 2, 2, ignored),
         createKeyValue(COMPACTION_START, 3, 2, "/t/f1"), createKeyValue(MUTATION, 4, 2, m),};
 
@@ -692,12 +700,12 @@ public void testLeaveAndComeBack() throws IOException {
     Mutation m2 = new ServerMutation(new Text("r2"));
     m2.put("f1", "q1", "v2");
 
-    KeyValue entries1[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries1[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 100, 10, extent), createKeyValue(MUTATION, 100, 10, m1),
         createKeyValue(COMPACTION_START, 101, 10, "/t/f1"),
         createKeyValue(COMPACTION_FINISH, 102, 10, null)};
 
-    KeyValue entries2[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries2[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 20, extent), createKeyValue(MUTATION, 1, 20, m2)};
 
     Arrays.sort(entries1);
@@ -729,7 +737,7 @@ public void testMultipleTablets() throws IOException {
     Mutation m4 = new ServerMutation(new Text("s"));
     m4.put("f1", "q2", "v4");
 
-    KeyValue entries1[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries1[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 7, 10, e1), createKeyValue(DEFINE_TABLET, 5, 11, e2),
         createKeyValue(MUTATION, 8, 10, m1), createKeyValue(COMPACTION_START, 9, 10, "/t/f1"),
         createKeyValue(MUTATION, 10, 10, m2), createKeyValue(COMPACTION_FINISH, 11, 10, null),
@@ -750,7 +758,7 @@ public void testMultipleTablets() throws IOException {
     Assert.assertEquals(m3, mutations2.get(0));
     Assert.assertEquals(m4, mutations2.get(1));
 
-    KeyValue entries2[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries2[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 9, 11, e2), createKeyValue(COMPACTION_FINISH, 10, 11, null)};
     Arrays.sort(entries2);
     logs.put("entries2", entries2);
@@ -767,7 +775,7 @@ private void runPathTest(boolean startMatches, String compactionStartFile, Strin
     Mutation m2 = new ServerMutation(new Text("row1"));
     m2.put("foo", "bar", "v2");
 
-    KeyValue entries[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 1, 2, extent), createKeyValue(MUTATION, 2, 2, m1),
         createKeyValue(COMPACTION_START, 3, 2, compactionStartFile),
         createKeyValue(MUTATION, 4, 2, m2),};
@@ -797,9 +805,9 @@ public void testPaths() throws IOException {
     runPathTest(false, "/t1/f1", "/t1/f0");
     runPathTest(true, "/t1/f1", "/t1/f0", "/t1/f1");
 
-    String aliases[] = new String[] {"/t1/f1", "hdfs://nn1/accumulo/tables/8/t1/f1",
+    String aliases[] = {"/t1/f1", "hdfs://nn1/accumulo/tables/8/t1/f1",
         "hdfs://1.2.3.4/accumulo/tables/8/t1/f1", "hdfs://1.2.3.4//accumulo//tables//8//t1//f1"};
-    String others[] = new String[] {"/t1/f0", "hdfs://nn1/accumulo/tables/8/t1/f2",
+    String others[] = {"/t1/f0", "hdfs://nn1/accumulo/tables/8/t1/f2",
         "hdfs://1.2.3.4//accumulo//tables//8//t1//f3", "hdfs://nn1/accumulo/tables/8/t1/t1",
         "hdfs://nn1/accumulo/tables/8/f1/f1"};
 
@@ -831,7 +839,7 @@ public void testOnlyCompactionFinishEvent() throws IOException {
     // The presence of only a compaction finish event indicates the write ahead logs are incomplete
     // in some way. This should cause an exception.
 
-    KeyValue entries1[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries1[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 100, 10, extent), createKeyValue(MUTATION, 100, 10, m1),
         createKeyValue(COMPACTION_FINISH, 102, 10, null), createKeyValue(MUTATION, 105, 10, m2)};
 
@@ -857,7 +865,7 @@ public void testConsecutiveCompactionFinishEvents() throws IOException {
     // Consecutive compaction finish events indicate the write ahead logs are incomplete in some
     // way. This should cause an exception.
 
-    KeyValue entries1[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries1[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 100, 10, extent), createKeyValue(MUTATION, 100, 10, m1),
         createKeyValue(COMPACTION_START, 102, 10, "/t/f1"),
         createKeyValue(COMPACTION_FINISH, 103, 10, null),
@@ -883,7 +891,7 @@ public void testDuplicateCompactionFinishEvents() throws IOException {
 
     // Duplicate consecutive compaction finish events should not cause an exception.
 
-    KeyValue entries1[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries1[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 100, 10, extent), createKeyValue(MUTATION, 100, 10, m1),
         createKeyValue(COMPACTION_START, 102, 10, "/t/f1"),
         createKeyValue(COMPACTION_FINISH, 104, 10, null),
@@ -907,22 +915,22 @@ public void testEmptyLogFiles() throws IOException {
     Mutation m2 = new ServerMutation(new Text("r2"));
     m2.put("f1", "q1", "v2");
 
-    KeyValue entries1[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries1[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 100, 10, extent), createKeyValue(MUTATION, 100, 10, m1)};
 
-    KeyValue entries2[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1")};
+    KeyValue entries2[] = {createKeyValue(OPEN, 0, -1, "1")};
 
-    KeyValue entries3[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries3[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 105, 10, extent),
         createKeyValue(COMPACTION_START, 107, 10, "/t/f1")};
 
-    KeyValue entries4[] = new KeyValue[] {};
+    KeyValue entries4[] = {};
 
-    KeyValue entries5[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries5[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 107, 10, extent),
         createKeyValue(COMPACTION_FINISH, 111, 10, null)};
 
-    KeyValue entries6[] = new KeyValue[] {createKeyValue(OPEN, 0, -1, "1"),
+    KeyValue entries6[] = {createKeyValue(OPEN, 0, -1, "1"),
         createKeyValue(DEFINE_TABLET, 122, 10, extent), createKeyValue(MUTATION, 123, 10, m2)};
 
     Arrays.sort(entries1);
@@ -981,7 +989,7 @@ public void testFileWithoutOpen() throws IOException {
     // Its expected that every log file should have an open event as the first event. Should throw
     // an error if not present.
 
-    KeyValue entries1[] = new KeyValue[] {createKeyValue(DEFINE_TABLET, 100, 10, extent),
+    KeyValue entries1[] = {createKeyValue(DEFINE_TABLET, 100, 10, extent),
         createKeyValue(MUTATION, 100, 10, m1), createKeyValue(COMPACTION_FINISH, 102, 10, null),
         createKeyValue(MUTATION, 105, 10, m2)};
 
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 270cd10c2b..7347a95d90 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
@@ -81,7 +81,7 @@ public void run() {
   }
 
   private static List<WeakReference<DefaultFileSystemManager>> vfsInstances = Collections
-      .synchronizedList(new ArrayList<WeakReference<DefaultFileSystemManager>>());
+      .synchronizedList(new ArrayList<>());
 
   public static final String DYNAMIC_CLASSPATH_PROPERTY_NAME = "general.dynamic.classpaths";
 
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 edbac45913..123db8b28e 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
@@ -38,13 +38,13 @@
  */
 public class UniqueFileReplicator implements VfsComponent, FileReplicator {
 
-  private static final char[] TMP_RESERVED_CHARS = new char[] {'?', '/', '\\', ' ', '&', '"', '\'',
-      '*', '#', ';', ':', '<', '>', '|'};
+  private static final char[] TMP_RESERVED_CHARS = {'?', '/', '\\', ' ', '&', '"', '\'', '*', '#',
+      ';', ':', '<', '>', '|'};
   private static final Logger log = LoggerFactory.getLogger(UniqueFileReplicator.class);
 
   private File tempDir;
   private VfsComponentContext context;
-  private List<File> tmpFiles = Collections.synchronizedList(new ArrayList<File>());
+  private List<File> tmpFiles = Collections.synchronizedList(new ArrayList<>());
 
   public UniqueFileReplicator(File tempDir) {
     this.tempDir = tempDir;
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 e5775c3f4e..0c3610a5cc 100644
--- a/test/src/main/java/org/apache/accumulo/test/AuditMessageIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/AuditMessageIT.java
@@ -155,9 +155,9 @@ private static long findAuditMessage(ArrayList<String> input, String pattern) {
 
   private void grantEverySystemPriv(Connector conn, String user)
       throws AccumuloSecurityException, AccumuloException {
-    SystemPermission[] arrayOfP = new SystemPermission[] {SystemPermission.SYSTEM,
-        SystemPermission.ALTER_TABLE, SystemPermission.ALTER_USER, SystemPermission.CREATE_TABLE,
-        SystemPermission.CREATE_USER, SystemPermission.DROP_TABLE, SystemPermission.DROP_USER};
+    SystemPermission[] arrayOfP = {SystemPermission.SYSTEM, SystemPermission.ALTER_TABLE,
+        SystemPermission.ALTER_USER, SystemPermission.CREATE_TABLE, SystemPermission.CREATE_USER,
+        SystemPermission.DROP_TABLE, SystemPermission.DROP_USER};
     for (SystemPermission p : arrayOfP) {
       conn.securityOperations().grantSystemPermission(user, p);
     }
diff --git a/test/src/main/java/org/apache/accumulo/test/NativeMapConcurrencyTest.java b/test/src/main/java/org/apache/accumulo/test/NativeMapConcurrencyTest.java
index 1781187e99..e0b71e10d9 100644
--- a/test/src/main/java/org/apache/accumulo/test/NativeMapConcurrencyTest.java
+++ b/test/src/main/java/org/apache/accumulo/test/NativeMapConcurrencyTest.java
@@ -37,8 +37,8 @@
 
   private static final Logger log = LoggerFactory.getLogger(NativeMapConcurrencyTest.class);
 
-  private static final byte ROW_PREFIX[] = new byte[] {'r'};
-  private static final byte COL_PREFIX[] = new byte[] {'c'};
+  private static final byte ROW_PREFIX[] = {'r'};
+  private static final byte COL_PREFIX[] = {'c'};
 
   static Mutation nm(int r) {
     return new Mutation(new Text(FastFormat.toZeroPaddedString(r, 6, 10, ROW_PREFIX)));
diff --git a/test/src/main/java/org/apache/accumulo/test/NativeMapPerformanceTest.java b/test/src/main/java/org/apache/accumulo/test/NativeMapPerformanceTest.java
index e1b8757cdd..8d83ebd19f 100644
--- a/test/src/main/java/org/apache/accumulo/test/NativeMapPerformanceTest.java
+++ b/test/src/main/java/org/apache/accumulo/test/NativeMapPerformanceTest.java
@@ -37,8 +37,8 @@
 
 public class NativeMapPerformanceTest {
 
-  private static final byte ROW_PREFIX[] = new byte[] {'r'};
-  private static final byte COL_PREFIX[] = new byte[] {'c'};
+  private static final byte ROW_PREFIX[] = {'r'};
+  private static final byte COL_PREFIX[] = {'c'};
 
   static Key newKey(int r, int c) {
     return new Key(new Text(FastFormat.toZeroPaddedString(r, 9, 10, ROW_PREFIX)),
@@ -63,7 +63,7 @@ static void runPerformanceTest(int numRows, int numCols, int numLookups, String
     if (mapType.equals("SKIP_LIST"))
       tm = new ConcurrentSkipListMap<>();
     else if (mapType.equals("TREE_MAP"))
-      tm = Collections.synchronizedSortedMap(new TreeMap<Key,Value>());
+      tm = Collections.synchronizedSortedMap(new TreeMap<>());
     else if (mapType.equals("NATIVE_MAP"))
       nm = new NativeMap();
     else
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 26c56d6e3f..aeffc46421 100644
--- a/test/src/main/java/org/apache/accumulo/test/ShellServerIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ShellServerIT.java
@@ -380,7 +380,7 @@ public void exporttableImporttable() throws Exception {
         }
       }
     } else {
-      String[] distCpArgs = new String[] {"-f", exportUri + "/distcp.txt", import_};
+      String[] distCpArgs = {"-f", exportUri + "/distcp.txt", import_};
       assertEquals("Failed to run distcp: " + Arrays.toString(distCpArgs), 0, cp.run(distCpArgs));
     }
     ts.exec("importtable " + table2 + " " + import_, true);
diff --git a/test/src/main/java/org/apache/accumulo/test/YieldScannersIT.java b/test/src/main/java/org/apache/accumulo/test/YieldScannersIT.java
index 891112ef86..f349812a74 100644
--- a/test/src/main/java/org/apache/accumulo/test/YieldScannersIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/YieldScannersIT.java
@@ -65,7 +65,7 @@ public void testScan() throws Exception {
     conn.tableOperations().create(tableName);
     final BatchWriter writer = conn.createBatchWriter(tableName, new BatchWriterConfig());
     for (int i = 0; i < 10; i++) {
-      byte[] row = new byte[] {(byte) (START_ROW + i)};
+      byte[] row = {(byte) (START_ROW + i)};
       Mutation m = new Mutation(new Text(row));
       m.put(new Text(), new Text(), new Value());
       writer.addMutation(m);
@@ -121,7 +121,7 @@ public void testBatchScan() throws Exception {
     conn.tableOperations().create(tableName);
     final BatchWriter writer = conn.createBatchWriter(tableName, new BatchWriterConfig());
     for (int i = 0; i < 10; i++) {
-      byte[] row = new byte[] {(byte) (START_ROW + i)};
+      byte[] row = {(byte) (START_ROW + i)};
       Mutation m = new Mutation(new Text(row));
       m.put(new Text(), new Text(), new Value());
       writer.addMutation(m);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/DeleteRowsIT.java b/test/src/main/java/org/apache/accumulo/test/functional/DeleteRowsIT.java
index 547b4b3a56..66ec09208f 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/DeleteRowsIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/DeleteRowsIT.java
@@ -52,8 +52,8 @@ protected int defaultTimeoutSeconds() {
   private static final Logger log = LoggerFactory.getLogger(DeleteRowsIT.class);
 
   private static final int ROWS_PER_TABLET = 10;
-  private static final String[] LETTERS = new String[] {"a", "b", "c", "d", "e", "f", "g", "h", "i",
-      "j", "k", "l", "m", "n", "o", "p", "q", "r", "s", "t", "u", "v", "w", "x", "y", "z"};
+  private static final String[] LETTERS = {"a", "b", "c", "d", "e", "f", "g", "h", "i", "j", "k",
+      "l", "m", "n", "o", "p", "q", "r", "s", "t", "u", "v", "w", "x", "y", "z"};
   static final SortedSet<Text> SPLITS = new TreeSet<>();
   static {
     for (String alpha : LETTERS) {
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 7b9305d294..c23cf4dceb 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
@@ -51,7 +51,7 @@
   @BeforeClass
   public static void initHttps() throws NoSuchAlgorithmException, KeyManagementException {
     SSLContext ctx = SSLContext.getInstance("SSL");
-    TrustManager[] tm = new TrustManager[] {new TestTrustManager()};
+    TrustManager[] tm = {new TestTrustManager()};
     ctx.init(new KeyManager[0], tm, new SecureRandom());
     SSLContext.setDefault(ctx);
     HttpsURLConnection.setDefaultSSLSocketFactory(ctx.getSocketFactory());
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/NativeMapIT.java b/test/src/main/java/org/apache/accumulo/test/functional/NativeMapIT.java
index 70a7a4b73c..791120ccce 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/NativeMapIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/NativeMapIT.java
@@ -536,8 +536,8 @@ public void testBinary() {
 
     for (int i = 0; i < 256; i++) {
       for (int j = 0; j < 256; j++) {
-        byte row[] = new byte[] {'r', (byte) (0xff & i), (byte) (0xff & j)};
-        byte data[] = new byte[] {'v', (byte) (0xff & i), (byte) (0xff & j)};
+        byte row[] = {'r', (byte) (0xff & i), (byte) (0xff & j)};
+        byte data[] = {'v', (byte) (0xff & i), (byte) (0xff & j)};
 
         Key k = new Key(row, emptyBytes, emptyBytes, emptyBytes, 1);
         Value v = new Value(data);
@@ -549,8 +549,8 @@ public void testBinary() {
     Iterator<Entry<Key,Value>> iter = nm.iterator();
     for (int i = 0; i < 256; i++) {
       for (int j = 0; j < 256; j++) {
-        byte row[] = new byte[] {'r', (byte) (0xff & i), (byte) (0xff & j)};
-        byte data[] = new byte[] {'v', (byte) (0xff & i), (byte) (0xff & j)};
+        byte row[] = {'r', (byte) (0xff & i), (byte) (0xff & j)};
+        byte data[] = {'v', (byte) (0xff & i), (byte) (0xff & j)};
 
         Key k = new Key(row, emptyBytes, emptyBytes, emptyBytes, 1);
         Value v = new Value(data);
@@ -568,8 +568,8 @@ public void testBinary() {
 
     for (int i = 0; i < 256; i++) {
       for (int j = 0; j < 256; j++) {
-        byte row[] = new byte[] {'r', (byte) (0xff & i), (byte) (0xff & j)};
-        byte data[] = new byte[] {'v', (byte) (0xff & i), (byte) (0xff & j)};
+        byte row[] = {'r', (byte) (0xff & i), (byte) (0xff & j)};
+        byte data[] = {'v', (byte) (0xff & i), (byte) (0xff & j)};
 
         Key k = new Key(row, emptyBytes, emptyBytes, emptyBytes, 1);
         Value v = new Value(data);
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 de1bb50bac..a5d7ee4361 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
@@ -161,7 +161,7 @@ public void sunnyDay() throws Exception {
               accumuloSite);
           scheme = "https://";
           SSLContext ctx = SSLContext.getInstance("SSL");
-          TrustManager[] tm = new TrustManager[] {new TestTrustManager()};
+          TrustManager[] tm = {new TestTrustManager()};
           ctx.init(new KeyManager[0], tm, new SecureRandom());
           SSLContext.setDefault(ctx);
           HttpsURLConnection.setDefaultSSLSocketFactory(ctx.getSocketFactory());
@@ -476,7 +476,7 @@ public void localityGroupChange() throws Exception {
     String table = getUniqueNames(1)[0];
     TableOperations to = connector.tableOperations();
     to.create(table);
-    String[] config = new String[] {"lg1:colf", null, "lg1:colf,xyz", "lg1:colf,xyz;lg2:c1,c2"};
+    String[] config = {"lg1:colf", null, "lg1:colf,xyz", "lg1:colf,xyz;lg2:c1,c2"};
     int i = 0;
     for (String cfg : config) {
       to.setLocalityGroups(table, getGroups(cfg));
diff --git a/test/src/main/java/org/apache/accumulo/test/performance/scan/CollectTabletStats.java b/test/src/main/java/org/apache/accumulo/test/performance/scan/CollectTabletStats.java
index 45d47ec6e5..9cdad9891e 100644
--- a/test/src/main/java/org/apache/accumulo/test/performance/scan/CollectTabletStats.java
+++ b/test/src/main/java/org/apache/accumulo/test/performance/scan/CollectTabletStats.java
@@ -102,7 +102,7 @@ public static void main(String[] args) throws Exception {
     final ScannerOpts scanOpts = new ScannerOpts();
     opts.parseArgs(CollectTabletStats.class.getName(), args, scanOpts);
 
-    String columnsTmp[] = new String[] {};
+    String columnsTmp[] = {};
     if (opts.columns != null)
       columnsTmp = opts.columns.split(",");
     final String columns[] = columnsTmp;


 

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services