You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by ct...@apache.org on 2016/07/01 01:59:21 UTC

[24/32] accumulo git commit: ACCUMULO-4357 Remove unneeded code for readability

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/examples/simple/src/main/java/org/apache/accumulo/examples/simple/reservations/ARS.java
----------------------------------------------------------------------
diff --git a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/reservations/ARS.java b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/reservations/ARS.java
index d99f7af..eff8e21 100644
--- a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/reservations/ARS.java
+++ b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/reservations/ARS.java
@@ -220,7 +220,7 @@ public class ARS {
       scanner.setRange(new Range(row));
       scanner.fetchColumnFamily(new Text("res"));
 
-      List<String> reservations = new ArrayList<String>();
+      List<String> reservations = new ArrayList<>();
 
       for (Entry<Key,Value> entry : scanner) {
         String val = entry.getValue().toString();
@@ -246,7 +246,7 @@ public class ARS {
         // start up multiple threads all trying to reserve the same resource, no more than one should succeed
 
         final ARS fars = ars;
-        ArrayList<Thread> threads = new ArrayList<Thread>();
+        ArrayList<Thread> threads = new ArrayList<>();
         for (int i = 3; i < tokens.length; i++) {
           final int whoIndex = i;
           Runnable reservationTask = new Runnable() {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/ContinuousQuery.java
----------------------------------------------------------------------
diff --git a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/ContinuousQuery.java b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/ContinuousQuery.java
index 6f0ceac..604c851 100644
--- a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/ContinuousQuery.java
+++ b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/ContinuousQuery.java
@@ -98,8 +98,8 @@ public class ContinuousQuery {
 
     Text currentRow = null;
 
-    ArrayList<Text> words = new ArrayList<Text>();
-    ArrayList<Text[]> ret = new ArrayList<Text[]>();
+    ArrayList<Text> words = new ArrayList<>();
+    ArrayList<Text[]> ret = new ArrayList<>();
 
     Random rand = new Random();
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/Index.java
----------------------------------------------------------------------
diff --git a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/Index.java b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/Index.java
index bc76c03..ba1e32e 100644
--- a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/Index.java
+++ b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/Index.java
@@ -53,7 +53,7 @@ public class Index {
 
     Mutation m = new Mutation(partition);
 
-    HashSet<String> tokensSeen = new HashSet<String>();
+    HashSet<String> tokensSeen = new HashSet<>();
 
     for (String token : tokens) {
       token = token.toLowerCase();
@@ -98,7 +98,7 @@ public class Index {
     @Parameter(names = "--partitions", required = true, description = "the number of shards to create")
     int partitions;
     @Parameter(required = true, description = "<file> { <file> ... }")
-    List<String> files = new ArrayList<String>();
+    List<String> files = new ArrayList<>();
   }
 
   public static void main(String[] args) throws Exception {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/Query.java
----------------------------------------------------------------------
diff --git a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/Query.java b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/Query.java
index 72a6384..13adcca 100644
--- a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/Query.java
+++ b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shard/Query.java
@@ -46,7 +46,7 @@ public class Query {
 
   static class Opts extends ClientOnRequiredTable {
     @Parameter(description = " term { <term> ... }")
-    List<String> terms = new ArrayList<String>();
+    List<String> terms = new ArrayList<>();
 
     @Parameter(names = {"--sample"}, description = "Do queries against sample, useful when sample is built using column qualifier")
     private boolean useSample = false;
@@ -76,7 +76,7 @@ public class Query {
     IntersectingIterator.setColumnFamilies(ii, columns);
     bs.addScanIterator(ii);
     bs.setRanges(Collections.singleton(new Range()));
-    List<String> result = new ArrayList<String>();
+    List<String> result = new ArrayList<>();
     for (Entry<Key,Value> entry : bs) {
       result.add(entry.getKey().getColumnQualifier().toString());
     }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shell/DebugCommand.java
----------------------------------------------------------------------
diff --git a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shell/DebugCommand.java b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shell/DebugCommand.java
index e429f62..4395fe7 100644
--- a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shell/DebugCommand.java
+++ b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/shell/DebugCommand.java
@@ -27,7 +27,7 @@ public class DebugCommand extends Command {
 
   @Override
   public int execute(String fullCommand, CommandLine cl, Shell shellState) throws Exception {
-    Set<String> lines = new TreeSet<String>();
+    Set<String> lines = new TreeSet<>();
     lines.add("This is a test");
     shellState.printLines(lines.iterator(), true);
     return 0;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/examples/simple/src/test/java/org/apache/accumulo/examples/simple/filedata/ChunkCombinerTest.java
----------------------------------------------------------------------
diff --git a/examples/simple/src/test/java/org/apache/accumulo/examples/simple/filedata/ChunkCombinerTest.java b/examples/simple/src/test/java/org/apache/accumulo/examples/simple/filedata/ChunkCombinerTest.java
index 9efd68b..40f4bb9 100644
--- a/examples/simple/src/test/java/org/apache/accumulo/examples/simple/filedata/ChunkCombinerTest.java
+++ b/examples/simple/src/test/java/org/apache/accumulo/examples/simple/filedata/ChunkCombinerTest.java
@@ -135,22 +135,22 @@ public class ChunkCombinerTest extends TestCase {
 
   @Override
   protected void setUp() {
-    row1 = new TreeMap<Key,Value>();
-    row2 = new TreeMap<Key,Value>();
-    row3 = new TreeMap<Key,Value>();
-    allRows = new TreeMap<Key,Value>();
+    row1 = new TreeMap<>();
+    row2 = new TreeMap<>();
+    row3 = new TreeMap<>();
+    allRows = new TreeMap<>();
 
-    cRow1 = new TreeMap<Key,Value>();
-    cRow2 = new TreeMap<Key,Value>();
-    cRow3 = new TreeMap<Key,Value>();
-    allCRows = new TreeMap<Key,Value>();
+    cRow1 = new TreeMap<>();
+    cRow2 = new TreeMap<>();
+    cRow3 = new TreeMap<>();
+    allCRows = new TreeMap<>();
 
-    cOnlyRow1 = new TreeMap<Key,Value>();
-    cOnlyRow2 = new TreeMap<Key,Value>();
-    cOnlyRow3 = new TreeMap<Key,Value>();
-    allCOnlyRows = new TreeMap<Key,Value>();
+    cOnlyRow1 = new TreeMap<>();
+    cOnlyRow2 = new TreeMap<>();
+    cOnlyRow3 = new TreeMap<>();
+    allCOnlyRows = new TreeMap<>();
 
-    badrow = new TreeMap<Key,Value>();
+    badrow = new TreeMap<>();
 
     String refs = FileDataIngest.REFS_CF.toString();
     String fileext = FileDataIngest.REFS_FILE_EXT;
@@ -218,7 +218,7 @@ public class ChunkCombinerTest extends TestCase {
     allCOnlyRows.putAll(cOnlyRow3);
   }
 
-  private static final Collection<ByteSequence> emptyColfs = new HashSet<ByteSequence>();
+  private static final Collection<ByteSequence> emptyColfs = new HashSet<>();
 
   public void test1() throws IOException {
     runTest(false, allRows, allCRows, emptyColfs);
@@ -241,7 +241,7 @@ public class ChunkCombinerTest extends TestCase {
     iter = iter.deepCopy(null);
     iter.seek(new Range(), cols, true);
 
-    TreeMap<Key,Value> seen = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> seen = new TreeMap<>();
 
     while (iter.hasTop()) {
       assertFalse("already contains " + iter.getTopKey(), seen.containsKey(iter.getTopKey()));

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/examples/simple/src/test/java/org/apache/accumulo/examples/simple/filedata/ChunkInputStreamTest.java
----------------------------------------------------------------------
diff --git a/examples/simple/src/test/java/org/apache/accumulo/examples/simple/filedata/ChunkInputStreamTest.java b/examples/simple/src/test/java/org/apache/accumulo/examples/simple/filedata/ChunkInputStreamTest.java
index 4f249fb..2796d47 100644
--- a/examples/simple/src/test/java/org/apache/accumulo/examples/simple/filedata/ChunkInputStreamTest.java
+++ b/examples/simple/src/test/java/org/apache/accumulo/examples/simple/filedata/ChunkInputStreamTest.java
@@ -43,7 +43,7 @@ public class ChunkInputStreamTest {
 
   @Before
   public void setupData() {
-    data = new ArrayList<Entry<Key,Value>>();
+    data = new ArrayList<>();
     addData(data, "a", "refs", "id\0ext", "A&B", "ext");
     addData(data, "a", "refs", "id\0name", "A&B", "name");
     addData(data, "a", "~chunk", 100, 0, "A&B", "asdfjkl;");
@@ -61,7 +61,7 @@ public class ChunkInputStreamTest {
     addData(data, "d", "~chunk", 100, 0, "A&B", "");
     addData(data, "e", "~chunk", 100, 0, "A&B", "asdfjkl;");
     addData(data, "e", "~chunk", 100, 1, "A&B", "");
-    baddata = new ArrayList<Entry<Key,Value>>();
+    baddata = new ArrayList<>();
     addData(baddata, "a", "~chunk", 100, 0, "A", "asdfjkl;");
     addData(baddata, "b", "~chunk", 100, 0, "B", "asdfjkl;");
     addData(baddata, "b", "~chunk", 100, 2, "C", "");
@@ -75,7 +75,7 @@ public class ChunkInputStreamTest {
     addData(baddata, "e", "~chunk", 100, 2, "I", "asdfjkl;");
     addData(baddata, "f", "~chunk", 100, 2, "K", "asdfjkl;");
     addData(baddata, "g", "~chunk", 100, 0, "L", "");
-    multidata = new ArrayList<Entry<Key,Value>>();
+    multidata = new ArrayList<>();
     addData(multidata, "a", "~chunk", 100, 0, "A&B", "asdfjkl;");
     addData(multidata, "a", "~chunk", 100, 1, "A&B", "");
     addData(multidata, "a", "~chunk", 200, 0, "B&C", "asdfjkl;");
@@ -99,8 +99,8 @@ public class ChunkInputStreamTest {
   @Test
   public void testExceptionOnMultipleSetSourceWithoutClose() throws IOException {
     ChunkInputStream cis = new ChunkInputStream();
-    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<Entry<Key,Value>>(data.iterator());
-    pi = new PeekingIterator<Entry<Key,Value>>(data.iterator());
+    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<>(data.iterator());
+    pi = new PeekingIterator<>(data.iterator());
     cis.setSource(pi);
     try {
       cis.setSource(pi);
@@ -114,7 +114,7 @@ public class ChunkInputStreamTest {
   @Test
   public void testExceptionOnGetVisBeforeClose() throws IOException {
     ChunkInputStream cis = new ChunkInputStream();
-    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<Entry<Key,Value>>(data.iterator());
+    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<>(data.iterator());
 
     cis.setSource(pi);
     try {
@@ -132,7 +132,7 @@ public class ChunkInputStreamTest {
     ChunkInputStream cis = new ChunkInputStream();
     byte[] b = new byte[5];
 
-    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<Entry<Key,Value>>(data.iterator());
+    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<>(data.iterator());
 
     cis.setSource(pi);
     int read;
@@ -184,7 +184,7 @@ public class ChunkInputStreamTest {
     ChunkInputStream cis = new ChunkInputStream();
     byte[] b = new byte[20];
     int read;
-    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<Entry<Key,Value>>(data.iterator());
+    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<>(data.iterator());
 
     cis.setSource(pi);
     assertEquals(read = cis.read(b), 8);
@@ -243,7 +243,7 @@ public class ChunkInputStreamTest {
     ChunkInputStream cis = new ChunkInputStream();
     byte[] b = new byte[20];
     int read;
-    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<Entry<Key,Value>>(baddata.iterator());
+    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<>(baddata.iterator());
 
     cis.setSource(pi);
     assumeExceptionOnRead(cis, b);
@@ -289,7 +289,7 @@ public class ChunkInputStreamTest {
 
     assertFalse(pi.hasNext());
 
-    pi = new PeekingIterator<Entry<Key,Value>>(baddata.iterator());
+    pi = new PeekingIterator<>(baddata.iterator());
     cis.setSource(pi);
     assumeExceptionOnClose(cis);
   }
@@ -299,7 +299,7 @@ public class ChunkInputStreamTest {
     ChunkInputStream cis = new ChunkInputStream();
     byte[] b = new byte[20];
     int read;
-    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<Entry<Key,Value>>(baddata.iterator());
+    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<>(baddata.iterator());
 
     cis.setSource(pi);
     assumeExceptionOnRead(cis, b);
@@ -340,7 +340,7 @@ public class ChunkInputStreamTest {
 
     assertFalse(pi.hasNext());
 
-    pi = new PeekingIterator<Entry<Key,Value>>(baddata.iterator());
+    pi = new PeekingIterator<>(baddata.iterator());
     cis.setSource(pi);
     assumeExceptionOnClose(cis);
   }
@@ -350,7 +350,7 @@ public class ChunkInputStreamTest {
     ChunkInputStream cis = new ChunkInputStream();
     byte[] b = new byte[20];
     int read;
-    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<Entry<Key,Value>>(multidata.iterator());
+    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<>(multidata.iterator());
 
     b = new byte[20];
 
@@ -377,7 +377,7 @@ public class ChunkInputStreamTest {
   @Test
   public void testSingleByteRead() throws IOException {
     ChunkInputStream cis = new ChunkInputStream();
-    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<Entry<Key,Value>>(data.iterator());
+    PeekingIterator<Entry<Key,Value>> pi = new PeekingIterator<>(data.iterator());
 
     cis.setSource(pi);
     assertEquals((byte) 'a', (byte) cis.read());

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/main/java/org/apache/accumulo/fate/AdminUtil.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/AdminUtil.java b/fate/src/main/java/org/apache/accumulo/fate/AdminUtil.java
index 8532e92..f6aa811 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/AdminUtil.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/AdminUtil.java
@@ -68,15 +68,15 @@ public class AdminUtil<T> {
 
   public void print(ReadOnlyTStore<T> zs, IZooReaderWriter zk, String lockPath, Formatter fmt, Set<Long> filterTxid, EnumSet<TStatus> filterStatus)
       throws KeeperException, InterruptedException {
-    Map<Long,List<String>> heldLocks = new HashMap<Long,List<String>>();
-    Map<Long,List<String>> waitingLocks = new HashMap<Long,List<String>>();
+    Map<Long,List<String>> heldLocks = new HashMap<>();
+    Map<Long,List<String>> waitingLocks = new HashMap<>();
 
     List<String> lockedIds = zk.getChildren(lockPath);
 
     for (String id : lockedIds) {
       try {
         List<String> lockNodes = zk.getChildren(lockPath + "/" + id);
-        lockNodes = new ArrayList<String>(lockNodes);
+        lockNodes = new ArrayList<>(lockNodes);
         Collections.sort(lockNodes);
 
         int pos = 0;
@@ -104,7 +104,7 @@ public class AdminUtil<T> {
 
             List<String> tables = locks.get(Long.parseLong(lda[1], 16));
             if (tables == null) {
-              tables = new ArrayList<String>();
+              tables = new ArrayList<>();
               locks.put(Long.parseLong(lda[1], 16), tables);
             }
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/main/java/org/apache/accumulo/fate/AgeOffStore.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/AgeOffStore.java b/fate/src/main/java/org/apache/accumulo/fate/AgeOffStore.java
index 83b726b..376dad4 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/AgeOffStore.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/AgeOffStore.java
@@ -70,7 +70,7 @@ public class AgeOffStore<T> implements TStore<T> {
   }
 
   public void ageOff() {
-    HashSet<Long> oldTxs = new HashSet<Long>();
+    HashSet<Long> oldTxs = new HashSet<>();
 
     synchronized (this) {
       long time = timeSource.currentTimeMillis();
@@ -114,7 +114,7 @@ public class AgeOffStore<T> implements TStore<T> {
     this.store = store;
     this.ageOffTime = ageOffTime;
     this.timeSource = timeSource;
-    candidates = new HashMap<Long,Long>();
+    candidates = new HashMap<>();
 
     minTime = Long.MAX_VALUE;
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/main/java/org/apache/accumulo/fate/ReadOnlyStore.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/ReadOnlyStore.java b/fate/src/main/java/org/apache/accumulo/fate/ReadOnlyStore.java
index cf2683b..5d5aeab 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/ReadOnlyStore.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/ReadOnlyStore.java
@@ -86,7 +86,7 @@ public class ReadOnlyStore<T> implements ReadOnlyTStore<T> {
 
   @Override
   public ReadOnlyRepo<T> top(long tid) {
-    return new ReadOnlyRepoWrapper<T>(store.top(tid));
+    return new ReadOnlyRepoWrapper<>(store.top(tid));
   }
 
   @Override

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/main/java/org/apache/accumulo/fate/ZooStore.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/ZooStore.java b/fate/src/main/java/org/apache/accumulo/fate/ZooStore.java
index 36a88e3..2a68f44 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/ZooStore.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/ZooStore.java
@@ -97,8 +97,8 @@ public class ZooStore<T> implements TStore<T> {
 
     this.path = path;
     this.zk = zk;
-    this.reserved = new HashSet<Long>();
-    this.defered = new HashMap<Long,Long>();
+    this.reserved = new HashSet<>();
+    this.defered = new HashMap<>();
     this.idgenerator = new SecureRandom();
 
     zk.putPersistentData(path, new byte[0], NodeExistsPolicy.SKIP);
@@ -130,7 +130,7 @@ public class ZooStore<T> implements TStore<T> {
           events = statusChangeEvents;
         }
 
-        List<String> txdirs = new ArrayList<String>(zk.getChildren(path));
+        List<String> txdirs = new ArrayList<>(zk.getChildren(path));
         Collections.sort(txdirs);
 
         synchronized (this) {
@@ -287,7 +287,7 @@ public class ZooStore<T> implements TStore<T> {
   private String findTop(String txpath) throws KeeperException, InterruptedException {
     List<String> ops = zk.getChildren(txpath);
 
-    ops = new ArrayList<String>(ops);
+    ops = new ArrayList<>(ops);
 
     String max = "";
 
@@ -448,7 +448,7 @@ public class ZooStore<T> implements TStore<T> {
   @Override
   public List<Long> list() {
     try {
-      ArrayList<Long> l = new ArrayList<Long>();
+      ArrayList<Long> l = new ArrayList<>();
       List<String> transactions = zk.getChildren(path);
       for (String txid : transactions) {
         l.add(parseTid(txid));
@@ -473,7 +473,7 @@ public class ZooStore<T> implements TStore<T> {
         throw new RuntimeException(e1);
       }
 
-      ops = new ArrayList<String>(ops);
+      ops = new ArrayList<>(ops);
       Collections.sort(ops, Collections.reverseOrder());
 
       ArrayList<ReadOnlyRepo<T>> dops = new ArrayList<>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/main/java/org/apache/accumulo/fate/zookeeper/DistributedReadWriteLock.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/DistributedReadWriteLock.java b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/DistributedReadWriteLock.java
index 624ce5d..fe31011 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/DistributedReadWriteLock.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/DistributedReadWriteLock.java
@@ -37,7 +37,7 @@ public class DistributedReadWriteLock implements java.util.concurrent.locks.Read
 
   static enum LockType {
     READ, WRITE,
-  };
+  }
 
   // serializer for lock type and user data
   static class ParsedLock {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/main/java/org/apache/accumulo/fate/zookeeper/TransactionWatcher.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/TransactionWatcher.java b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/TransactionWatcher.java
index dda7db9..b10ddea 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/TransactionWatcher.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/TransactionWatcher.java
@@ -33,7 +33,7 @@ public class TransactionWatcher {
   }
 
   private static final Logger log = LoggerFactory.getLogger(TransactionWatcher.class);
-  final private Map<Long,AtomicInteger> counts = new HashMap<Long,AtomicInteger>();
+  final private Map<Long,AtomicInteger> counts = new HashMap<>();
   final private Arbitrator arbitrator;
 
   public TransactionWatcher(Arbitrator arbitrator) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooCache.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooCache.java b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooCache.java
index 2526aad..bec3d64 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooCache.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooCache.java
@@ -148,9 +148,9 @@ public class ZooCache {
    */
   public ZooCache(ZooReader reader, Watcher watcher) {
     this.zReader = reader;
-    this.cache = new HashMap<String,byte[]>();
-    this.statCache = new HashMap<String,Stat>();
-    this.childrenCache = new HashMap<String,List<String>>();
+    this.cache = new HashMap<>();
+    this.statCache = new HashMap<>();
+    this.childrenCache = new HashMap<>();
     this.externalWatcher = watcher;
   }
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooCacheFactory.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooCacheFactory.java b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooCacheFactory.java
index 1475928..9fecf2e 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooCacheFactory.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooCacheFactory.java
@@ -26,7 +26,7 @@ import org.apache.zookeeper.Watcher;
  */
 public class ZooCacheFactory {
   // TODO: make this better - LRU, soft references, ...
-  private static Map<String,ZooCache> instances = new HashMap<String,ZooCache>();
+  private static Map<String,ZooCache> instances = new HashMap<>();
 
   /**
    * Gets a {@link ZooCache}. The same object may be returned for multiple calls with the same arguments.

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooLock.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooLock.java b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooLock.java
index 992a444..90fb4aa 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooLock.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooLock.java
@@ -404,7 +404,7 @@ public class ZooLock implements Watcher {
       return false;
     }
 
-    children = new ArrayList<String>(children);
+    children = new ArrayList<>(children);
     Collections.sort(children);
 
     String lockNode = children.get(0);
@@ -437,7 +437,7 @@ public class ZooLock implements Watcher {
       return null;
     }
 
-    children = new ArrayList<String>(children);
+    children = new ArrayList<>(children);
     Collections.sort(children);
 
     String lockNode = children.get(0);
@@ -456,7 +456,7 @@ public class ZooLock implements Watcher {
       return 0;
     }
 
-    children = new ArrayList<String>(children);
+    children = new ArrayList<>(children);
     Collections.sort(children);
 
     String lockNode = children.get(0);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooQueueLock.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooQueueLock.java b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooQueueLock.java
index 1b22dc9..25c735b 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooQueueLock.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooQueueLock.java
@@ -68,7 +68,7 @@ public class ZooQueueLock implements QueueLock {
 
   @Override
   public SortedMap<Long,byte[]> getEarlierEntries(long entry) {
-    SortedMap<Long,byte[]> result = new TreeMap<Long,byte[]>();
+    SortedMap<Long,byte[]> result = new TreeMap<>();
     try {
       List<String> children = Collections.emptyList();
       try {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooSession.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooSession.java b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooSession.java
index 837785f..b9fedac 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooSession.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooSession.java
@@ -51,7 +51,7 @@ public class ZooSession {
     ZooKeeper zooKeeper;
   }
 
-  private static Map<String,ZooSessionInfo> sessions = new HashMap<String,ZooSessionInfo>();
+  private static Map<String,ZooSessionInfo> sessions = new HashMap<>();
 
   private static String sessionKey(String keepers, int timeout, String scheme, byte[] auth) {
     return keepers + ":" + timeout + ":" + (scheme == null ? "" : scheme) + ":" + (auth == null ? "" : new String(auth, UTF_8));

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooUtil.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooUtil.java b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooUtil.java
index 4c4aa13..6ea10d0 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooUtil.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooUtil.java
@@ -161,9 +161,9 @@ public class ZooUtil {
   private static final RetryFactory RETRY_FACTORY;
 
   static {
-    PRIVATE = new ArrayList<ACL>();
+    PRIVATE = new ArrayList<>();
     PRIVATE.addAll(Ids.CREATOR_ALL_ACL);
-    PUBLIC = new ArrayList<ACL>();
+    PUBLIC = new ArrayList<>();
     PUBLIC.addAll(PRIVATE);
     PUBLIC.add(new ACL(Perms.READ, Ids.ANYONE_ID_UNSAFE));
     RETRY_FACTORY = RetryFactory.DEFAULT_INSTANCE;
@@ -483,7 +483,7 @@ public class ZooUtil {
       return null;
     }
 
-    children = new ArrayList<String>(children);
+    children = new ArrayList<>(children);
     Collections.sort(children);
 
     String lockNode = children.get(0);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/test/java/org/apache/accumulo/fate/AgeOffStoreTest.java
----------------------------------------------------------------------
diff --git a/fate/src/test/java/org/apache/accumulo/fate/AgeOffStoreTest.java b/fate/src/test/java/org/apache/accumulo/fate/AgeOffStoreTest.java
index 2c3b813..9549bd8 100644
--- a/fate/src/test/java/org/apache/accumulo/fate/AgeOffStoreTest.java
+++ b/fate/src/test/java/org/apache/accumulo/fate/AgeOffStoreTest.java
@@ -43,8 +43,8 @@ public class AgeOffStoreTest {
   public void testBasic() {
 
     TestTimeSource tts = new TestTimeSource();
-    SimpleStore<String> sstore = new SimpleStore<String>();
-    AgeOffStore<String> aoStore = new AgeOffStore<String>(sstore, 10, tts);
+    SimpleStore<String> sstore = new SimpleStore<>();
+    AgeOffStore<String> aoStore = new AgeOffStore<>(sstore, 10, tts);
 
     aoStore.ageOff();
 
@@ -73,22 +73,22 @@ public class AgeOffStoreTest {
 
     aoStore.ageOff();
 
-    Assert.assertEquals(new HashSet<Long>(Arrays.asList(txid1, txid2, txid3, txid4)), new HashSet<Long>(aoStore.list()));
-    Assert.assertEquals(4, new HashSet<Long>(aoStore.list()).size());
+    Assert.assertEquals(new HashSet<>(Arrays.asList(txid1, txid2, txid3, txid4)), new HashSet<>(aoStore.list()));
+    Assert.assertEquals(4, new HashSet<>(aoStore.list()).size());
 
     tts.time = 15;
 
     aoStore.ageOff();
 
-    Assert.assertEquals(new HashSet<Long>(Arrays.asList(txid1, txid3, txid4)), new HashSet<Long>(aoStore.list()));
-    Assert.assertEquals(3, new HashSet<Long>(aoStore.list()).size());
+    Assert.assertEquals(new HashSet<>(Arrays.asList(txid1, txid3, txid4)), new HashSet<>(aoStore.list()));
+    Assert.assertEquals(3, new HashSet<>(aoStore.list()).size());
 
     tts.time = 30;
 
     aoStore.ageOff();
 
-    Assert.assertEquals(new HashSet<Long>(Arrays.asList(txid1)), new HashSet<Long>(aoStore.list()));
-    Assert.assertEquals(1, new HashSet<Long>(aoStore.list()).size());
+    Assert.assertEquals(new HashSet<>(Arrays.asList(txid1)), new HashSet<>(aoStore.list()));
+    Assert.assertEquals(1, new HashSet<>(aoStore.list()).size());
   }
 
   @Test
@@ -96,7 +96,7 @@ public class AgeOffStoreTest {
     // test age off when source store starts off non empty
 
     TestTimeSource tts = new TestTimeSource();
-    SimpleStore<String> sstore = new SimpleStore<String>();
+    SimpleStore<String> sstore = new SimpleStore<>();
     Long txid1 = sstore.create();
     sstore.reserve(txid1);
     sstore.setStatus(txid1, TStatus.IN_PROGRESS);
@@ -116,22 +116,22 @@ public class AgeOffStoreTest {
 
     Long txid4 = sstore.create();
 
-    AgeOffStore<String> aoStore = new AgeOffStore<String>(sstore, 10, tts);
+    AgeOffStore<String> aoStore = new AgeOffStore<>(sstore, 10, tts);
 
-    Assert.assertEquals(new HashSet<Long>(Arrays.asList(txid1, txid2, txid3, txid4)), new HashSet<Long>(aoStore.list()));
-    Assert.assertEquals(4, new HashSet<Long>(aoStore.list()).size());
+    Assert.assertEquals(new HashSet<>(Arrays.asList(txid1, txid2, txid3, txid4)), new HashSet<>(aoStore.list()));
+    Assert.assertEquals(4, new HashSet<>(aoStore.list()).size());
 
     aoStore.ageOff();
 
-    Assert.assertEquals(new HashSet<Long>(Arrays.asList(txid1, txid2, txid3, txid4)), new HashSet<Long>(aoStore.list()));
-    Assert.assertEquals(4, new HashSet<Long>(aoStore.list()).size());
+    Assert.assertEquals(new HashSet<>(Arrays.asList(txid1, txid2, txid3, txid4)), new HashSet<>(aoStore.list()));
+    Assert.assertEquals(4, new HashSet<>(aoStore.list()).size());
 
     tts.time = 15;
 
     aoStore.ageOff();
 
-    Assert.assertEquals(new HashSet<Long>(Arrays.asList(txid1)), new HashSet<Long>(aoStore.list()));
-    Assert.assertEquals(1, new HashSet<Long>(aoStore.list()).size());
+    Assert.assertEquals(new HashSet<>(Arrays.asList(txid1)), new HashSet<>(aoStore.list()));
+    Assert.assertEquals(1, new HashSet<>(aoStore.list()).size());
 
     aoStore.reserve(txid1);
     aoStore.setStatus(txid1, TStatus.FAILED_IN_PROGRESS);
@@ -141,8 +141,8 @@ public class AgeOffStoreTest {
 
     aoStore.ageOff();
 
-    Assert.assertEquals(new HashSet<Long>(Arrays.asList(txid1)), new HashSet<Long>(aoStore.list()));
-    Assert.assertEquals(1, new HashSet<Long>(aoStore.list()).size());
+    Assert.assertEquals(new HashSet<>(Arrays.asList(txid1)), new HashSet<>(aoStore.list()));
+    Assert.assertEquals(1, new HashSet<>(aoStore.list()).size());
 
     aoStore.reserve(txid1);
     aoStore.setStatus(txid1, TStatus.FAILED);
@@ -150,13 +150,13 @@ public class AgeOffStoreTest {
 
     aoStore.ageOff();
 
-    Assert.assertEquals(new HashSet<Long>(Arrays.asList(txid1)), new HashSet<Long>(aoStore.list()));
-    Assert.assertEquals(1, new HashSet<Long>(aoStore.list()).size());
+    Assert.assertEquals(new HashSet<>(Arrays.asList(txid1)), new HashSet<>(aoStore.list()));
+    Assert.assertEquals(1, new HashSet<>(aoStore.list()).size());
 
     tts.time = 42;
 
     aoStore.ageOff();
 
-    Assert.assertEquals(0, new HashSet<Long>(aoStore.list()).size());
+    Assert.assertEquals(0, new HashSet<>(aoStore.list()).size());
   }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/test/java/org/apache/accumulo/fate/ReadOnlyStoreTest.java
----------------------------------------------------------------------
diff --git a/fate/src/test/java/org/apache/accumulo/fate/ReadOnlyStoreTest.java b/fate/src/test/java/org/apache/accumulo/fate/ReadOnlyStoreTest.java
index eea5f1b..e8f0cee 100644
--- a/fate/src/test/java/org/apache/accumulo/fate/ReadOnlyStoreTest.java
+++ b/fate/src/test/java/org/apache/accumulo/fate/ReadOnlyStoreTest.java
@@ -51,7 +51,7 @@ public class ReadOnlyStoreTest {
     EasyMock.replay(repo);
     EasyMock.replay(mock);
 
-    ReadOnlyTStore<String> store = new ReadOnlyStore<String>(mock);
+    ReadOnlyTStore<String> store = new ReadOnlyStore<>(mock);
     Assert.assertEquals(0xdeadbeefl, store.reserve());
     store.reserve(0xdeadbeefl);
     ReadOnlyRepo<String> top = store.top(0xdeadbeefl);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/test/java/org/apache/accumulo/fate/SimpleStore.java
----------------------------------------------------------------------
diff --git a/fate/src/test/java/org/apache/accumulo/fate/SimpleStore.java b/fate/src/test/java/org/apache/accumulo/fate/SimpleStore.java
index ab03525..3277270 100644
--- a/fate/src/test/java/org/apache/accumulo/fate/SimpleStore.java
+++ b/fate/src/test/java/org/apache/accumulo/fate/SimpleStore.java
@@ -33,8 +33,8 @@ import org.apache.commons.lang.NotImplementedException;
 public class SimpleStore<T> implements TStore<T> {
 
   private long nextId = 1;
-  private Map<Long,TStatus> statuses = new HashMap<Long,TStore.TStatus>();
-  private Set<Long> reserved = new HashSet<Long>();
+  private Map<Long,TStatus> statuses = new HashMap<>();
+  private Set<Long> reserved = new HashSet<>();
 
   @Override
   public long create() {
@@ -120,7 +120,7 @@ public class SimpleStore<T> implements TStore<T> {
 
   @Override
   public List<Long> list() {
-    return new ArrayList<Long>(statuses.keySet());
+    return new ArrayList<>(statuses.keySet());
   }
 
   @Override

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/test/java/org/apache/accumulo/fate/zookeeper/DistributedReadWriteLockTest.java
----------------------------------------------------------------------
diff --git a/fate/src/test/java/org/apache/accumulo/fate/zookeeper/DistributedReadWriteLockTest.java b/fate/src/test/java/org/apache/accumulo/fate/zookeeper/DistributedReadWriteLockTest.java
index 0b04bd1..486a4c6 100644
--- a/fate/src/test/java/org/apache/accumulo/fate/zookeeper/DistributedReadWriteLockTest.java
+++ b/fate/src/test/java/org/apache/accumulo/fate/zookeeper/DistributedReadWriteLockTest.java
@@ -34,11 +34,11 @@ public class DistributedReadWriteLockTest {
   public static class MockQueueLock implements QueueLock {
 
     long next = 0L;
-    final SortedMap<Long,byte[]> locks = new TreeMap<Long,byte[]>();
+    final SortedMap<Long,byte[]> locks = new TreeMap<>();
 
     @Override
     synchronized public SortedMap<Long,byte[]> getEarlierEntries(long entry) {
-      SortedMap<Long,byte[]> result = new TreeMap<Long,byte[]>();
+      SortedMap<Long,byte[]> result = new TreeMap<>();
       result.putAll(locks.headMap(entry + 1));
       return result;
     }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/fate/src/test/java/org/apache/accumulo/fate/zookeeper/TransactionWatcherTest.java
----------------------------------------------------------------------
diff --git a/fate/src/test/java/org/apache/accumulo/fate/zookeeper/TransactionWatcherTest.java b/fate/src/test/java/org/apache/accumulo/fate/zookeeper/TransactionWatcherTest.java
index 0e4e329..6779f6c 100644
--- a/fate/src/test/java/org/apache/accumulo/fate/zookeeper/TransactionWatcherTest.java
+++ b/fate/src/test/java/org/apache/accumulo/fate/zookeeper/TransactionWatcherTest.java
@@ -28,13 +28,13 @@ import org.junit.Test;
 public class TransactionWatcherTest {
 
   static class SimpleArbitrator implements TransactionWatcher.Arbitrator {
-    Map<String,List<Long>> started = new HashMap<String,List<Long>>();
-    Map<String,List<Long>> cleanedUp = new HashMap<String,List<Long>>();
+    Map<String,List<Long>> started = new HashMap<>();
+    Map<String,List<Long>> cleanedUp = new HashMap<>();
 
     public synchronized void start(String txType, Long txid) throws Exception {
       List<Long> txids = started.get(txType);
       if (txids == null)
-        txids = new ArrayList<Long>();
+        txids = new ArrayList<>();
       if (txids.contains(txid))
         throw new Exception("transaction already started");
       txids.add(txid);
@@ -42,7 +42,7 @@ public class TransactionWatcherTest {
 
       txids = cleanedUp.get(txType);
       if (txids == null)
-        txids = new ArrayList<Long>();
+        txids = new ArrayList<>();
       if (txids.contains(txid))
         throw new IllegalStateException("transaction was started but not cleaned up");
       txids.add(txid);
@@ -124,7 +124,7 @@ public class TransactionWatcherTest {
       });
       Assert.fail("work against stopped transaction should fail");
     } catch (Exception ex) {
-      ;
+
     }
     final long txid2 = 9;
     sa.start(txType, txid2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/maven-plugin/src/main/java/org/apache/accumulo/maven/plugin/AbstractAccumuloMojo.java
----------------------------------------------------------------------
diff --git a/maven-plugin/src/main/java/org/apache/accumulo/maven/plugin/AbstractAccumuloMojo.java b/maven-plugin/src/main/java/org/apache/accumulo/maven/plugin/AbstractAccumuloMojo.java
index 2028a2e..37eeb4d 100644
--- a/maven-plugin/src/main/java/org/apache/accumulo/maven/plugin/AbstractAccumuloMojo.java
+++ b/maven-plugin/src/main/java/org/apache/accumulo/maven/plugin/AbstractAccumuloMojo.java
@@ -43,7 +43,7 @@ public abstract class AbstractAccumuloMojo extends AbstractMojo {
   }
 
   void configureMiniClasspath(MiniAccumuloConfigImpl macConfig, String miniClasspath) throws MalformedURLException {
-    ArrayList<String> classpathItems = new ArrayList<String>();
+    ArrayList<String> classpathItems = new ArrayList<>();
     if (miniClasspath == null && project != null) {
       classpathItems.add(project.getBuild().getOutputDirectory());
       classpathItems.add(project.getBuild().getTestOutputDirectory());

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/minicluster/src/main/java/org/apache/accumulo/cluster/standalone/StandaloneClusterControl.java
----------------------------------------------------------------------
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 3edf60d..febc94c 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
@@ -377,7 +377,7 @@ public class StandaloneClusterControl implements ClusterControl {
   protected List<String> getHosts(File f) throws IOException {
     BufferedReader reader = new BufferedReader(new FileReader(f));
     try {
-      List<String> hosts = new ArrayList<String>();
+      List<String> hosts = new ArrayList<>();
       String line = null;
       while ((line = reader.readLine()) != null) {
         line = line.trim();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/minicluster/src/main/java/org/apache/accumulo/minicluster/MiniAccumuloRunner.java
----------------------------------------------------------------------
diff --git a/minicluster/src/main/java/org/apache/accumulo/minicluster/MiniAccumuloRunner.java b/minicluster/src/main/java/org/apache/accumulo/minicluster/MiniAccumuloRunner.java
index 78af6a0..4745e0a 100644
--- a/minicluster/src/main/java/org/apache/accumulo/minicluster/MiniAccumuloRunner.java
+++ b/minicluster/src/main/java/org/apache/accumulo/minicluster/MiniAccumuloRunner.java
@@ -184,7 +184,7 @@ public class MiniAccumuloRunner {
     if (opts.prop.containsKey(SHUTDOWN_PORT_PROP))
       shutdownPort = Integer.parseInt(opts.prop.getProperty(SHUTDOWN_PORT_PROP));
 
-    Map<String,String> siteConfig = new HashMap<String,String>();
+    Map<String,String> siteConfig = new HashMap<>();
     for (Map.Entry<Object,Object> entry : opts.prop.entrySet()) {
       String key = (String) entry.getKey();
       if (key.startsWith("site."))

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterControl.java
----------------------------------------------------------------------
diff --git a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterControl.java b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterControl.java
index 80c4edc..8cc7950 100644
--- a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterControl.java
+++ b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterControl.java
@@ -56,7 +56,7 @@ public class MiniAccumuloClusterControl implements ClusterControl {
   Process gcProcess = null;
   Process monitor = null;
   Process tracer = null;
-  final List<Process> tabletServerProcesses = new ArrayList<Process>();
+  final List<Process> tabletServerProcesses = new ArrayList<>();
 
   public MiniAccumuloClusterControl(MiniAccumuloClusterImpl cluster) {
     requireNonNull(cluster);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
----------------------------------------------------------------------
diff --git a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
index 772ba69..fd017be 100644
--- a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
+++ b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
@@ -169,7 +169,7 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
 
   private boolean initialized = false;
 
-  private Set<Pair<ServerType,Integer>> debugPorts = new HashSet<Pair<ServerType,Integer>>();
+  private Set<Pair<ServerType,Integer>> debugPorts = new HashSet<>();
 
   private File zooCfgFile;
   private String dfsUri;
@@ -178,11 +178,11 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
     return logWriters;
   }
 
-  private List<LogWriter> logWriters = new ArrayList<MiniAccumuloClusterImpl.LogWriter>();
+  private List<LogWriter> logWriters = new ArrayList<>();
 
   private MiniAccumuloConfigImpl config;
   private MiniDFSCluster miniDFS = null;
-  private List<Process> cleanup = new ArrayList<Process>();
+  private List<Process> cleanup = new ArrayList<>();
 
   private ExecutorService executor;
 
@@ -197,7 +197,7 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
   }
 
   public Process exec(Class<?> clazz, List<String> jvmArgs, String... args) throws IOException {
-    ArrayList<String> jvmArgs2 = new ArrayList<String>(1 + (jvmArgs == null ? 0 : jvmArgs.size()));
+    ArrayList<String> jvmArgs2 = new ArrayList<>(1 + (jvmArgs == null ? 0 : jvmArgs.size()));
     jvmArgs2.add("-Xmx" + config.getDefaultMemory());
     if (jvmArgs != null)
       jvmArgs2.addAll(jvmArgs);
@@ -231,7 +231,7 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
   private String getClasspath() throws IOException {
 
     try {
-      ArrayList<ClassLoader> classloaders = new ArrayList<ClassLoader>();
+      ArrayList<ClassLoader> classloaders = new ArrayList<>();
 
       ClassLoader cl = this.getClass().getClassLoader();
 
@@ -289,7 +289,7 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
 
     String className = clazz.getName();
 
-    ArrayList<String> argList = new ArrayList<String>();
+    ArrayList<String> argList = new ArrayList<>();
     argList.addAll(Arrays.asList(javaBin, "-Dproc=" + clazz.getSimpleName(), "-cp", classpath));
     argList.addAll(extraJvmOpts);
     for (Entry<String,String> sysProp : config.getSystemProperties().entrySet()) {
@@ -344,13 +344,13 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
 
   Process _exec(Class<?> clazz, ServerType serverType, String... args) throws IOException {
 
-    List<String> jvmOpts = new ArrayList<String>();
+    List<String> jvmOpts = new ArrayList<>();
     jvmOpts.add("-Xmx" + config.getMemory(serverType));
 
     if (config.isJDWPEnabled()) {
       Integer port = PortUtils.getRandomFreePort();
       jvmOpts.addAll(buildRemoteDebugParams(port));
-      debugPorts.add(new Pair<ServerType,Integer>(serverType, port));
+      debugPorts.add(new Pair<>(serverType, port));
     }
     return _exec(clazz, jvmOpts, args);
   }
@@ -649,7 +649,7 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
   }
 
   List<ProcessReference> references(Process... procs) {
-    List<ProcessReference> result = new ArrayList<ProcessReference>();
+    List<ProcessReference> result = new ArrayList<>();
     for (Process proc : procs) {
       result.add(new ProcessReference(proc));
     }
@@ -657,7 +657,7 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
   }
 
   public Map<ServerType,Collection<ProcessReference>> getProcesses() {
-    Map<ServerType,Collection<ProcessReference>> result = new HashMap<ServerType,Collection<ProcessReference>>();
+    Map<ServerType,Collection<ProcessReference>> result = new HashMap<>();
     MiniAccumuloClusterControl control = getClusterControl();
     result.put(ServerType.MASTER, references(control.masterProcess));
     result.put(ServerType.TABLET_SERVER, references(control.tabletServerProcesses.toArray(new Process[0])));
@@ -771,7 +771,7 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
   }
 
   int stopProcessWithTimeout(final Process proc, long timeout, TimeUnit unit) throws InterruptedException, ExecutionException, TimeoutException {
-    FutureTask<Integer> future = new FutureTask<Integer>(new Callable<Integer>() {
+    FutureTask<Integer> future = new FutureTask<>(new Callable<Integer>() {
       @Override
       public Integer call() throws InterruptedException {
         proc.destroy();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloConfigImpl.java
----------------------------------------------------------------------
diff --git a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloConfigImpl.java b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloConfigImpl.java
index 5939d2f..8e35705 100644
--- a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloConfigImpl.java
+++ b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloConfigImpl.java
@@ -47,12 +47,12 @@ public class MiniAccumuloConfigImpl {
 
   private File dir = null;
   private String rootPassword = null;
-  private Map<String,String> siteConfig = new HashMap<String,String>();
-  private Map<String,String> configuredSiteConig = new HashMap<String,String>();
+  private Map<String,String> siteConfig = new HashMap<>();
+  private Map<String,String> configuredSiteConig = new HashMap<>();
   private int numTservers = 2;
-  private Map<ServerType,Long> memoryConfig = new HashMap<ServerType,Long>();
+  private Map<ServerType,Long> memoryConfig = new HashMap<>();
   private boolean jdwpEnabled = false;
-  private Map<String,String> systemProperties = new HashMap<String,String>();
+  private Map<String,String> systemProperties = new HashMap<>();
 
   private String instanceName = "miniInstance";
   private String rootUserName = "root";
@@ -284,8 +284,8 @@ public class MiniAccumuloConfigImpl {
   }
 
   private MiniAccumuloConfigImpl _setSiteConfig(Map<String,String> siteConfig) {
-    this.siteConfig = new HashMap<String,String>(siteConfig);
-    this.configuredSiteConig = new HashMap<String,String>(siteConfig);
+    this.siteConfig = new HashMap<>(siteConfig);
+    this.configuredSiteConig = new HashMap<>(siteConfig);
     return this;
   }
 
@@ -378,11 +378,11 @@ public class MiniAccumuloConfigImpl {
    * @return a copy of the site config
    */
   public Map<String,String> getSiteConfig() {
-    return new HashMap<String,String>(siteConfig);
+    return new HashMap<>(siteConfig);
   }
 
   public Map<String,String> getConfiguredSiteConfig() {
-    return new HashMap<String,String>(configuredSiteConig);
+    return new HashMap<>(configuredSiteConig);
   }
 
   /**
@@ -547,7 +547,7 @@ public class MiniAccumuloConfigImpl {
    * @since 1.6.0
    */
   public void setSystemProperties(Map<String,String> systemProperties) {
-    this.systemProperties = new HashMap<String,String>(systemProperties);
+    this.systemProperties = new HashMap<>(systemProperties);
   }
 
   /**
@@ -556,7 +556,7 @@ public class MiniAccumuloConfigImpl {
    * @since 1.6.0
    */
   public Map<String,String> getSystemProperties() {
-    return new HashMap<String,String>(systemProperties);
+    return new HashMap<>(systemProperties);
   }
 
   /**
@@ -662,7 +662,7 @@ public class MiniAccumuloConfigImpl {
       throw e1;
     }
 
-    Map<String,String> siteConfigMap = new HashMap<String,String>();
+    Map<String,String> siteConfigMap = new HashMap<>();
     for (Entry<String,String> e : accumuloConf) {
       siteConfigMap.put(e.getKey(), e.getValue());
     }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/minicluster/src/test/java/org/apache/accumulo/minicluster/MiniAccumuloClusterTest.java
----------------------------------------------------------------------
diff --git a/minicluster/src/test/java/org/apache/accumulo/minicluster/MiniAccumuloClusterTest.java b/minicluster/src/test/java/org/apache/accumulo/minicluster/MiniAccumuloClusterTest.java
index 7c62384..f691bf6 100644
--- a/minicluster/src/test/java/org/apache/accumulo/minicluster/MiniAccumuloClusterTest.java
+++ b/minicluster/src/test/java/org/apache/accumulo/minicluster/MiniAccumuloClusterTest.java
@@ -69,7 +69,7 @@ public class MiniAccumuloClusterTest {
 
     MiniAccumuloConfig config = new MiniAccumuloConfig(testDir, "superSecret").setJDWPEnabled(true);
     config.setZooKeeperPort(0);
-    HashMap<String,String> site = new HashMap<String,String>();
+    HashMap<String,String> site = new HashMap<>();
     site.put(Property.TSERV_WORKQ_THREADS.getKey(), "2");
     config.setSiteConfig(site);
     accumulo = new MiniAccumuloCluster(config);
@@ -216,7 +216,7 @@ public class MiniAccumuloClusterTest {
   public void testConfig() {
     // ensure what user passed in is what comes back
     Assert.assertEquals(0, accumulo.getConfig().getZooKeeperPort());
-    HashMap<String,String> site = new HashMap<String,String>();
+    HashMap<String,String> site = new HashMap<>();
     site.put(Property.TSERV_WORKQ_THREADS.getKey(), "2");
     Assert.assertEquals(site, accumulo.getConfig().getSiteConfig());
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/minicluster/src/test/java/org/apache/accumulo/minicluster/impl/MiniAccumuloConfigImplTest.java
----------------------------------------------------------------------
diff --git a/minicluster/src/test/java/org/apache/accumulo/minicluster/impl/MiniAccumuloConfigImplTest.java b/minicluster/src/test/java/org/apache/accumulo/minicluster/impl/MiniAccumuloConfigImplTest.java
index dc616df..ba12f53 100644
--- a/minicluster/src/test/java/org/apache/accumulo/minicluster/impl/MiniAccumuloConfigImplTest.java
+++ b/minicluster/src/test/java/org/apache/accumulo/minicluster/impl/MiniAccumuloConfigImplTest.java
@@ -66,7 +66,7 @@ public class MiniAccumuloConfigImplTest {
   public void testSiteConfig() {
 
     // constructor site config overrides default props
-    Map<String,String> siteConfig = new HashMap<String,String>();
+    Map<String,String> siteConfig = new HashMap<>();
     siteConfig.put(Property.INSTANCE_DFS_URI.getKey(), "hdfs://");
     MiniAccumuloConfigImpl config = new MiniAccumuloConfigImpl(tempFolder.getRoot(), "password").setSiteConfig(siteConfig).initialize();
     assertEquals("hdfs://", config.getSiteConfig().get(Property.INSTANCE_DFS_URI.getKey()));

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/proxy/src/main/java/org/apache/accumulo/proxy/Proxy.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/Proxy.java b/proxy/src/main/java/org/apache/accumulo/proxy/Proxy.java
index 5f3b991..a3d185d 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/Proxy.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/Proxy.java
@@ -204,7 +204,7 @@ public class Proxy implements KeywordExecutable {
     AccumuloProxy.Iface wrappedImpl = RpcWrapper.service(impl, new AccumuloProxy.Processor<AccumuloProxy.Iface>(impl));
 
     // Create the processor from the implementation
-    TProcessor processor = new AccumuloProxy.Processor<AccumuloProxy.Iface>(wrappedImpl);
+    TProcessor processor = new AccumuloProxy.Processor<>(wrappedImpl);
 
     // Get the type of thrift server to instantiate
     final String serverTypeStr = properties.getProperty(THRIFT_SERVER_TYPE, THRIFT_SERVER_TYPE_DEFAULT);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java
----------------------------------------------------------------------
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 7e2c312..a62e1a1 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java
@@ -364,7 +364,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
       org.apache.accumulo.proxy.thrift.AccumuloSecurityException, org.apache.accumulo.proxy.thrift.TableNotFoundException, TException {
 
     try {
-      SortedSet<Text> sorted = new TreeSet<Text>();
+      SortedSet<Text> sorted = new TreeSet<>();
       for (ByteBuffer split : splits) {
         sorted.add(ByteBufferUtil.toText(split));
       }
@@ -420,7 +420,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
   }
 
   private List<IteratorSetting> getIteratorSettings(List<org.apache.accumulo.proxy.thrift.IteratorSetting> iterators) {
-    List<IteratorSetting> result = new ArrayList<IteratorSetting>();
+    List<IteratorSetting> result = new ArrayList<>();
     if (iterators != null) {
       for (org.apache.accumulo.proxy.thrift.IteratorSetting is : iterators) {
         result.add(getIteratorSetting(is));
@@ -493,9 +493,9 @@ public class ProxyServer implements AccumuloProxy.Iface {
       org.apache.accumulo.proxy.thrift.AccumuloSecurityException, org.apache.accumulo.proxy.thrift.TableNotFoundException, TException {
     try {
       Map<String,Set<Text>> groups = getConnector(login).tableOperations().getLocalityGroups(tableName);
-      Map<String,Set<String>> ret = new HashMap<String,Set<String>>();
+      Map<String,Set<String>> ret = new HashMap<>();
       for (Entry<String,Set<Text>> entry : groups.entrySet()) {
-        Set<String> value = new HashSet<String>();
+        Set<String> value = new HashSet<>();
         ret.put(entry.getKey(), value);
         for (Text val : entry.getValue()) {
           value.add(val.toString());
@@ -534,7 +534,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
   public Map<String,String> getTableProperties(ByteBuffer login, String tableName) throws org.apache.accumulo.proxy.thrift.AccumuloException,
       org.apache.accumulo.proxy.thrift.AccumuloSecurityException, org.apache.accumulo.proxy.thrift.TableNotFoundException, TException {
     try {
-      Map<String,String> ret = new HashMap<String,String>();
+      Map<String,String> ret = new HashMap<>();
 
       for (Map.Entry<String,String> entry : getConnector(login).tableOperations().getProperties(tableName)) {
         ret.put(entry.getKey(), entry.getValue());
@@ -551,7 +551,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
       org.apache.accumulo.proxy.thrift.AccumuloSecurityException, org.apache.accumulo.proxy.thrift.TableNotFoundException, TException {
     try {
       Collection<Text> splits = getConnector(login).tableOperations().listSplits(tableName, maxSplits);
-      List<ByteBuffer> ret = new ArrayList<ByteBuffer>();
+      List<ByteBuffer> ret = new ArrayList<>();
       for (Text split : splits) {
         ret.add(TextUtil.getByteBuffer(split));
       }
@@ -651,7 +651,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
       throws org.apache.accumulo.proxy.thrift.AccumuloException, org.apache.accumulo.proxy.thrift.AccumuloSecurityException,
       org.apache.accumulo.proxy.thrift.TableNotFoundException, TException {
     try {
-      Map<String,Set<Text>> groups = new HashMap<String,Set<Text>>();
+      Map<String,Set<Text>> groups = new HashMap<>();
       for (Entry<String,Set<String>> groupEntry : groupStrings.entrySet()) {
         groups.put(groupEntry.getKey(), new HashSet<Text>());
         for (String val : groupEntry.getValue()) {
@@ -688,10 +688,10 @@ public class ProxyServer implements AccumuloProxy.Iface {
       org.apache.accumulo.proxy.thrift.AccumuloSecurityException, org.apache.accumulo.proxy.thrift.TableNotFoundException, TException {
     try {
       List<org.apache.accumulo.core.client.admin.DiskUsage> diskUsages = getConnector(login).tableOperations().getDiskUsage(tables);
-      List<DiskUsage> retUsages = new ArrayList<DiskUsage>();
+      List<DiskUsage> retUsages = new ArrayList<>();
       for (org.apache.accumulo.core.client.admin.DiskUsage diskUsage : diskUsages) {
         DiskUsage usage = new DiskUsage();
-        usage.setTables(new ArrayList<String>(diskUsage.getTables()));
+        usage.setTables(new ArrayList<>(diskUsage.getTables()));
         usage.setUsage(diskUsage.getUsage());
         retUsages.add(usage);
       }
@@ -736,7 +736,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
   @Override
   public List<org.apache.accumulo.proxy.thrift.ActiveScan> getActiveScans(ByteBuffer login, String tserver)
       throws org.apache.accumulo.proxy.thrift.AccumuloException, org.apache.accumulo.proxy.thrift.AccumuloSecurityException, TException {
-    List<org.apache.accumulo.proxy.thrift.ActiveScan> result = new ArrayList<org.apache.accumulo.proxy.thrift.ActiveScan>();
+    List<org.apache.accumulo.proxy.thrift.ActiveScan> result = new ArrayList<>();
     try {
       List<ActiveScan> activeScans = getConnector(login).instanceOperations().getActiveScans(tserver);
       for (ActiveScan scan : activeScans) {
@@ -751,7 +751,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
         TabletId e = scan.getTablet();
         pscan.extent = new org.apache.accumulo.proxy.thrift.KeyExtent(e.getTableId().toString(), TextUtil.getByteBuffer(e.getEndRow()),
             TextUtil.getByteBuffer(e.getPrevEndRow()));
-        pscan.columns = new ArrayList<org.apache.accumulo.proxy.thrift.Column>();
+        pscan.columns = new ArrayList<>();
         if (scan.getColumns() != null) {
           for (Column c : scan.getColumns()) {
             org.apache.accumulo.proxy.thrift.Column column = new org.apache.accumulo.proxy.thrift.Column();
@@ -761,7 +761,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
             pscan.columns.add(column);
           }
         }
-        pscan.iterators = new ArrayList<org.apache.accumulo.proxy.thrift.IteratorSetting>();
+        pscan.iterators = new ArrayList<>();
         for (String iteratorString : scan.getSsiList()) {
           String[] parts = iteratorString.split("[=,]");
           if (parts.length == 3) {
@@ -773,7 +773,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
             pscan.iterators.add(settings);
           }
         }
-        pscan.authorizations = new ArrayList<ByteBuffer>();
+        pscan.authorizations = new ArrayList<>();
         if (scan.getAuthorizations() != null) {
           for (byte[] a : scan.getAuthorizations()) {
             pscan.authorizations.add(ByteBuffer.wrap(a));
@@ -793,7 +793,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
       throws org.apache.accumulo.proxy.thrift.AccumuloException, org.apache.accumulo.proxy.thrift.AccumuloSecurityException, TException {
 
     try {
-      List<org.apache.accumulo.proxy.thrift.ActiveCompaction> result = new ArrayList<org.apache.accumulo.proxy.thrift.ActiveCompaction>();
+      List<org.apache.accumulo.proxy.thrift.ActiveCompaction> result = new ArrayList<>();
       List<ActiveCompaction> active = getConnector(login).instanceOperations().getActiveCompactions(tserver);
       for (ActiveCompaction comp : active) {
         org.apache.accumulo.proxy.thrift.ActiveCompaction pcomp = new org.apache.accumulo.proxy.thrift.ActiveCompaction();
@@ -803,7 +803,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
         TabletId e = comp.getTablet();
         pcomp.extent = new org.apache.accumulo.proxy.thrift.KeyExtent(e.getTableId().toString(), TextUtil.getByteBuffer(e.getEndRow()),
             TextUtil.getByteBuffer(e.getPrevEndRow()));
-        pcomp.inputFiles = new ArrayList<String>();
+        pcomp.inputFiles = new ArrayList<>();
         if (comp.getInputFiles() != null) {
           pcomp.inputFiles.addAll(comp.getInputFiles());
         }
@@ -812,7 +812,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
         pcomp.reason = CompactionReason.valueOf(comp.getReason().toString());
         pcomp.type = CompactionType.valueOf(comp.getType().toString());
 
-        pcomp.iterators = new ArrayList<org.apache.accumulo.proxy.thrift.IteratorSetting>();
+        pcomp.iterators = new ArrayList<>();
         if (comp.getIterators() != null) {
           for (IteratorSetting setting : comp.getIterators()) {
             org.apache.accumulo.proxy.thrift.IteratorSetting psetting = new org.apache.accumulo.proxy.thrift.IteratorSetting(setting.getPriority(),
@@ -875,7 +875,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
   public void changeUserAuthorizations(ByteBuffer login, String user, Set<ByteBuffer> authorizations)
       throws org.apache.accumulo.proxy.thrift.AccumuloException, org.apache.accumulo.proxy.thrift.AccumuloSecurityException, TException {
     try {
-      Set<String> auths = new HashSet<String>();
+      Set<String> auths = new HashSet<>();
       for (ByteBuffer auth : authorizations) {
         auths.add(ByteBufferUtil.toString(auth));
       }
@@ -1035,7 +1035,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
   }
 
   private Authorizations getAuthorizations(Set<ByteBuffer> authorizations) {
-    List<String> auths = new ArrayList<String>();
+    List<String> auths = new ArrayList<>();
     for (ByteBuffer bbauth : authorizations) {
       auths.add(ByteBufferUtil.toString(bbauth));
     }
@@ -1117,7 +1117,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
           }
         }
 
-        ArrayList<Range> ranges = new ArrayList<Range>();
+        ArrayList<Range> ranges = new ArrayList<>();
 
         if (opts.ranges == null) {
           ranges.add(new Range());
@@ -1265,7 +1265,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
     if (bwpe.exception != null)
       return;
 
-    HashMap<Text,ColumnVisibility> vizMap = new HashMap<Text,ColumnVisibility>();
+    HashMap<Text,ColumnVisibility> vizMap = new HashMap<>();
 
     for (Map.Entry<ByteBuffer,List<ColumnUpdate>> entry : cells.entrySet()) {
       Mutation m = new Mutation(ByteBufferUtil.toBytes(entry.getKey()));
@@ -1524,7 +1524,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
       org.apache.accumulo.proxy.thrift.TableNotFoundException, TException {
     try {
       Map<String,EnumSet<IteratorScope>> iterMap = getConnector(login).tableOperations().listIterators(tableName);
-      Map<String,Set<org.apache.accumulo.proxy.thrift.IteratorScope>> result = new HashMap<String,Set<org.apache.accumulo.proxy.thrift.IteratorScope>>();
+      Map<String,Set<org.apache.accumulo.proxy.thrift.IteratorScope>> result = new HashMap<>();
       for (Map.Entry<String,EnumSet<IteratorScope>> entry : iterMap.entrySet()) {
         result.put(entry.getKey(), getProxyIteratorScopes(entry.getValue()));
       }
@@ -1552,7 +1552,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
       org.apache.accumulo.proxy.thrift.TableNotFoundException, TException {
     try {
       Set<Range> ranges = getConnector(login).tableOperations().splitRangeByTablets(tableName, getRange(range), maxSplits);
-      Set<org.apache.accumulo.proxy.thrift.Range> result = new HashSet<org.apache.accumulo.proxy.thrift.Range>();
+      Set<org.apache.accumulo.proxy.thrift.Range> result = new HashSet<>();
       for (Range r : ranges) {
         result.add(getRange(r));
       }
@@ -1939,9 +1939,9 @@ public class ProxyServer implements AccumuloProxy.Iface {
     }
 
     try {
-      HashMap<Text,ColumnVisibility> vizMap = new HashMap<Text,ColumnVisibility>();
+      HashMap<Text,ColumnVisibility> vizMap = new HashMap<>();
 
-      ArrayList<ConditionalMutation> cmuts = new ArrayList<ConditionalMutation>(updates.size());
+      ArrayList<ConditionalMutation> cmuts = new ArrayList<>(updates.size());
       for (Entry<ByteBuffer,ConditionalUpdates> cu : updates.entrySet()) {
         ConditionalMutation cmut = new ConditionalMutation(ByteBufferUtil.toBytes(cu.getKey()));
 
@@ -1973,7 +1973,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
 
       Iterator<Result> results = cw.write(cmuts.iterator());
 
-      HashMap<ByteBuffer,ConditionalStatus> resultMap = new HashMap<ByteBuffer,ConditionalStatus>();
+      HashMap<ByteBuffer,ConditionalStatus> resultMap = new HashMap<>();
 
       while (results.hasNext()) {
         Result result = results.next();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/proxy/src/test/java/org/apache/accumulo/proxy/ProxyServerTest.java
----------------------------------------------------------------------
diff --git a/proxy/src/test/java/org/apache/accumulo/proxy/ProxyServerTest.java b/proxy/src/test/java/org/apache/accumulo/proxy/ProxyServerTest.java
index 07fdc45..2f64445 100644
--- a/proxy/src/test/java/org/apache/accumulo/proxy/ProxyServerTest.java
+++ b/proxy/src/test/java/org/apache/accumulo/proxy/ProxyServerTest.java
@@ -48,7 +48,7 @@ public class ProxyServerTest {
 
     final ByteBuffer login = ByteBuffer.wrap("my_login".getBytes(UTF_8));
     final String tableName = "table1";
-    final Map<ByteBuffer,List<ColumnUpdate>> cells = new HashMap<ByteBuffer,List<ColumnUpdate>>();
+    final Map<ByteBuffer,List<ColumnUpdate>> cells = new HashMap<>();
 
     EasyMock.expect(server.getWriter(login, tableName, null)).andReturn(bwpe);
     server.addCellsToWriter(cells, bwpe);
@@ -83,7 +83,7 @@ public class ProxyServerTest {
 
     final ByteBuffer login = ByteBuffer.wrap("my_login".getBytes(UTF_8));
     final String tableName = "table1";
-    final Map<ByteBuffer,List<ColumnUpdate>> cells = new HashMap<ByteBuffer,List<ColumnUpdate>>();
+    final Map<ByteBuffer,List<ColumnUpdate>> cells = new HashMap<>();
 
     EasyMock.expect(server.getWriter(login, tableName, null)).andReturn(bwpe);
     server.addCellsToWriter(cells, bwpe);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/server/base/src/main/java/org/apache/accumulo/server/Accumulo.java
----------------------------------------------------------------------
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 302b6f9..3cfd759 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
@@ -182,7 +182,7 @@ public class Accumulo {
       throw new RuntimeException("This version of accumulo (" + codeVersion + ") is not compatible with files stored using data version " + dataVersion);
     }
 
-    TreeMap<String,String> sortedProps = new TreeMap<String,String>();
+    TreeMap<String,String> sortedProps = new TreeMap<>();
     for (Entry<String,String> entry : conf)
       sortedProps.put(entry.getKey(), entry.getValue());
 
@@ -313,8 +313,8 @@ public class Accumulo {
    */
   public static void abortIfFateTransactions() {
     try {
-      final ReadOnlyTStore<Accumulo> fate = new ReadOnlyStore<Accumulo>(new ZooStore<Accumulo>(
-          ZooUtil.getRoot(HdfsZooInstance.getInstance()) + Constants.ZFATE, ZooReaderWriter.getInstance()));
+      final ReadOnlyTStore<Accumulo> fate = new ReadOnlyStore<>(new ZooStore<Accumulo>(ZooUtil.getRoot(HdfsZooInstance.getInstance()) + Constants.ZFATE,
+          ZooReaderWriter.getInstance()));
       if (!(fate.list().isEmpty())) {
         throw new AccumuloException("Aborting upgrade because there are outstanding FATE transactions from a previous Accumulo version. "
             + "Please see the README document for instructions on what to do under your previous version.");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/server/base/src/main/java/org/apache/accumulo/server/GarbageCollectionLogger.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/GarbageCollectionLogger.java b/server/base/src/main/java/org/apache/accumulo/server/GarbageCollectionLogger.java
index 993f0ea..a275df7 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/GarbageCollectionLogger.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/GarbageCollectionLogger.java
@@ -30,7 +30,7 @@ import org.slf4j.LoggerFactory;
 public class GarbageCollectionLogger {
   private static final Logger log = LoggerFactory.getLogger(GarbageCollectionLogger.class);
 
-  private final HashMap<String,Long> prevGcTime = new HashMap<String,Long>();
+  private final HashMap<String,Long> prevGcTime = new HashMap<>();
   private long lastMemorySize = 0;
   private long gcTimeIncreasedCount = 0;
   private static long lastMemoryCheckTime = 0;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/server/base/src/main/java/org/apache/accumulo/server/ServerConstants.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/ServerConstants.java b/server/base/src/main/java/org/apache/accumulo/server/ServerConstants.java
index c268e83..8c64d50 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/ServerConstants.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/ServerConstants.java
@@ -96,7 +96,7 @@ public class ServerConstants {
     String firstDir = null;
     String firstIid = null;
     Integer firstVersion = null;
-    ArrayList<String> baseDirsList = new ArrayList<String>();
+    ArrayList<String> baseDirsList = new ArrayList<>();
     for (String baseDir : configuredBaseDirs) {
       Path path = new Path(baseDir, INSTANCE_ID_DIR);
       String currentIid;
@@ -177,7 +177,7 @@ public class ServerConstants {
         return Collections.emptyList();
 
       String[] pairs = replacements.split(",");
-      List<Pair<Path,Path>> ret = new ArrayList<Pair<Path,Path>>();
+      List<Pair<Path,Path>> ret = new ArrayList<>();
 
       for (String pair : pairs) {
 
@@ -203,10 +203,10 @@ public class ServerConstants {
           throw new IllegalArgumentException(Property.INSTANCE_VOLUMES_REPLACEMENTS.getKey() + " contains " + uris[1] + " which has a syntax error", e);
         }
 
-        ret.add(new Pair<Path,Path>(p1, p2));
+        ret.add(new Pair<>(p1, p2));
       }
 
-      HashSet<Path> baseDirs = new HashSet<Path>();
+      HashSet<Path> baseDirs = new HashSet<>();
       for (String baseDir : getBaseUris()) {
         // normalize using path
         baseDirs.add(new Path(baseDir));

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/server/base/src/main/java/org/apache/accumulo/server/client/BulkImporter.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/client/BulkImporter.java b/server/base/src/main/java/org/apache/accumulo/server/client/BulkImporter.java
index e27ce52..c9af520 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/client/BulkImporter.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/client/BulkImporter.java
@@ -82,7 +82,7 @@ public class BulkImporter {
   public static List<String> bulkLoad(ClientContext context, long tid, String tableId, List<String> files, String errorDir, boolean setTime)
       throws IOException, AccumuloException, AccumuloSecurityException, ThriftTableOperationException {
     AssignmentStats stats = new BulkImporter(context, tid, tableId, setTime).importFiles(files, new Path(errorDir));
-    List<String> result = new ArrayList<String>();
+    List<String> result = new ArrayList<>();
     for (Path p : stats.completeFailures.keySet()) {
       result.add(p.toString());
     }
@@ -113,14 +113,14 @@ public class BulkImporter {
     int numThreads = context.getConfiguration().getCount(Property.TSERV_BULK_PROCESS_THREADS);
     int numAssignThreads = context.getConfiguration().getCount(Property.TSERV_BULK_ASSIGNMENT_THREADS);
 
-    timer = new StopWatch<Timers>(Timers.class);
+    timer = new StopWatch<>(Timers.class);
     timer.start(Timers.TOTAL);
 
     Configuration conf = CachedConfiguration.getInstance();
     VolumeManagerImpl.get(context.getConfiguration());
     final VolumeManager fs = VolumeManagerImpl.get(context.getConfiguration());
 
-    Set<Path> paths = new HashSet<Path>();
+    Set<Path> paths = new HashSet<>();
     for (String file : files) {
       paths.add(new Path(file));
     }
@@ -172,7 +172,7 @@ public class BulkImporter {
       Map<Path,List<KeyExtent>> assignmentFailures = assignMapFiles(context, conf, fs, tableId, assignments, paths, numAssignThreads, numThreads);
       assignmentStats.assignmentsFailed(assignmentFailures);
 
-      Map<Path,Integer> failureCount = new TreeMap<Path,Integer>();
+      Map<Path,Integer> failureCount = new TreeMap<>();
 
       for (Entry<Path,List<KeyExtent>> entry : assignmentFailures.entrySet())
         failureCount.put(entry.getKey(), 1);
@@ -199,7 +199,7 @@ public class BulkImporter {
         for (Entry<Path,List<KeyExtent>> entry : assignmentFailures.entrySet()) {
           Iterator<KeyExtent> keListIter = entry.getValue().iterator();
 
-          List<TabletLocation> tabletsToAssignMapFileTo = new ArrayList<TabletLocation>();
+          List<TabletLocation> tabletsToAssignMapFileTo = new ArrayList<>();
 
           while (keListIter.hasNext()) {
             KeyExtent ke = keListIter.next();
@@ -273,7 +273,7 @@ public class BulkImporter {
 
       totalTime += timer.get(t);
     }
-    List<String> files = new ArrayList<String>();
+    List<String> files = new ArrayList<>();
     for (Path path : paths) {
       files.add(path.getName());
     }
@@ -326,7 +326,7 @@ public class BulkImporter {
   }
 
   private static List<KeyExtent> extentsOf(List<TabletLocation> locations) {
-    List<KeyExtent> result = new ArrayList<KeyExtent>(locations.size());
+    List<KeyExtent> result = new ArrayList<>(locations.size());
     for (TabletLocation tl : locations)
       result.add(tl.tablet_extent);
     return result;
@@ -336,7 +336,7 @@ public class BulkImporter {
       Map<Path,List<TabletLocation>> assignments, Collection<Path> paths, int numThreads) {
 
     long t1 = System.currentTimeMillis();
-    final Map<Path,Long> mapFileSizes = new TreeMap<Path,Long>();
+    final Map<Path,Long> mapFileSizes = new TreeMap<>();
 
     try {
       for (Path path : paths) {
@@ -376,13 +376,13 @@ public class BulkImporter {
 
           if (estimatedSizes == null) {
             // estimation failed, do a simple estimation
-            estimatedSizes = new TreeMap<KeyExtent,Long>();
+            estimatedSizes = new TreeMap<>();
             long estSize = (long) (mapFileSizes.get(entry.getKey()) / (double) entry.getValue().size());
             for (TabletLocation tl : entry.getValue())
               estimatedSizes.put(tl.tablet_extent, estSize);
           }
 
-          List<AssignmentInfo> assignmentInfoList = new ArrayList<AssignmentInfo>(estimatedSizes.size());
+          List<AssignmentInfo> assignmentInfoList = new ArrayList<>(estimatedSizes.size());
 
           for (Entry<KeyExtent,Long> entry2 : estimatedSizes.entrySet())
             assignmentInfoList.add(new AssignmentInfo(entry2.getKey(), entry2.getValue()));
@@ -413,7 +413,7 @@ public class BulkImporter {
   }
 
   private static Map<KeyExtent,String> locationsOf(Map<Path,List<TabletLocation>> assignments) {
-    Map<KeyExtent,String> result = new HashMap<KeyExtent,String>();
+    Map<KeyExtent,String> result = new HashMap<>();
     for (List<TabletLocation> entry : assignments.values()) {
       for (TabletLocation tl : entry) {
         result.put(tl.tablet_extent, tl.tablet_location);
@@ -455,7 +455,7 @@ public class BulkImporter {
           for (PathSize pathSize : mapFiles) {
             List<KeyExtent> existingFailures = assignmentFailures.get(pathSize.path);
             if (existingFailures == null) {
-              existingFailures = new ArrayList<KeyExtent>();
+              existingFailures = new ArrayList<>();
               assignmentFailures.put(pathSize.path, existingFailures);
             }
 
@@ -469,7 +469,7 @@ public class BulkImporter {
 
     @Override
     public void run() {
-      HashSet<Path> uniqMapFiles = new HashSet<Path>();
+      HashSet<Path> uniqMapFiles = new HashSet<>();
       for (List<PathSize> mapFiles : assignmentsPerTablet.values())
         for (PathSize ps : mapFiles)
           uniqMapFiles.add(ps.path);
@@ -506,7 +506,7 @@ public class BulkImporter {
   private Map<Path,List<KeyExtent>> assignMapFiles(String tableName, Map<Path,List<AssignmentInfo>> assignments, Map<KeyExtent,String> locations, int numThreads) {
 
     // group assignments by tablet
-    Map<KeyExtent,List<PathSize>> assignmentsPerTablet = new TreeMap<KeyExtent,List<PathSize>>();
+    Map<KeyExtent,List<PathSize>> assignmentsPerTablet = new TreeMap<>();
     for (Entry<Path,List<AssignmentInfo>> entry : assignments.entrySet()) {
       Path mapFile = entry.getKey();
       List<AssignmentInfo> tabletsToAssignMapFileTo = entry.getValue();
@@ -514,7 +514,7 @@ public class BulkImporter {
       for (AssignmentInfo ai : tabletsToAssignMapFileTo) {
         List<PathSize> mapFiles = assignmentsPerTablet.get(ai.ke);
         if (mapFiles == null) {
-          mapFiles = new ArrayList<PathSize>();
+          mapFiles = new ArrayList<>();
           assignmentsPerTablet.put(ai.ke, mapFiles);
         }
 
@@ -526,7 +526,7 @@ public class BulkImporter {
 
     Map<Path,List<KeyExtent>> assignmentFailures = Collections.synchronizedMap(new TreeMap<Path,List<KeyExtent>>());
 
-    TreeMap<String,Map<KeyExtent,List<PathSize>>> assignmentsPerTabletServer = new TreeMap<String,Map<KeyExtent,List<PathSize>>>();
+    TreeMap<String,Map<KeyExtent,List<PathSize>>> assignmentsPerTabletServer = new TreeMap<>();
 
     for (Entry<KeyExtent,List<PathSize>> entry : assignmentsPerTablet.entrySet()) {
       KeyExtent ke = entry.getKey();
@@ -537,7 +537,7 @@ public class BulkImporter {
           synchronized (assignmentFailures) {
             List<KeyExtent> failures = assignmentFailures.get(pathSize.path);
             if (failures == null) {
-              failures = new ArrayList<KeyExtent>();
+              failures = new ArrayList<>();
               assignmentFailures.put(pathSize.path, failures);
             }
 
@@ -552,7 +552,7 @@ public class BulkImporter {
 
       Map<KeyExtent,List<PathSize>> apt = assignmentsPerTabletServer.get(location);
       if (apt == null) {
-        apt = new TreeMap<KeyExtent,List<PathSize>>();
+        apt = new TreeMap<>();
         assignmentsPerTabletServer.put(location, apt);
       }
 
@@ -586,9 +586,9 @@ public class BulkImporter {
       long timeInMillis = context.getConfiguration().getTimeInMillis(Property.TSERV_BULK_TIMEOUT);
       TabletClientService.Iface client = ThriftUtil.getTServerClient(location, context, timeInMillis);
       try {
-        HashMap<KeyExtent,Map<String,org.apache.accumulo.core.data.thrift.MapFileInfo>> files = new HashMap<KeyExtent,Map<String,org.apache.accumulo.core.data.thrift.MapFileInfo>>();
+        HashMap<KeyExtent,Map<String,org.apache.accumulo.core.data.thrift.MapFileInfo>> files = new HashMap<>();
         for (Entry<KeyExtent,List<PathSize>> entry : assignmentsPerTablet.entrySet()) {
-          HashMap<String,org.apache.accumulo.core.data.thrift.MapFileInfo> tabletFiles = new HashMap<String,org.apache.accumulo.core.data.thrift.MapFileInfo>();
+          HashMap<String,org.apache.accumulo.core.data.thrift.MapFileInfo> tabletFiles = new HashMap<>();
           files.put(entry.getKey(), tabletFiles);
 
           for (PathSize pathSize : entry.getValue()) {
@@ -637,7 +637,7 @@ public class BulkImporter {
 
   public static List<TabletLocation> findOverlappingTablets(ClientContext context, VolumeManager vm, TabletLocator locator, Path file, Text startRow,
       Text endRow) throws Exception {
-    List<TabletLocation> result = new ArrayList<TabletLocation>();
+    List<TabletLocation> result = new ArrayList<>();
     Collection<ByteSequence> columnFamilies = Collections.emptyList();
     String filename = file.toString();
     // log.debug(filename + " finding overlapping tablets " + startRow + " -> " + endRow);
@@ -680,7 +680,7 @@ public class BulkImporter {
     private Set<Path> failedFailures = null;
 
     AssignmentStats(int fileCount) {
-      counts = new HashMap<KeyExtent,Integer>();
+      counts = new HashMap<>();
       numUniqueMapFiles = fileCount;
     }
 
@@ -751,7 +751,7 @@ public class BulkImporter {
       stddev = stddev / counts.size();
       stddev = Math.sqrt(stddev);
 
-      Set<KeyExtent> failedTablets = new HashSet<KeyExtent>();
+      Set<KeyExtent> failedTablets = new HashSet<>();
       for (List<KeyExtent> ft : completeFailures.values())
         failedTablets.addAll(ft);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/server/base/src/main/java/org/apache/accumulo/server/client/ClientServiceHandler.java
----------------------------------------------------------------------
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 c306e85..3beb1e0 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
@@ -262,7 +262,7 @@ public class ClientServiceHandler implements ClientService.Iface {
     security.authenticateUser(credentials, credentials);
     conf.invalidateCache();
 
-    Map<String,String> result = new HashMap<String,String>();
+    Map<String,String> result = new HashMap<>();
     for (Entry<String,String> entry : conf) {
       String key = entry.getKey();
       if (!Property.isSensitive(key))
@@ -421,7 +421,7 @@ public class ClientServiceHandler implements ClientService.Iface {
   @Override
   public List<TDiskUsage> getDiskUsage(Set<String> tables, TCredentials credentials) throws ThriftTableOperationException, ThriftSecurityException, TException {
     try {
-      HashSet<String> tableIds = new HashSet<String>();
+      HashSet<String> tableIds = new HashSet<>();
 
       for (String table : tables) {
         // ensure that table table exists
@@ -435,9 +435,9 @@ public class ClientServiceHandler implements ClientService.Iface {
       // use the same set of tableIds that were validated above to avoid race conditions
       Map<TreeSet<String>,Long> diskUsage = TableDiskUsage.getDiskUsage(context.getServerConfigurationFactory().getConfiguration(), tableIds, fs,
           context.getConnector());
-      List<TDiskUsage> retUsages = new ArrayList<TDiskUsage>();
+      List<TDiskUsage> retUsages = new ArrayList<>();
       for (Map.Entry<TreeSet<String>,Long> usageItem : diskUsage.entrySet()) {
-        retUsages.add(new TDiskUsage(new ArrayList<String>(usageItem.getKey()), usageItem.getValue()));
+        retUsages.add(new TDiskUsage(new ArrayList<>(usageItem.getKey()), usageItem.getValue()));
       }
       return retUsages;
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/server/base/src/main/java/org/apache/accumulo/server/conf/NamespaceConfiguration.java
----------------------------------------------------------------------
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 3d19723..1ca083e 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
@@ -38,7 +38,7 @@ import com.google.common.base.Predicate;
 public class NamespaceConfiguration extends ObservableConfiguration {
   private static final Logger log = LoggerFactory.getLogger(NamespaceConfiguration.class);
 
-  private static final Map<PropCacheKey,ZooCache> propCaches = new java.util.HashMap<PropCacheKey,ZooCache>();
+  private static final Map<PropCacheKey,ZooCache> propCaches = new java.util.HashMap<>();
 
   private final AccumuloConfiguration parent;
   private ZooCachePropertyAccessor propCacheAccessor = null;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/server/base/src/main/java/org/apache/accumulo/server/conf/ServerConfigurationFactory.java
----------------------------------------------------------------------
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 2995fc8..5cea8b5 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
@@ -34,9 +34,9 @@ import org.apache.accumulo.fate.zookeeper.ZooCacheFactory;
  */
 public class ServerConfigurationFactory extends ServerConfiguration {
 
-  private static final Map<String,Map<String,TableConfiguration>> tableConfigs = new HashMap<String,Map<String,TableConfiguration>>(1);
-  private static final Map<String,Map<String,NamespaceConfiguration>> namespaceConfigs = new HashMap<String,Map<String,NamespaceConfiguration>>(1);
-  private static final Map<String,Map<String,NamespaceConfiguration>> tableParentConfigs = new HashMap<String,Map<String,NamespaceConfiguration>>(1);
+  private static final Map<String,Map<String,TableConfiguration>> tableConfigs = new HashMap<>(1);
+  private static final Map<String,Map<String,NamespaceConfiguration>> namespaceConfigs = new HashMap<>(1);
+  private static final Map<String,Map<String,NamespaceConfiguration>> tableParentConfigs = new HashMap<>(1);
 
   private static void addInstanceToCaches(String iid) {
     synchronized (tableConfigs) {