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

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

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/mapred/AccumuloMultiTableInputFormatTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/mapred/AccumuloMultiTableInputFormatTest.java b/core/src/test/java/org/apache/accumulo/core/client/mapred/AccumuloMultiTableInputFormatTest.java
index ef19901..4e75ab6 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/mapred/AccumuloMultiTableInputFormatTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/mapred/AccumuloMultiTableInputFormatTest.java
@@ -48,14 +48,14 @@ public class AccumuloMultiTableInputFormatTest {
     JobConf job = new JobConf();
 
     InputTableConfig table1 = new InputTableConfig().setRanges(Collections.singletonList(new Range("a", "b")))
-        .fetchColumns(Collections.singleton(new Pair<Text,Text>(new Text("CF1"), new Text("CQ1"))))
+        .fetchColumns(Collections.singleton(new Pair<>(new Text("CF1"), new Text("CQ1"))))
         .setIterators(Collections.singletonList(new IteratorSetting(50, "iter1", "iterclass1")));
 
     InputTableConfig table2 = new InputTableConfig().setRanges(Collections.singletonList(new Range("a", "b")))
-        .fetchColumns(Collections.singleton(new Pair<Text,Text>(new Text("CF1"), new Text("CQ1"))))
+        .fetchColumns(Collections.singleton(new Pair<>(new Text("CF1"), new Text("CQ1"))))
         .setIterators(Collections.singletonList(new IteratorSetting(50, "iter1", "iterclass1")));
 
-    Map<String,InputTableConfig> configMap = new HashMap<String,InputTableConfig>();
+    Map<String,InputTableConfig> configMap = new HashMap<>();
     configMap.put(table1Name, table1);
     configMap.put(table2Name, table2);
     AccumuloMultiTableInputFormat.setInputTableConfigs(job, configMap);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/mapred/RangeInputSplitTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/mapred/RangeInputSplitTest.java b/core/src/test/java/org/apache/accumulo/core/client/mapred/RangeInputSplitTest.java
index 6c75ec2..c399fb0 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/mapred/RangeInputSplitTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/mapred/RangeInputSplitTest.java
@@ -64,13 +64,13 @@ public class RangeInputSplitTest {
   public void testAllFieldsWritable() throws IOException {
     RangeInputSplit split = new RangeInputSplit("table", "1", new Range(new Key("a"), new Key("b")), new String[] {"localhost"});
 
-    Set<Pair<Text,Text>> fetchedColumns = new HashSet<Pair<Text,Text>>();
+    Set<Pair<Text,Text>> fetchedColumns = new HashSet<>();
 
-    fetchedColumns.add(new Pair<Text,Text>(new Text("colf1"), new Text("colq1")));
-    fetchedColumns.add(new Pair<Text,Text>(new Text("colf2"), new Text("colq2")));
+    fetchedColumns.add(new Pair<>(new Text("colf1"), new Text("colq1")));
+    fetchedColumns.add(new Pair<>(new Text("colf2"), new Text("colq2")));
 
     // Fake some iterators
-    ArrayList<IteratorSetting> iterators = new ArrayList<IteratorSetting>();
+    ArrayList<IteratorSetting> iterators = new ArrayList<>();
     IteratorSetting setting = new IteratorSetting(50, SummingCombiner.class);
     setting.addOption("foo", "bar");
     iterators.add(setting);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java b/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java
index 56c8195..3eef024 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java
@@ -175,12 +175,12 @@ public class AccumuloInputFormatTest {
   @Test
   public void testEmptyColumnFamily() throws IOException {
     Job job = Job.getInstance();
-    Set<Pair<Text,Text>> cols = new HashSet<Pair<Text,Text>>();
+    Set<Pair<Text,Text>> cols = new HashSet<>();
     cols.add(new Pair<Text,Text>(new Text(""), null));
-    cols.add(new Pair<Text,Text>(new Text("foo"), new Text("bar")));
-    cols.add(new Pair<Text,Text>(new Text(""), new Text("bar")));
-    cols.add(new Pair<Text,Text>(new Text(""), new Text("")));
-    cols.add(new Pair<Text,Text>(new Text("foo"), new Text("")));
+    cols.add(new Pair<>(new Text("foo"), new Text("bar")));
+    cols.add(new Pair<>(new Text(""), new Text("bar")));
+    cols.add(new Pair<>(new Text(""), new Text("")));
+    cols.add(new Pair<>(new Text("foo"), new Text("")));
     AccumuloInputFormat.fetchColumns(job, cols);
     Set<Pair<Text,Text>> setCols = AccumuloInputFormat.getFetchedColumns(job);
     assertEquals(cols, setCols);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloMultiTableInputFormatTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloMultiTableInputFormatTest.java b/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloMultiTableInputFormatTest.java
index 1137916..12849fe 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloMultiTableInputFormatTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloMultiTableInputFormatTest.java
@@ -47,10 +47,10 @@ public class AccumuloMultiTableInputFormatTest {
     Job job = Job.getInstance();
 
     InputTableConfig tableConfig = new InputTableConfig().setRanges(Collections.singletonList(new Range("a", "b")))
-        .fetchColumns(Collections.singleton(new Pair<Text,Text>(new Text("CF1"), new Text("CQ1"))))
+        .fetchColumns(Collections.singleton(new Pair<>(new Text("CF1"), new Text("CQ1"))))
         .setIterators(Collections.singletonList(new IteratorSetting(50, "iter1", "iterclass1")));
 
-    Map<String,InputTableConfig> configMap = new HashMap<String,InputTableConfig>();
+    Map<String,InputTableConfig> configMap = new HashMap<>();
     configMap.put(table1, tableConfig);
     configMap.put(table2, tableConfig);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/mapreduce/InputTableConfigTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/mapreduce/InputTableConfigTest.java b/core/src/test/java/org/apache/accumulo/core/client/mapreduce/InputTableConfigTest.java
index 4953654..f6f7b2f 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/mapreduce/InputTableConfigTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/mapreduce/InputTableConfigTest.java
@@ -66,7 +66,7 @@ public class InputTableConfigTest {
 
   @Test
   public void testSerialization_ranges() throws IOException {
-    List<Range> ranges = new ArrayList<Range>();
+    List<Range> ranges = new ArrayList<>();
     ranges.add(new Range("a", "b"));
     ranges.add(new Range("c", "d"));
     tableQueryConfig.setRanges(ranges);
@@ -79,8 +79,8 @@ public class InputTableConfigTest {
 
   @Test
   public void testSerialization_columns() throws IOException {
-    Set<Pair<Text,Text>> columns = new HashSet<Pair<Text,Text>>();
-    columns.add(new Pair<Text,Text>(new Text("cf1"), new Text("cq1")));
+    Set<Pair<Text,Text>> columns = new HashSet<>();
+    columns.add(new Pair<>(new Text("cf1"), new Text("cq1")));
     columns.add(new Pair<Text,Text>(new Text("cf2"), null));
     tableQueryConfig.fetchColumns(columns);
 
@@ -92,7 +92,7 @@ public class InputTableConfigTest {
 
   @Test
   public void testSerialization_iterators() throws IOException {
-    List<IteratorSetting> settings = new ArrayList<IteratorSetting>();
+    List<IteratorSetting> settings = new ArrayList<>();
     settings.add(new IteratorSetting(50, "iter", "iterclass"));
     settings.add(new IteratorSetting(55, "iter2", "iterclass2"));
     tableQueryConfig.setIterators(settings);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplitTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplitTest.java b/core/src/test/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplitTest.java
index 1cf8c55..0eb8010 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplitTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplitTest.java
@@ -66,13 +66,13 @@ public class RangeInputSplitTest {
   public void testAllFieldsWritable() throws IOException {
     RangeInputSplit split = new RangeInputSplit("table", "1", new Range(new Key("a"), new Key("b")), new String[] {"localhost"});
 
-    Set<Pair<Text,Text>> fetchedColumns = new HashSet<Pair<Text,Text>>();
+    Set<Pair<Text,Text>> fetchedColumns = new HashSet<>();
 
-    fetchedColumns.add(new Pair<Text,Text>(new Text("colf1"), new Text("colq1")));
-    fetchedColumns.add(new Pair<Text,Text>(new Text("colf2"), new Text("colq2")));
+    fetchedColumns.add(new Pair<>(new Text("colf1"), new Text("colq1")));
+    fetchedColumns.add(new Pair<>(new Text("colf2"), new Text("colq2")));
 
     // Fake some iterators
-    ArrayList<IteratorSetting> iterators = new ArrayList<IteratorSetting>();
+    ArrayList<IteratorSetting> iterators = new ArrayList<>();
     IteratorSetting setting = new IteratorSetting(50, SummingCombiner.class);
     setting.addOption("foo", "bar");
     iterators.add(setting);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/mapreduce/impl/BatchInputSplitTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/mapreduce/impl/BatchInputSplitTest.java b/core/src/test/java/org/apache/accumulo/core/client/mapreduce/impl/BatchInputSplitTest.java
index 74c3438..17c781d 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/mapreduce/impl/BatchInputSplitTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/mapreduce/impl/BatchInputSplitTest.java
@@ -68,13 +68,13 @@ public class BatchInputSplitTest {
     Range[] ranges = new Range[] {new Range(new Key("a"), new Key("b"))};
     BatchInputSplit split = new BatchInputSplit("table", "1", Arrays.asList(ranges), new String[] {"localhost"});
 
-    Set<Pair<Text,Text>> fetchedColumns = new HashSet<Pair<Text,Text>>();
+    Set<Pair<Text,Text>> fetchedColumns = new HashSet<>();
 
-    fetchedColumns.add(new Pair<Text,Text>(new Text("colf1"), new Text("colq1")));
-    fetchedColumns.add(new Pair<Text,Text>(new Text("colf2"), new Text("colq2")));
+    fetchedColumns.add(new Pair<>(new Text("colf1"), new Text("colq1")));
+    fetchedColumns.add(new Pair<>(new Text("colf2"), new Text("colq2")));
 
     // Fake some iterators
-    ArrayList<IteratorSetting> iterators = new ArrayList<IteratorSetting>();
+    ArrayList<IteratorSetting> iterators = new ArrayList<>();
     IteratorSetting setting = new IteratorSetting(50, SummingCombiner.class);
     setting.addOption("foo", "bar");
     iterators.add(setting);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/mock/MockConnectorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/mock/MockConnectorTest.java b/core/src/test/java/org/apache/accumulo/core/client/mock/MockConnectorTest.java
index 4a78a4b..b70cb00 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/mock/MockConnectorTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/mock/MockConnectorTest.java
@@ -125,7 +125,7 @@ public class MockConnectorTest {
 
     Mutation good = new Mutation("good");
     good.put(asText(random.nextInt()), asText(random.nextInt()), new Value("good".getBytes()));
-    List<Mutation> mutations = new ArrayList<Mutation>();
+    List<Mutation> mutations = new ArrayList<>();
     mutations.add(good);
     mutations.add(bad);
     try {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/mock/MockNamespacesTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/mock/MockNamespacesTest.java b/core/src/test/java/org/apache/accumulo/core/client/mock/MockNamespacesTest.java
index c1f39e2..ca12838 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/mock/MockNamespacesTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/mock/MockNamespacesTest.java
@@ -248,7 +248,7 @@ public class MockNamespacesTest {
     conn.tableOperations().create(tableName);
 
     IteratorSetting setting = new IteratorSetting(250, iter, SimpleFilter.class.getName());
-    HashSet<IteratorScope> scope = new HashSet<IteratorScope>();
+    HashSet<IteratorScope> scope = new HashSet<>();
     scope.add(IteratorScope.scan);
     conn.namespaceOperations().attachIterator(namespace, setting, EnumSet.copyOf(scope));
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/mock/MockTableOperationsTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/mock/MockTableOperationsTest.java b/core/src/test/java/org/apache/accumulo/core/client/mock/MockTableOperationsTest.java
index 9bd1455..58f3777 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/mock/MockTableOperationsTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/mock/MockTableOperationsTest.java
@@ -228,9 +228,9 @@ public class MockTableOperationsTest {
     FileSKVWriter writer = FileOperations.getInstance().newWriterBuilder().forFile(tempFile.toString(), fs, defaultConf)
         .withTableConfiguration(AccumuloConfiguration.getDefaultConfiguration()).build();
     writer.startDefaultLocalityGroup();
-    List<Pair<Key,Value>> keyVals = new ArrayList<Pair<Key,Value>>();
+    List<Pair<Key,Value>> keyVals = new ArrayList<>();
     for (int i = 0; i < 5; i++) {
-      keyVals.add(new Pair<Key,Value>(new Key("a" + i, "b" + i, "c" + i, new ColumnVisibility(""), 1000l + i), new Value(Integer.toString(i).getBytes())));
+      keyVals.add(new Pair<>(new Key("a" + i, "b" + i, "c" + i, new ColumnVisibility(""), 1000l + i), new Value(Integer.toString(i).getBytes())));
     }
     for (Pair<Key,Value> keyVal : keyVals) {
       writer.append(keyVal.getFirst(), keyVal.getSecond());

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/client/security/SecurityErrorCodeTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/security/SecurityErrorCodeTest.java b/core/src/test/java/org/apache/accumulo/core/client/security/SecurityErrorCodeTest.java
index 75d4c35..8843e3a 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/security/SecurityErrorCodeTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/security/SecurityErrorCodeTest.java
@@ -28,8 +28,8 @@ public class SecurityErrorCodeTest {
 
   @Test
   public void testEnumsSame() {
-    HashSet<String> secNames1 = new HashSet<String>();
-    HashSet<String> secNames2 = new HashSet<String>();
+    HashSet<String> secNames1 = new HashSet<>();
+    HashSet<String> secNames2 = new HashSet<>();
 
     for (SecurityErrorCode sec : SecurityErrorCode.values())
       secNames1.add(sec.name());

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/conf/ConfigSanityCheckTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/conf/ConfigSanityCheckTest.java b/core/src/test/java/org/apache/accumulo/core/conf/ConfigSanityCheckTest.java
index f34bf3b..7ac2113 100644
--- a/core/src/test/java/org/apache/accumulo/core/conf/ConfigSanityCheckTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/conf/ConfigSanityCheckTest.java
@@ -27,7 +27,7 @@ public class ConfigSanityCheckTest {
 
   @Before
   public void setUp() {
-    m = new java.util.HashMap<String,String>();
+    m = new java.util.HashMap<>();
   }
 
   @Test

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/conf/CredentialProviderFactoryShimTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/conf/CredentialProviderFactoryShimTest.java b/core/src/test/java/org/apache/accumulo/core/conf/CredentialProviderFactoryShimTest.java
index 37dff20..e540b72 100644
--- a/core/src/test/java/org/apache/accumulo/core/conf/CredentialProviderFactoryShimTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/conf/CredentialProviderFactoryShimTest.java
@@ -83,7 +83,7 @@ public class CredentialProviderFactoryShimTest {
     List<String> keys = CredentialProviderFactoryShim.getKeys(conf);
     Assert.assertNotNull(keys);
 
-    Assert.assertEquals(expectation.keySet(), new HashSet<String>(keys));
+    Assert.assertEquals(expectation.keySet(), new HashSet<>(keys));
     for (String expectedKey : keys) {
       char[] value = CredentialProviderFactoryShim.getValueFromCredentialProvider(conf, expectedKey);
       Assert.assertNotNull(value);
@@ -96,7 +96,7 @@ public class CredentialProviderFactoryShimTest {
     String absPath = getKeyStoreUrl(populatedKeyStore);
     Configuration conf = new Configuration();
     conf.set(CredentialProviderFactoryShim.CREDENTIAL_PROVIDER_PATH, absPath);
-    Map<String,String> expectations = new HashMap<String,String>();
+    Map<String,String> expectations = new HashMap<>();
     expectations.put("key1", "value1");
     expectations.put("key2", "value2");
 
@@ -117,7 +117,7 @@ public class CredentialProviderFactoryShimTest {
     String populatedAbsPath = getKeyStoreUrl(populatedKeyStore), emptyAbsPath = getKeyStoreUrl(emptyKeyStore);
     Configuration conf = new Configuration();
     conf.set(CredentialProviderFactoryShim.CREDENTIAL_PROVIDER_PATH, populatedAbsPath + "," + emptyAbsPath);
-    Map<String,String> expectations = new HashMap<String,String>();
+    Map<String,String> expectations = new HashMap<>();
     expectations.put("key1", "value1");
     expectations.put("key2", "value2");
 
@@ -186,7 +186,7 @@ public class CredentialProviderFactoryShimTest {
       Configuration cpConf = CredentialProviderFactoryShim.getConfiguration(dfsConfiguration, "jceks://hdfs/accumulo.jceks");
 
       // The values in the keystore
-      Map<String,String> expectations = new HashMap<String,String>();
+      Map<String,String> expectations = new HashMap<>();
       expectations.put("key1", "value1");
       expectations.put("key2", "value2");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/conf/DefaultConfigurationTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/conf/DefaultConfigurationTest.java b/core/src/test/java/org/apache/accumulo/core/conf/DefaultConfigurationTest.java
index 9566f2e..cb6810c 100644
--- a/core/src/test/java/org/apache/accumulo/core/conf/DefaultConfigurationTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/conf/DefaultConfigurationTest.java
@@ -42,7 +42,7 @@ public class DefaultConfigurationTest {
   @Test
   public void testGetProperties() {
     Predicate<String> all = Predicates.alwaysTrue();
-    Map<String,String> p = new java.util.HashMap<String,String>();
+    Map<String,String> p = new java.util.HashMap<>();
     c.getProperties(p, all);
     assertEquals(Property.MASTER_CLIENTPORT.getDefaultValue(), p.get(Property.MASTER_CLIENTPORT.getKey()));
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/conf/PropertyTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/conf/PropertyTest.java b/core/src/test/java/org/apache/accumulo/core/conf/PropertyTest.java
index 297f5f8..79f2f21 100644
--- a/core/src/test/java/org/apache/accumulo/core/conf/PropertyTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/conf/PropertyTest.java
@@ -36,12 +36,12 @@ import org.junit.Test;
 public class PropertyTest {
   @Test
   public void testProperties() {
-    HashSet<String> validPrefixes = new HashSet<String>();
+    HashSet<String> validPrefixes = new HashSet<>();
     for (Property prop : Property.values())
       if (prop.getType().equals(PropertyType.PREFIX))
         validPrefixes.add(prop.getKey());
 
-    HashSet<String> propertyNames = new HashSet<String>();
+    HashSet<String> propertyNames = new HashSet<>();
     for (Property prop : Property.values()) {
       // make sure properties default values match their type
       if (prop.getType() == PropertyType.PREFIX) {
@@ -72,7 +72,7 @@ public class PropertyTest {
 
   @Test
   public void testPorts() {
-    HashSet<Integer> usedPorts = new HashSet<Integer>();
+    HashSet<Integer> usedPorts = new HashSet<>();
     for (Property prop : Property.values())
       if (prop.getType().equals(PropertyType.PORT)) {
         int port = Integer.parseInt(prop.getDefaultValue());
@@ -98,7 +98,7 @@ public class PropertyTest {
 
   @Test
   public void testSensitiveKeys() {
-    final TreeMap<String,String> extras = new TreeMap<String,String>();
+    final TreeMap<String,String> extras = new TreeMap<>();
     extras.put("trace.token.property.blah", "something");
 
     AccumuloConfiguration conf = new DefaultConfiguration() {
@@ -126,14 +126,14 @@ public class PropertyTest {
         };
       }
     };
-    TreeSet<String> expected = new TreeSet<String>();
+    TreeSet<String> expected = new TreeSet<>();
     for (Entry<String,String> entry : conf) {
       String key = entry.getKey();
       if (key.equals(Property.INSTANCE_SECRET.getKey()) || key.toLowerCase().contains("password") || key.toLowerCase().endsWith("secret")
           || key.startsWith(Property.TRACE_TOKEN_PROPERTY_PREFIX.getKey()))
         expected.add(key);
     }
-    TreeSet<String> actual = new TreeSet<String>();
+    TreeSet<String> actual = new TreeSet<>();
     for (Entry<String,String> entry : conf) {
       String key = entry.getKey();
       if (Property.isSensitive(key))

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/conf/SiteConfigurationTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/conf/SiteConfigurationTest.java b/core/src/test/java/org/apache/accumulo/core/conf/SiteConfigurationTest.java
index a0d48b9..f89dbfa 100644
--- a/core/src/test/java/org/apache/accumulo/core/conf/SiteConfigurationTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/conf/SiteConfigurationTest.java
@@ -66,7 +66,7 @@ public class SiteConfigurationTest {
 
     EasyMock.replay(siteCfg);
 
-    Map<String,String> props = new HashMap<String,String>();
+    Map<String,String> props = new HashMap<>();
     Predicate<String> all = Predicates.alwaysTrue();
     siteCfg.getProperties(props, all);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/data/KeyExtentTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/data/KeyExtentTest.java b/core/src/test/java/org/apache/accumulo/core/data/KeyExtentTest.java
index 724bfee..79968be 100644
--- a/core/src/test/java/org/apache/accumulo/core/data/KeyExtentTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/data/KeyExtentTest.java
@@ -52,7 +52,7 @@ public class KeyExtentTest {
 
   @Before
   public void setup() {
-    set0 = new TreeSet<KeyExtent>();
+    set0 = new TreeSet<>();
   }
 
   @Test
@@ -90,7 +90,7 @@ public class KeyExtentTest {
     assertNull(KeyExtent.findContainingExtent(nke("t", "1", null), set0));
     assertNull(KeyExtent.findContainingExtent(nke("t", null, "0"), set0));
 
-    TreeSet<KeyExtent> set1 = new TreeSet<KeyExtent>();
+    TreeSet<KeyExtent> set1 = new TreeSet<>();
 
     set1.add(nke("t", null, null));
 
@@ -99,7 +99,7 @@ public class KeyExtentTest {
     assertEquals(nke("t", null, null), KeyExtent.findContainingExtent(nke("t", "1", null), set1));
     assertEquals(nke("t", null, null), KeyExtent.findContainingExtent(nke("t", null, "0"), set1));
 
-    TreeSet<KeyExtent> set2 = new TreeSet<KeyExtent>();
+    TreeSet<KeyExtent> set2 = new TreeSet<>();
 
     set2.add(nke("t", "g", null));
     set2.add(nke("t", null, "g"));
@@ -123,7 +123,7 @@ public class KeyExtentTest {
     assertEquals(nke("t", null, "g"), KeyExtent.findContainingExtent(nke("t", "z", "h"), set2));
     assertEquals(nke("t", null, "g"), KeyExtent.findContainingExtent(nke("t", null, "h"), set2));
 
-    TreeSet<KeyExtent> set3 = new TreeSet<KeyExtent>();
+    TreeSet<KeyExtent> set3 = new TreeSet<>();
 
     set3.add(nke("t", "g", null));
     set3.add(nke("t", "s", "g"));
@@ -149,7 +149,7 @@ public class KeyExtentTest {
     assertEquals(nke("t", "g", null), KeyExtent.findContainingExtent(nke("t", "f", null), set3));
     assertNull(KeyExtent.findContainingExtent(nke("t", "h", null), set3));
 
-    TreeSet<KeyExtent> set4 = new TreeSet<KeyExtent>();
+    TreeSet<KeyExtent> set4 = new TreeSet<>();
 
     set4.add(nke("t1", "d", null));
     set4.add(nke("t1", "q", "d"));
@@ -185,14 +185,14 @@ public class KeyExtentTest {
 
   @Test
   public void testOverlaps() {
-    SortedMap<KeyExtent,Object> set0 = new TreeMap<KeyExtent,Object>();
+    SortedMap<KeyExtent,Object> set0 = new TreeMap<>();
     set0.put(nke("a", null, null), null);
 
     // Nothing overlaps with the empty set
     assertFalse(overlaps(nke("t", null, null), null));
     assertFalse(overlaps(nke("t", null, null), set0));
 
-    SortedMap<KeyExtent,Object> set1 = new TreeMap<KeyExtent,Object>();
+    SortedMap<KeyExtent,Object> set1 = new TreeMap<>();
 
     // Everything overlaps with the infinite range
     set1.put(nke("t", null, null), null);
@@ -206,7 +206,7 @@ public class KeyExtentTest {
     assertTrue(overlaps(nke("t", null, "a"), set1));
 
     // simple overlaps
-    SortedMap<KeyExtent,Object> set2 = new TreeMap<KeyExtent,Object>();
+    SortedMap<KeyExtent,Object> set2 = new TreeMap<>();
     set2.put(nke("a", null, null), null);
     set2.put(nke("t", "m", "j"), null);
     set2.put(nke("z", null, null), null);
@@ -225,7 +225,7 @@ public class KeyExtentTest {
     assertFalse(overlaps(nke("t", null, "m"), set2));
 
     // infinite overlaps
-    SortedMap<KeyExtent,Object> set3 = new TreeMap<KeyExtent,Object>();
+    SortedMap<KeyExtent,Object> set3 = new TreeMap<>();
     set3.put(nke("t", "j", null), null);
     set3.put(nke("t", null, "m"), null);
     assertTrue(overlaps(nke("t", "k", "a"), set3));
@@ -237,7 +237,7 @@ public class KeyExtentTest {
     // falls between
     assertFalse(overlaps(nke("t", "l", "k"), set3));
 
-    SortedMap<KeyExtent,Object> set4 = new TreeMap<KeyExtent,Object>();
+    SortedMap<KeyExtent,Object> set4 = new TreeMap<>();
     set4.put(nke("t", null, null), null);
     assertTrue(overlaps(nke("t", "k", "a"), set4));
     assertTrue(overlaps(nke("t", "k", null), set4));

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/data/KeyTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/data/KeyTest.java b/core/src/test/java/org/apache/accumulo/core/data/KeyTest.java
index 9cee691..c94c6b4 100644
--- a/core/src/test/java/org/apache/accumulo/core/data/KeyTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/data/KeyTest.java
@@ -141,7 +141,7 @@ public class KeyTest {
 
   @Test
   public void testCompressDecompress() {
-    List<KeyValue> kvs = new ArrayList<KeyValue>();
+    List<KeyValue> kvs = new ArrayList<>();
     kvs.add(new KeyValue(new Key(), new byte[] {}));
     kvs.add(new KeyValue(new Key("r"), new byte[] {}));
     kvs.add(new KeyValue(new Key("r", "cf"), new byte[] {}));

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/data/OldMutation.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/data/OldMutation.java b/core/src/test/java/org/apache/accumulo/core/data/OldMutation.java
index a40f4e0..5e7d7bd 100644
--- a/core/src/test/java/org/apache/accumulo/core/data/OldMutation.java
+++ b/core/src/test/java/org/apache/accumulo/core/data/OldMutation.java
@@ -221,7 +221,7 @@ public class OldMutation implements Writable {
       put(val);
     } else {
       if (values == null)
-        values = new ArrayList<byte[]>();
+        values = new ArrayList<>();
       byte copy[] = new byte[val.length];
       System.arraycopy(val, 0, copy, 0, val.length);
       values.add(copy);
@@ -428,7 +428,7 @@ public class OldMutation implements Writable {
     if (!valuesPresent) {
       values = null;
     } else {
-      values = new ArrayList<byte[]>();
+      values = new ArrayList<>();
       int numValues = in.readInt();
       for (int i = 0; i < numValues; i++) {
         len = in.readInt();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/data/RangeTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/data/RangeTest.java b/core/src/test/java/org/apache/accumulo/core/data/RangeTest.java
index 2641ef1..c4837fe 100644
--- a/core/src/test/java/org/apache/accumulo/core/data/RangeTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/data/RangeTest.java
@@ -49,8 +49,8 @@ public class RangeTest extends TestCase {
   }
 
   private void check(List<Range> rl, List<Range> expected) {
-    HashSet<Range> s1 = new HashSet<Range>(rl);
-    HashSet<Range> s2 = new HashSet<Range>(expected);
+    HashSet<Range> s1 = new HashSet<>(rl);
+    HashSet<Range> s2 = new HashSet<>(expected);
 
     assertTrue("got : " + rl + " expected : " + expected, s1.equals(s2));
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/data/ValueTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/data/ValueTest.java b/core/src/test/java/org/apache/accumulo/core/data/ValueTest.java
index 0cae140..93fab1f 100644
--- a/core/src/test/java/org/apache/accumulo/core/data/ValueTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/data/ValueTest.java
@@ -202,7 +202,7 @@ public class ValueTest {
   @Test
   @Deprecated
   public void testToArray() {
-    List<byte[]> l = new java.util.ArrayList<byte[]>();
+    List<byte[]> l = new java.util.ArrayList<>();
     byte[] one = toBytes("one");
     byte[] two = toBytes("two");
     byte[] three = toBytes("three");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/file/BloomFilterLayerLookupTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/file/BloomFilterLayerLookupTest.java b/core/src/test/java/org/apache/accumulo/core/file/BloomFilterLayerLookupTest.java
index 5470722..065438c 100644
--- a/core/src/test/java/org/apache/accumulo/core/file/BloomFilterLayerLookupTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/file/BloomFilterLayerLookupTest.java
@@ -59,12 +59,12 @@ public class BloomFilterLayerLookupTest {
 
   @Test
   public void test() throws IOException {
-    HashSet<Integer> valsSet = new HashSet<Integer>();
+    HashSet<Integer> valsSet = new HashSet<>();
     for (int i = 0; i < 100000; i++) {
       valsSet.add(random.nextInt(Integer.MAX_VALUE));
     }
 
-    ArrayList<Integer> vals = new ArrayList<Integer>(valsSet);
+    ArrayList<Integer> vals = new ArrayList<>(valsSet);
     Collections.sort(vals);
 
     ConfigurationCopy acuconf = new ConfigurationCopy(AccumuloConfiguration.getDefaultConfiguration());

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/file/rfile/CreateCompatTestFile.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/file/rfile/CreateCompatTestFile.java b/core/src/test/java/org/apache/accumulo/core/file/rfile/CreateCompatTestFile.java
index ad29a69..e7c8b46 100644
--- a/core/src/test/java/org/apache/accumulo/core/file/rfile/CreateCompatTestFile.java
+++ b/core/src/test/java/org/apache/accumulo/core/file/rfile/CreateCompatTestFile.java
@@ -32,7 +32,7 @@ import org.apache.hadoop.fs.Path;
 public class CreateCompatTestFile {
 
   public static Set<ByteSequence> ncfs(String... colFams) {
-    HashSet<ByteSequence> cfs = new HashSet<ByteSequence>();
+    HashSet<ByteSequence> cfs = new HashSet<>();
 
     for (String cf : colFams) {
       cfs.add(new ArrayByteSequence(cf));

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileTest.java b/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileTest.java
index a60dfa4..069077c 100644
--- a/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileTest.java
@@ -110,7 +110,7 @@ public class RFileTest {
     }
   }
 
-  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<ByteSequence>();
+  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<>();
 
   @Rule
   public TemporaryFolder tempFolder = new TemporaryFolder(new File(System.getProperty("user.dir") + "/target"));
@@ -373,8 +373,8 @@ public class RFileTest {
 
     int val = 0;
 
-    ArrayList<Key> expectedKeys = new ArrayList<Key>(10000);
-    ArrayList<Value> expectedValues = new ArrayList<Value>(10000);
+    ArrayList<Key> expectedKeys = new ArrayList<>(10000);
+    ArrayList<Value> expectedValues = new ArrayList<>(10000);
 
     for (int row = 0; row < 4; row++) {
       String rowS = nf("r_", row);
@@ -797,7 +797,7 @@ public class RFileTest {
   }
 
   public static Set<ByteSequence> ncfs(String... colFams) {
-    HashSet<ByteSequence> cfs = new HashSet<ByteSequence>();
+    HashSet<ByteSequence> cfs = new HashSet<>();
 
     for (String cf : colFams) {
       cfs.add(new ArrayByteSequence(cf));
@@ -1394,7 +1394,7 @@ public class RFileTest {
   }
 
   private Set<ByteSequence> t18ncfs(int... colFams) {
-    HashSet<ByteSequence> cfs = new HashSet<ByteSequence>();
+    HashSet<ByteSequence> cfs = new HashSet<>();
     for (int i : colFams) {
       cfs.add(new ArrayByteSequence(t18ncf(i)));
     }
@@ -1411,7 +1411,7 @@ public class RFileTest {
   private void t18Verify(Set<ByteSequence> cfs, SortedKeyValueIterator<Key,Value> iter, Reader reader, HashSet<ByteSequence> allCf, int eialg, int eealg)
       throws IOException {
 
-    HashSet<ByteSequence> colFamsSeen = new HashSet<ByteSequence>();
+    HashSet<ByteSequence> colFamsSeen = new HashSet<>();
 
     iter.seek(new Range(), cfs, true);
     assertEquals(eialg, reader.getNumLocalityGroupsSeeked());
@@ -1421,7 +1421,7 @@ public class RFileTest {
       iter.next();
     }
 
-    HashSet<ByteSequence> expected = new HashSet<ByteSequence>(allCf);
+    HashSet<ByteSequence> expected = new HashSet<>(allCf);
     expected.retainAll(cfs);
     assertEquals(expected, colFamsSeen);
 
@@ -1434,7 +1434,7 @@ public class RFileTest {
       iter.next();
     }
 
-    HashSet<ByteSequence> nonExcluded = new HashSet<ByteSequence>(allCf);
+    HashSet<ByteSequence> nonExcluded = new HashSet<>(allCf);
     nonExcluded.removeAll(cfs);
     assertEquals(nonExcluded, colFamsSeen);
   }
@@ -1447,7 +1447,7 @@ public class RFileTest {
 
     trf.openWriter(false);
 
-    HashSet<ByteSequence> allCf = new HashSet<ByteSequence>();
+    HashSet<ByteSequence> allCf = new HashSet<>();
 
     trf.writer.startNewLocalityGroup("lg1", t18ncfs(0));
     for (int i = 0; i < 1; i++)
@@ -1850,7 +1850,7 @@ public class RFileTest {
 
   private static void add(TestRFile trf, Key key, Value val, Hasher dataHasher, List<Entry<Key,Value>> sample, Sampler sampler) throws IOException {
     if (sampler.accept(key)) {
-      sample.add(new AbstractMap.SimpleImmutableEntry<Key,Value>(key, val));
+      sample.add(new AbstractMap.SimpleImmutableEntry<>(key, val));
     }
 
     hash(dataHasher, key, val);
@@ -1862,7 +1862,7 @@ public class RFileTest {
     ArrayList<Entry<Key,Value>> ret = new ArrayList<>();
 
     while (sample.hasTop()) {
-      ret.add(new AbstractMap.SimpleImmutableEntry<Key,Value>(new Key(sample.getTopKey()), new Value(sample.getTopValue())));
+      ret.add(new AbstractMap.SimpleImmutableEntry<>(new Key(sample.getTopKey()), new Value(sample.getTopValue())));
       sample.next();
     }
 
@@ -1929,7 +1929,7 @@ public class RFileTest {
 
       for (int modulus : new int[] {19, 103, 1019}) {
         Hasher dataHasher = Hashing.md5().newHasher();
-        List<Entry<Key,Value>> sampleData = new ArrayList<Entry<Key,Value>>();
+        List<Entry<Key,Value>> sampleData = new ArrayList<>();
 
         ConfigurationCopy sampleConf = new ConfigurationCopy(conf == null ? AccumuloConfiguration.getDefaultConfiguration() : conf);
         sampleConf.set(Property.TABLE_SAMPLER, RowSampler.class.getName());
@@ -2009,8 +2009,8 @@ public class RFileTest {
       RFile.setSampleBufferSize(sampleBufferSize);
 
       for (int modulus : new int[] {19, 103, 1019}) {
-        List<Entry<Key,Value>> sampleDataLG1 = new ArrayList<Entry<Key,Value>>();
-        List<Entry<Key,Value>> sampleDataLG2 = new ArrayList<Entry<Key,Value>>();
+        List<Entry<Key,Value>> sampleDataLG1 = new ArrayList<>();
+        List<Entry<Key,Value>> sampleDataLG2 = new ArrayList<>();
 
         ConfigurationCopy sampleConf = new ConfigurationCopy(conf == null ? AccumuloConfiguration.getDefaultConfiguration() : conf);
         sampleConf.set(Property.TABLE_SAMPLER, RowSampler.class.getName());
@@ -2035,9 +2035,9 @@ public class RFileTest {
           Value v3 = new Value(("" + r * 113).getBytes());
 
           if (sampler.accept(k1)) {
-            sampleDataLG1.add(new AbstractMap.SimpleImmutableEntry<Key,Value>(k1, v1));
-            sampleDataLG1.add(new AbstractMap.SimpleImmutableEntry<Key,Value>(k2, v2));
-            sampleDataLG1.add(new AbstractMap.SimpleImmutableEntry<Key,Value>(k3, v3));
+            sampleDataLG1.add(new AbstractMap.SimpleImmutableEntry<>(k1, v1));
+            sampleDataLG1.add(new AbstractMap.SimpleImmutableEntry<>(k2, v2));
+            sampleDataLG1.add(new AbstractMap.SimpleImmutableEntry<>(k3, v3));
           }
 
           trf.writer.append(k1, v1);
@@ -2054,7 +2054,7 @@ public class RFileTest {
           Value v1 = new Value(("" + r).getBytes());
 
           if (sampler.accept(k1)) {
-            sampleDataLG2.add(new AbstractMap.SimpleImmutableEntry<Key,Value>(k1, v1));
+            sampleDataLG2.add(new AbstractMap.SimpleImmutableEntry<>(k1, v1));
           }
 
           trf.writer.append(k1, v1);
@@ -2076,7 +2076,7 @@ public class RFileTest {
         checkSample(sample, sampleDataLG2, ncfs("metaA", "metaB"), false);
         checkSample(sample, sampleDataLG2, ncfs("dataA"), true);
 
-        ArrayList<Entry<Key,Value>> allSampleData = new ArrayList<Entry<Key,Value>>();
+        ArrayList<Entry<Key,Value>> allSampleData = new ArrayList<>();
         allSampleData.addAll(sampleDataLG1);
         allSampleData.addAll(sampleDataLG2);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/file/rfile/RelativeKeyTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/file/rfile/RelativeKeyTest.java b/core/src/test/java/org/apache/accumulo/core/file/rfile/RelativeKeyTest.java
index 4ca4b6c..4334ccc 100644
--- a/core/src/test/java/org/apache/accumulo/core/file/rfile/RelativeKeyTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/file/rfile/RelativeKeyTest.java
@@ -122,9 +122,9 @@ public class RelativeKeyTest {
     baos = new ByteArrayOutputStream();
     DataOutputStream out = new DataOutputStream(baos);
 
-    expectedKeys = new ArrayList<Key>(initialListSize);
-    expectedValues = new ArrayList<Value>(initialListSize);
-    expectedPositions = new ArrayList<Integer>(initialListSize);
+    expectedKeys = new ArrayList<>(initialListSize);
+    expectedValues = new ArrayList<>(initialListSize);
+    expectedPositions = new ArrayList<>(initialListSize);
 
     Key prev = null;
     int val = 0;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
index e39d0d5..09064a5 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
@@ -39,7 +39,7 @@ import org.junit.Test;
 
 public class AggregatingIteratorTest {
 
-  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<ByteSequence>();
+  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<>();
 
   /**
    * @deprecated since 1.4; visible only for testing
@@ -101,7 +101,7 @@ public class AggregatingIteratorTest {
   @Test
   public void test1() throws IOException {
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     // keys that do not aggregate
     nkv(tm1, 1, 1, 1, 1, false, "2");
@@ -162,7 +162,7 @@ public class AggregatingIteratorTest {
   @SuppressWarnings("deprecation")
   @Test
   public void test2() throws IOException {
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     // keys that aggregate
     nkv(tm1, 1, 1, 1, 1, false, "2");
@@ -171,7 +171,7 @@ public class AggregatingIteratorTest {
 
     AggregatingIterator ai = new AggregatingIterator();
 
-    Map<String,String> opts = new HashMap<String,String>();
+    Map<String,String> opts = new HashMap<>();
 
     opts.put("cf001", SummationAggregator.class.getName());
 
@@ -224,7 +224,7 @@ public class AggregatingIteratorTest {
   @Test
   public void test3() throws IOException {
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     // keys that aggregate
     nkv(tm1, 1, 1, 1, 1, false, "2");
@@ -237,7 +237,7 @@ public class AggregatingIteratorTest {
 
     AggregatingIterator ai = new AggregatingIterator();
 
-    Map<String,String> opts = new HashMap<String,String>();
+    Map<String,String> opts = new HashMap<>();
 
     opts.put("cf001", SummationAggregator.class.getName());
 
@@ -290,7 +290,7 @@ public class AggregatingIteratorTest {
   @Test
   public void test4() throws IOException {
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     // keys that do not aggregate
     nkv(tm1, 0, 0, 1, 1, false, "7");
@@ -306,7 +306,7 @@ public class AggregatingIteratorTest {
 
     AggregatingIterator ai = new AggregatingIterator();
 
-    Map<String,String> opts = new HashMap<String,String>();
+    Map<String,String> opts = new HashMap<>();
 
     opts.put("cf001", SummationAggregator.class.getName());
 
@@ -367,20 +367,20 @@ public class AggregatingIteratorTest {
     // try aggregating across multiple data sets that contain
     // the exact same keys w/ different values
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
     nkv(tm1, 1, 1, 1, 1, false, "2");
 
-    TreeMap<Key,Value> tm2 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm2 = new TreeMap<>();
     nkv(tm2, 1, 1, 1, 1, false, "3");
 
-    TreeMap<Key,Value> tm3 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm3 = new TreeMap<>();
     nkv(tm3, 1, 1, 1, 1, false, "4");
 
     AggregatingIterator ai = new AggregatingIterator();
-    Map<String,String> opts = new HashMap<String,String>();
+    Map<String,String> opts = new HashMap<>();
     opts.put("cf001", SummationAggregator.class.getName());
 
-    List<SortedKeyValueIterator<Key,Value>> sources = new ArrayList<SortedKeyValueIterator<Key,Value>>(3);
+    List<SortedKeyValueIterator<Key,Value>> sources = new ArrayList<>(3);
     sources.add(new SortedMapIterator(tm1));
     sources.add(new SortedMapIterator(tm2));
     sources.add(new SortedMapIterator(tm3));
@@ -397,7 +397,7 @@ public class AggregatingIteratorTest {
   @SuppressWarnings("deprecation")
   @Test
   public void test6() throws IOException {
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     // keys that aggregate
     nkv(tm1, 1, 1, 1, 1, false, "2");
@@ -406,7 +406,7 @@ public class AggregatingIteratorTest {
 
     AggregatingIterator ai = new AggregatingIterator();
 
-    Map<String,String> opts = new HashMap<String,String>();
+    Map<String,String> opts = new HashMap<>();
 
     opts.put("cf001", SummationAggregator.class.getName());
 
@@ -425,7 +425,7 @@ public class AggregatingIteratorTest {
   public void test7() throws IOException {
     // test that delete is not aggregated
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     nkv(tm1, 1, 1, 1, 2, true, "");
     nkv(tm1, 1, 1, 1, 3, false, "4");
@@ -433,7 +433,7 @@ public class AggregatingIteratorTest {
 
     AggregatingIterator ai = new AggregatingIterator();
 
-    Map<String,String> opts = new HashMap<String,String>();
+    Map<String,String> opts = new HashMap<>();
 
     opts.put("cf001", SummationAggregator.class.getName());
 
@@ -453,7 +453,7 @@ public class AggregatingIteratorTest {
     ai.next();
     assertFalse(ai.hasTop());
 
-    tm1 = new TreeMap<Key,Value>();
+    tm1 = new TreeMap<>();
     nkv(tm1, 1, 1, 1, 2, true, "");
     ai = new AggregatingIterator();
     ai.init(new SortedMapIterator(tm1), opts, new DefaultIteratorEnvironment());

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/iterators/FirstEntryInRowIteratorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/FirstEntryInRowIteratorTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/FirstEntryInRowIteratorTest.java
index 5455aa6..34b01bc 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/FirstEntryInRowIteratorTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/FirstEntryInRowIteratorTest.java
@@ -51,12 +51,12 @@ public class FirstEntryInRowIteratorTest {
 
   @Test
   public void test() throws IOException {
-    TreeMap<Key,Value> sourceMap = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> sourceMap = new TreeMap<>();
     Value emptyValue = new Value("".getBytes());
     sourceMap.put(new Key("r1", "cf", "cq"), emptyValue);
     sourceMap.put(new Key("r2", "cf", "cq"), emptyValue);
     sourceMap.put(new Key("r3", "cf", "cq"), emptyValue);
-    TreeMap<Key,Value> resultMap = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> resultMap = new TreeMap<>();
     long numSourceEntries = sourceMap.size();
     long numNexts = process(sourceMap, resultMap, new Range(), 10);
     assertEquals(numNexts, numSourceEntries);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/iterators/FirstEntryInRowTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/FirstEntryInRowTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/FirstEntryInRowTest.java
index 8214c2c..9a5174b 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/FirstEntryInRowTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/FirstEntryInRowTest.java
@@ -34,8 +34,8 @@ import org.apache.hadoop.io.Text;
 import org.junit.Test;
 
 public class FirstEntryInRowTest {
-  private static final Map<String,String> EMPTY_MAP = new HashMap<String,String>();
-  private static final Collection<ByteSequence> EMPTY_SET = new HashSet<ByteSequence>();
+  private static final Map<String,String> EMPTY_MAP = new HashMap<>();
+  private static final Collection<ByteSequence> EMPTY_SET = new HashSet<>();
 
   private Key nk(String row, String cf, String cq, long time) {
     return new Key(new Text(row), new Text(cf), new Text(cq), time);
@@ -73,7 +73,7 @@ public class FirstEntryInRowTest {
 
   @Test
   public void test1() throws Exception {
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
     put(tm1, "r1", "cf1", "cq1", 5, "v1");
     put(tm1, "r1", "cf1", "cq3", 5, "v2");
     put(tm1, "r2", "cf1", "cq1", 5, "v3");
@@ -94,7 +94,7 @@ public class FirstEntryInRowTest {
 
   @Test
   public void test2() throws Exception {
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     for (int r = 0; r < 5; r++) {
       for (int cf = r; cf < 100; cf++) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/iterators/IteratorUtilTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/IteratorUtilTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/IteratorUtilTest.java
index 4c4303c..c9b9dcf 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/IteratorUtilTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/IteratorUtilTest.java
@@ -45,7 +45,7 @@ import org.junit.Test;
 
 public class IteratorUtilTest {
 
-  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<ByteSequence>();
+  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<>();
 
   static class WrappedIter implements SortedKeyValueIterator<Key,Value> {
 
@@ -131,7 +131,7 @@ public class IteratorUtilTest {
     conf.set(Property.TABLE_ITERATOR_PREFIX + IteratorScope.minc.name() + ".addIter", "1," + AddingIter.class.getName());
     conf.set(Property.TABLE_ITERATOR_PREFIX + IteratorScope.minc.name() + ".sqIter", "2," + SquaringIter.class.getName());
 
-    TreeMap<Key,Value> tm = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm = new TreeMap<>();
 
     MultiIteratorTest.nkv(tm, 1, 0, false, "1");
     MultiIteratorTest.nkv(tm, 2, 0, false, "2");
@@ -163,7 +163,7 @@ public class IteratorUtilTest {
     // try loading for a different scope
     AccumuloConfiguration conf = new ConfigurationCopy();
 
-    TreeMap<Key,Value> tm = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm = new TreeMap<>();
 
     MultiIteratorTest.nkv(tm, 1, 0, false, "1");
     MultiIteratorTest.nkv(tm, 2, 0, false, "2");
@@ -196,7 +196,7 @@ public class IteratorUtilTest {
 
     ConfigurationCopy conf = new ConfigurationCopy();
 
-    TreeMap<Key,Value> tm = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm = new TreeMap<>();
 
     MultiIteratorTest.nkv(tm, 1, 0, false, "1");
     MultiIteratorTest.nkv(tm, 2, 0, false, "2");
@@ -235,7 +235,7 @@ public class IteratorUtilTest {
     conf.set(Property.TABLE_ITERATOR_PREFIX + IteratorScope.minc.name() + ".addIter.opt.amount", "7");
     conf.set(Property.TABLE_ITERATOR_PREFIX + IteratorScope.minc.name() + ".sqIter", "2," + SquaringIter.class.getName());
 
-    TreeMap<Key,Value> tm = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm = new TreeMap<>();
 
     MultiIteratorTest.nkv(tm, 1, 0, false, "1");
     MultiIteratorTest.nkv(tm, 2, 0, false, "2");
@@ -271,7 +271,7 @@ public class IteratorUtilTest {
     conf.set(Property.TABLE_ITERATOR_PREFIX + IteratorScope.minc.name() + ".filter.opt.ttl", "100");
     conf.set(Property.TABLE_ITERATOR_PREFIX + IteratorScope.minc.name() + ".filter.opt.currentTime", "1000");
 
-    TreeMap<Key,Value> tm = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm = new TreeMap<>();
 
     MultiIteratorTest.nkv(tm, 1, 850, false, "1");
     MultiIteratorTest.nkv(tm, 2, 950, false, "2");
@@ -292,7 +292,7 @@ public class IteratorUtilTest {
 
   @Test
   public void onlyReadsRelevantIteratorScopeConfigurations() throws Exception {
-    Map<String,String> data = new HashMap<String,String>();
+    Map<String,String> data = new HashMap<>();
 
     // Make some configuration items, one with a bogus scope
     data.put(Property.TABLE_ITERATOR_SCAN_PREFIX + "foo", "50," + SummingCombiner.class.getName());
@@ -302,8 +302,8 @@ public class IteratorUtilTest {
 
     AccumuloConfiguration conf = new ConfigurationCopy(data);
 
-    List<IterInfo> iterators = new ArrayList<IterInfo>();
-    Map<String,Map<String,String>> options = new HashMap<String,Map<String,String>>();
+    List<IterInfo> iterators = new ArrayList<>();
+    Map<String,Map<String,String>> options = new HashMap<>();
 
     IteratorUtil.parseIterConf(IteratorScope.scan, iterators, options, conf);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/iterators/system/ColumnFamilySkippingIteratorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/system/ColumnFamilySkippingIteratorTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/system/ColumnFamilySkippingIteratorTest.java
index fbe7fd5..33c398f 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/system/ColumnFamilySkippingIteratorTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/system/ColumnFamilySkippingIteratorTest.java
@@ -32,7 +32,7 @@ import org.apache.hadoop.io.Text;
 
 public class ColumnFamilySkippingIteratorTest extends TestCase {
 
-  private static final Collection<ByteSequence> EMPTY_SET = new HashSet<ByteSequence>();
+  private static final Collection<ByteSequence> EMPTY_SET = new HashSet<>();
 
   Key nk(String row, String cf, String cq, long time) {
     return new Key(new Text(row), new Text(cf), new Text(cq), time);
@@ -62,7 +62,7 @@ public class ColumnFamilySkippingIteratorTest extends TestCase {
   }
 
   public void test1() throws Exception {
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
     put(tm1, "r1", "cf1", "cq1", 5, "v1");
     put(tm1, "r1", "cf1", "cq3", 5, "v2");
     put(tm1, "r2", "cf1", "cq1", 5, "v3");
@@ -77,14 +77,14 @@ public class ColumnFamilySkippingIteratorTest extends TestCase {
 
     cfi.seek(new Range(), EMPTY_SET, false);
     assertTrue(cfi.hasTop());
-    TreeMap<Key,Value> tm2 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm2 = new TreeMap<>();
     while (cfi.hasTop()) {
       tm2.put(cfi.getTopKey(), cfi.getTopValue());
       cfi.next();
     }
     assertEquals(tm1, tm2);
 
-    HashSet<ByteSequence> colfams = new HashSet<ByteSequence>();
+    HashSet<ByteSequence> colfams = new HashSet<>();
     colfams.add(new ArrayByteSequence("cf2"));
     cfi.seek(new Range(), colfams, true);
     aten(cfi, "r2", "cf2", "cq4", 5, "v4");
@@ -108,7 +108,7 @@ public class ColumnFamilySkippingIteratorTest extends TestCase {
   }
 
   public void test2() throws Exception {
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     for (int r = 0; r < 10; r++) {
       for (int cf = 0; cf < 1000; cf++) {
@@ -118,13 +118,13 @@ public class ColumnFamilySkippingIteratorTest extends TestCase {
       }
     }
 
-    HashSet<ByteSequence> allColfams = new HashSet<ByteSequence>();
+    HashSet<ByteSequence> allColfams = new HashSet<>();
     for (int cf = 0; cf < 1000; cf++) {
       allColfams.add(new ArrayByteSequence(String.format("%06d", cf)));
     }
 
     ColumnFamilySkippingIterator cfi = new ColumnFamilySkippingIterator(new SortedMapIterator(tm1));
-    HashSet<ByteSequence> colfams = new HashSet<ByteSequence>();
+    HashSet<ByteSequence> colfams = new HashSet<>();
 
     runTest(cfi, 30000, 0, allColfams, colfams);
 
@@ -162,11 +162,11 @@ public class ColumnFamilySkippingIteratorTest extends TestCase {
   private void runTest(ColumnFamilySkippingIterator cfi, int total, int expected, HashSet<ByteSequence> allColfams, HashSet<ByteSequence> colfams)
       throws Exception {
     cfi.seek(new Range(), colfams, true);
-    HashSet<ByteSequence> excpected1 = new HashSet<ByteSequence>(colfams);
+    HashSet<ByteSequence> excpected1 = new HashSet<>(colfams);
     excpected1.retainAll(allColfams);
     runTest(cfi, expected, excpected1);
 
-    HashSet<ByteSequence> excpected2 = new HashSet<ByteSequence>(allColfams);
+    HashSet<ByteSequence> excpected2 = new HashSet<>(allColfams);
     excpected2.removeAll(colfams);
     cfi.seek(new Range(), colfams, false);
     runTest(cfi, total - expected, excpected2);
@@ -175,7 +175,7 @@ public class ColumnFamilySkippingIteratorTest extends TestCase {
   private void runTest(ColumnFamilySkippingIterator cfi, int expected, HashSet<ByteSequence> colfams) throws Exception {
     int count = 0;
 
-    HashSet<ByteSequence> ocf = new HashSet<ByteSequence>();
+    HashSet<ByteSequence> ocf = new HashSet<>();
 
     while (cfi.hasTop()) {
       count++;
@@ -189,7 +189,7 @@ public class ColumnFamilySkippingIteratorTest extends TestCase {
 
   public void test3() throws Exception {
     // construct test where ColumnFamilySkippingIterator might try to seek past the end of the user supplied range
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     for (int r = 0; r < 3; r++) {
       for (int cf = 4; cf < 1000; cf++) {
@@ -201,7 +201,7 @@ public class ColumnFamilySkippingIteratorTest extends TestCase {
 
     CountingIterator ci = new CountingIterator(new SortedMapIterator(tm1));
     ColumnFamilySkippingIterator cfi = new ColumnFamilySkippingIterator(ci);
-    HashSet<ByteSequence> colfams = new HashSet<ByteSequence>();
+    HashSet<ByteSequence> colfams = new HashSet<>();
     colfams.add(new ArrayByteSequence(String.format("%06d", 4)));
 
     Range range = new Range(nk(0, 4, 0, 6), true, nk(0, 400, 0, 6), true);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/iterators/system/ColumnFilterTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/system/ColumnFilterTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/system/ColumnFilterTest.java
index 3fd66b4..cfed90f 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/system/ColumnFilterTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/system/ColumnFilterTest.java
@@ -40,7 +40,7 @@ public class ColumnFilterTest extends TestCase {
   }
 
   public void test1() {
-    HashSet<Column> columns = new HashSet<Column>();
+    HashSet<Column> columns = new HashSet<>();
 
     columns.add(nc("cf1"));
 
@@ -52,7 +52,7 @@ public class ColumnFilterTest extends TestCase {
   }
 
   public void test2() {
-    HashSet<Column> columns = new HashSet<Column>();
+    HashSet<Column> columns = new HashSet<>();
 
     columns.add(nc("cf1"));
     columns.add(nc("cf2", "cq1"));
@@ -65,7 +65,7 @@ public class ColumnFilterTest extends TestCase {
   }
 
   public void test3() {
-    HashSet<Column> columns = new HashSet<Column>();
+    HashSet<Column> columns = new HashSet<>();
 
     columns.add(nc("cf2", "cq1"));
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/iterators/system/DeletingIteratorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/system/DeletingIteratorTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/system/DeletingIteratorTest.java
index 4fd48d5..9082a36 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/system/DeletingIteratorTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/system/DeletingIteratorTest.java
@@ -33,7 +33,7 @@ import org.apache.hadoop.io.Text;
 
 public class DeletingIteratorTest extends TestCase {
 
-  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<ByteSequence>();
+  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<>();
 
   public void test1() {
     Text colf = new Text("a");
@@ -42,7 +42,7 @@ public class DeletingIteratorTest extends TestCase {
     Value dvDel = new Value("old".getBytes());
     Value dvNew = new Value("new".getBytes());
 
-    TreeMap<Key,Value> tm = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm = new TreeMap<>();
     Key k;
 
     for (int i = 0; i < 2; i++) {
@@ -67,7 +67,7 @@ public class DeletingIteratorTest extends TestCase {
       DeletingIterator it = new DeletingIterator(new SortedMapIterator(tm), false);
       it.seek(new Range(), EMPTY_COL_FAMS, false);
 
-      TreeMap<Key,Value> tmOut = new TreeMap<Key,Value>();
+      TreeMap<Key,Value> tmOut = new TreeMap<>();
       while (it.hasTop()) {
         tmOut.put(it.getTopKey(), it.getTopValue());
         it.next();
@@ -88,7 +88,7 @@ public class DeletingIteratorTest extends TestCase {
     try {
       DeletingIterator it = new DeletingIterator(new SortedMapIterator(tm), true);
       it.seek(new Range(), EMPTY_COL_FAMS, false);
-      TreeMap<Key,Value> tmOut = new TreeMap<Key,Value>();
+      TreeMap<Key,Value> tmOut = new TreeMap<>();
       while (it.hasTop()) {
         tmOut.put(it.getTopKey(), it.getTopValue());
         it.next();
@@ -115,7 +115,7 @@ public class DeletingIteratorTest extends TestCase {
 
   // seek test
   public void test2() throws IOException {
-    TreeMap<Key,Value> tm = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm = new TreeMap<>();
 
     nkv(tm, "r000", 4, false, "v4");
     nkv(tm, "r000", 3, false, "v3");
@@ -165,7 +165,7 @@ public class DeletingIteratorTest extends TestCase {
 
   // test delete with same timestamp as existing key
   public void test3() throws IOException {
-    TreeMap<Key,Value> tm = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm = new TreeMap<>();
 
     nkv(tm, "r000", 3, false, "v3");
     nkv(tm, "r000", 2, false, "v2");
@@ -190,7 +190,7 @@ public class DeletingIteratorTest extends TestCase {
 
   // test range inclusiveness
   public void test4() throws IOException {
-    TreeMap<Key,Value> tm = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm = new TreeMap<>();
 
     nkv(tm, "r000", 3, false, "v3");
     nkv(tm, "r000", 2, false, "v2");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/iterators/system/MultiIteratorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/system/MultiIteratorTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/system/MultiIteratorTest.java
index bbf87e5..8949c92 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/system/MultiIteratorTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/system/MultiIteratorTest.java
@@ -36,7 +36,7 @@ import junit.framework.TestCase;
 
 public class MultiIteratorTest extends TestCase {
 
-  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<ByteSequence>();
+  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<>();
 
   public static Key nk(int row, long ts) {
     return new Key(nr(row), ts);
@@ -57,7 +57,7 @@ public class MultiIteratorTest extends TestCase {
   }
 
   void verify(int start, int end, Key seekKey, Text endRow, Text prevEndRow, boolean init, boolean incrRow, List<TreeMap<Key,Value>> maps) throws IOException {
-    List<SortedKeyValueIterator<Key,Value>> iters = new ArrayList<SortedKeyValueIterator<Key,Value>>(maps.size());
+    List<SortedKeyValueIterator<Key,Value>> iters = new ArrayList<>(maps.size());
 
     for (TreeMap<Key,Value> map : maps) {
       iters.add(new SortedMapIterator(map));
@@ -121,14 +121,14 @@ public class MultiIteratorTest extends TestCase {
   public void test1() throws IOException {
     // TEST non overlapping inputs
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
-    List<TreeMap<Key,Value>> tmpList = new ArrayList<TreeMap<Key,Value>>(2);
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
+    List<TreeMap<Key,Value>> tmpList = new ArrayList<>(2);
 
     for (int i = 0; i < 4; i++) {
       nkv(tm1, 0, i, false, "v" + i);
     }
     tmpList.add(tm1);
-    tm1 = new TreeMap<Key,Value>();
+    tm1 = new TreeMap<>();
     for (int i = 4; i < 8; i++) {
       nkv(tm1, 0, i, false, "v" + i);
     }
@@ -144,9 +144,9 @@ public class MultiIteratorTest extends TestCase {
   public void test2() throws IOException {
     // TEST overlapping inputs
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
-    TreeMap<Key,Value> tm2 = new TreeMap<Key,Value>();
-    List<TreeMap<Key,Value>> tmpList = new ArrayList<TreeMap<Key,Value>>(2);
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
+    TreeMap<Key,Value> tm2 = new TreeMap<>();
+    List<TreeMap<Key,Value>> tmpList = new ArrayList<>(2);
 
     for (int i = 0; i < 8; i++) {
       if (i % 2 == 0)
@@ -167,8 +167,8 @@ public class MultiIteratorTest extends TestCase {
   public void test3() throws IOException {
     // TEST single input
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
-    List<TreeMap<Key,Value>> tmpList = new ArrayList<TreeMap<Key,Value>>(2);
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
+    List<TreeMap<Key,Value>> tmpList = new ArrayList<>(2);
 
     for (int i = 0; i < 8; i++) {
       nkv(tm1, 0, i, false, "v" + i);
@@ -186,9 +186,9 @@ public class MultiIteratorTest extends TestCase {
   public void test4() throws IOException {
     // TEST empty input
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
-    List<SortedKeyValueIterator<Key,Value>> skvil = new ArrayList<SortedKeyValueIterator<Key,Value>>(1);
+    List<SortedKeyValueIterator<Key,Value>> skvil = new ArrayList<>(1);
     skvil.add(new SortedMapIterator(tm1));
     MultiIterator mi = new MultiIterator(skvil, true);
 
@@ -201,9 +201,9 @@ public class MultiIteratorTest extends TestCase {
   public void test5() throws IOException {
     // TEST overlapping inputs AND prevRow AND endRow AND seek
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
-    TreeMap<Key,Value> tm2 = new TreeMap<Key,Value>();
-    List<TreeMap<Key,Value>> tmpList = new ArrayList<TreeMap<Key,Value>>(2);
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
+    TreeMap<Key,Value> tm2 = new TreeMap<>();
+    List<TreeMap<Key,Value>> tmpList = new ArrayList<>(2);
 
     for (int i = 0; i < 8; i++) {
       if (i % 2 == 0)
@@ -257,12 +257,12 @@ public class MultiIteratorTest extends TestCase {
 
   public void test6() throws IOException {
     // TEst setting an endKey
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
     nkv(tm1, 3, 0, false, "1");
     nkv(tm1, 4, 0, false, "2");
     nkv(tm1, 6, 0, false, "3");
 
-    List<SortedKeyValueIterator<Key,Value>> skvil = new ArrayList<SortedKeyValueIterator<Key,Value>>(1);
+    List<SortedKeyValueIterator<Key,Value>> skvil = new ArrayList<>(1);
     skvil.add(new SortedMapIterator(tm1));
     MultiIterator mi = new MultiIterator(skvil, true);
     mi.seek(new Range(null, true, nk(5, 9), false), EMPTY_COL_FAMS, false);
@@ -330,7 +330,7 @@ public class MultiIteratorTest extends TestCase {
 
   public void test7() throws IOException {
     // TEst setting an endKey
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
     nkv(tm1, 0, 3, false, "1");
     nkv(tm1, 0, 2, false, "2");
     nkv(tm1, 0, 1, false, "3");
@@ -341,7 +341,7 @@ public class MultiIteratorTest extends TestCase {
     nkv(tm1, 2, 1, false, "8");
     nkv(tm1, 2, 0, false, "9");
 
-    List<SortedKeyValueIterator<Key,Value>> skvil = new ArrayList<SortedKeyValueIterator<Key,Value>>(1);
+    List<SortedKeyValueIterator<Key,Value>> skvil = new ArrayList<>(1);
     skvil.add(new SortedMapIterator(tm1));
 
     KeyExtent extent = new KeyExtent("tablename", nr(1), nr(0));

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/iterators/system/SourceSwitchingIteratorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/system/SourceSwitchingIteratorTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/system/SourceSwitchingIteratorTest.java
index 7567871..1ebf9df 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/system/SourceSwitchingIteratorTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/system/SourceSwitchingIteratorTest.java
@@ -60,7 +60,7 @@ public class SourceSwitchingIteratorTest extends TestCase {
 
     DataSource next;
     SortedKeyValueIterator<Key,Value> iter;
-    List<TestDataSource> copies = new ArrayList<TestDataSource>();
+    List<TestDataSource> copies = new ArrayList<>();
     AtomicBoolean iflag;
 
     TestDataSource(SortedKeyValueIterator<Key,Value> iter) {
@@ -111,7 +111,7 @@ public class SourceSwitchingIteratorTest extends TestCase {
   }
 
   public void test1() throws Exception {
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
     put(tm1, "r1", "cf1", "cq1", 5, "v1");
     put(tm1, "r1", "cf1", "cq3", 5, "v2");
     put(tm1, "r2", "cf1", "cq1", 5, "v3");
@@ -128,7 +128,7 @@ public class SourceSwitchingIteratorTest extends TestCase {
   }
 
   public void test2() throws Exception {
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
     put(tm1, "r1", "cf1", "cq1", 5, "v1");
     put(tm1, "r1", "cf1", "cq3", 5, "v2");
     put(tm1, "r2", "cf1", "cq1", 5, "v3");
@@ -140,7 +140,7 @@ public class SourceSwitchingIteratorTest extends TestCase {
     ssi.seek(new Range(), new ArrayList<ByteSequence>(), false);
     ane(ssi, "r1", "cf1", "cq1", 5, "v1", true);
 
-    TreeMap<Key,Value> tm2 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm2 = new TreeMap<>();
     put(tm2, "r1", "cf1", "cq1", 5, "v4");
     put(tm2, "r1", "cf1", "cq3", 5, "v5");
     put(tm2, "r2", "cf1", "cq1", 5, "v6");
@@ -157,7 +157,7 @@ public class SourceSwitchingIteratorTest extends TestCase {
   public void test3() throws Exception {
     // test switching after a row
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
     put(tm1, "r1", "cf1", "cq1", 5, "v1");
     put(tm1, "r1", "cf1", "cq2", 5, "v2");
     put(tm1, "r1", "cf1", "cq3", 5, "v3");
@@ -172,7 +172,7 @@ public class SourceSwitchingIteratorTest extends TestCase {
     ssi.seek(new Range(), new ArrayList<ByteSequence>(), false);
     ane(ssi, "r1", "cf1", "cq1", 5, "v1", true);
 
-    TreeMap<Key,Value> tm2 = new TreeMap<Key,Value>(tm1);
+    TreeMap<Key,Value> tm2 = new TreeMap<>(tm1);
     put(tm2, "r1", "cf1", "cq5", 5, "v7"); // should not see this because it should not switch until the row is finished
     put(tm2, "r2", "cf1", "cq1", 5, "v8"); // should see this new row after it switches
 
@@ -192,7 +192,7 @@ public class SourceSwitchingIteratorTest extends TestCase {
 
   public void test4() throws Exception {
     // ensure switch is done on initial seek
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
     put(tm1, "r1", "cf1", "cq1", 5, "v1");
     put(tm1, "r1", "cf1", "cq2", 5, "v2");
 
@@ -200,7 +200,7 @@ public class SourceSwitchingIteratorTest extends TestCase {
     TestDataSource tds = new TestDataSource(smi);
     SourceSwitchingIterator ssi = new SourceSwitchingIterator(tds, false);
 
-    TreeMap<Key,Value> tm2 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm2 = new TreeMap<>();
     put(tm2, "r1", "cf1", "cq1", 6, "v3");
     put(tm2, "r1", "cf1", "cq2", 6, "v4");
 
@@ -217,7 +217,7 @@ public class SourceSwitchingIteratorTest extends TestCase {
 
   public void test5() throws Exception {
     // esnure switchNow() works w/ deepCopy()
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
     put(tm1, "r1", "cf1", "cq1", 5, "v1");
     put(tm1, "r1", "cf1", "cq2", 5, "v2");
 
@@ -227,7 +227,7 @@ public class SourceSwitchingIteratorTest extends TestCase {
 
     SortedKeyValueIterator<Key,Value> dc1 = ssi.deepCopy(null);
 
-    TreeMap<Key,Value> tm2 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm2 = new TreeMap<>();
     put(tm2, "r1", "cf1", "cq1", 6, "v3");
     put(tm2, "r2", "cf1", "cq2", 6, "v4");
 
@@ -248,7 +248,7 @@ public class SourceSwitchingIteratorTest extends TestCase {
 
   public void testSetInterrupt() throws Exception {
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
     put(tm1, "r1", "cf1", "cq1", 5, "v1");
 
     SortedMapIterator smi = new SortedMapIterator(tm1);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/iterators/system/TimeSettingIteratorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/system/TimeSettingIteratorTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/system/TimeSettingIteratorTest.java
index 3dbe7ca..9a363a1 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/system/TimeSettingIteratorTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/system/TimeSettingIteratorTest.java
@@ -34,7 +34,7 @@ public class TimeSettingIteratorTest {
 
   @Test
   public void test1() throws Exception {
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     tm1.put(new Key("r0", "cf1", "cq1", 9l), new Value("v0".getBytes()));
     tm1.put(new Key("r1", "cf1", "cq1", Long.MAX_VALUE), new Value("v1".getBytes()));
@@ -87,7 +87,7 @@ public class TimeSettingIteratorTest {
 
   @Test
   public void testAvoidKeyCopy() throws Exception {
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
     final Key k = new Key("r0", "cf1", "cq1", 9l);
 
     tm1.put(k, new Value("v0".getBytes()));

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/iterators/system/VisibilityFilterTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/system/VisibilityFilterTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/system/VisibilityFilterTest.java
index 667aa5f..68323c6 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/system/VisibilityFilterTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/system/VisibilityFilterTest.java
@@ -34,7 +34,7 @@ import org.apache.log4j.Logger;
 public class VisibilityFilterTest extends TestCase {
 
   public void testBadVisibility() throws IOException {
-    TreeMap<Key,Value> tm = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm = new TreeMap<>();
 
     tm.put(new Key("r1", "cf1", "cq1", "A&"), new Value(new byte[0]));
     VisibilityFilter filter = new VisibilityFilter(new SortedMapIterator(tm), new Authorizations("A"), "".getBytes());

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/iterators/user/BigDecimalCombinerTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/user/BigDecimalCombinerTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/user/BigDecimalCombinerTest.java
index dfcb869..861ce02 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/user/BigDecimalCombinerTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/user/BigDecimalCombinerTest.java
@@ -42,7 +42,7 @@ import org.junit.Test;
 
 public class BigDecimalCombinerTest {
 
-  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<ByteSequence>();
+  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<>();
   private static double delta = 0.00001;
 
   Encoder<BigDecimal> encoder;
@@ -53,7 +53,7 @@ public class BigDecimalCombinerTest {
   @Before
   public void setup() {
     encoder = new BigDecimalCombiner.BigDecimalEncoder();
-    tm1 = new TreeMap<Key,Value>();
+    tm1 = new TreeMap<>();
     columns = Collections.singletonList(new IteratorSetting.Column("cf001"));
 
     // keys that will aggregate

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/iterators/user/ColumnSliceFilterTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/user/ColumnSliceFilterTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/user/ColumnSliceFilterTest.java
index 11ad192..698d9ec 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/user/ColumnSliceFilterTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/user/ColumnSliceFilterTest.java
@@ -40,9 +40,9 @@ import org.junit.Test;
 
 public class ColumnSliceFilterTest {
 
-  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<ByteSequence>();
+  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<>();
 
-  private static final SortedMap<Key,Value> TEST_DATA = new TreeMap<Key,Value>();
+  private static final SortedMap<Key,Value> TEST_DATA = new TreeMap<>();
   private static final Key KEY_1 = nkv(TEST_DATA, "boo1", "yup", "20080201", "dog");
   private static final Key KEY_2 = nkv(TEST_DATA, "boo1", "yap", "20080202", "cat");
   private static final Key KEY_3 = nkv(TEST_DATA, "boo2", "yap", "20080203", "hamster");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b102e760/core/src/test/java/org/apache/accumulo/core/iterators/user/CombinerTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/user/CombinerTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/user/CombinerTest.java
index a442534..6300532 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/user/CombinerTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/user/CombinerTest.java
@@ -58,7 +58,7 @@ import org.junit.Test;
 
 public class CombinerTest {
 
-  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<ByteSequence>();
+  private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<>();
 
   static class CombinerIteratorEnvironment extends DefaultIteratorEnvironment {
 
@@ -115,7 +115,7 @@ public class CombinerTest {
   public void test1() throws IOException {
     Encoder<Long> encoder = LongCombiner.VAR_LEN_ENCODER;
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     // keys that do not aggregate
     nkv(tm1, 1, 1, 1, 1, false, 2l, encoder);
@@ -180,7 +180,7 @@ public class CombinerTest {
   public void test2() throws IOException {
     Encoder<Long> encoder = LongCombiner.VAR_LEN_ENCODER;
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     // keys that aggregate
     nkv(tm1, 1, 1, 1, 1, false, 2l, encoder);
@@ -242,7 +242,7 @@ public class CombinerTest {
   public void test3() throws IOException {
     Encoder<Long> encoder = LongCombiner.FIXED_LEN_ENCODER;
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     // keys that aggregate
     nkv(tm1, 1, 1, 1, 1, false, 2l, encoder);
@@ -308,7 +308,7 @@ public class CombinerTest {
   public void testDeepCopy() throws IOException {
     Encoder<Long> encoder = LongCombiner.FIXED_LEN_ENCODER;
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     // keys that aggregate
     nkv(tm1, 1, 1, 1, 1, false, 2l, encoder);
@@ -376,7 +376,7 @@ public class CombinerTest {
   public void test4() throws IOException {
     Encoder<Long> encoder = LongCombiner.STRING_ENCODER;
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     // keys that do not aggregate
     nkv(tm1, 0, 0, 1, 1, false, 7l, encoder);
@@ -481,13 +481,13 @@ public class CombinerTest {
     // try aggregating across multiple data sets that contain
     // the exact same keys w/ different values
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
     nkv(tm1, 1, 1, 1, 1, false, 2l, encoder);
 
-    TreeMap<Key,Value> tm2 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm2 = new TreeMap<>();
     nkv(tm2, 1, 1, 1, 1, false, 3l, encoder);
 
-    TreeMap<Key,Value> tm3 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm3 = new TreeMap<>();
     nkv(tm3, 1, 1, 1, 1, false, 4l, encoder);
 
     Combiner ai = new SummingCombiner();
@@ -496,7 +496,7 @@ public class CombinerTest {
     LongCombiner.setEncodingType(is, StringEncoder.class);
     Combiner.setColumns(is, Collections.singletonList(new IteratorSetting.Column("cf001")));
 
-    List<SortedKeyValueIterator<Key,Value>> sources = new ArrayList<SortedKeyValueIterator<Key,Value>>(3);
+    List<SortedKeyValueIterator<Key,Value>> sources = new ArrayList<>(3);
     sources.add(new SortedMapIterator(tm1));
     sources.add(new SortedMapIterator(tm2));
     sources.add(new SortedMapIterator(tm3));
@@ -513,7 +513,7 @@ public class CombinerTest {
   @Test
   public void test6() throws IOException {
     Encoder<Long> encoder = LongCombiner.VAR_LEN_ENCODER;
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     // keys that aggregate
     nkv(tm1, 1, 1, 1, 1, false, 2l, encoder);
@@ -542,7 +542,7 @@ public class CombinerTest {
 
     // test that delete is not aggregated
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     nkv(tm1, 1, 1, 1, 2, true, 0l, encoder);
     nkv(tm1, 1, 1, 1, 3, false, 4l, encoder);
@@ -570,7 +570,7 @@ public class CombinerTest {
     ai.next();
     assertFalse(ai.hasTop());
 
-    tm1 = new TreeMap<Key,Value>();
+    tm1 = new TreeMap<>();
     nkv(tm1, 1, 1, 1, 2, true, 0l, encoder);
     ai = new SummingCombiner();
     ai.init(new SortedMapIterator(tm1), is.getOptions(), SCAN_IE);
@@ -587,7 +587,7 @@ public class CombinerTest {
 
   @Test
   public void valueIteratorTest() throws IOException {
-    TreeMap<Key,Value> tm = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm = new TreeMap<>();
     tm.put(new Key("r", "f", "q", 1), new Value("1".getBytes()));
     tm.put(new Key("r", "f", "q", 2), new Value("2".getBytes()));
     SortedMapIterator smi = new SortedMapIterator(tm);
@@ -600,7 +600,7 @@ public class CombinerTest {
 
   @Test
   public void sumAllColumns() throws IOException {
-    TreeMap<Key,Value> tm = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm = new TreeMap<>();
     tm.put(new Key("r", "count", "a", 1), new Value("1".getBytes()));
     tm.put(new Key("r", "count", "a", 2), new Value("1".getBytes()));
     tm.put(new Key("r", "count", "b", 3), new Value("1".getBytes()));
@@ -636,7 +636,7 @@ public class CombinerTest {
   public void maxMinTest() throws IOException {
     Encoder<Long> encoder = LongCombiner.VAR_LEN_ENCODER;
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     // keys that aggregate
     nkv(tm1, 1, 1, 1, 1, false, 4l, encoder);
@@ -675,7 +675,7 @@ public class CombinerTest {
   }
 
   public static List<Long> nal(Long... longs) {
-    List<Long> al = new ArrayList<Long>(longs.length);
+    List<Long> al = new ArrayList<>(longs.length);
     for (Long l : longs) {
       al.add(l);
     }
@@ -692,7 +692,7 @@ public class CombinerTest {
       IllegalAccessException {
     Encoder<List<Long>> encoder = encoderClass.newInstance();
 
-    TreeMap<Key,Value> tm1 = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> tm1 = new TreeMap<>();
 
     // keys that aggregate
     nkv(tm1, 1, 1, 1, 1, false, nal(1l, 2l), encoder);
@@ -773,11 +773,11 @@ public class CombinerTest {
 
     @Override
     public List<Long> decode(byte[] b) {
-      return new ArrayList<Long>();
+      return new ArrayList<>();
     }
 
     public List<Long> decode(byte[] b, int offset, int len) {
-      return new ArrayList<Long>();
+      return new ArrayList<>();
     }
 
   }
@@ -821,7 +821,7 @@ public class CombinerTest {
   }
 
   private TreeMap<Key,Value> readAll(SortedKeyValueIterator<Key,Value> combiner) throws Exception {
-    TreeMap<Key,Value> ret = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> ret = new TreeMap<>();
 
     combiner.seek(new Range(), EMPTY_COL_FAMS, false);
 
@@ -895,7 +895,7 @@ public class CombinerTest {
   public void testDeleteHandling() throws Exception {
     Encoder<Long> encoder = LongCombiner.STRING_ENCODER;
 
-    TreeMap<Key,Value> input = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> input = new TreeMap<>();
 
     IteratorEnvironment paritalMajcIe = new CombinerIteratorEnvironment(IteratorScope.majc, false);
     IteratorEnvironment fullMajcIe = new CombinerIteratorEnvironment(IteratorScope.majc, true);
@@ -906,7 +906,7 @@ public class CombinerTest {
     nkv(input, 1, 1, 1, 3, false, 2l, encoder);
     nkv(input, 1, 1, 1, 4, false, 9l, encoder);
 
-    TreeMap<Key,Value> expected = new TreeMap<Key,Value>();
+    TreeMap<Key,Value> expected = new TreeMap<>();
     nkv(expected, 1, 1, 1, 1, false, 4l, encoder);
     nkv(expected, 1, 1, 1, 2, true, 0l, encoder);
     nkv(expected, 1, 1, 1, 4, false, 11l, encoder);