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:24 UTC

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

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/conf/ColumnToClassMapping.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/conf/ColumnToClassMapping.java b/core/src/main/java/org/apache/accumulo/core/iterators/conf/ColumnToClassMapping.java
index 84a6996..11d5222 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/conf/ColumnToClassMapping.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/conf/ColumnToClassMapping.java
@@ -37,8 +37,8 @@ public class ColumnToClassMapping<K> {
   private ColFamHashKey lookupCF = new ColFamHashKey();
 
   public ColumnToClassMapping() {
-    objectsCF = new HashMap<ColFamHashKey,K>();
-    objectsCol = new HashMap<ColHashKey,K>();
+    objectsCF = new HashMap<>();
+    objectsCol = new HashMap<>();
   }
 
   public ColumnToClassMapping(Map<String,String> objectStrings, Class<? extends K> c) throws InstantiationException, IllegalAccessException,

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/system/ColumnFamilySkippingIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/system/ColumnFamilySkippingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/system/ColumnFamilySkippingIterator.java
index 350c4cd..53f3643 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/system/ColumnFamilySkippingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/system/ColumnFamilySkippingIterator.java
@@ -108,12 +108,12 @@ public class ColumnFamilySkippingIterator extends SkippingIterator implements In
     if (columnFamilies instanceof Set<?>) {
       colFamSet = (Set<ByteSequence>) columnFamilies;
     } else {
-      colFamSet = new HashSet<ByteSequence>();
+      colFamSet = new HashSet<>();
       colFamSet.addAll(columnFamilies);
     }
 
     if (inclusive) {
-      sortedColFams = new TreeSet<ByteSequence>(colFamSet);
+      sortedColFams = new TreeSet<>(colFamSet);
     } else {
       sortedColFams = null;
     }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/system/ColumnQualifierFilter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/system/ColumnQualifierFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/system/ColumnQualifierFilter.java
index aa6426d..866f04f 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/system/ColumnQualifierFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/system/ColumnQualifierFilter.java
@@ -66,8 +66,8 @@ public class ColumnQualifierFilter extends Filter {
   }
 
   public void init(Set<Column> columns) {
-    this.columnFamilies = new HashSet<ByteSequence>();
-    this.columnsQualifiers = new HashMap<ByteSequence,HashSet<ByteSequence>>();
+    this.columnFamilies = new HashSet<>();
+    this.columnsQualifiers = new HashMap<>();
 
     for (Iterator<Column> iter = columns.iterator(); iter.hasNext();) {
       Column col = iter.next();
@@ -75,7 +75,7 @@ public class ColumnQualifierFilter extends Filter {
         ArrayByteSequence cq = new ArrayByteSequence(col.columnQualifier);
         HashSet<ByteSequence> cfset = this.columnsQualifiers.get(cq);
         if (cfset == null) {
-          cfset = new HashSet<ByteSequence>();
+          cfset = new HashSet<>();
           this.columnsQualifiers.put(cq, cfset);
         }
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/system/HeapIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/system/HeapIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/system/HeapIterator.java
index 8f2f66c..6ed2d3e 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/system/HeapIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/system/HeapIterator.java
@@ -53,7 +53,7 @@ public abstract class HeapIterator implements SortedKeyValueIterator<Key,Value>
     if (heap != null)
       throw new IllegalStateException("heap already exist");
 
-    heap = new PriorityQueue<SortedKeyValueIterator<Key,Value>>(maxSize == 0 ? 1 : maxSize, new SKVIComparator());
+    heap = new PriorityQueue<>(maxSize == 0 ? 1 : maxSize, new SKVIComparator());
   }
 
   @Override

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/system/LocalityGroupIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/system/LocalityGroupIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/system/LocalityGroupIterator.java
index b2fae6d..ac8355b 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/system/LocalityGroupIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/system/LocalityGroupIterator.java
@@ -91,7 +91,7 @@ public class LocalityGroupIterator extends HeapIterator implements Interruptible
       if (columnFamilies instanceof Set<?>) {
         cfSet = (Set<ByteSequence>) columnFamilies;
       } else {
-        cfSet = new HashSet<ByteSequence>();
+        cfSet = new HashSet<>();
         cfSet.addAll(columnFamilies);
       }
     else

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/system/MultiIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/system/MultiIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/system/MultiIterator.java
index aef6aeb..7ff07e6 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/system/MultiIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/system/MultiIterator.java
@@ -50,7 +50,7 @@ public class MultiIterator extends HeapIterator {
 
   private MultiIterator(MultiIterator other, IteratorEnvironment env) {
     super(other.iters.size());
-    this.iters = new ArrayList<SortedKeyValueIterator<Key,Value>>();
+    this.iters = new ArrayList<>();
     this.fence = other.fence;
     for (SortedKeyValueIterator<Key,Value> iter : other.iters) {
       iters.add(iter.deepCopy(env));

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/system/SourceSwitchingIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/system/SourceSwitchingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/system/SourceSwitchingIterator.java
index 1f06a71..098aa63 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/system/SourceSwitchingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/system/SourceSwitchingIterator.java
@@ -36,7 +36,7 @@ import org.apache.accumulo.core.iterators.SortedKeyValueIterator;
  * (InMemoryMap that was minor compacted to a file). Clients reading from a table that has data in memory should not see interruption in their scan when that
  * data is minor compacted. This iterator is designed to manage this behind the scene.
  */
-public class SourceSwitchingIterator implements SortedKeyValueIterator<Key,Value>, InterruptibleIterator {
+public class SourceSwitchingIterator implements InterruptibleIterator {
 
   public interface DataSource {
     boolean isCurrent();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/system/SynchronizedIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/system/SynchronizedIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/system/SynchronizedIterator.java
index a095106..43da54d 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/system/SynchronizedIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/system/SynchronizedIterator.java
@@ -68,7 +68,7 @@ public class SynchronizedIterator<K extends WritableComparable<?>,V extends Writ
 
   @Override
   public synchronized SortedKeyValueIterator<K,V> deepCopy(IteratorEnvironment env) {
-    return new SynchronizedIterator<K,V>(source.deepCopy(env));
+    return new SynchronizedIterator<>(source.deepCopy(env));
   }
 
   public SynchronizedIterator() {}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/user/BigDecimalCombiner.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/BigDecimalCombiner.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/BigDecimalCombiner.java
index d9e6cdd..77f33d9 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/BigDecimalCombiner.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/BigDecimalCombiner.java
@@ -101,8 +101,7 @@ public abstract class BigDecimalCombiner extends TypedValueCombiner<BigDecimal>
    * Provides the ability to encode scientific notation.
    *
    */
-  public static class BigDecimalEncoder extends AbstractLexicoder<BigDecimal> implements
-      org.apache.accumulo.core.iterators.TypedValueCombiner.Encoder<BigDecimal> {
+  public static class BigDecimalEncoder extends AbstractLexicoder<BigDecimal> {
     @Override
     public byte[] encode(BigDecimal v) {
       return v.toString().getBytes(UTF_8);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceFilter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceFilter.java
index a323028..d4630b0 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceFilter.java
@@ -16,17 +16,16 @@
  */
 package org.apache.accumulo.core.iterators.user;
 
+import java.io.IOException;
+import java.util.Map;
+
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.PartialKey;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.iterators.Filter;
 import org.apache.accumulo.core.iterators.IteratorEnvironment;
-import org.apache.accumulo.core.iterators.OptionDescriber;
 import org.apache.accumulo.core.iterators.SortedKeyValueIterator;
 
-import java.io.IOException;
-import java.util.Map;
-
 /**
  * Filters key/value pairs for a range of column families and a range of column qualifiers. Only keys which fall in both ranges will be passed by the filter.
  * Note that if you have a small, well-defined set of column families it will be much more efficient to configure locality groups to isolate that data instead
@@ -34,7 +33,7 @@ import java.util.Map;
  *
  * @see org.apache.accumulo.core.iterators.user.CfCqSliceOpts for a description of this iterator's options.
  */
-public class CfCqSliceFilter extends Filter implements OptionDescriber {
+public class CfCqSliceFilter extends Filter {
 
   private CfCqSliceOpts cso;
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceOpts.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceOpts.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceOpts.java
index c70e4bd..53cbfb0 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceOpts.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/CfCqSliceOpts.java
@@ -95,7 +95,7 @@ public class CfCqSliceOpts {
   static class Describer implements OptionDescriber {
     @Override
     public OptionDescriber.IteratorOptions describeOptions() {
-      Map<String,String> options = new HashMap<String,String>();
+      Map<String,String> options = new HashMap<>();
       options.put(OPT_MIN_CF, OPT_MIN_CF_DESC);
       options.put(OPT_MIN_CQ, OPT_MIN_CQ_DESC);
       options.put(OPT_MAX_CF, OPT_MAX_CF_DESC);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/user/LargeRowFilter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/LargeRowFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/LargeRowFilter.java
index 59a5dec..9fd40b6 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/LargeRowFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/LargeRowFilter.java
@@ -56,8 +56,8 @@ public class LargeRowFilter implements SortedKeyValueIterator<Key,Value>, Option
   private SortedKeyValueIterator<Key,Value> source;
 
   // a cache of keys
-  private ArrayList<Key> keys = new ArrayList<Key>();
-  private ArrayList<Value> values = new ArrayList<Value>();
+  private ArrayList<Key> keys = new ArrayList<>();
+  private ArrayList<Value> values = new ArrayList<>();
 
   private int currentPosition;
 
@@ -195,11 +195,11 @@ public class LargeRowFilter implements SortedKeyValueIterator<Key,Value>, Option
   public void seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive) throws IOException {
 
     if (inclusive && !columnFamilies.contains(EMPTY)) {
-      columnFamilies = new HashSet<ByteSequence>(columnFamilies);
+      columnFamilies = new HashSet<>(columnFamilies);
       columnFamilies.add(EMPTY);
       dropEmptyColFams = true;
     } else if (!inclusive && columnFamilies.contains(EMPTY)) {
-      columnFamilies = new HashSet<ByteSequence>(columnFamilies);
+      columnFamilies = new HashSet<>(columnFamilies);
       columnFamilies.remove(EMPTY);
       dropEmptyColFams = true;
     } else {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/user/RowDeletingIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/RowDeletingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/RowDeletingIterator.java
index 60870d8..3f704db 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/RowDeletingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/RowDeletingIterator.java
@@ -144,11 +144,11 @@ public class RowDeletingIterator implements SortedKeyValueIterator<Key,Value> {
   public void seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive) throws IOException {
 
     if (inclusive && !columnFamilies.contains(EMPTY)) {
-      columnFamilies = new HashSet<ByteSequence>(columnFamilies);
+      columnFamilies = new HashSet<>(columnFamilies);
       columnFamilies.add(EMPTY);
       dropEmptyColFams = true;
     } else if (!inclusive && columnFamilies.contains(EMPTY)) {
-      columnFamilies = new HashSet<ByteSequence>(columnFamilies);
+      columnFamilies = new HashSet<>(columnFamilies);
       columnFamilies.remove(EMPTY);
       dropEmptyColFams = true;
     } else {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/user/RowEncodingIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/RowEncodingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/RowEncodingIterator.java
index 320301d..e0fd64e 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/RowEncodingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/RowEncodingIterator.java
@@ -91,8 +91,8 @@ public abstract class RowEncodingIterator implements SortedKeyValueIterator<Key,
     return newInstance;
   }
 
-  List<Key> keys = new ArrayList<Key>();
-  List<Value> values = new ArrayList<Value>();
+  List<Key> keys = new ArrayList<>();
+  List<Value> values = new ArrayList<>();
 
   private void prepKeys() throws IOException {
     long kvBufSize = 0;
@@ -163,7 +163,7 @@ public abstract class RowEncodingIterator implements SortedKeyValueIterator<Key,
   public IteratorOptions describeOptions() {
     String desc = "This iterator encapsulates an entire row of Key/Value pairs into a single Key/Value pair.";
     String bufferDesc = "Maximum buffer size (in accumulo memory spec) to use for buffering keys before throwing a BufferOverflowException.";
-    HashMap<String,String> namedOptions = new HashMap<String,String>();
+    HashMap<String,String> namedOptions = new HashMap<>();
     namedOptions.put(MAX_BUFFER_SIZE_OPT, bufferDesc);
     return new IteratorOptions(getClass().getSimpleName(), desc, namedOptions, null);
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/user/SummingArrayCombiner.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/SummingArrayCombiner.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/SummingArrayCombiner.java
index 260fa36..2e59b2c 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/SummingArrayCombiner.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/SummingArrayCombiner.java
@@ -69,7 +69,7 @@ public class SummingArrayCombiner extends TypedValueCombiner<List<Long>> {
 
   @Override
   public List<Long> typedReduce(Key key, Iterator<List<Long>> iter) {
-    List<Long> sum = new ArrayList<Long>();
+    List<Long> sum = new ArrayList<>();
     while (iter.hasNext()) {
       sum = arrayAdd(sum, iter.next());
     }
@@ -142,7 +142,7 @@ public class SummingArrayCombiner extends TypedValueCombiner<List<Long>> {
     return true;
   }
 
-  public abstract static class DOSArrayEncoder<V> extends AbstractLexicoder<List<V>> implements Encoder<List<V>> {
+  public abstract static class DOSArrayEncoder<V> extends AbstractLexicoder<List<V>> {
     public abstract void write(DataOutputStream dos, V v) throws IOException;
 
     public abstract V read(DataInputStream dis) throws IOException;
@@ -173,7 +173,7 @@ public class SummingArrayCombiner extends TypedValueCombiner<List<Long>> {
       DataInputStream dis = new DataInputStream(new ByteArrayInputStream(b, offset, origLen));
       try {
         int len = WritableUtils.readVInt(dis);
-        List<V> vl = new ArrayList<V>(len);
+        List<V> vl = new ArrayList<>(len);
         for (int i = 0; i < len; i++) {
           vl.add(read(dis));
         }
@@ -208,7 +208,7 @@ public class SummingArrayCombiner extends TypedValueCombiner<List<Long>> {
     }
   }
 
-  public static class StringArrayEncoder extends AbstractEncoder<List<Long>> implements Encoder<List<Long>> {
+  public static class StringArrayEncoder extends AbstractEncoder<List<Long>> {
     @Override
     public byte[] encode(List<Long> la) {
       if (la.size() == 0)
@@ -230,7 +230,7 @@ public class SummingArrayCombiner extends TypedValueCombiner<List<Long>> {
     @Override
     protected List<Long> decodeUnchecked(byte[] b, int offset, int len) {
       String[] longstrs = new String(b, offset, len, UTF_8).split(",");
-      List<Long> la = new ArrayList<Long>(longstrs.length);
+      List<Long> la = new ArrayList<>(longstrs.length);
       for (String s : longstrs) {
         if (s.length() == 0)
           la.add(0l);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/user/TransformingIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/TransformingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/TransformingIterator.java
index 66de3d6..1c99f7a 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/TransformingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/TransformingIterator.java
@@ -86,7 +86,7 @@ abstract public class TransformingIterator extends WrappingIterator implements O
 
   protected Logger log = LoggerFactory.getLogger(getClass());
 
-  protected ArrayList<Pair<Key,Value>> keys = new ArrayList<Pair<Key,Value>>();
+  protected ArrayList<Pair<Key,Value>> keys = new ArrayList<>();
   protected int keyPos = -1;
   protected boolean scanning;
   protected Range seekRange;
@@ -136,7 +136,7 @@ abstract public class TransformingIterator extends WrappingIterator implements O
     String bufferDesc = "Maximum buffer size (in accumulo memory spec) to use for buffering keys before throwing a BufferOverflowException.  "
         + "Users should keep this limit in mind when deciding what to transform.  That is, if transforming the column family for example, then all "
         + "keys sharing the same row and column family must fit within this limit (along with their associated values)";
-    HashMap<String,String> namedOptions = new HashMap<String,String>();
+    HashMap<String,String> namedOptions = new HashMap<>();
     namedOptions.put(AUTH_OPT, authDesc);
     namedOptions.put(MAX_BUFFER_SIZE_OPT, bufferDesc);
     return new IteratorOptions(getClass().getSimpleName(), desc, namedOptions, null);
@@ -176,7 +176,7 @@ abstract public class TransformingIterator extends WrappingIterator implements O
     copy.keyPos = keyPos;
     copy.keys.addAll(keys);
     copy.seekRange = (seekRange == null) ? null : new Range(seekRange);
-    copy.seekColumnFamilies = (seekColumnFamilies == null) ? null : new HashSet<ByteSequence>(seekColumnFamilies);
+    copy.seekColumnFamilies = (seekColumnFamilies == null) ? null : new HashSet<>(seekColumnFamilies);
     copy.seekColumnFamiliesInclusive = seekColumnFamiliesInclusive;
 
     copy.ve = ve;
@@ -334,7 +334,7 @@ abstract public class TransformingIterator extends WrappingIterator implements O
 
           if (getSource().hasTop() && key == getSource().getTopKey())
             key = new Key(key);
-          keys.add(new Pair<Key,Value>(key, new Value(val)));
+          keys.add(new Pair<>(key, new Value(val)));
           appened += (key.getSize() + val.getSize() + 128);
         }
       }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/user/VisibilityFilter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/VisibilityFilter.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/VisibilityFilter.java
index 6e55aec..f7007a1 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/VisibilityFilter.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/VisibilityFilter.java
@@ -25,7 +25,6 @@ import org.apache.accumulo.core.client.IteratorSetting;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.iterators.IteratorEnvironment;
-import org.apache.accumulo.core.iterators.OptionDescriber;
 import org.apache.accumulo.core.iterators.SortedKeyValueIterator;
 import org.apache.accumulo.core.security.Authorizations;
 import org.apache.accumulo.core.security.ColumnVisibility;
@@ -37,7 +36,7 @@ import org.apache.hadoop.io.Text;
 /**
  *
  */
-public class VisibilityFilter extends org.apache.accumulo.core.iterators.system.VisibilityFilter implements OptionDescriber {
+public class VisibilityFilter extends org.apache.accumulo.core.iterators.system.VisibilityFilter {
 
   private static final String AUTHS = "auths";
   private static final String FILTER_INVALID_ONLY = "filterInvalid";

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeColumnFamilyIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeColumnFamilyIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeColumnFamilyIterator.java
index 982d0df..0a3f3e5 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeColumnFamilyIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeColumnFamilyIterator.java
@@ -73,7 +73,7 @@ public class WholeColumnFamilyIterator implements SortedKeyValueIterator<Key,Val
    *           Signals that an I/O exception has occurred.
    */
   public static final SortedMap<Key,Value> decodeColumnFamily(Key rowKey, Value rowValue) throws IOException {
-    SortedMap<Key,Value> map = new TreeMap<Key,Value>();
+    SortedMap<Key,Value> map = new TreeMap<>();
     ByteArrayInputStream in = new ByteArrayInputStream(rowValue.get());
     DataInputStream din = new DataInputStream(in);
     int numKeys = din.readInt();
@@ -148,8 +148,8 @@ public class WholeColumnFamilyIterator implements SortedKeyValueIterator<Key,Val
     return new Value(out.toByteArray());
   }
 
-  List<Key> keys = new ArrayList<Key>();
-  List<Value> values = new ArrayList<Value>();
+  List<Key> keys = new ArrayList<>();
+  List<Value> values = new ArrayList<>();
 
   private void prepKeys() throws IOException {
     if (topKey != null)

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeRowIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeRowIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeRowIterator.java
index 665cbfe..17bf315 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeRowIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/user/WholeRowIterator.java
@@ -84,7 +84,7 @@ public class WholeRowIterator extends RowEncodingIterator {
 
   // decode a bunch of key value pairs that have been encoded into a single value
   public static final SortedMap<Key,Value> decodeRow(Key rowKey, Value rowValue) throws IOException {
-    SortedMap<Key,Value> map = new TreeMap<Key,Value>();
+    SortedMap<Key,Value> map = new TreeMap<>();
     ByteArrayInputStream in = new ByteArrayInputStream(rowValue.get());
     DataInputStream din = new DataInputStream(in);
     int numKeys = din.readInt();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/metadata/MetadataLocationObtainer.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/MetadataLocationObtainer.java b/core/src/main/java/org/apache/accumulo/core/metadata/MetadataLocationObtainer.java
index d6af8ba..6336d12 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/MetadataLocationObtainer.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/MetadataLocationObtainer.java
@@ -68,10 +68,10 @@ public class MetadataLocationObtainer implements TabletLocationObtainer {
 
   public MetadataLocationObtainer() {
 
-    locCols = new TreeSet<Column>();
+    locCols = new TreeSet<>();
     locCols.add(new Column(TextUtil.getBytes(TabletsSection.CurrentLocationColumnFamily.NAME), null, null));
     locCols.add(TabletsSection.TabletColumnFamily.PREV_ROW_COLUMN.toColumn());
-    columns = new ArrayList<Column>(locCols);
+    columns = new ArrayList<>(locCols);
   }
 
   @Override
@@ -90,12 +90,12 @@ public class MetadataLocationObtainer implements TabletLocationObtainer {
 
       Range range = new Range(row, true, stopRow, true);
 
-      TreeMap<Key,Value> encodedResults = new TreeMap<Key,Value>();
-      TreeMap<Key,Value> results = new TreeMap<Key,Value>();
+      TreeMap<Key,Value> encodedResults = new TreeMap<>();
+      TreeMap<Key,Value> results = new TreeMap<>();
 
       // Use the whole row iterator so that a partial mutations is not read. The code that extracts locations for tablets does a sanity check to ensure there is
       // only one location. Reading a partial mutation could make it appear there are multiple locations when there are not.
-      List<IterInfo> serverSideIteratorList = new ArrayList<IterInfo>();
+      List<IterInfo> serverSideIteratorList = new ArrayList<>();
       serverSideIteratorList.add(new IterInfo(10000, WholeRowIterator.class.getName(), "WRI"));
       Map<String,Map<String,String>> serverSideIteratorOptions = Collections.emptyMap();
       boolean more = ThriftScanner.getBatchFromServer(context, range, src.tablet_extent, src.tablet_location, encodedResults, locCols, serverSideIteratorList,
@@ -162,7 +162,7 @@ public class MetadataLocationObtainer implements TabletLocationObtainer {
   public List<TabletLocation> lookupTablets(ClientContext context, String tserver, Map<KeyExtent,List<Range>> tabletsRanges, TabletLocator parent)
       throws AccumuloSecurityException, AccumuloException {
 
-    final TreeMap<Key,Value> results = new TreeMap<Key,Value>();
+    final TreeMap<Key,Value> results = new TreeMap<>();
 
     ResultReceiver rr = new ResultReceiver() {
 
@@ -183,8 +183,8 @@ public class MetadataLocationObtainer implements TabletLocationObtainer {
       opts = unsetOpts.setColumns(locCols);
     }
 
-    Map<KeyExtent,List<Range>> unscanned = new HashMap<KeyExtent,List<Range>>();
-    Map<KeyExtent,List<Range>> failures = new HashMap<KeyExtent,List<Range>>();
+    Map<KeyExtent,List<Range>> unscanned = new HashMap<>();
+    Map<KeyExtent,List<Range>> failures = new HashMap<>();
     try {
       TabletServerBatchReaderIterator.doLookup(context, tserver, tabletsRanges, failures, unscanned, rr, columns, opts, Authorizations.EMPTY);
       if (failures.size() > 0) {
@@ -212,8 +212,8 @@ public class MetadataLocationObtainer implements TabletLocationObtainer {
     Value prevRow = null;
     KeyExtent ke;
 
-    List<TabletLocation> results = new ArrayList<TabletLocation>();
-    ArrayList<KeyExtent> locationless = new ArrayList<KeyExtent>();
+    List<TabletLocation> results = new ArrayList<>();
+    ArrayList<KeyExtent> locationless = new ArrayList<>();
 
     Text lastRowFromKey = new Text();
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/rpc/ThriftUtil.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/ThriftUtil.java b/core/src/main/java/org/apache/accumulo/core/rpc/ThriftUtil.java
index be4238e..49e4349 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/ThriftUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/ThriftUtil.java
@@ -59,7 +59,7 @@ public class ThriftUtil {
 
   private static final TraceProtocolFactory protocolFactory = new TraceProtocolFactory();
   private static final TFramedTransport.Factory transportFactory = new TFramedTransport.Factory(Integer.MAX_VALUE);
-  private static final Map<Integer,TTransportFactory> factoryCache = new HashMap<Integer,TTransportFactory>();
+  private static final Map<Integer,TTransportFactory> factoryCache = new HashMap<>();
 
   public static final String GSSAPI = "GSSAPI", DIGEST_MD5 = "DIGEST-MD5";
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/sample/impl/SamplerConfigurationImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/sample/impl/SamplerConfigurationImpl.java b/core/src/main/java/org/apache/accumulo/core/sample/impl/SamplerConfigurationImpl.java
index 8abf4e7..d3e2fe7 100644
--- a/core/src/main/java/org/apache/accumulo/core/sample/impl/SamplerConfigurationImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/sample/impl/SamplerConfigurationImpl.java
@@ -109,7 +109,7 @@ public class SamplerConfigurationImpl implements Writable {
 
     className = in.readUTF();
 
-    options = new HashMap<String,String>();
+    options = new HashMap<>();
 
     int num = in.readInt();
 
@@ -130,11 +130,11 @@ public class SamplerConfigurationImpl implements Writable {
     ArrayList<Pair<String,String>> props = new ArrayList<>();
 
     for (Entry<String,String> entry : options.entrySet()) {
-      props.add(new Pair<String,String>(Property.TABLE_SAMPLER_OPTS.getKey() + entry.getKey(), entry.getValue()));
+      props.add(new Pair<>(Property.TABLE_SAMPLER_OPTS.getKey() + entry.getKey(), entry.getValue()));
     }
 
     // intentionally added last, so its set last
-    props.add(new Pair<String,String>(Property.TABLE_SAMPLER.getKey(), className));
+    props.add(new Pair<>(Property.TABLE_SAMPLER.getKey(), className));
 
     return props;
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/security/Authorizations.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/Authorizations.java b/core/src/main/java/org/apache/accumulo/core/security/Authorizations.java
index 001fed2..c725d9b 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/Authorizations.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/Authorizations.java
@@ -42,8 +42,8 @@ public class Authorizations implements Iterable<byte[]>, Serializable, Authoriza
 
   private static final long serialVersionUID = 1L;
 
-  private Set<ByteSequence> auths = new HashSet<ByteSequence>();
-  private List<byte[]> authsList = new ArrayList<byte[]>(); // sorted order
+  private Set<ByteSequence> auths = new HashSet<>();
+  private List<byte[]> authsList = new ArrayList<>(); // sorted order
 
   /**
    * An empty set of authorizations.
@@ -88,7 +88,7 @@ public class Authorizations implements Iterable<byte[]>, Serializable, Authoriza
   }
 
   private void checkAuths() {
-    Set<ByteSequence> sortedAuths = new TreeSet<ByteSequence>(auths);
+    Set<ByteSequence> sortedAuths = new TreeSet<>(auths);
 
     for (ByteSequence bs : sortedAuths) {
       if (bs.length() == 0) {
@@ -212,7 +212,7 @@ public class Authorizations implements Iterable<byte[]>, Serializable, Authoriza
    * @see #Authorizations(Collection)
    */
   public List<byte[]> getAuthorizations() {
-    ArrayList<byte[]> copy = new ArrayList<byte[]>(authsList.size());
+    ArrayList<byte[]> copy = new ArrayList<>(authsList.size());
     for (byte[] auth : authsList) {
       byte[] bytes = new byte[auth.length];
       System.arraycopy(auth, 0, bytes, 0, auth.length);
@@ -227,7 +227,7 @@ public class Authorizations implements Iterable<byte[]>, Serializable, Authoriza
    * @return authorizations, each as a string encoded in UTF-8 and within a buffer
    */
   public List<ByteBuffer> getAuthorizationsBB() {
-    ArrayList<ByteBuffer> copy = new ArrayList<ByteBuffer>(authsList.size());
+    ArrayList<ByteBuffer> copy = new ArrayList<>(authsList.size());
     for (byte[] auth : authsList) {
       byte[] bytes = new byte[auth.length];
       System.arraycopy(auth, 0, bytes, 0, auth.length);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/security/ColumnVisibility.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/ColumnVisibility.java b/core/src/main/java/org/apache/accumulo/core/security/ColumnVisibility.java
index 4e0d597..c51e688 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/ColumnVisibility.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/ColumnVisibility.java
@@ -123,7 +123,7 @@ public class ColumnVisibility {
 
     public void add(Node child) {
       if (children == EMPTY)
-        children = new ArrayList<Node>();
+        children = new ArrayList<>();
 
       children.add(child);
     }
@@ -220,7 +220,7 @@ public class ColumnVisibility {
   // @formatter:on
   public static Node normalize(Node root, byte[] expression, NodeComparator comparator) {
     if (root.type != NodeType.TERM) {
-      TreeSet<Node> rolledUp = new TreeSet<Node>(comparator);
+      TreeSet<Node> rolledUp = new TreeSet<>(comparator);
       java.util.Iterator<Node> itr = root.children.iterator();
       while (itr.hasNext()) {
         Node c = normalize(itr.next(), expression, comparator);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/security/NamespacePermission.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/NamespacePermission.java b/core/src/main/java/org/apache/accumulo/core/security/NamespacePermission.java
index 638f630..55a7b75 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/NamespacePermission.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/NamespacePermission.java
@@ -63,7 +63,7 @@ public enum NamespacePermission {
   public static List<String> printableValues() {
     NamespacePermission[] a = NamespacePermission.values();
 
-    List<String> list = new ArrayList<String>(a.length);
+    List<String> list = new ArrayList<>(a.length);
 
     for (NamespacePermission p : a)
       list.add("Namespace." + p);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/security/SystemPermission.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/SystemPermission.java b/core/src/main/java/org/apache/accumulo/core/security/SystemPermission.java
index a1df5dc..cf70ec2 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/SystemPermission.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/SystemPermission.java
@@ -44,7 +44,7 @@ public enum SystemPermission {
 
   private static HashMap<Byte,SystemPermission> mapping;
   static {
-    mapping = new HashMap<Byte,SystemPermission>(SystemPermission.values().length);
+    mapping = new HashMap<>(SystemPermission.values().length);
     for (SystemPermission perm : SystemPermission.values())
       mapping.put(perm.permID, perm);
   }
@@ -70,7 +70,7 @@ public enum SystemPermission {
   public static List<String> printableValues() {
     SystemPermission[] a = SystemPermission.values();
 
-    List<String> list = new ArrayList<String>(a.length);
+    List<String> list = new ArrayList<>(a.length);
 
     for (SystemPermission p : a)
       list.add("System." + p);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/security/TablePermission.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/TablePermission.java b/core/src/main/java/org/apache/accumulo/core/security/TablePermission.java
index b6d122f..a80be9a 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/TablePermission.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/TablePermission.java
@@ -64,7 +64,7 @@ public enum TablePermission {
   public static List<String> printableValues() {
     TablePermission[] a = TablePermission.values();
 
-    List<String> list = new ArrayList<String>(a.length);
+    List<String> list = new ArrayList<>(a.length);
 
     for (TablePermission p : a)
       list.add("Table." + p);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/security/VisibilityEvaluator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/VisibilityEvaluator.java b/core/src/main/java/org/apache/accumulo/core/security/VisibilityEvaluator.java
index 03b336b..efd7ea3 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/VisibilityEvaluator.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/VisibilityEvaluator.java
@@ -93,7 +93,7 @@ public class VisibilityEvaluator {
    * @see #escape(byte[], boolean)
    */
   static Authorizations escape(Authorizations auths) {
-    ArrayList<byte[]> retAuths = new ArrayList<byte[]>(auths.getAuthorizations().size());
+    ArrayList<byte[]> retAuths = new ArrayList<>(auths.getAuthorizations().size());
 
     for (byte[] auth : auths.getAuthorizations())
       retAuths.add(escape(auth, false));

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/security/crypto/CachingHDFSSecretKeyEncryptionStrategy.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/crypto/CachingHDFSSecretKeyEncryptionStrategy.java b/core/src/main/java/org/apache/accumulo/core/security/crypto/CachingHDFSSecretKeyEncryptionStrategy.java
index 4ee27ef..7b79d99 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/crypto/CachingHDFSSecretKeyEncryptionStrategy.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/crypto/CachingHDFSSecretKeyEncryptionStrategy.java
@@ -112,7 +112,7 @@ public class CachingHDFSSecretKeyEncryptionStrategy implements SecretKeyEncrypti
     private byte[] keyEncryptionKey;
     private String pathToKeyName;
 
-    public SecretKeyCache() {};
+    public SecretKeyCache() {}
 
     public synchronized void ensureSecretKeyCacheInitialized(CryptoModuleParameters context) throws IOException {
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModuleFactory.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModuleFactory.java b/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModuleFactory.java
index e8e2326..79db306 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModuleFactory.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/crypto/CryptoModuleFactory.java
@@ -34,8 +34,8 @@ import org.slf4j.LoggerFactory;
 public class CryptoModuleFactory {
 
   private static final Logger log = LoggerFactory.getLogger(CryptoModuleFactory.class);
-  private static final Map<String,CryptoModule> cryptoModulesCache = new HashMap<String,CryptoModule>();
-  private static final Map<String,SecretKeyEncryptionStrategy> secretKeyEncryptionStrategyCache = new HashMap<String,SecretKeyEncryptionStrategy>();
+  private static final Map<String,CryptoModule> cryptoModulesCache = new HashMap<>();
+  private static final Map<String,SecretKeyEncryptionStrategy> secretKeyEncryptionStrategyCache = new HashMap<>();
 
   /**
    * This method returns a crypto module based on settings in the given configuration parameter.

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/security/crypto/DefaultCryptoModule.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/crypto/DefaultCryptoModule.java b/core/src/main/java/org/apache/accumulo/core/security/crypto/DefaultCryptoModule.java
index b7e089f..13104b2 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/crypto/DefaultCryptoModule.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/crypto/DefaultCryptoModule.java
@@ -300,7 +300,7 @@ public class DefaultCryptoModule implements CryptoModule {
       String marker = dataIn.readUTF();
       if (marker.equals(ENCRYPTION_HEADER_MARKER_V1) || marker.equals(ENCRYPTION_HEADER_MARKER_V2)) {
 
-        Map<String,String> paramsFromFile = new HashMap<String,String>();
+        Map<String,String> paramsFromFile = new HashMap<>();
 
         // Read in the bulk of parameters
         int paramsCount = dataIn.readInt();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/trace/DistributedTrace.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/trace/DistributedTrace.java b/core/src/main/java/org/apache/accumulo/core/trace/DistributedTrace.java
index 14886f1..f833b11 100644
--- a/core/src/main/java/org/apache/accumulo/core/trace/DistributedTrace.java
+++ b/core/src/main/java/org/apache/accumulo/core/trace/DistributedTrace.java
@@ -52,7 +52,7 @@ public class DistributedTrace {
   public static final String TRACER_ZK_TIMEOUT = "tracer.zookeeper.timeout";
   public static final String TRACER_ZK_PATH = "tracer.zookeeper.path";
 
-  private static final HashSet<SpanReceiver> receivers = new HashSet<SpanReceiver>();
+  private static final HashSet<SpanReceiver> receivers = new HashSet<>();
 
   /**
    * @deprecated since 1.7, use {@link DistributedTrace#enable(String, String, org.apache.accumulo.core.client.ClientConfiguration)} instead

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/trace/wrappers/TraceWrap.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/trace/wrappers/TraceWrap.java b/core/src/main/java/org/apache/accumulo/core/trace/wrappers/TraceWrap.java
index bbfa386..8f83bd2 100644
--- a/core/src/main/java/org/apache/accumulo/core/trace/wrappers/TraceWrap.java
+++ b/core/src/main/java/org/apache/accumulo/core/trace/wrappers/TraceWrap.java
@@ -39,12 +39,12 @@ import java.lang.reflect.Proxy;
 public class TraceWrap {
 
   public static <T> T service(final T instance) {
-    InvocationHandler handler = new RpcServerInvocationHandler<T>(instance);
+    InvocationHandler handler = new RpcServerInvocationHandler<>(instance);
     return wrappedInstance(handler, instance);
   }
 
   public static <T> T client(final T instance) {
-    InvocationHandler handler = new RpcClientInvocationHandler<T>(instance);
+    InvocationHandler handler = new RpcClientInvocationHandler<>(instance);
     return wrappedInstance(handler, instance);
   }
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/util/ByteArraySet.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/ByteArraySet.java b/core/src/main/java/org/apache/accumulo/core/util/ByteArraySet.java
index bf177fd..337fe9c 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/ByteArraySet.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/ByteArraySet.java
@@ -38,7 +38,7 @@ public class ByteArraySet extends TreeSet<byte[]> {
   }
 
   public static ByteArraySet fromStrings(Collection<String> c) {
-    List<byte[]> lst = new ArrayList<byte[]>();
+    List<byte[]> lst = new ArrayList<>();
     for (String s : c)
       lst.add(s.getBytes(UTF_8));
     return new ByteArraySet(lst);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/util/ByteBufferUtil.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/ByteBufferUtil.java b/core/src/main/java/org/apache/accumulo/core/util/ByteBufferUtil.java
index de889a4..27188fe 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/ByteBufferUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/ByteBufferUtil.java
@@ -48,7 +48,7 @@ public class ByteBufferUtil {
   public static List<ByteBuffer> toByteBuffers(Collection<byte[]> bytesList) {
     if (bytesList == null)
       return null;
-    ArrayList<ByteBuffer> result = new ArrayList<ByteBuffer>();
+    ArrayList<ByteBuffer> result = new ArrayList<>();
     for (byte[] bytes : bytesList) {
       result.add(ByteBuffer.wrap(bytes));
     }
@@ -58,7 +58,7 @@ public class ByteBufferUtil {
   public static List<byte[]> toBytesList(Collection<ByteBuffer> bytesList) {
     if (bytesList == null)
       return null;
-    ArrayList<byte[]> result = new ArrayList<byte[]>(bytesList.size());
+    ArrayList<byte[]> result = new ArrayList<>(bytesList.size());
     for (ByteBuffer bytes : bytesList) {
       result.add(toBytes(bytes));
     }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/util/LocalityGroupUtil.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/LocalityGroupUtil.java b/core/src/main/java/org/apache/accumulo/core/util/LocalityGroupUtil.java
index a5255c7..2063855 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/LocalityGroupUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/LocalityGroupUtil.java
@@ -51,7 +51,7 @@ public class LocalityGroupUtil {
   public static Set<ByteSequence> families(Collection<Column> columns) {
     if (columns.size() == 0)
       return EMPTY_CF_SET;
-    Set<ByteSequence> result = new HashSet<ByteSequence>(columns.size());
+    Set<ByteSequence> result = new HashSet<>(columns.size());
     for (Column col : columns) {
       result.add(new ArrayByteSequence(col.getColumnFamily()));
     }
@@ -66,13 +66,13 @@ public class LocalityGroupUtil {
   }
 
   public static Map<String,Set<ByteSequence>> getLocalityGroups(AccumuloConfiguration acuconf) throws LocalityGroupConfigurationError {
-    Map<String,Set<ByteSequence>> result = new HashMap<String,Set<ByteSequence>>();
+    Map<String,Set<ByteSequence>> result = new HashMap<>();
     String[] groups = acuconf.get(Property.TABLE_LOCALITY_GROUPS).split(",");
     for (String group : groups) {
       if (group.length() > 0)
         result.put(group, new HashSet<ByteSequence>());
     }
-    HashSet<ByteSequence> all = new HashSet<ByteSequence>();
+    HashSet<ByteSequence> all = new HashSet<>();
     for (Entry<String,String> entry : acuconf) {
       String property = entry.getKey();
       String value = entry.getValue();
@@ -101,7 +101,7 @@ public class LocalityGroupUtil {
   }
 
   public static Set<ByteSequence> decodeColumnFamilies(String colFams) throws LocalityGroupConfigurationError {
-    HashSet<ByteSequence> colFamsSet = new HashSet<ByteSequence>();
+    HashSet<ByteSequence> colFamsSet = new HashSet<>();
 
     for (String family : colFams.split(",")) {
       ByteSequence cfbs = decodeColumnFamily(family);
@@ -152,7 +152,7 @@ public class LocalityGroupUtil {
   }
 
   public static String encodeColumnFamilies(Set<Text> colFams) {
-    SortedSet<String> ecfs = new TreeSet<String>();
+    SortedSet<String> ecfs = new TreeSet<>();
 
     StringBuilder sb = new StringBuilder();
 
@@ -235,7 +235,7 @@ public class LocalityGroupUtil {
 
     public Partitioner(PreAllocatedArray<Map<ByteSequence,MutableLong>> groups) {
       this.groups = groups;
-      this.colfamToLgidMap = new HashMap<ByteSequence,Integer>();
+      this.colfamToLgidMap = new HashMap<>();
 
       for (int i = 0; i < groups.length; i++) {
         for (ByteSequence cf : groups.get(i).keySet()) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/util/MapCounter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/MapCounter.java b/core/src/main/java/org/apache/accumulo/core/util/MapCounter.java
index 4372cfc..9c504e9 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/MapCounter.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/MapCounter.java
@@ -30,7 +30,7 @@ public class MapCounter<KT> {
   private HashMap<KT,MutableLong> map;
 
   public MapCounter() {
-    map = new HashMap<KT,MutableLong>();
+    map = new HashMap<>();
   }
 
   public long increment(KT key, long l) {
@@ -68,7 +68,7 @@ public class MapCounter<KT> {
 
   public Collection<Long> values() {
     Collection<MutableLong> vals = map.values();
-    ArrayList<Long> ret = new ArrayList<Long>(vals.size());
+    ArrayList<Long> ret = new ArrayList<>(vals.size());
     for (MutableLong ml : vals) {
       ret.add(ml.l);
     }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/util/Merge.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/Merge.java b/core/src/main/java/org/apache/accumulo/core/util/Merge.java
index 71f8325..1af5e37 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/Merge.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/Merge.java
@@ -51,7 +51,7 @@ public class Merge {
     MergeException(Exception ex) {
       super(ex);
     }
-  };
+  }
 
   private static final Logger log = LoggerFactory.getLogger(Merge.class);
 
@@ -120,7 +120,7 @@ public class Merge {
       if (table.equals(MetadataTable.NAME)) {
         throw new IllegalArgumentException("cannot merge tablets on the metadata table");
       }
-      List<Size> sizes = new ArrayList<Size>();
+      List<Size> sizes = new ArrayList<>();
       long totalSize = 0;
       // Merge any until you get larger than the goal size, and then merge one less tablet
       Iterator<Size> sizeIterator = getSizeIterator(conn, table, start, end);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/util/Pair.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/Pair.java b/core/src/main/java/org/apache/accumulo/core/util/Pair.java
index 293d126..2d51bcd 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/Pair.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/Pair.java
@@ -73,11 +73,11 @@ public class Pair<A,B> {
   }
 
   public Entry<A,B> toMapEntry() {
-    return new SimpleImmutableEntry<A,B>(getFirst(), getSecond());
+    return new SimpleImmutableEntry<>(getFirst(), getSecond());
   }
 
   public Pair<B,A> swap() {
-    return new Pair<B,A>(getSecond(), getFirst());
+    return new Pair<>(getSecond(), getFirst());
   }
 
   public static <K2,V2,K1 extends K2,V1 extends V2> Pair<K2,V2> fromEntry(Entry<K1,V1> entry) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/util/ServerServices.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/ServerServices.java b/core/src/main/java/org/apache/accumulo/core/util/ServerServices.java
index a07ef76..de39d5c 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/ServerServices.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/ServerServices.java
@@ -32,7 +32,7 @@ public class ServerServices implements Comparable<ServerServices> {
   private String stringForm = null;
 
   public ServerServices(String services) {
-    this.services = new EnumMap<Service,String>(Service.class);
+    this.services = new EnumMap<>(Service.class);
 
     String[] addresses = services.split(SERVICE_SEPARATOR);
     for (String address : addresses) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/util/StopWatch.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/StopWatch.java b/core/src/main/java/org/apache/accumulo/core/util/StopWatch.java
index 8abe19e..5a574db 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/StopWatch.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/StopWatch.java
@@ -23,8 +23,8 @@ public class StopWatch<K extends Enum<K>> {
   EnumMap<K,Long> totalTime;
 
   public StopWatch(Class<K> k) {
-    startTime = new EnumMap<K,Long>(k);
-    totalTime = new EnumMap<K,Long>(k);
+    startTime = new EnumMap<>(k);
+    totalTime = new EnumMap<>(k);
   }
 
   public synchronized void start(K timer) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/util/format/ShardedTableDistributionFormatter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/format/ShardedTableDistributionFormatter.java b/core/src/main/java/org/apache/accumulo/core/util/format/ShardedTableDistributionFormatter.java
index 877f164..336e986 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/format/ShardedTableDistributionFormatter.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/format/ShardedTableDistributionFormatter.java
@@ -34,7 +34,7 @@ import org.apache.accumulo.core.data.Value;
  */
 public class ShardedTableDistributionFormatter extends AggregatingFormatter {
 
-  private Map<String,HashSet<String>> countsByDay = new HashMap<String,HashSet<String>>();
+  private Map<String,HashSet<String>> countsByDay = new HashMap<>();
 
   @Override
   protected void aggregateStats(Entry<Key,Value> entry) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/util/format/StatisticsDisplayFormatter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/format/StatisticsDisplayFormatter.java b/core/src/main/java/org/apache/accumulo/core/util/format/StatisticsDisplayFormatter.java
index b3ee3ee..0f4858a 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/format/StatisticsDisplayFormatter.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/format/StatisticsDisplayFormatter.java
@@ -28,9 +28,9 @@ import org.apache.accumulo.core.data.Value;
  * debugging. If used on large result sets it will likely fail.
  */
 public class StatisticsDisplayFormatter extends AggregatingFormatter {
-  private Map<String,Long> classifications = new HashMap<String,Long>();
-  private Map<String,Long> columnFamilies = new HashMap<String,Long>();
-  private Map<String,Long> columnQualifiers = new HashMap<String,Long>();
+  private Map<String,Long> classifications = new HashMap<>();
+  private Map<String,Long> columnFamilies = new HashMap<>();
+  private Map<String,Long> columnQualifiers = new HashMap<>();
   private long total = 0;
 
   @Override
@@ -71,9 +71,9 @@ public class StatisticsDisplayFormatter extends AggregatingFormatter {
 
     buf.append(total).append(" entries matched.");
     total = 0;
-    classifications = new HashMap<String,Long>();
-    columnFamilies = new HashMap<String,Long>();
-    columnQualifiers = new HashMap<String,Long>();
+    classifications = new HashMap<>();
+    columnFamilies = new HashMap<>();
+    columnQualifiers = new HashMap<>();
 
     return buf.toString();
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/main/java/org/apache/accumulo/core/util/interpret/HexScanInterpreter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/interpret/HexScanInterpreter.java b/core/src/main/java/org/apache/accumulo/core/util/interpret/HexScanInterpreter.java
index 964e8c6..3794f27 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/interpret/HexScanInterpreter.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/interpret/HexScanInterpreter.java
@@ -22,6 +22,6 @@ import org.apache.accumulo.core.util.format.HexFormatter;
  * As simple scan interpreter that converts hex to binary. IT supports translating the output of {@link HexFormatter} back to binary. The hex input can contain
  * dashes (because {@link HexFormatter} outputs dashes) which are ignored.
  */
-public class HexScanInterpreter extends HexFormatter implements ScanInterpreter {
+public class HexScanInterpreter extends HexFormatter {
 
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/IteratorSettingTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/IteratorSettingTest.java b/core/src/test/java/org/apache/accumulo/core/client/IteratorSettingTest.java
index bbe2415..ddea0b3 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/IteratorSettingTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/IteratorSettingTest.java
@@ -104,7 +104,7 @@ public class IteratorSettingTest {
 
     assertNotEquals(setting1, notEqual1);
 
-    Map<String,String> props = new HashMap<String,String>();
+    Map<String,String> props = new HashMap<>();
     props.put("foo", "bar");
     IteratorSetting notEquals2 = new IteratorSetting(100, "Combiner", Combiner.class, props);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/RowIteratorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/RowIteratorTest.java b/core/src/test/java/org/apache/accumulo/core/client/RowIteratorTest.java
index 55e21d1..d8b0696 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/RowIteratorTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/RowIteratorTest.java
@@ -36,7 +36,7 @@ import org.junit.Test;
 public class RowIteratorTest {
 
   Iterator<Entry<Key,Value>> makeIterator(final String... args) {
-    final Map<Key,Value> result = new TreeMap<Key,Value>();
+    final Map<Key,Value> result = new TreeMap<>();
     for (String s : args) {
       final String parts[] = s.split("[ \t]");
       final Key key = new Key(parts[0], parts[1], parts[2]);
@@ -47,11 +47,11 @@ public class RowIteratorTest {
   }
 
   List<List<Entry<Key,Value>>> getRows(final Iterator<Entry<Key,Value>> iter) {
-    final List<List<Entry<Key,Value>>> result = new ArrayList<List<Entry<Key,Value>>>();
+    final List<List<Entry<Key,Value>>> result = new ArrayList<>();
     final RowIterator riter = new RowIterator(iter);
     while (riter.hasNext()) {
       final Iterator<Entry<Key,Value>> row = riter.next();
-      final List<Entry<Key,Value>> rlist = new ArrayList<Entry<Key,Value>>();
+      final List<Entry<Key,Value>> rlist = new ArrayList<>();
       while (row.hasNext())
         rlist.add(row.next());
       result.add(rlist);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/ZooKeeperInstanceTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/ZooKeeperInstanceTest.java b/core/src/test/java/org/apache/accumulo/core/client/ZooKeeperInstanceTest.java
index 41e0b92..aecc947 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/ZooKeeperInstanceTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/ZooKeeperInstanceTest.java
@@ -139,7 +139,7 @@ public class ZooKeeperInstanceTest {
     replay(config);
     zki = new ZooKeeperInstance(config, zcf);
     expect(zc.get(Constants.ZROOT + "/" + IID_STRING)).andReturn("yup".getBytes());
-    List<String> children = new java.util.ArrayList<String>();
+    List<String> children = new java.util.ArrayList<>();
     children.add("child1");
     children.add("child2");
     expect(zc.getChildren(Constants.ZROOT + Constants.ZINSTANCES)).andReturn(children);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/impl/ClientContextTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/impl/ClientContextTest.java b/core/src/test/java/org/apache/accumulo/core/client/impl/ClientContextTest.java
index ff9863c..4eb348e 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/impl/ClientContextTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/impl/ClientContextTest.java
@@ -99,7 +99,7 @@ public class ClientContextTest {
     clientConf.addProperty(Property.GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS.getKey(), absPath);
 
     AccumuloConfiguration accClientConf = ClientContext.convertClientConfig(clientConf);
-    Map<String,String> props = new HashMap<String,String>();
+    Map<String,String> props = new HashMap<>();
     Predicate<String> all = Predicates.alwaysTrue();
     accClientConf.getProperties(props, all);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/impl/TableOperationsHelperTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/impl/TableOperationsHelperTest.java b/core/src/test/java/org/apache/accumulo/core/client/impl/TableOperationsHelperTest.java
index c55b62f..1d699c2 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/impl/TableOperationsHelperTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/impl/TableOperationsHelperTest.java
@@ -49,7 +49,7 @@ import org.junit.Test;
 public class TableOperationsHelperTest {
 
   static class Tester extends TableOperationsHelper {
-    Map<String,Map<String,String>> settings = new HashMap<String,Map<String,String>>();
+    Map<String,Map<String,String>> settings = new HashMap<>();
 
     @Override
     public SortedSet<String> list() {
@@ -256,12 +256,12 @@ public class TableOperationsHelperTest {
   }
 
   void check(TableOperationsHelper t, String tablename, String[] values) throws Exception {
-    Map<String,String> expected = new TreeMap<String,String>();
+    Map<String,String> expected = new TreeMap<>();
     for (String value : values) {
       String parts[] = value.split("=", 2);
       expected.put(parts[0], parts[1]);
     }
-    Map<String,String> actual = new TreeMap<String,String>();
+    Map<String,String> actual = new TreeMap<>();
     for (Entry<String,String> entry : t.getProperties(tablename)) {
       actual.put(entry.getKey(), entry.getValue());
     }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/impl/TabletLocatorImplTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/impl/TabletLocatorImplTest.java b/core/src/test/java/org/apache/accumulo/core/client/impl/TabletLocatorImplTest.java
index a053cef..bab52f6 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/impl/TabletLocatorImplTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/impl/TabletLocatorImplTest.java
@@ -88,13 +88,13 @@ public class TabletLocatorImplTest {
   @SuppressWarnings("unchecked")
   static Map<String,Map<KeyExtent,List<Range>>> createExpectedBinnings(Object... data) {
 
-    Map<String,Map<KeyExtent,List<Range>>> expBinnedRanges = new HashMap<String,Map<KeyExtent,List<Range>>>();
+    Map<String,Map<KeyExtent,List<Range>>> expBinnedRanges = new HashMap<>();
 
     for (int i = 0; i < data.length; i += 2) {
       String loc = (String) data[i];
       Object binData[] = (Object[]) data[i + 1];
 
-      HashMap<KeyExtent,List<Range>> binnedKE = new HashMap<KeyExtent,List<Range>>();
+      HashMap<KeyExtent,List<Range>> binnedKE = new HashMap<>();
 
       expBinnedRanges.put(loc, binnedKE);
 
@@ -110,7 +110,7 @@ public class TabletLocatorImplTest {
   }
 
   static TreeMap<KeyExtent,TabletLocation> createMetaCacheKE(Object... data) {
-    TreeMap<KeyExtent,TabletLocation> mcke = new TreeMap<KeyExtent,TabletLocation>();
+    TreeMap<KeyExtent,TabletLocation> mcke = new TreeMap<>();
 
     for (int i = 0; i < data.length; i += 2) {
       KeyExtent ke = (KeyExtent) data[i];
@@ -124,7 +124,7 @@ public class TabletLocatorImplTest {
   static TreeMap<Text,TabletLocation> createMetaCache(Object... data) {
     TreeMap<KeyExtent,TabletLocation> mcke = createMetaCacheKE(data);
 
-    TreeMap<Text,TabletLocation> mc = new TreeMap<Text,TabletLocation>(TabletLocatorImpl.endRowComparator);
+    TreeMap<Text,TabletLocation> mc = new TreeMap<>(TabletLocatorImpl.endRowComparator);
 
     for (Entry<KeyExtent,TabletLocation> entry : mcke.entrySet()) {
       if (entry.getKey().getEndRow() == null)
@@ -182,18 +182,18 @@ public class TabletLocatorImplTest {
   private void runTest(Text tableName, List<Range> ranges, TabletLocatorImpl tab1TabletCache, Map<String,Map<KeyExtent,List<Range>>> expected,
       List<Range> efailures) throws Exception {
 
-    Map<String,Map<KeyExtent,List<Range>>> binnedRanges = new HashMap<String,Map<KeyExtent,List<Range>>>();
+    Map<String,Map<KeyExtent,List<Range>>> binnedRanges = new HashMap<>();
     List<Range> f = tab1TabletCache.binRanges(context, ranges, binnedRanges);
     assertEquals(expected, binnedRanges);
 
-    HashSet<Range> f1 = new HashSet<Range>(f);
-    HashSet<Range> f2 = new HashSet<Range>(efailures);
+    HashSet<Range> f1 = new HashSet<>(f);
+    HashSet<Range> f2 = new HashSet<>(efailures);
 
     assertEquals(f2, f1);
   }
 
   static Set<KeyExtent> nkes(KeyExtent... extents) {
-    HashSet<KeyExtent> kes = new HashSet<KeyExtent>();
+    HashSet<KeyExtent> kes = new HashSet<>();
 
     for (KeyExtent keyExtent : extents) {
       kes.add(keyExtent);
@@ -205,11 +205,11 @@ public class TabletLocatorImplTest {
   static void runTest(TreeMap<Text,TabletLocation> mc, KeyExtent remove, Set<KeyExtent> expected) {
     // copy so same metaCache can be used for multiple test
 
-    mc = new TreeMap<Text,TabletLocation>(mc);
+    mc = new TreeMap<>(mc);
 
     TabletLocatorImpl.removeOverlapping(mc, remove);
 
-    HashSet<KeyExtent> eic = new HashSet<KeyExtent>();
+    HashSet<KeyExtent> eic = new HashSet<>();
     for (TabletLocation tl : mc.values()) {
       eic.add(tl.tablet_extent);
     }
@@ -235,14 +235,14 @@ public class TabletLocatorImplTest {
   }
 
   private void runTest(TabletLocatorImpl metaCache, List<Mutation> ml, Map<String,Map<KeyExtent,List<String>>> emb, String... efailures) throws Exception {
-    Map<String,TabletServerMutations<Mutation>> binnedMutations = new HashMap<String,TabletServerMutations<Mutation>>();
-    List<Mutation> afailures = new ArrayList<Mutation>();
+    Map<String,TabletServerMutations<Mutation>> binnedMutations = new HashMap<>();
+    List<Mutation> afailures = new ArrayList<>();
     metaCache.binMutations(context, ml, binnedMutations, afailures);
 
     verify(emb, binnedMutations);
 
-    ArrayList<String> afs = new ArrayList<String>();
-    ArrayList<String> efs = new ArrayList<String>(Arrays.asList(efailures));
+    ArrayList<String> afs = new ArrayList<>();
+    ArrayList<String> efs = new ArrayList<>(Arrays.asList(efailures));
 
     for (Mutation mutation : afailures) {
       afs.add(new String(mutation.getRow()));
@@ -265,8 +265,8 @@ public class TabletLocatorImplTest {
       assertEquals(etb.keySet(), atb.getMutations().keySet());
 
       for (KeyExtent ke : etb.keySet()) {
-        ArrayList<String> eRows = new ArrayList<String>(etb.get(ke));
-        ArrayList<String> aRows = new ArrayList<String>();
+        ArrayList<String> eRows = new ArrayList<>(etb.get(ke));
+        ArrayList<String> aRows = new ArrayList<>();
 
         for (Mutation m : atb.getMutations().get(ke)) {
           aRows.add(new String(m.getRow()));
@@ -283,7 +283,7 @@ public class TabletLocatorImplTest {
 
   static Map<String,Map<KeyExtent,List<String>>> cemb(Object[]... ols) {
 
-    Map<String,Map<KeyExtent,List<String>>> emb = new HashMap<String,Map<KeyExtent,List<String>>>();
+    Map<String,Map<KeyExtent,List<String>>> emb = new HashMap<>();
 
     for (Object[] ol : ols) {
       String row = (String) ol[0];
@@ -292,13 +292,13 @@ public class TabletLocatorImplTest {
 
       Map<KeyExtent,List<String>> tb = emb.get(server);
       if (tb == null) {
-        tb = new HashMap<KeyExtent,List<String>>();
+        tb = new HashMap<>();
         emb.put(server, tb);
       }
 
       List<String> rl = tb.get(ke);
       if (rl == null) {
-        rl = new ArrayList<String>();
+        rl = new ArrayList<>();
         tb.put(ke, rl);
       }
 
@@ -476,7 +476,7 @@ public class TabletLocatorImplTest {
   }
 
   static class TServers {
-    private final Map<String,Map<KeyExtent,SortedMap<Key,Value>>> tservers = new HashMap<String,Map<KeyExtent,SortedMap<Key,Value>>>();
+    private final Map<String,Map<KeyExtent,SortedMap<Key,Value>>> tservers = new HashMap<>();
   }
 
   static class TestTabletLocationObtainer implements TabletLocationObtainer {
@@ -523,7 +523,7 @@ public class TabletLocatorImplTest {
     public List<TabletLocation> lookupTablets(ClientContext context, String tserver, Map<KeyExtent,List<Range>> map, TabletLocator parent)
         throws AccumuloSecurityException {
 
-      ArrayList<TabletLocation> list = new ArrayList<TabletLocation>();
+      ArrayList<TabletLocation> list = new ArrayList<>();
 
       Map<KeyExtent,SortedMap<Key,Value>> tablets = tservers.get(tserver);
 
@@ -532,10 +532,10 @@ public class TabletLocatorImplTest {
         return list;
       }
 
-      TreeMap<Key,Value> results = new TreeMap<Key,Value>();
+      TreeMap<Key,Value> results = new TreeMap<>();
 
       Set<Entry<KeyExtent,List<Range>>> es = map.entrySet();
-      List<KeyExtent> failures = new ArrayList<KeyExtent>();
+      List<KeyExtent> failures = new ArrayList<>();
       for (Entry<KeyExtent,List<Range>> entry : es) {
         SortedMap<Key,Value> tabletData = tablets.get(entry.getKey());
 
@@ -601,13 +601,13 @@ public class TabletLocatorImplTest {
   static void createEmptyTablet(TServers tservers, String server, KeyExtent tablet) {
     Map<KeyExtent,SortedMap<Key,Value>> tablets = tservers.tservers.get(server);
     if (tablets == null) {
-      tablets = new HashMap<KeyExtent,SortedMap<Key,Value>>();
+      tablets = new HashMap<>();
       tservers.tservers.put(server, tablets);
     }
 
     SortedMap<Key,Value> tabletData = tablets.get(tablet);
     if (tabletData == null) {
-      tabletData = new TreeMap<Key,Value>();
+      tabletData = new TreeMap<>();
       tablets.put(tablet, tabletData);
     } else if (tabletData.size() > 0) {
       throw new RuntimeException("Asked for empty tablet, but non empty tablet exists");
@@ -634,13 +634,13 @@ public class TabletLocatorImplTest {
   static void setLocation(TServers tservers, String server, KeyExtent tablet, KeyExtent ke, String location, String instance) {
     Map<KeyExtent,SortedMap<Key,Value>> tablets = tservers.tservers.get(server);
     if (tablets == null) {
-      tablets = new HashMap<KeyExtent,SortedMap<Key,Value>>();
+      tablets = new HashMap<>();
       tservers.tservers.put(server, tablets);
     }
 
     SortedMap<Key,Value> tabletData = tablets.get(tablet);
     if (tabletData == null) {
-      tabletData = new TreeMap<Key,Value>();
+      tabletData = new TreeMap<>();
       tablets.put(tablet, tabletData);
     }
 
@@ -1269,7 +1269,7 @@ public class TabletLocatorImplTest {
     setLocation(tservers, "tserver1", RTE, mte2, "tserver3");
 
     // create the ~ tablet so it exists
-    Map<KeyExtent,SortedMap<Key,Value>> ts3 = new HashMap<KeyExtent,SortedMap<Key,Value>>();
+    Map<KeyExtent,SortedMap<Key,Value>> ts3 = new HashMap<>();
     ts3.put(mte2, new TreeMap<Key,Value>());
     tservers.tservers.put("tserver3", ts3);
 
@@ -1336,7 +1336,7 @@ public class TabletLocatorImplTest {
   @Test
   public void testLostLock() throws Exception {
 
-    final HashSet<String> activeLocks = new HashSet<String>();
+    final HashSet<String> activeLocks = new HashSet<>();
 
     TServers tservers = new TServers();
     TabletLocatorImpl metaCache = createLocators(tservers, "tserver1", "tserver2", "foo", new TabletServerLockChecker() {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/lexicoder/LexicoderTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/lexicoder/LexicoderTest.java b/core/src/test/java/org/apache/accumulo/core/client/lexicoder/LexicoderTest.java
index 6d06f97..faf3c23 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/lexicoder/LexicoderTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/lexicoder/LexicoderTest.java
@@ -32,8 +32,8 @@ public abstract class LexicoderTest extends TestCase {
   }
 
   public <T extends Comparable<T>> void assertSortOrder(Lexicoder<T> lexicoder, Comparator<T> comp, List<T> data) {
-    List<T> list = new ArrayList<T>();
-    List<Text> encList = new ArrayList<Text>();
+    List<T> list = new ArrayList<>();
+    List<Text> encList = new ArrayList<>();
 
     for (T d : data) {
       list.add(d);
@@ -47,7 +47,7 @@ public abstract class LexicoderTest extends TestCase {
 
     Collections.sort(encList);
 
-    List<T> decodedList = new ArrayList<T>();
+    List<T> decodedList = new ArrayList<>();
 
     for (Text t : encList) {
       decodedList.add(lexicoder.decode(TextUtil.getBytes(t)));

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/lexicoder/ListLexicoderTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/lexicoder/ListLexicoderTest.java b/core/src/test/java/org/apache/accumulo/core/client/lexicoder/ListLexicoderTest.java
index 6353863..22cdc50 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/lexicoder/ListLexicoderTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/lexicoder/ListLexicoderTest.java
@@ -26,11 +26,11 @@ import org.apache.hadoop.io.Text;
 
 public class ListLexicoderTest extends AbstractLexicoderTest {
 
-  private List<Long> data1 = new ArrayList<Long>();
-  private List<Long> data2 = new ArrayList<Long>();
-  private List<Long> data3 = new ArrayList<Long>();
-  private List<Long> data4 = new ArrayList<Long>();
-  private List<Long> data5 = new ArrayList<Long>();
+  private List<Long> data1 = new ArrayList<>();
+  private List<Long> data2 = new ArrayList<>();
+  private List<Long> data3 = new ArrayList<>();
+  private List<Long> data4 = new ArrayList<>();
+  private List<Long> data5 = new ArrayList<>();
 
   @Override
   public void setUp() {
@@ -52,7 +52,7 @@ public class ListLexicoderTest extends AbstractLexicoderTest {
   }
 
   public void testSortOrder() {
-    List<List<Long>> data = new ArrayList<List<Long>>();
+    List<List<Long>> data = new ArrayList<>();
 
     // add list in expected sort order
     data.add(data2);
@@ -61,15 +61,15 @@ public class ListLexicoderTest extends AbstractLexicoderTest {
     data.add(data3);
     data.add(data5);
 
-    TreeSet<Text> sortedEnc = new TreeSet<Text>();
+    TreeSet<Text> sortedEnc = new TreeSet<>();
 
-    ListLexicoder<Long> listLexicoder = new ListLexicoder<Long>(new LongLexicoder());
+    ListLexicoder<Long> listLexicoder = new ListLexicoder<>(new LongLexicoder());
 
     for (List<Long> list : data) {
       sortedEnc.add(new Text(listLexicoder.encode(list)));
     }
 
-    List<List<Long>> unenc = new ArrayList<List<Long>>();
+    List<List<Long>> unenc = new ArrayList<>();
 
     for (Text enc : sortedEnc) {
       unenc.add(listLexicoder.decode(TextUtil.getBytes(enc)));
@@ -80,10 +80,10 @@ public class ListLexicoderTest extends AbstractLexicoderTest {
   }
 
   public void testDecodes() {
-    assertDecodes(new ListLexicoder<Long>(new LongLexicoder()), data1);
-    assertDecodes(new ListLexicoder<Long>(new LongLexicoder()), data2);
-    assertDecodes(new ListLexicoder<Long>(new LongLexicoder()), data3);
-    assertDecodes(new ListLexicoder<Long>(new LongLexicoder()), data4);
-    assertDecodes(new ListLexicoder<Long>(new LongLexicoder()), data5);
+    assertDecodes(new ListLexicoder<>(new LongLexicoder()), data1);
+    assertDecodes(new ListLexicoder<>(new LongLexicoder()), data2);
+    assertDecodes(new ListLexicoder<>(new LongLexicoder()), data3);
+    assertDecodes(new ListLexicoder<>(new LongLexicoder()), data4);
+    assertDecodes(new ListLexicoder<>(new LongLexicoder()), data5);
   }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/lexicoder/PairLexicoderTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/lexicoder/PairLexicoderTest.java b/core/src/test/java/org/apache/accumulo/core/client/lexicoder/PairLexicoderTest.java
index 0979801..d94793e 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/lexicoder/PairLexicoderTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/lexicoder/PairLexicoderTest.java
@@ -26,20 +26,19 @@ import java.util.Arrays;
  */
 public class PairLexicoderTest extends AbstractLexicoderTest {
   public void testSortOrder() {
-    PairLexicoder<String,String> plexc = new PairLexicoder<String,String>(new StringLexicoder(), new StringLexicoder());
+    PairLexicoder<String,String> plexc = new PairLexicoder<>(new StringLexicoder(), new StringLexicoder());
 
-    assertSortOrder(plexc, Arrays.asList(new ComparablePair<String,String>("a", "b"), new ComparablePair<String,String>("a", "bc"),
-        new ComparablePair<String,String>("a", "c"), new ComparablePair<String,String>("ab", "c"), new ComparablePair<String,String>("ab", ""),
-        new ComparablePair<String,String>("ab", "d"), new ComparablePair<String,String>("b", "f"), new ComparablePair<String,String>("b", "a")));
+    assertSortOrder(plexc, Arrays.asList(new ComparablePair<>("a", "b"), new ComparablePair<>("a", "bc"), new ComparablePair<>("a", "c"), new ComparablePair<>(
+        "ab", "c"), new ComparablePair<>("ab", ""), new ComparablePair<>("ab", "d"), new ComparablePair<>("b", "f"), new ComparablePair<>("b", "a")));
 
-    PairLexicoder<Long,String> plexc2 = new PairLexicoder<Long,String>(new LongLexicoder(), new StringLexicoder());
+    PairLexicoder<Long,String> plexc2 = new PairLexicoder<>(new LongLexicoder(), new StringLexicoder());
 
-    assertSortOrder(plexc2, Arrays.asList(new ComparablePair<Long,String>(0x100l, "a"), new ComparablePair<Long,String>(0x100l, "ab"),
-        new ComparablePair<Long,String>(0xf0l, "a"), new ComparablePair<Long,String>(0xf0l, "ab")));
+    assertSortOrder(plexc2, Arrays.asList(new ComparablePair<>(0x100l, "a"), new ComparablePair<>(0x100l, "ab"), new ComparablePair<>(0xf0l, "a"),
+        new ComparablePair<>(0xf0l, "ab")));
   }
 
   public void testDecodes() {
-    PairLexicoder<String,String> plexc = new PairLexicoder<String,String>(new StringLexicoder(), new StringLexicoder());
-    assertDecodes(plexc, new ComparablePair<String,String>("a", "b"));
+    PairLexicoder<String,String> plexc = new PairLexicoder<>(new StringLexicoder(), new StringLexicoder());
+    assertDecodes(plexc, new ComparablePair<>("a", "b"));
   }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/lexicoder/ReverseLexicoderTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/lexicoder/ReverseLexicoderTest.java b/core/src/test/java/org/apache/accumulo/core/client/lexicoder/ReverseLexicoderTest.java
index a49409f..df6f131 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/lexicoder/ReverseLexicoderTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/lexicoder/ReverseLexicoderTest.java
@@ -29,12 +29,12 @@ import java.util.Date;
 public class ReverseLexicoderTest extends AbstractLexicoderTest {
   public void testSortOrder() {
     Comparator<Long> comp = Collections.reverseOrder();
-    assertSortOrder(new ReverseLexicoder<Long>(new LongLexicoder()), comp, Arrays.asList(Long.MIN_VALUE, 0xff1234567890abcdl, 0xffff1234567890abl,
+    assertSortOrder(new ReverseLexicoder<>(new LongLexicoder()), comp, Arrays.asList(Long.MIN_VALUE, 0xff1234567890abcdl, 0xffff1234567890abl,
         0xffffff567890abcdl, 0xffffffff7890abcdl, 0xffffffffff90abcdl, 0xffffffffffffabcdl, 0xffffffffffffffcdl, -1l, 0l, 0x01l, 0x1234l, 0x123456l,
         0x12345678l, 0x1234567890l, 0x1234567890abl, 0x1234567890abcdl, 0x1234567890abcdefl, Long.MAX_VALUE));
 
     Comparator<String> comp2 = Collections.reverseOrder();
-    assertSortOrder(new ReverseLexicoder<String>(new StringLexicoder()), comp2, Arrays.asList("a", "aa", "ab", "b", "aab"));
+    assertSortOrder(new ReverseLexicoder<>(new StringLexicoder()), comp2, Arrays.asList("a", "aa", "ab", "b", "aab"));
 
   }
 
@@ -44,7 +44,7 @@ public class ReverseLexicoderTest extends AbstractLexicoderTest {
   @Test
   public void testReverseSortDates() throws UnsupportedEncodingException {
 
-    ReverseLexicoder<Date> revLex = new ReverseLexicoder<Date>(new DateLexicoder());
+    ReverseLexicoder<Date> revLex = new ReverseLexicoder<>(new DateLexicoder());
 
     Calendar cal = Calendar.getInstance();
     cal.set(1920, 1, 2, 3, 4, 5); // create an instance prior to 1970 for ACCUMULO-3385
@@ -65,10 +65,10 @@ public class ReverseLexicoderTest extends AbstractLexicoderTest {
   }
 
   public void testDecodes() {
-    assertDecodes(new ReverseLexicoder<Long>(new LongLexicoder()), Long.MIN_VALUE);
-    assertDecodes(new ReverseLexicoder<Long>(new LongLexicoder()), -1l);
-    assertDecodes(new ReverseLexicoder<Long>(new LongLexicoder()), 0l);
-    assertDecodes(new ReverseLexicoder<Long>(new LongLexicoder()), 1l);
-    assertDecodes(new ReverseLexicoder<Long>(new LongLexicoder()), Long.MAX_VALUE);
+    assertDecodes(new ReverseLexicoder<>(new LongLexicoder()), Long.MIN_VALUE);
+    assertDecodes(new ReverseLexicoder<>(new LongLexicoder()), -1l);
+    assertDecodes(new ReverseLexicoder<>(new LongLexicoder()), 0l);
+    assertDecodes(new ReverseLexicoder<>(new LongLexicoder()), 1l);
+    assertDecodes(new ReverseLexicoder<>(new LongLexicoder()), Long.MAX_VALUE);
   }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/lexicoder/UUIDLexicoderTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/lexicoder/UUIDLexicoderTest.java b/core/src/test/java/org/apache/accumulo/core/client/lexicoder/UUIDLexicoderTest.java
index 60c89a3..8424a75 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/lexicoder/UUIDLexicoderTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/lexicoder/UUIDLexicoderTest.java
@@ -28,7 +28,7 @@ public class UUIDLexicoderTest extends AbstractLexicoderTest {
     assertSortOrder(new UUIDLexicoder(),
         Arrays.asList(UUID.randomUUID(), UUID.randomUUID(), UUID.randomUUID(), UUID.randomUUID(), UUID.randomUUID(), UUID.randomUUID()));
 
-    ArrayList<UUID> uuids = new ArrayList<UUID>();
+    ArrayList<UUID> uuids = new ArrayList<>();
 
     for (long ms = -260l; ms < 260l; ms++) {
       for (long ls = -2l; ls < 2; ls++) {