You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@accumulo.apache.org by GitBox <gi...@apache.org> on 2018/12/13 19:15:39 UTC

[GitHub] mikewalch closed pull request #827: #820 Fix ITs by using createAccumuloClient

mikewalch closed pull request #827:  #820 Fix ITs by using createAccumuloClient
URL: https://github.com/apache/accumulo/pull/827
 
 
   

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

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

diff --git a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/AccumuloFileOutputFormatIT.java b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/AccumuloFileOutputFormatIT.java
index 225b461e00..1a833b1fdb 100644
--- a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/AccumuloFileOutputFormatIT.java
+++ b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/AccumuloFileOutputFormatIT.java
@@ -82,7 +82,7 @@
 
   @Test
   public void testEmptyWrite() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(EMPTY_TABLE);
       handleWriteTests(false);
     }
@@ -90,7 +90,7 @@ public void testEmptyWrite() throws Exception {
 
   @Test
   public void testRealWrite() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(TEST_TABLE);
       BatchWriter bw = c.createBatchWriter(TEST_TABLE, new BatchWriterConfig());
       Mutation m = new Mutation("Key");
@@ -206,7 +206,7 @@ private void handleWriteTests(boolean content) throws Exception {
 
   @Test
   public void writeBadVisibility() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(BAD_TABLE);
       BatchWriter bw = c.createBatchWriter(BAD_TABLE, new BatchWriterConfig());
       Mutation m = new Mutation("r1");
diff --git a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/AccumuloInputFormatIT.java b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/AccumuloInputFormatIT.java
index ce55953dbc..c79c440651 100644
--- a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/AccumuloInputFormatIT.java
+++ b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/AccumuloInputFormatIT.java
@@ -153,7 +153,7 @@ public static void main(String... args) throws Exception {
   @Test
   public void testMap() throws Exception {
     String table = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(table);
       BatchWriter bw = c.createBatchWriter(table, new BatchWriterConfig());
       for (int i = 0; i < 100; i++) {
@@ -179,7 +179,7 @@ public void testMap() throws Exception {
   public void testSample() throws Exception {
     final String TEST_TABLE_3 = getUniqueNames(1)[0];
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(TEST_TABLE_3,
           new NewTableConfiguration().enableSampling(SAMPLER_CONFIG));
       BatchWriter bw = c.createBatchWriter(TEST_TABLE_3, new BatchWriterConfig());
@@ -215,7 +215,7 @@ public void testCorrectRangeInputSplits() throws Exception {
     Collection<IteratorSetting.Column> fetchColumns = Collections
         .singleton(new IteratorSetting.Column(new Text("foo"), new Text("bar")));
 
-    try (AccumuloClient accumuloClient = getAccumuloClient()) {
+    try (AccumuloClient accumuloClient = createAccumuloClient()) {
       accumuloClient.tableOperations().create(table);
 
       AccumuloInputFormat.configure().clientProperties(getClientInfo().getProperties()).table(table)
diff --git a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/AccumuloRowInputFormatIT.java b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/AccumuloRowInputFormatIT.java
index 58beb78819..d13d0991b6 100644
--- a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/AccumuloRowInputFormatIT.java
+++ b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/AccumuloRowInputFormatIT.java
@@ -188,7 +188,7 @@ public static void main(String[] args) throws Exception {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
       BatchWriter writer = null;
diff --git a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/TokenFileIT.java b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/TokenFileIT.java
index 688146fc89..ed19e57837 100644
--- a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/TokenFileIT.java
+++ b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapred/TokenFileIT.java
@@ -150,7 +150,7 @@ public void testMR() throws Exception {
     String[] tableNames = getUniqueNames(2);
     String table1 = tableNames[0];
     String table2 = tableNames[1];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(table1);
       c.tableOperations().create(table2);
       BatchWriter bw = c.createBatchWriter(table1, new BatchWriterConfig());
diff --git a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloFileOutputFormatIT.java b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloFileOutputFormatIT.java
index f0366110a4..a7dcacbce1 100644
--- a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloFileOutputFormatIT.java
+++ b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloFileOutputFormatIT.java
@@ -83,7 +83,7 @@ public void setup() throws Exception {
     TEST_TABLE = PREFIX + "_mapreduce_test_table";
     EMPTY_TABLE = PREFIX + "_mapreduce_empty_table";
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(EMPTY_TABLE);
       c.tableOperations().create(TEST_TABLE);
       c.tableOperations().create(BAD_TABLE);
diff --git a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloInputFormatIT.java b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloInputFormatIT.java
index b0d8cef04c..8b701a8fb5 100644
--- a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloInputFormatIT.java
+++ b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloInputFormatIT.java
@@ -62,6 +62,7 @@
 import org.apache.hadoop.mapreduce.lib.output.NullOutputFormat;
 import org.apache.hadoop.util.Tool;
 import org.apache.hadoop.util.ToolRunner;
+import org.junit.After;
 import org.junit.Before;
 import org.junit.Rule;
 import org.junit.Test;
@@ -78,6 +79,7 @@
 public class AccumuloInputFormatIT extends AccumuloClusterHarness {
 
   AccumuloInputFormat inputFormat;
+  AccumuloClient client;
 
   @Override
   protected int defaultTimeoutSeconds() {
@@ -92,6 +94,12 @@ public void configureMiniCluster(MiniAccumuloConfigImpl cfg, Configuration hadoo
   @Before
   public void before() {
     inputFormat = new AccumuloInputFormat();
+    client = createAccumuloClient();
+  }
+
+  @After
+  public void closeClient() {
+    client.close();
   }
 
   @Rule
@@ -103,7 +111,6 @@ public void before() {
    */
   @Test
   public void testGetSplits() throws Exception {
-    AccumuloClient client = getAccumuloClient();
     String table = getUniqueNames(1)[0];
     client.tableOperations().create(table);
     insertData(table, currentTimeMillis());
@@ -204,7 +211,7 @@ public void testGetSplits() throws Exception {
 
   private void insertData(String tableName, long ts)
       throws AccumuloException, TableNotFoundException {
-    BatchWriter bw = getAccumuloClient().createBatchWriter(tableName, null);
+    BatchWriter bw = client.createBatchWriter(tableName, null);
 
     for (int i = 0; i < 10000; i++) {
       String row = String.format("%09d", i);
@@ -319,9 +326,8 @@ public static int main(String[] args) throws Exception {
   public void testMap() throws Exception {
     final String TEST_TABLE_1 = getUniqueNames(1)[0];
 
-    AccumuloClient c = getAccumuloClient();
-    c.tableOperations().create(TEST_TABLE_1);
-    BatchWriter bw = c.createBatchWriter(TEST_TABLE_1, new BatchWriterConfig());
+    client.tableOperations().create(TEST_TABLE_1);
+    BatchWriter bw = client.createBatchWriter(TEST_TABLE_1, new BatchWriterConfig());
     for (int i = 0; i < 100; i++) {
       Mutation m = new Mutation(new Text(String.format("%09x", i + 1)));
       m.put(new Text(), new Text(), new Value(String.format("%09x", i).getBytes()));
@@ -342,10 +348,9 @@ public void testMap() throws Exception {
   public void testSample() throws Exception {
     final String TEST_TABLE_3 = getUniqueNames(1)[0];
 
-    AccumuloClient c = getAccumuloClient();
-    c.tableOperations().create(TEST_TABLE_3,
+    client.tableOperations().create(TEST_TABLE_3,
         new NewTableConfiguration().enableSampling(SAMPLER_CONFIG));
-    BatchWriter bw = c.createBatchWriter(TEST_TABLE_3, new BatchWriterConfig());
+    BatchWriter bw = client.createBatchWriter(TEST_TABLE_3, new BatchWriterConfig());
     for (int i = 0; i < 100; i++) {
       Mutation m = new Mutation(new Text(String.format("%09x", i + 1)));
       m.put(new Text(), new Text(), new Value(String.format("%09x", i).getBytes()));
@@ -375,9 +380,8 @@ public void testSample() throws Exception {
   public void testMapWithBatchScanner() throws Exception {
     final String TEST_TABLE_2 = getUniqueNames(1)[0];
 
-    AccumuloClient c = getAccumuloClient();
-    c.tableOperations().create(TEST_TABLE_2);
-    BatchWriter bw = c.createBatchWriter(TEST_TABLE_2, new BatchWriterConfig());
+    client.tableOperations().create(TEST_TABLE_2);
+    BatchWriter bw = client.createBatchWriter(TEST_TABLE_2, new BatchWriterConfig());
     for (int i = 0; i < 100; i++) {
       Mutation m = new Mutation(new Text(String.format("%09x", i + 1)));
       m.put(new Text(), new Text(), new Value(String.format("%09x", i).getBytes()));
@@ -402,8 +406,7 @@ public void testCorrectRangeInputSplits() throws Exception {
     Collection<Pair<Text,Text>> fetchColumnsText = Collections
         .singleton(new Pair<>(new Text("foo"), new Text("bar")));
 
-    AccumuloClient accumuloClient = getAccumuloClient();
-    accumuloClient.tableOperations().create(table);
+    client.tableOperations().create(table);
 
     InputFormatOptions<Job> opts = AccumuloInputFormat.configure()
         .clientProperties(getClientInfo().getProperties()).table(table).auths(auths);
@@ -430,9 +433,8 @@ public void testCorrectRangeInputSplits() throws Exception {
   @Test
   public void testPartialInputSplitDelegationToConfiguration() throws Exception {
     String table = getUniqueNames(1)[0];
-    AccumuloClient c = getAccumuloClient();
-    c.tableOperations().create(table);
-    BatchWriter bw = c.createBatchWriter(table, new BatchWriterConfig());
+    client.tableOperations().create(table);
+    BatchWriter bw = client.createBatchWriter(table, new BatchWriterConfig());
     for (int i = 0; i < 100; i++) {
       Mutation m = new Mutation(new Text(String.format("%09x", i + 1)));
       m.put(new Text(), new Text(), new Value(String.format("%09x", i).getBytes()));
diff --git a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloOutputFormatIT.java b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloOutputFormatIT.java
index 2fbc1f286c..75b27b154e 100644
--- a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloOutputFormatIT.java
+++ b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloOutputFormatIT.java
@@ -127,7 +127,7 @@ public void testMR() throws Exception {
     String[] tableNames = getUniqueNames(2);
     String table1 = tableNames[0];
     String table2 = tableNames[1];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(table1);
       c.tableOperations().create(table2);
       BatchWriter bw = c.createBatchWriter(table1, new BatchWriterConfig());
diff --git a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloRowInputFormatIT.java b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloRowInputFormatIT.java
index 17c3f6a56b..ccca41c997 100644
--- a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloRowInputFormatIT.java
+++ b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/AccumuloRowInputFormatIT.java
@@ -183,7 +183,7 @@ public static void main(String[] args) throws Exception {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
       BatchWriter writer = null;
diff --git a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/TokenFileIT.java b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/TokenFileIT.java
index c5d7e37853..3abb3b9780 100644
--- a/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/TokenFileIT.java
+++ b/hadoop-mapreduce/src/test/java/org/apache/accumulo/hadoop/its/mapreduce/TokenFileIT.java
@@ -144,7 +144,7 @@ public void testMR() throws Exception {
     String[] tableNames = getUniqueNames(2);
     String table1 = tableNames[0];
     String table2 = tableNames[1];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(table1);
       c.tableOperations().create(table2);
       BatchWriter bw = c.createBatchWriter(table1, new BatchWriterConfig());
diff --git a/test/src/main/java/org/apache/accumulo/harness/AccumuloClusterHarness.java b/test/src/main/java/org/apache/accumulo/harness/AccumuloClusterHarness.java
index 30bb569de2..97afa061c9 100644
--- a/test/src/main/java/org/apache/accumulo/harness/AccumuloClusterHarness.java
+++ b/test/src/main/java/org/apache/accumulo/harness/AccumuloClusterHarness.java
@@ -78,13 +78,12 @@ public boolean isDynamic() {
   private static boolean initialized = false;
 
   protected static AccumuloCluster cluster;
-  protected static AccumuloClient client;
   protected static ClusterType type;
   protected static AccumuloClusterPropertyConfiguration clusterConf;
   protected static TestingKdc krb;
 
   @BeforeClass
-  public static void setUp() throws Exception {
+  public static void setUpHarness() throws Exception {
     clusterConf = AccumuloClusterPropertyConfiguration.get();
     type = clusterConf.getClusterType();
 
@@ -99,13 +98,10 @@ public static void setUp() throws Exception {
   }
 
   @AfterClass
-  public static void tearDownKdc() throws Exception {
+  public static void tearDownHarness() throws Exception {
     if (null != krb) {
       krb.stop();
     }
-    if (client != null) {
-      client.close();
-    }
   }
 
   /**
@@ -188,26 +184,28 @@ public void setupCluster() throws Exception {
           // permissions to)
           UserGroupInformation.loginUserFromKeytab(systemUser.getPrincipal(),
               systemUser.getKeytab().getAbsolutePath());
-          AccumuloClient client = cluster.createAccumuloClient(systemUser.getPrincipal(),
+          AccumuloClient c = cluster.createAccumuloClient(systemUser.getPrincipal(),
               new KerberosToken());
+          c.close();
 
           // Then, log back in as the "root" user and do the grant
           UserGroupInformation.loginUserFromKeytab(rootUser.getPrincipal(),
               rootUser.getKeytab().getAbsolutePath());
-          client = getAccumuloClient();
-
-          // Create the trace table
-          client.tableOperations().create(traceTable);
-
-          // Trace user (which is the same kerberos principal as the system user, but using a normal
-          // KerberosToken) needs
-          // to have the ability to read, write and alter the trace table
-          client.securityOperations().grantTablePermission(systemUser.getPrincipal(), traceTable,
-              TablePermission.READ);
-          client.securityOperations().grantTablePermission(systemUser.getPrincipal(), traceTable,
-              TablePermission.WRITE);
-          client.securityOperations().grantTablePermission(systemUser.getPrincipal(), traceTable,
-              TablePermission.ALTER_TABLE);
+
+          try (AccumuloClient client = createAccumuloClient()) {
+            // Create the trace table
+            client.tableOperations().create(traceTable);
+
+            // Trace user (which is the same kerberos principal as the system user, but using a normal
+            // KerberosToken) needs
+            // to have the ability to read, write and alter the trace table
+            client.securityOperations()
+                .grantTablePermission(systemUser.getPrincipal(), traceTable, TablePermission.READ);
+            client.securityOperations()
+                .grantTablePermission(systemUser.getPrincipal(), traceTable, TablePermission.WRITE);
+            client.securityOperations().grantTablePermission(systemUser.getPrincipal(), traceTable,
+                TablePermission.ALTER_TABLE);
+          }
         }
         break;
       default:
@@ -217,22 +215,26 @@ public void setupCluster() throws Exception {
 
   public void cleanupTables() throws Exception {
     final String tablePrefix = this.getClass().getSimpleName() + "_";
-    final TableOperations tops = getAccumuloClient().tableOperations();
-    for (String table : tops.list()) {
-      if (table.startsWith(tablePrefix)) {
-        log.debug("Removing table {}", table);
-        tops.delete(table);
+    try (AccumuloClient client = createAccumuloClient()) {
+      final TableOperations tops = client.tableOperations();
+      for (String table : tops.list()) {
+        if (table.startsWith(tablePrefix)) {
+          log.debug("Removing table {}", table);
+          tops.delete(table);
+        }
       }
     }
   }
 
   public void cleanupUsers() throws Exception {
     final String userPrefix = this.getClass().getSimpleName();
-    final SecurityOperations secOps = getAccumuloClient().securityOperations();
-    for (String user : secOps.listLocalUsers()) {
-      if (user.startsWith(userPrefix)) {
-        log.info("Dropping local user {}", user);
-        secOps.dropLocalUser(user);
+    try (AccumuloClient client = createAccumuloClient()) {
+      final SecurityOperations secOps = client.securityOperations();
+      for (String user : secOps.listLocalUsers()) {
+        if (user.startsWith(userPrefix)) {
+          log.info("Dropping local user {}", user);
+          secOps.dropLocalUser(user);
+        }
       }
     }
   }
@@ -352,20 +354,17 @@ public static AccumuloClusterConfiguration getClusterConfiguration() {
     return clusterConf;
   }
 
-  public AccumuloClient getAccumuloClient() {
-    if (client == null) {
-      try {
-        String princ = getAdminPrincipal();
-        AuthenticationToken token = getAdminToken();
-        log.debug("Creating client as {} with {}", princ, token);
-        client = cluster.createAccumuloClient(princ, token);
-      } catch (Exception e) {
-        log.error("Could not connect to Accumulo", e);
-        fail("Could not connect to Accumulo: " + e.getMessage());
-        throw new RuntimeException("Could not connect to Accumulo", e);
-      }
+  public AccumuloClient createAccumuloClient() {
+    try {
+      String princ = getAdminPrincipal();
+      AuthenticationToken token = getAdminToken();
+      log.debug("Creating client as {} with {}", princ, token);
+      return cluster.createAccumuloClient(princ, token);
+    } catch (Exception e) {
+      log.error("Could not connect to Accumulo", e);
+      fail("Could not connect to Accumulo: " + e.getMessage());
+      throw new RuntimeException("Could not connect to Accumulo", e);
     }
-    return client;
   }
 
   // TODO Really don't want this here. Will ultimately need to abstract configuration method away
diff --git a/test/src/main/java/org/apache/accumulo/test/BadDeleteMarkersCreatedIT.java b/test/src/main/java/org/apache/accumulo/test/BadDeleteMarkersCreatedIT.java
index 5219fb4211..0a21de715f 100644
--- a/test/src/main/java/org/apache/accumulo/test/BadDeleteMarkersCreatedIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/BadDeleteMarkersCreatedIT.java
@@ -85,7 +85,7 @@ public void getTimeoutFactor() {
 
   @Before
   public void alterConfig() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       InstanceOperations iops = client.instanceOperations();
       Map<String,String> config = iops.getSystemConfiguration();
       gcCycleDelay = config.get(Property.GC_CYCLE_DELAY.getKey());
@@ -96,7 +96,7 @@ public void alterConfig() throws Exception {
     }
     getCluster().getClusterControl().stopAllServers(ServerType.GARBAGE_COLLECTOR);
 
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       ClientInfo info = ClientInfo.from(client.properties());
       ZooCache zcache = new ZooCache(info.getZooKeepers(), info.getZooKeepersSessionTimeOut());
       zcache.clear();
@@ -130,7 +130,7 @@ public void alterConfig() throws Exception {
 
   @After
   public void restoreConfig() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       InstanceOperations iops = c.instanceOperations();
       if (null != gcCycleDelay) {
         iops.setProperty(Property.GC_CYCLE_DELAY.getKey(), gcCycleDelay);
@@ -149,7 +149,7 @@ public void restoreConfig() throws Exception {
   public void test() throws Exception {
     // make a table
     String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       log.info("Creating table to be deleted");
       c.tableOperations().create(tableName);
       final String tableId = c.tableOperations().tableIdMap().get(tableName);
diff --git a/test/src/main/java/org/apache/accumulo/test/BalanceIT.java b/test/src/main/java/org/apache/accumulo/test/BalanceIT.java
index 765b0584b4..12228cbb04 100644
--- a/test/src/main/java/org/apache/accumulo/test/BalanceIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/BalanceIT.java
@@ -37,7 +37,7 @@ public int defaultTimeoutSeconds() {
   @Test
   public void testBalance() throws Exception {
     String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       log.info("Creating table");
       c.tableOperations().create(tableName);
       SortedSet<Text> splits = new TreeSet<>();
diff --git a/test/src/main/java/org/apache/accumulo/test/BatchWriterIT.java b/test/src/main/java/org/apache/accumulo/test/BatchWriterIT.java
index d89d734dac..5d70d16ea6 100644
--- a/test/src/main/java/org/apache/accumulo/test/BatchWriterIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/BatchWriterIT.java
@@ -35,7 +35,7 @@ public int defaultTimeoutSeconds() {
   public void test() throws Exception {
     // call the batchwriter with buffer of size zero
     String table = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(table);
       BatchWriterConfig config = new BatchWriterConfig();
       config.setMaxMemory(0);
diff --git a/test/src/main/java/org/apache/accumulo/test/BatchWriterInTabletServerIT.java b/test/src/main/java/org/apache/accumulo/test/BatchWriterInTabletServerIT.java
index 7b01bff2bb..857dddbf7f 100644
--- a/test/src/main/java/org/apache/accumulo/test/BatchWriterInTabletServerIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/BatchWriterInTabletServerIT.java
@@ -60,7 +60,7 @@ public boolean canRunTest(ClusterType type) {
   public void testNormalWrite() throws Exception {
     String[] uniqueNames = getUniqueNames(2);
     String t1 = uniqueNames[0], t2 = uniqueNames[1];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       int numEntriesToWritePerEntry = 50;
       IteratorSetting itset = BatchWriterIterator.iteratorSetting(6, 0, 15, 1000,
           numEntriesToWritePerEntry, t2, c, getAdminToken(), false, false);
@@ -80,7 +80,7 @@ public void testNormalWrite() throws Exception {
   public void testClearLocatorAndSplitWrite() throws Exception {
     String[] uniqueNames = getUniqueNames(2);
     String t1 = uniqueNames[0], t2 = uniqueNames[1];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       int numEntriesToWritePerEntry = 50;
       IteratorSetting itset = BatchWriterIterator.iteratorSetting(6, 0, 15, 1000,
           numEntriesToWritePerEntry, t2, c, getAdminToken(), true, true);
diff --git a/test/src/main/java/org/apache/accumulo/test/BulkImportSequentialRowsIT.java b/test/src/main/java/org/apache/accumulo/test/BulkImportSequentialRowsIT.java
index 8187d2e31e..69d3273f62 100644
--- a/test/src/main/java/org/apache/accumulo/test/BulkImportSequentialRowsIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/BulkImportSequentialRowsIT.java
@@ -62,7 +62,7 @@ public void configureMiniCluster(MiniAccumuloConfigImpl cfg, Configuration hadoo
   @Test
   public void testBulkImportFailure() throws Exception {
     String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       TableOperations to = client.tableOperations();
       to.create(tableName);
       FileSystem fs = getFileSystem();
diff --git a/test/src/main/java/org/apache/accumulo/test/BulkImportVolumeIT.java b/test/src/main/java/org/apache/accumulo/test/BulkImportVolumeIT.java
index b94baae626..95dc1ca7dc 100644
--- a/test/src/main/java/org/apache/accumulo/test/BulkImportVolumeIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/BulkImportVolumeIT.java
@@ -66,7 +66,7 @@ public void configureMiniCluster(MiniAccumuloConfigImpl cfg, Configuration hadoo
   @Test
   public void testBulkImportFailure() throws Exception {
     String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       client.tableOperations().create(tableName);
       FileSystem fs = getFileSystem();
       Path rootPath = new Path(cluster.getTemporaryPath(), getClass().getName());
diff --git a/test/src/main/java/org/apache/accumulo/test/CleanWalIT.java b/test/src/main/java/org/apache/accumulo/test/CleanWalIT.java
index 30c7d7ce6e..5d06cc7387 100644
--- a/test/src/main/java/org/apache/accumulo/test/CleanWalIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/CleanWalIT.java
@@ -68,7 +68,7 @@ public void configureMiniCluster(MiniAccumuloConfigImpl cfg, Configuration hadoo
 
   @Before
   public void offlineTraceTable() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String traceTable = client.instanceOperations().getSystemConfiguration()
           .get(Property.TRACE_TABLE.getKey());
       if (client.tableOperations().exists(traceTable)) {
@@ -80,7 +80,7 @@ public void offlineTraceTable() throws Exception {
   @After
   public void onlineTraceTable() throws Exception {
     if (null != cluster) {
-      try (AccumuloClient client = getAccumuloClient()) {
+      try (AccumuloClient client = createAccumuloClient()) {
         String traceTable = client.instanceOperations().getSystemConfiguration()
             .get(Property.TRACE_TABLE.getKey());
         if (client.tableOperations().exists(traceTable)) {
@@ -93,7 +93,7 @@ public void onlineTraceTable() throws Exception {
   // test for ACCUMULO-1830
   @Test
   public void test() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
       BatchWriter bw = client.createBatchWriter(tableName, new BatchWriterConfig());
diff --git a/test/src/main/java/org/apache/accumulo/test/ClientSideIteratorIT.java b/test/src/main/java/org/apache/accumulo/test/ClientSideIteratorIT.java
index d4dd5d5c5a..82a2c22340 100644
--- a/test/src/main/java/org/apache/accumulo/test/ClientSideIteratorIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ClientSideIteratorIT.java
@@ -77,7 +77,7 @@ private void checkResults(final Iterable<Entry<Key,Value>> scanner, final List<K
 
   @Before
   public void setupInstance() throws Exception {
-    client = getAccumuloClient();
+    client = createAccumuloClient();
     tableName = getUniqueNames(1)[0];
   }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/CloneIT.java b/test/src/main/java/org/apache/accumulo/test/CloneIT.java
index 379da9cff1..8f9a9389a2 100644
--- a/test/src/main/java/org/apache/accumulo/test/CloneIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/CloneIT.java
@@ -46,7 +46,7 @@
 
   @Test
   public void testNoFiles() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
 
@@ -75,7 +75,7 @@ public void testNoFiles() throws Exception {
 
   @Test
   public void testFilesChange() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
 
@@ -133,7 +133,7 @@ public void testFilesChange() throws Exception {
   // test split where files of children are the same
   @Test
   public void testSplit1() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
 
@@ -177,7 +177,7 @@ public void testSplit1() throws Exception {
   // test split where files of children differ... like majc and split occurred
   @Test
   public void testSplit2() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
 
@@ -255,7 +255,7 @@ private static Mutation createTablet(String tid, String endRow, String prevRow,
   // test two tablets splitting into four
   @Test
   public void testSplit3() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
 
@@ -304,7 +304,7 @@ public void testSplit3() throws Exception {
   // test cloned marker
   @Test
   public void testClonedMarker() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
 
@@ -371,7 +371,7 @@ public void testClonedMarker() throws Exception {
   // test two tablets splitting into four
   @Test
   public void testMerge() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
 
diff --git a/test/src/main/java/org/apache/accumulo/test/ConditionalWriterIT.java b/test/src/main/java/org/apache/accumulo/test/ConditionalWriterIT.java
index 2b65f1b6d7..265b227df4 100644
--- a/test/src/main/java/org/apache/accumulo/test/ConditionalWriterIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ConditionalWriterIT.java
@@ -136,7 +136,7 @@ public static long abs(long l) {
 
   @Before
   public void deleteUsers() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       Set<String> users = client.securityOperations().listLocalUsers();
       ClusterUser user = getUser(0);
       if (users.contains(user.getPrincipal())) {
@@ -148,7 +148,7 @@ public void deleteUsers() throws Exception {
   @Test
   public void testBasic() throws Exception {
 
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
 
       client.tableOperations().create(tableName);
@@ -243,7 +243,7 @@ public void testBasic() throws Exception {
   @Test
   public void testFields() throws Exception {
 
-    try (AccumuloClient client1 = getAccumuloClient()) {
+    try (AccumuloClient client1 = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
 
       String user = null;
@@ -351,7 +351,7 @@ public void testFields() throws Exception {
   public void testBadColVis() throws Exception {
     // test when a user sets a col vis in a condition that can never be seen
 
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
 
       client.tableOperations().create(tableName);
@@ -464,7 +464,7 @@ public void testBadColVis() throws Exception {
   public void testConstraints() throws Exception {
     // ensure constraint violations are properly reported
 
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
 
       client.tableOperations().create(tableName);
@@ -497,7 +497,7 @@ public void testConstraints() throws Exception {
   @Test
   public void testIterators() throws Exception {
 
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
 
       client.tableOperations().create(tableName,
@@ -647,7 +647,7 @@ public void init(SortedKeyValueIterator<Key,Value> source, Map<String,String> op
   public void testTableAndConditionIterators() throws Exception {
 
     // test w/ table that has iterators configured
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
 
       IteratorSetting aiConfig1 = new IteratorSetting(30, "AI1", AddingIterator.class);
@@ -746,7 +746,7 @@ public void testTableAndConditionIterators() throws Exception {
   @Test
   public void testBatch() throws Exception {
 
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
 
       client.tableOperations().create(tableName);
@@ -864,7 +864,7 @@ public void testBatch() throws Exception {
   @Test
   public void testBigBatch() throws Exception {
 
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
 
       client.tableOperations().create(tableName);
@@ -939,7 +939,7 @@ public void testBigBatch() throws Exception {
   @Test
   public void testBatchErrors() throws Exception {
 
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
 
       client.tableOperations().create(tableName);
@@ -1026,7 +1026,7 @@ public void testBatchErrors() throws Exception {
   public void testSameRow() throws Exception {
     // test multiple mutations for same row in same batch
 
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
 
       client.tableOperations().create(tableName);
@@ -1214,7 +1214,7 @@ public void testThreads() throws Exception {
     // test multiple threads using a single conditional writer
 
     String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
 
       client.tableOperations().create(tableName);
 
@@ -1295,7 +1295,7 @@ public void testThreads() throws Exception {
   @Test
   public void testSecurity() throws Exception {
     // test against table user does not have read and/or write permissions for
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String user = null;
 
       // Create a new user
@@ -1361,7 +1361,7 @@ public void testSecurity() throws Exception {
 
   @Test
   public void testTimeout() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
 
       String table = getUniqueNames(1)[0];
 
@@ -1414,7 +1414,7 @@ else if (cf.equals("data") && cq.equals("x"))
   @Test
   public void testDeleteTable() throws Exception {
     String table = getUniqueNames(1)[0];
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
 
       try {
         client.createConditionalWriter(table, new ConditionalWriterConfig());
@@ -1448,7 +1448,7 @@ public void testDeleteTable() throws Exception {
   @Test
   public void testOffline() throws Exception {
     String table = getUniqueNames(1)[0];
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
 
       client.tableOperations().create(table);
 
@@ -1482,7 +1482,7 @@ public void testOffline() throws Exception {
   @Test
   public void testError() throws Exception {
     String table = getUniqueNames(1)[0];
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
 
       client.tableOperations().create(table);
 
@@ -1513,7 +1513,7 @@ public void testError() throws Exception {
   public void testNoConditions() throws AccumuloException, AccumuloSecurityException,
       TableExistsException, TableNotFoundException {
     String table = getUniqueNames(1)[0];
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
 
       client.tableOperations().create(table);
 
@@ -1534,7 +1534,7 @@ public void testTrace() throws Exception {
     // Need to add a getClientConfig() to AccumuloCluster
     Assume.assumeTrue(getClusterType() == ClusterType.MINI);
     Process tracer = null;
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       AccumuloCluster cluster = getCluster();
       MiniAccumuloClusterImpl mac = (MiniAccumuloClusterImpl) cluster;
       if (!client.tableOperations().exists("trace")) {
diff --git a/test/src/main/java/org/apache/accumulo/test/FindMaxIT.java b/test/src/main/java/org/apache/accumulo/test/FindMaxIT.java
index 3415fef930..60467ebf0e 100644
--- a/test/src/main/java/org/apache/accumulo/test/FindMaxIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/FindMaxIT.java
@@ -50,7 +50,7 @@ private static Mutation nm(String row) {
 
   @Test
   public void test1() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
 
       client.tableOperations().create(tableName);
diff --git a/test/src/main/java/org/apache/accumulo/test/ImportExportIT.java b/test/src/main/java/org/apache/accumulo/test/ImportExportIT.java
index 17c52d8d39..cd7491bd90 100644
--- a/test/src/main/java/org/apache/accumulo/test/ImportExportIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ImportExportIT.java
@@ -69,7 +69,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void testExportImportThenScan() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
 
       String[] tableNames = getUniqueNames(2);
       String srcTable = tableNames[0], destTable = tableNames[1];
diff --git a/test/src/main/java/org/apache/accumulo/test/InterruptibleScannersIT.java b/test/src/main/java/org/apache/accumulo/test/InterruptibleScannersIT.java
index a96f8f18e2..abc855f0f3 100644
--- a/test/src/main/java/org/apache/accumulo/test/InterruptibleScannersIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/InterruptibleScannersIT.java
@@ -51,7 +51,7 @@ public void configureMiniCluster(MiniAccumuloConfigImpl cfg, Configuration hadoo
   public void test() throws Exception {
     // make a table
     final String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       client.tableOperations().create(tableName);
 
       // make the world's slowest scanner
diff --git a/test/src/main/java/org/apache/accumulo/test/IsolationAndDeepCopyIT.java b/test/src/main/java/org/apache/accumulo/test/IsolationAndDeepCopyIT.java
index 1e47482e6e..5c704e6a39 100644
--- a/test/src/main/java/org/apache/accumulo/test/IsolationAndDeepCopyIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/IsolationAndDeepCopyIT.java
@@ -45,7 +45,7 @@ public void testBugFix() throws Exception {
     // test bug fox for ACCUMULO-3977
 
     String table = super.getUniqueNames(1)[0];
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
 
       client.tableOperations().create(table);
 
diff --git a/test/src/main/java/org/apache/accumulo/test/KeyValueEqualityIT.java b/test/src/main/java/org/apache/accumulo/test/KeyValueEqualityIT.java
index f536cb01d2..6a5b042707 100644
--- a/test/src/main/java/org/apache/accumulo/test/KeyValueEqualityIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/KeyValueEqualityIT.java
@@ -42,7 +42,7 @@ public int defaultTimeoutSeconds() {
 
   @Test
   public void testEquality() throws Exception {
-    try (AccumuloClient client = this.getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       final BatchWriterConfig config = new BatchWriterConfig();
 
       final String[] tables = getUniqueNames(2);
diff --git a/test/src/main/java/org/apache/accumulo/test/LocatorIT.java b/test/src/main/java/org/apache/accumulo/test/LocatorIT.java
index e57268bf77..50a3e0b92f 100644
--- a/test/src/main/java/org/apache/accumulo/test/LocatorIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/LocatorIT.java
@@ -86,7 +86,7 @@ private static TabletId newTabletId(String tableId, String endRow, String prevRo
 
   @Test
   public void testBasic() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
 
       client.tableOperations().create(tableName);
diff --git a/test/src/main/java/org/apache/accumulo/test/MetaConstraintRetryIT.java b/test/src/main/java/org/apache/accumulo/test/MetaConstraintRetryIT.java
index a27893e7cb..448926cf96 100644
--- a/test/src/main/java/org/apache/accumulo/test/MetaConstraintRetryIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/MetaConstraintRetryIT.java
@@ -40,7 +40,7 @@ public int defaultTimeoutSeconds() {
   // a test for ACCUMULO-3096
   @Test(expected = ConstraintViolationException.class)
   public void test() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       client.securityOperations().grantTablePermission(getAdminPrincipal(), MetadataTable.NAME,
           TablePermission.WRITE);
 
diff --git a/test/src/main/java/org/apache/accumulo/test/MetaSplitIT.java b/test/src/main/java/org/apache/accumulo/test/MetaSplitIT.java
index 7baa8847cf..7c185db1c3 100644
--- a/test/src/main/java/org/apache/accumulo/test/MetaSplitIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/MetaSplitIT.java
@@ -52,7 +52,7 @@ public int defaultTimeoutSeconds() {
   @Before
   public void saveMetadataSplits() throws Exception {
     if (ClusterType.STANDALONE == getClusterType()) {
-      try (AccumuloClient client = getAccumuloClient()) {
+      try (AccumuloClient client = createAccumuloClient()) {
         Collection<Text> splits = client.tableOperations().listSplits(MetadataTable.NAME);
         // We expect a single split
         if (!splits.equals(Arrays.asList(new Text("~")))) {
@@ -71,7 +71,7 @@ public void saveMetadataSplits() throws Exception {
   public void restoreMetadataSplits() throws Exception {
     if (null != metadataSplits) {
       log.info("Restoring split on metadata table");
-      try (AccumuloClient client = getAccumuloClient()) {
+      try (AccumuloClient client = createAccumuloClient()) {
         client.tableOperations().merge(MetadataTable.NAME, null, null);
         client.tableOperations().addSplits(MetadataTable.NAME, new TreeSet<>(metadataSplits));
       }
@@ -80,7 +80,7 @@ public void restoreMetadataSplits() throws Exception {
 
   @Test(expected = AccumuloException.class)
   public void testRootTableSplit() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       SortedSet<Text> splits = new TreeSet<>();
       splits.add(new Text("5"));
       client.tableOperations().addSplits(RootTable.NAME, splits);
@@ -89,7 +89,7 @@ public void testRootTableSplit() throws Exception {
 
   @Test
   public void testRootTableMerge() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       client.tableOperations().merge(RootTable.NAME, null, null);
     }
   }
@@ -104,7 +104,7 @@ private void addSplits(TableOperations opts, String... points) throws Exception
 
   @Test
   public void testMetadataTableSplit() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       TableOperations opts = client.tableOperations();
       for (int i = 1; i <= 10; i++) {
         opts.create(Integer.toString(i));
diff --git a/test/src/main/java/org/apache/accumulo/test/MultiTableBatchWriterIT.java b/test/src/main/java/org/apache/accumulo/test/MultiTableBatchWriterIT.java
index e1b0a9c50d..007ed4d832 100644
--- a/test/src/main/java/org/apache/accumulo/test/MultiTableBatchWriterIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/MultiTableBatchWriterIT.java
@@ -58,7 +58,7 @@ public int defaultTimeoutSeconds() {
 
   @Before
   public void setUpArgs() throws AccumuloException, AccumuloSecurityException {
-    accumuloClient = getAccumuloClient();
+    accumuloClient = createAccumuloClient();
     mtbw = getMultiTableBatchWriter();
   }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/NamespacesIT.java b/test/src/main/java/org/apache/accumulo/test/NamespacesIT.java
index 29fdbeabcb..05c6766d5f 100644
--- a/test/src/main/java/org/apache/accumulo/test/NamespacesIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/NamespacesIT.java
@@ -106,7 +106,7 @@ public void setupConnectorAndNamespace() throws Exception {
     Assume.assumeTrue(ClusterType.MINI == getClusterType());
 
     // prepare a unique namespace and get a new root client for each test
-    c = getAccumuloClient();
+    c = createAccumuloClient();
     namespace = "ns_" + getUniqueNames(1)[0];
   }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/OrIteratorIT.java b/test/src/main/java/org/apache/accumulo/test/OrIteratorIT.java
index 1e9ce63fde..4298bd34ec 100644
--- a/test/src/main/java/org/apache/accumulo/test/OrIteratorIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/OrIteratorIT.java
@@ -59,7 +59,7 @@ public int defaultTimeoutSeconds() {
 
   @Test
   public void testMultipleRowsInTablet() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
 
@@ -101,7 +101,7 @@ public void testMultipleRowsInTablet() throws Exception {
 
   @Test
   public void testMultipleTablets() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
 
@@ -153,7 +153,7 @@ public void testMultipleTablets() throws Exception {
 
   @Test
   public void testSingleLargeRow() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
       client.tableOperations().setProperty(tableName, Property.TABLE_SCAN_MAXMEM.getKey(), "1");
@@ -201,7 +201,7 @@ public void testSingleLargeRow() throws Exception {
 
   @Test
   public void testNoMatchesForTable() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
 
@@ -242,7 +242,7 @@ public void testNoMatchesForTable() throws Exception {
 
   @Test
   public void testNoMatchesInSingleTablet() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
 
@@ -297,7 +297,7 @@ public void testNoMatchesInSingleTablet() throws Exception {
 
   @Test
   public void testResultOrder() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
 
diff --git a/test/src/main/java/org/apache/accumulo/test/RecoveryCompactionsAreFlushesIT.java b/test/src/main/java/org/apache/accumulo/test/RecoveryCompactionsAreFlushesIT.java
index d446b5de51..13b0b1664b 100644
--- a/test/src/main/java/org/apache/accumulo/test/RecoveryCompactionsAreFlushesIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/RecoveryCompactionsAreFlushesIT.java
@@ -61,7 +61,7 @@ public void configureMiniCluster(MiniAccumuloConfigImpl cfg, Configuration hadoo
   public void test() throws Exception {
     // create a table
     String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(tableName);
       c.tableOperations().setProperty(tableName, Property.TABLE_MAJC_RATIO.getKey(), "100");
       c.tableOperations().setProperty(tableName, Property.TABLE_FILE_MAX.getKey(), "3");
diff --git a/test/src/main/java/org/apache/accumulo/test/SampleIT.java b/test/src/main/java/org/apache/accumulo/test/SampleIT.java
index 1169df7c54..c4bd7b935c 100644
--- a/test/src/main/java/org/apache/accumulo/test/SampleIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/SampleIT.java
@@ -124,7 +124,7 @@ public void init(SortedKeyValueIterator<Key,Value> source, Map<String,String> op
   @Test
   public void testBasic() throws Exception {
 
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       String clone = tableName + "_clone";
 
@@ -308,7 +308,7 @@ private void setRange(Range range, List<? extends ScannerBase> scanners) {
 
   @Test
   public void testIterator() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       String clone = tableName + "_clone";
 
@@ -421,7 +421,7 @@ private void setSamplerConfig(SamplerConfiguration sc, ScannerBase... scanners)
   @Test
   public void testSampleNotPresent() throws Exception {
 
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       String clone = tableName + "_clone";
 
diff --git a/test/src/main/java/org/apache/accumulo/test/ScanFlushWithTimeIT.java b/test/src/main/java/org/apache/accumulo/test/ScanFlushWithTimeIT.java
index e13a671f25..deff5872b3 100644
--- a/test/src/main/java/org/apache/accumulo/test/ScanFlushWithTimeIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ScanFlushWithTimeIT.java
@@ -49,7 +49,7 @@
   public void test() throws Exception {
     log.info("Creating table");
     String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(tableName);
       log.info("Adding slow iterator");
       IteratorSetting setting = new IteratorSetting(50, SlowIterator.class);
diff --git a/test/src/main/java/org/apache/accumulo/test/ShellConfigIT.java b/test/src/main/java/org/apache/accumulo/test/ShellConfigIT.java
index 093f72d4e7..aa9d956cb2 100644
--- a/test/src/main/java/org/apache/accumulo/test/ShellConfigIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ShellConfigIT.java
@@ -48,7 +48,7 @@ public int defaultTimeoutSeconds() {
 
   @Before
   public void checkProperty() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       // TABLE_VOLUME_CHOOSER is a valid property that can be updated in ZK, whereas the crypto
       // properties are not.
       // This lets us run this test more generically rather than forcibly needing to update some
@@ -63,7 +63,7 @@ public void checkProperty() throws Exception {
   @After
   public void resetProperty() throws Exception {
     if (null != origPropValue) {
-      try (AccumuloClient client = getAccumuloClient()) {
+      try (AccumuloClient client = createAccumuloClient()) {
         client.instanceOperations().setProperty(PerTableVolumeChooser.TABLE_VOLUME_CHOOSER,
             origPropValue);
       }
diff --git a/test/src/main/java/org/apache/accumulo/test/SplitRecoveryIT.java b/test/src/main/java/org/apache/accumulo/test/SplitRecoveryIT.java
index ac5b5ea001..d4035310b8 100644
--- a/test/src/main/java/org/apache/accumulo/test/SplitRecoveryIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/SplitRecoveryIT.java
@@ -71,7 +71,7 @@ public void test() throws Exception {
 
     String tableName = getUniqueNames(1)[0];
 
-    try (AccumuloClient accumuloClient = getAccumuloClient()) {
+    try (AccumuloClient accumuloClient = createAccumuloClient()) {
       for (int tn = 0; tn < 2; tn++) {
         // create a table and put some data in it
         accumuloClient.tableOperations().create(tableName);
diff --git a/test/src/main/java/org/apache/accumulo/test/TableConfigurationUpdateIT.java b/test/src/main/java/org/apache/accumulo/test/TableConfigurationUpdateIT.java
index 4d772fd532..43cb80f957 100644
--- a/test/src/main/java/org/apache/accumulo/test/TableConfigurationUpdateIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/TableConfigurationUpdateIT.java
@@ -53,7 +53,7 @@ public int defaultTimeoutSeconds() {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       ServerContext context = getCluster().getServerContext();
 
       String table = getUniqueNames(1)[0];
diff --git a/test/src/main/java/org/apache/accumulo/test/TableOperationsIT.java b/test/src/main/java/org/apache/accumulo/test/TableOperationsIT.java
index 0ed1e83d30..259ff58fbe 100644
--- a/test/src/main/java/org/apache/accumulo/test/TableOperationsIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/TableOperationsIT.java
@@ -81,7 +81,7 @@ public int defaultTimeoutSeconds() {
 
   @Before
   public void setup() throws Exception {
-    accumuloClient = getAccumuloClient();
+    accumuloClient = createAccumuloClient();
   }
 
   @After
diff --git a/test/src/main/java/org/apache/accumulo/test/ThriftServerBindsBeforeZooKeeperLockIT.java b/test/src/main/java/org/apache/accumulo/test/ThriftServerBindsBeforeZooKeeperLockIT.java
index 2cb43d6ff2..57c18bf45d 100644
--- a/test/src/main/java/org/apache/accumulo/test/ThriftServerBindsBeforeZooKeeperLockIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ThriftServerBindsBeforeZooKeeperLockIT.java
@@ -132,7 +132,7 @@ public void testMonitorService() throws Exception {
   @Test
   public void testMasterService() throws Exception {
     final MiniAccumuloClusterImpl cluster = (MiniAccumuloClusterImpl) getCluster();
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       final String instanceID = client.getInstanceID();
 
       // Wait for the Master to grab its lock
@@ -200,7 +200,7 @@ public void testMasterService() throws Exception {
   @Test
   public void testGarbageCollectorPorts() throws Exception {
     final MiniAccumuloClusterImpl cluster = (MiniAccumuloClusterImpl) getCluster();
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String instanceID = client.getInstanceID();
 
       // Wait for the Master to grab its lock
diff --git a/test/src/main/java/org/apache/accumulo/test/UserCompactionStrategyIT.java b/test/src/main/java/org/apache/accumulo/test/UserCompactionStrategyIT.java
index 9be76978de..714bb4fe2d 100644
--- a/test/src/main/java/org/apache/accumulo/test/UserCompactionStrategyIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/UserCompactionStrategyIT.java
@@ -73,7 +73,7 @@ public int defaultTimeoutSeconds() {
   @After
   public void checkForDanglingFateLocks() {
     // create an accumulo client even though it's not used in order to enable static stuff
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       assertNotNull(c);
       FunctionalTestUtils.assertNoDanglingFateLocks(getClientContext(), getCluster());
     }
@@ -81,7 +81,7 @@ public void checkForDanglingFateLocks() {
 
   @Test
   public void testDropA() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
 
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
@@ -113,7 +113,7 @@ public void testDropA() throws Exception {
 
   private void testDropNone(Map<String,String> options) throws Exception {
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
 
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
@@ -155,7 +155,7 @@ public void testPerTableClasspath() throws Exception {
 
     // test per-table classpath + user specified compaction strategy
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       File target = new File(System.getProperty("user.dir"), "target");
       assertTrue(target.mkdirs() || target.isDirectory());
@@ -202,7 +202,7 @@ private static File installJar(File destDir, String jarFile) throws IOException
   public void testIterators() throws Exception {
     // test compaction strategy + iterators
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
 
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
@@ -246,7 +246,7 @@ public void testIterators() throws Exception {
 
   @Test
   public void testFileSize() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
 
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
@@ -283,7 +283,7 @@ public void testFileSize() throws Exception {
   public void testConcurrent() throws Exception {
     // two compactions without iterators or strategy should be able to run concurrently
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
 
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
diff --git a/test/src/main/java/org/apache/accumulo/test/UsersIT.java b/test/src/main/java/org/apache/accumulo/test/UsersIT.java
index 3be15f4f80..af6ecc4846 100644
--- a/test/src/main/java/org/apache/accumulo/test/UsersIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/UsersIT.java
@@ -35,7 +35,7 @@
   @Test
   public void testCreateExistingUser() throws Exception {
     ClusterUser user0 = getUser(0);
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       Set<String> currentUsers = client.securityOperations().listLocalUsers();
 
       // Ensure that the user exists
diff --git a/test/src/main/java/org/apache/accumulo/test/YieldScannersIT.java b/test/src/main/java/org/apache/accumulo/test/YieldScannersIT.java
index 93d3c5edeb..473a285e94 100644
--- a/test/src/main/java/org/apache/accumulo/test/YieldScannersIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/YieldScannersIT.java
@@ -62,7 +62,7 @@ public void configureMiniCluster(MiniAccumuloConfigImpl cfg, Configuration hadoo
   public void testScan() throws Exception {
     // make a table
     final String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       client.tableOperations().create(tableName);
       final BatchWriter writer = client.createBatchWriter(tableName, new BatchWriterConfig());
       for (int i = 0; i < 10; i++) {
@@ -117,7 +117,7 @@ public void testScan() throws Exception {
   public void testBatchScan() throws Exception {
     // make a table
     final String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       client.tableOperations().create(tableName);
       final BatchWriter writer = client.createBatchWriter(tableName, new BatchWriterConfig());
       for (int i = 0; i < 10; i++) {
diff --git a/test/src/main/java/org/apache/accumulo/test/ZooKeeperPropertiesIT.java b/test/src/main/java/org/apache/accumulo/test/ZooKeeperPropertiesIT.java
index 4f3e9078af..7a4d17d13e 100644
--- a/test/src/main/java/org/apache/accumulo/test/ZooKeeperPropertiesIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ZooKeeperPropertiesIT.java
@@ -26,7 +26,7 @@
 
   @Test(expected = AccumuloException.class)
   public void testNoFiles() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       // Should throw an error as this property can't be changed in ZooKeeper
       client.instanceOperations().setProperty(Property.GENERAL_RPC_TIMEOUT.getKey(), "60s");
     }
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/AccumuloClientIT.java b/test/src/main/java/org/apache/accumulo/test/functional/AccumuloClientIT.java
index b7119a37fe..a46ca7fbe5 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/AccumuloClientIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/AccumuloClientIT.java
@@ -62,7 +62,7 @@ private static void expectClosed(CloseCheck cc) throws Exception {
   @SuppressWarnings("deprecation")
   @Test
   public void testGetConnectorFromAccumuloClient() throws Exception {
-    AccumuloClient client = getAccumuloClient();
+    AccumuloClient client = createAccumuloClient();
     org.apache.accumulo.core.client.Connector c = org.apache.accumulo.core.client.Connector
         .from(client);
     assertEquals(client.whoami(), c.whoami());
@@ -75,7 +75,7 @@ public void testGetConnectorFromAccumuloClient() throws Exception {
 
   @Test
   public void testAccumuloClientBuilder() throws Exception {
-    AccumuloClient c = getAccumuloClient();
+    AccumuloClient c = createAccumuloClient();
     String instanceName = getClientInfo().getInstanceName();
     String zookeepers = getClientInfo().getZooKeepers();
     final String user = "testuser";
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/AddSplitIT.java b/test/src/main/java/org/apache/accumulo/test/functional/AddSplitIT.java
index da5a41ef63..3baf99cf8b 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/AddSplitIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/AddSplitIT.java
@@ -51,7 +51,7 @@ protected int defaultTimeoutSeconds() {
   public void addSplitTest() throws Exception {
 
     String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(tableName);
 
       insertData(c, tableName, 1L);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/BadIteratorMincIT.java b/test/src/main/java/org/apache/accumulo/test/functional/BadIteratorMincIT.java
index 4112f311b3..3b83086495 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/BadIteratorMincIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/BadIteratorMincIT.java
@@ -47,7 +47,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
 
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/BalanceInPresenceOfOfflineTableIT.java b/test/src/main/java/org/apache/accumulo/test/functional/BalanceInPresenceOfOfflineTableIT.java
index 5050d26fc0..15d9be0f1a 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/BalanceInPresenceOfOfflineTableIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/BalanceInPresenceOfOfflineTableIT.java
@@ -90,7 +90,7 @@ protected int defaultTimeoutSeconds() {
   @Before
   public void setupTables() throws AccumuloException, AccumuloSecurityException,
       TableExistsException, TableNotFoundException {
-    accumuloClient = getAccumuloClient();
+    accumuloClient = createAccumuloClient();
     // Need at least two tservers
     Assume.assumeTrue("Not enough tservers to run test",
         accumuloClient.instanceOperations().getTabletServers().size() >= 2);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/BatchScanSplitIT.java b/test/src/main/java/org/apache/accumulo/test/functional/BatchScanSplitIT.java
index 5f405f0f74..bfe0bb3812 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/BatchScanSplitIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/BatchScanSplitIT.java
@@ -60,7 +60,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
 
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/BatchWriterFlushIT.java b/test/src/main/java/org/apache/accumulo/test/functional/BatchWriterFlushIT.java
index 1dbb667623..aa05064db0 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/BatchWriterFlushIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/BatchWriterFlushIT.java
@@ -67,7 +67,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void run() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String[] tableNames = getUniqueNames(2);
       String bwft = tableNames[0];
       c.tableOperations().create(bwft);
@@ -81,7 +81,7 @@ public void run() throws Exception {
   private void runLatencyTest(AccumuloClient client, String tableName) throws Exception {
     // should automatically flush after 2 seconds
     try (
-        BatchWriter bw = getAccumuloClient().createBatchWriter(tableName,
+        BatchWriter bw = client.createBatchWriter(tableName,
             new BatchWriterConfig().setMaxLatency(1000, TimeUnit.MILLISECONDS));
         Scanner scanner = client.createScanner(tableName, Authorizations.EMPTY)) {
 
@@ -183,7 +183,7 @@ private void runFlushTest(AccumuloClient client, String tableName) throws Accumu
 
   @Test
   public void runMultiThreadedBinningTest() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String[] tableNames = getUniqueNames(1);
       String tableName = tableNames[0];
       c.tableOperations().create(tableName);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/BigRootTabletIT.java b/test/src/main/java/org/apache/accumulo/test/functional/BigRootTabletIT.java
index b1bfe142de..3a26d1fef7 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/BigRootTabletIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/BigRootTabletIT.java
@@ -51,7 +51,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().addSplits(MetadataTable.NAME,
           FunctionalTestUtils.splits("0 1 2 3 4 5 6 7 8 9 a".split(" ")));
       String[] names = getUniqueNames(10);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/BinaryIT.java b/test/src/main/java/org/apache/accumulo/test/functional/BinaryIT.java
index 26b49f3482..8c85f3bc7d 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/BinaryIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/BinaryIT.java
@@ -36,7 +36,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       runTest(c, tableName);
@@ -46,7 +46,7 @@ public void test() throws Exception {
   @Test
   public void testPreSplit() throws Exception {
     String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(tableName);
       SortedSet<Text> splits = new TreeSet<>();
       splits.add(new Text("8"));
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/BinaryStressIT.java b/test/src/main/java/org/apache/accumulo/test/functional/BinaryStressIT.java
index b97e58f574..9b0790067a 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/BinaryStressIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/BinaryStressIT.java
@@ -62,7 +62,7 @@ public void alterConfig() throws Exception {
     if (ClusterType.MINI == getClusterType()) {
       return;
     }
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       InstanceOperations iops = client.instanceOperations();
       Map<String,String> conf = iops.getSystemConfiguration();
       majcDelay = conf.get(Property.TSERV_MAJC_DELAY.getKey());
@@ -79,7 +79,7 @@ public void alterConfig() throws Exception {
   @After
   public void resetConfig() throws Exception {
     if (null != majcDelay) {
-      try (AccumuloClient client = getAccumuloClient()) {
+      try (AccumuloClient client = createAccumuloClient()) {
         InstanceOperations iops = client.instanceOperations();
         iops.setProperty(Property.TSERV_MAJC_DELAY.getKey(), majcDelay);
         iops.setProperty(Property.TSERV_MAXMEM.getKey(), maxMem);
@@ -91,7 +91,7 @@ public void resetConfig() throws Exception {
 
   @Test
   public void binaryStressTest() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       c.tableOperations().setProperty(tableName, Property.TABLE_SPLIT_THRESHOLD.getKey(), "10K");
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/BloomFilterIT.java b/test/src/main/java/org/apache/accumulo/test/functional/BloomFilterIT.java
index 915a9208ee..42f64cfe56 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/BloomFilterIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/BloomFilterIT.java
@@ -70,7 +70,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       final String readAhead = c.instanceOperations().getSystemConfiguration()
           .get(Property.TSERV_SCAN_EXECUTORS_DEFAULT_THREADS.getKey());
       c.instanceOperations().setProperty(Property.TSERV_SCAN_EXECUTORS_DEFAULT_THREADS.getKey(),
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/BulkFileIT.java b/test/src/main/java/org/apache/accumulo/test/functional/BulkFileIT.java
index 26af281c1e..c10f268aef 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/BulkFileIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/BulkFileIT.java
@@ -63,7 +63,7 @@ protected int defaultTimeoutSeconds() {
   @SuppressWarnings("deprecation")
   @Test
   public void testBulkFile() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       SortedSet<Text> splits = new TreeSet<>();
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/BulkIT.java b/test/src/main/java/org/apache/accumulo/test/functional/BulkIT.java
index f01b2ad540..4c80b7033d 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/BulkIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/BulkIT.java
@@ -65,7 +65,7 @@ public void restoreConf() {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       runTest(client, getClientInfo(), getCluster().getFileSystem(),
           getCluster().getTemporaryPath(), getUniqueNames(1)[0], this.getClass().getName(),
           testName.getMethodName(), false);
@@ -74,7 +74,7 @@ public void test() throws Exception {
 
   @Test
   public void testOld() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       runTest(client, getClientInfo(), getCluster().getFileSystem(),
           getCluster().getTemporaryPath(), getUniqueNames(1)[0], this.getClass().getName(),
           testName.getMethodName(), true);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/BulkLoadIT.java b/test/src/main/java/org/apache/accumulo/test/functional/BulkLoadIT.java
index 0c2c25a298..f06612189e 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/BulkLoadIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/BulkLoadIT.java
@@ -102,7 +102,7 @@ protected int defaultTimeoutSeconds() {
 
   @Before
   public void setupBulkTest() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       aconf = getCluster().getServerContext().getConfiguration();
@@ -139,14 +139,14 @@ private void testSingleTabletSingleFile(AccumuloClient c, boolean offline) throw
 
   @Test
   public void testSingleTabletSingleFile() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       testSingleTabletSingleFile(client, false);
     }
   }
 
   @Test
   public void testSingleTabletSingleFileOffline() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       testSingleTabletSingleFile(client, true);
     }
   }
@@ -171,21 +171,21 @@ private void testSingleTabletSingleFileNoSplits(AccumuloClient c, boolean offlin
 
   @Test
   public void testSingleTabletSingleFileNoSplits() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       testSingleTabletSingleFileNoSplits(client, false);
     }
   }
 
   @Test
   public void testSingleTabletSingleFileNoSplitsOffline() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       testSingleTabletSingleFileNoSplits(client, true);
     }
   }
 
   @Test
   public void testBadPermissions() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       addSplits(c, tableName, "0333");
 
       String dir = getDir("/testBadPermissions-");
@@ -220,7 +220,7 @@ public void testBadPermissions() throws Exception {
   }
 
   private void testBulkFile(boolean offline, boolean usePlan) throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       addSplits(c, tableName, "0333 0666 0999 1333 1666");
 
       if (offline)
@@ -297,7 +297,7 @@ public void testLoadPlanOffline() throws Exception {
 
   @Test
   public void testBadLoadPlans() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       addSplits(c, tableName, "0333 0666 0999 1333 1666");
 
       String dir = getDir("/testBulkFile-");
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/BulkSplitOptimizationIT.java b/test/src/main/java/org/apache/accumulo/test/functional/BulkSplitOptimizationIT.java
index 340b827b69..d67b183328 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/BulkSplitOptimizationIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/BulkSplitOptimizationIT.java
@@ -55,7 +55,7 @@ protected int defaultTimeoutSeconds() {
 
   @Before
   public void alterConfig() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       majcDelay = client.instanceOperations().getSystemConfiguration()
           .get(Property.TSERV_MAJC_DELAY.getKey());
       if (!"1s".equals(majcDelay)) {
@@ -69,7 +69,7 @@ public void alterConfig() throws Exception {
   @After
   public void resetConfig() throws Exception {
     if (null != majcDelay) {
-      try (AccumuloClient client = getAccumuloClient()) {
+      try (AccumuloClient client = createAccumuloClient()) {
         client.instanceOperations().setProperty(Property.TSERV_MAJC_DELAY.getKey(), majcDelay);
         getClusterControl().stopAllServers(ServerType.TABLET_SERVER);
         getClusterControl().startAllServers(ServerType.TABLET_SERVER);
@@ -82,7 +82,7 @@ public void resetConfig() throws Exception {
 
   @Test
   public void testBulkSplitOptimization() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       c.tableOperations().setProperty(tableName, Property.TABLE_MAJC_RATIO.getKey(), "1000");
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ChaoticBalancerIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ChaoticBalancerIT.java
index 21b300e42d..07147375aa 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ChaoticBalancerIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ChaoticBalancerIT.java
@@ -53,7 +53,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String[] names = getUniqueNames(1);
       String tableName = names[0];
       NewTableConfiguration ntc = new NewTableConfiguration();
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ClassLoaderIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ClassLoaderIT.java
index fe139df022..8cec4205b3 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ClassLoaderIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ClassLoaderIT.java
@@ -88,7 +88,7 @@ private static void copyStreamToFileSystem(FileSystem fs, String jarName, Path p
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       BatchWriter bw = c.createBatchWriter(tableName, new BatchWriterConfig());
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/CloneTestIT.java b/test/src/main/java/org/apache/accumulo/test/functional/CloneTestIT.java
index 8f4a1a88dc..b0ff80c3f8 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/CloneTestIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/CloneTestIT.java
@@ -71,7 +71,7 @@ public void testProps() throws Exception {
     String table1 = tableNames[0];
     String table2 = tableNames[1];
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
 
       c.tableOperations().create(table1);
 
@@ -205,7 +205,7 @@ public void testDeleteClone() throws Exception {
     String table2 = tableNames[1];
     String table3 = tableNames[2];
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       AccumuloCluster cluster = getCluster();
       Assume.assumeTrue(cluster instanceof MiniAccumuloClusterImpl);
       MiniAccumuloClusterImpl mac = (MiniAccumuloClusterImpl) cluster;
@@ -266,7 +266,7 @@ public void testDeleteClone() throws Exception {
 
   @Test
   public void testCloneWithSplits() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
 
       List<Mutation> mutations = new ArrayList<>();
       TreeSet<Text> splits = new TreeSet<>();
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/CombinerIT.java b/test/src/main/java/org/apache/accumulo/test/functional/CombinerIT.java
index 6f96ef84a9..0ea4e099a7 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/CombinerIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/CombinerIT.java
@@ -57,7 +57,7 @@ private void checkSum(String tableName, AccumuloClient c) throws Exception {
 
   @Test
   public void aggregationTest() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       IteratorSetting setting = new IteratorSetting(10, SummingCombiner.class);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/CompactionIT.java b/test/src/main/java/org/apache/accumulo/test/functional/CompactionIT.java
index f26f0b8df3..f24dc376b5 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/CompactionIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/CompactionIT.java
@@ -73,7 +73,7 @@ protected int defaultTimeoutSeconds() {
   @Before
   public void alterConfig() throws Exception {
     if (ClusterType.STANDALONE == getClusterType()) {
-      try (AccumuloClient client = getAccumuloClient()) {
+      try (AccumuloClient client = createAccumuloClient()) {
         InstanceOperations iops = client.instanceOperations();
         Map<String,String> config = iops.getSystemConfiguration();
         majcThreadMaxOpen = config.get(Property.TSERV_MAJC_THREAD_MAXOPEN.getKey());
@@ -94,7 +94,7 @@ public void alterConfig() throws Exception {
   public void resetConfig() throws Exception {
     // We set the values..
     if (null != majcThreadMaxOpen) {
-      try (AccumuloClient client = getAccumuloClient()) {
+      try (AccumuloClient client = createAccumuloClient()) {
         InstanceOperations iops = client.instanceOperations();
 
         iops.setProperty(Property.TSERV_MAJC_THREAD_MAXOPEN.getKey(), majcThreadMaxOpen);
@@ -109,7 +109,7 @@ public void resetConfig() throws Exception {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       c.tableOperations().setProperty(tableName, Property.TABLE_MAJC_RATIO.getKey(), "1.0");
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ConcurrencyIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ConcurrencyIT.java
index 6bf2d96c3f..20afa56de3 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ConcurrencyIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ConcurrencyIT.java
@@ -98,7 +98,7 @@ protected int defaultTimeoutSeconds() {
   // @formatter:on
   @Test
   public void run() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       runTest(c, getUniqueNames(1)[0]);
     }
   }
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ConcurrentDeleteTableIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ConcurrentDeleteTableIT.java
index 55a941c733..ab0ef6f00b 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ConcurrentDeleteTableIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ConcurrentDeleteTableIT.java
@@ -52,7 +52,7 @@
 
   @Test
   public void testConcurrentDeleteTablesOps() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String[] tables = getUniqueNames(2);
 
       TreeSet<Text> splits = createSplits();
@@ -150,7 +150,7 @@ public void run() {
 
   @Test
   public void testConcurrentFateOpsWithDelete() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String[] tables = getUniqueNames(2);
 
       TreeSet<Text> splits = createSplits();
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ConstraintIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ConstraintIT.java
index 1e6c3bd226..f622ed422e 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ConstraintIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ConstraintIT.java
@@ -57,7 +57,7 @@ protected int defaultTimeoutSeconds() {
   @Test
   public void run() throws Exception {
     String[] tableNames = getUniqueNames(3);
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       for (String table : tableNames) {
         c.tableOperations().create(table);
         c.tableOperations().addConstraint(table, NumericValueConstraint.class.getName());
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/CreateAndUseIT.java b/test/src/main/java/org/apache/accumulo/test/functional/CreateAndUseIT.java
index 602f9bfabc..e52c6808b8 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/CreateAndUseIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/CreateAndUseIT.java
@@ -63,7 +63,7 @@ public static void createData() throws Exception {
   @Test
   public void verifyDataIsPresent() throws Exception {
 
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
 
       Text cf = new Text("cf1");
       Text cq = new Text("cq1");
@@ -98,7 +98,7 @@ public void verifyDataIsPresent() throws Exception {
 
   @Test
   public void createTableAndScan() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String table2 = getUniqueNames(1)[0];
       client.tableOperations().create(table2);
       client.tableOperations().addSplits(table2, splits);
@@ -118,7 +118,7 @@ public void createTableAndScan() throws Exception {
 
   @Test
   public void createTableAndBatchScan() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       ArrayList<Range> ranges = new ArrayList<>();
       for (int i = 1; i < 257; i++) {
         ranges.add(new Range(new Text(String.format("%08x", (i << 8) - 16))));
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/CreateInitialSplitsIT.java b/test/src/main/java/org/apache/accumulo/test/functional/CreateInitialSplitsIT.java
index 1370b312f8..6ea1b4409a 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/CreateInitialSplitsIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/CreateInitialSplitsIT.java
@@ -67,7 +67,7 @@ protected int defaultTimeoutSeconds() {
 
   @Before
   public void setupInitialSplits() {
-    client = getAccumuloClient();
+    client = createAccumuloClient();
   }
 
   @After
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/CreateManyScannersIT.java b/test/src/main/java/org/apache/accumulo/test/functional/CreateManyScannersIT.java
index 69cfa5619d..f38c6d3b7c 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/CreateManyScannersIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/CreateManyScannersIT.java
@@ -30,7 +30,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void run() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       for (int i = 0; i < 100000; i++) {
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/CredentialsIT.java b/test/src/main/java/org/apache/accumulo/test/functional/CredentialsIT.java
index ba6dde0315..7b9d2d9dab 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/CredentialsIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/CredentialsIT.java
@@ -57,7 +57,7 @@ public int defaultTimeoutSeconds() {
 
   @Before
   public void createLocalUser() throws AccumuloException, AccumuloSecurityException {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       ClusterUser user = getUser(0);
       username = user.getPrincipal();
       saslEnabled = saslEnabled();
@@ -81,7 +81,7 @@ public void deleteLocalUser() throws Exception {
       UserGroupInformation.loginUserFromKeytab(root.getPrincipal(),
           root.getKeytab().getAbsolutePath());
     }
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       client.securityOperations().dropLocalUser(username);
     }
   }
@@ -102,7 +102,7 @@ public void testConnectorWithDestroyedToken() throws Exception {
 
   @Test
   public void testDestroyTokenBeforeRPC() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       AuthenticationToken token = getUser(0).getToken();
       try (
           AccumuloClient userAccumuloClient = Accumulo.newClient().from(client.properties())
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/DeleteEverythingIT.java b/test/src/main/java/org/apache/accumulo/test/functional/DeleteEverythingIT.java
index 01b0368e36..92e96d6c3e 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/DeleteEverythingIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/DeleteEverythingIT.java
@@ -62,7 +62,7 @@ protected int defaultTimeoutSeconds() {
 
   @Before
   public void updateMajcDelay() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       majcDelay = c.instanceOperations().getSystemConfiguration()
           .get(Property.TSERV_MAJC_DELAY.getKey());
       c.instanceOperations().setProperty(Property.TSERV_MAJC_DELAY.getKey(), "1s");
@@ -75,14 +75,14 @@ public void updateMajcDelay() throws Exception {
 
   @After
   public void resetMajcDelay() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.instanceOperations().setProperty(Property.TSERV_MAJC_DELAY.getKey(), majcDelay);
     }
   }
 
   @Test
   public void run() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       BatchWriter bw = c.createBatchWriter(tableName, new BatchWriterConfig());
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/DeleteFailIT.java b/test/src/main/java/org/apache/accumulo/test/functional/DeleteFailIT.java
index 63091e122b..8f5fc4489c 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/DeleteFailIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/DeleteFailIT.java
@@ -35,7 +35,7 @@
 
   @Test
   public void testFail() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       NewTableConfiguration ntc = new NewTableConfiguration();
       ntc.setProperties(
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/DeleteIT.java b/test/src/main/java/org/apache/accumulo/test/functional/DeleteIT.java
index 7e10be2876..56151844be 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/DeleteIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/DeleteIT.java
@@ -43,7 +43,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       AuthenticationToken token = getAdminToken();
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/DeleteRowsIT.java b/test/src/main/java/org/apache/accumulo/test/functional/DeleteRowsIT.java
index e01d6d32f8..d27bb3c7ae 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/DeleteRowsIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/DeleteRowsIT.java
@@ -69,7 +69,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test(timeout = 5 * 60 * 1000)
   public void testDeleteAllRows() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String[] tableNames = this.getUniqueNames(20);
       for (String tableName : tableNames) {
         c.tableOperations().create(tableName);
@@ -83,7 +83,7 @@ public void testDeleteAllRows() throws Exception {
 
   @Test
   public void testManyRows() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       // Delete ranges of rows, and verify the tablets are removed.
       int i = 0;
       // Eliminate whole tablets
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/DeleteRowsSplitIT.java b/test/src/main/java/org/apache/accumulo/test/functional/DeleteRowsSplitIT.java
index e935ea7c8b..931bf5bd4e 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/DeleteRowsSplitIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/DeleteRowsSplitIT.java
@@ -67,7 +67,7 @@ public void run() throws Exception {
     // Delete ranges of rows, and verify the are removed
     // Do this while adding many splits
     final String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
 
       // Eliminate whole tablets
       for (int test = 0; test < 10; test++) {
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/DeleteTableDuringSplitIT.java b/test/src/main/java/org/apache/accumulo/test/functional/DeleteTableDuringSplitIT.java
index 5e3ae3746f..f1e889a43b 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/DeleteTableDuringSplitIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/DeleteTableDuringSplitIT.java
@@ -49,7 +49,7 @@ protected int defaultTimeoutSeconds() {
   @Test
   public void test() throws Exception {
 
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
 
       // 96 invocations, 8 at a time
       int batches = 12, batchSize = 8;
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/DynamicThreadPoolsIT.java b/test/src/main/java/org/apache/accumulo/test/functional/DynamicThreadPoolsIT.java
index ed98fd2cf1..cf6cce2263 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/DynamicThreadPoolsIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/DynamicThreadPoolsIT.java
@@ -61,7 +61,7 @@ protected int defaultTimeoutSeconds() {
 
   @Before
   public void updateMajcDelay() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       majcDelay = c.instanceOperations().getSystemConfiguration()
           .get(Property.TSERV_MAJC_DELAY.getKey());
       c.instanceOperations().setProperty(Property.TSERV_MAJC_DELAY.getKey(), "100ms");
@@ -73,7 +73,7 @@ public void updateMajcDelay() throws Exception {
 
   @After
   public void resetMajcDelay() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.instanceOperations().setProperty(Property.TSERV_MAJC_DELAY.getKey(), majcDelay);
     }
   }
@@ -82,7 +82,7 @@ public void resetMajcDelay() throws Exception {
   public void test() throws Exception {
     final String[] tables = getUniqueNames(15);
     String firstTable = tables[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.instanceOperations().setProperty(Property.TSERV_MAJC_MAXCONCURRENT.getKey(), "5");
       TestIngest.Opts opts = new TestIngest.Opts();
       opts.rows = 500 * 1000;
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/FateStarvationIT.java b/test/src/main/java/org/apache/accumulo/test/functional/FateStarvationIT.java
index e1ca4e5038..85db23bcfe 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/FateStarvationIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/FateStarvationIT.java
@@ -41,7 +41,7 @@ protected int defaultTimeoutSeconds() {
   @Test
   public void run() throws Exception {
     String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(tableName);
 
       c.tableOperations().addSplits(tableName, TestIngest.getSplitPoints(0, 100000, 50));
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/LargeRowIT.java b/test/src/main/java/org/apache/accumulo/test/functional/LargeRowIT.java
index 7f98b8c9a4..28579689e8 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/LargeRowIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/LargeRowIT.java
@@ -94,7 +94,7 @@ public void getTimeoutFactor() throws Exception {
     REG_TABLE_NAME = names[0];
     PRE_SPLIT_TABLE_NAME = names[1];
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       tservMajcDelay = c.instanceOperations().getSystemConfiguration()
           .get(Property.TSERV_MAJC_DELAY.getKey());
       c.instanceOperations().setProperty(Property.TSERV_MAJC_DELAY.getKey(), "10ms");
@@ -104,7 +104,7 @@ public void getTimeoutFactor() throws Exception {
   @After
   public void resetMajcDelay() throws Exception {
     if (null != tservMajcDelay) {
-      try (AccumuloClient client = getAccumuloClient()) {
+      try (AccumuloClient client = createAccumuloClient()) {
         client.instanceOperations().setProperty(Property.TSERV_MAJC_DELAY.getKey(), tservMajcDelay);
       }
     }
@@ -123,7 +123,7 @@ public void run() throws Exception {
       TestIngest.toPrintableChars(rowData);
       splitPoints.add(new Text(rowData));
     }
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(REG_TABLE_NAME);
       c.tableOperations().create(PRE_SPLIT_TABLE_NAME);
       c.tableOperations().setProperty(PRE_SPLIT_TABLE_NAME,
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/LogicalTimeIT.java b/test/src/main/java/org/apache/accumulo/test/functional/LogicalTimeIT.java
index fdf9dbd691..01e8c43a76 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/LogicalTimeIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/LogicalTimeIT.java
@@ -45,7 +45,7 @@ protected int defaultTimeoutSeconds() {
   public void run() throws Exception {
     int tc = 0;
     String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       runMergeTest(c, tableName + tc++, new String[] {"m"}, new String[] {"a"}, null, null, "b",
           2L);
       runMergeTest(c, tableName + tc++, new String[] {"m"}, new String[] {"z"}, null, null, "b",
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/MasterAssignmentIT.java b/test/src/main/java/org/apache/accumulo/test/functional/MasterAssignmentIT.java
index 063edc3f06..a5a1c34fa9 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/MasterAssignmentIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/MasterAssignmentIT.java
@@ -46,7 +46,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = super.getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       String tableId = c.tableOperations().tableIdMap().get(tableName);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/MasterFailoverIT.java b/test/src/main/java/org/apache/accumulo/test/functional/MasterFailoverIT.java
index ee50b5c005..413f652cbd 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/MasterFailoverIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/MasterFailoverIT.java
@@ -49,7 +49,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String[] names = getUniqueNames(2);
       c.tableOperations().create(names[0]);
       TestIngest.Opts opts = new TestIngest.Opts();
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/MaxOpenIT.java b/test/src/main/java/org/apache/accumulo/test/functional/MaxOpenIT.java
index 05ae5ddb27..5ad2e652d0 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/MaxOpenIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/MaxOpenIT.java
@@ -65,7 +65,7 @@ protected int defaultTimeoutSeconds() {
 
   @Before
   public void alterConfig() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       InstanceOperations iops = client.instanceOperations();
       Map<String,String> sysConfig = iops.getSystemConfiguration();
       scanMaxOpenFiles = sysConfig.get(Property.TSERV_SCAN_MAX_OPENFILES.getKey());
@@ -76,7 +76,7 @@ public void alterConfig() throws Exception {
 
   @After
   public void restoreConfig() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       InstanceOperations iops = client.instanceOperations();
       if (null != scanMaxOpenFiles) {
         iops.setProperty(Property.TSERV_SCAN_MAX_OPENFILES.getKey(), scanMaxOpenFiles);
@@ -95,7 +95,7 @@ public void restoreConfig() throws Exception {
 
   @Test
   public void run() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       c.tableOperations().setProperty(tableName, Property.TABLE_MAJC_RATIO.getKey(), "10");
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/MergeIT.java b/test/src/main/java/org/apache/accumulo/test/functional/MergeIT.java
index f4e501a041..fdd7244f9c 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/MergeIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/MergeIT.java
@@ -56,7 +56,7 @@ public int defaultTimeoutSeconds() {
 
   @Test
   public void merge() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       c.tableOperations().addSplits(tableName, splits("a b c d e f g h i j k".split(" ")));
@@ -75,7 +75,7 @@ public void merge() throws Exception {
 
   @Test
   public void mergeSize() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       c.tableOperations().addSplits(tableName,
@@ -113,7 +113,7 @@ public void mergeSize() throws Exception {
   @Test
   public void mergeTest() throws Exception {
     int tc = 0;
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       runMergeTest(c, tableName + tc++, ns(), ns(), ns("l", "m", "n"), ns(null, "l"),
           ns(null, "n"));
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/MetadataIT.java b/test/src/main/java/org/apache/accumulo/test/functional/MetadataIT.java
index efd70a8db4..8b3750f44f 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/MetadataIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/MetadataIT.java
@@ -61,7 +61,7 @@ public int defaultTimeoutSeconds() {
 
   @Test
   public void testFlushAndCompact() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableNames[] = getUniqueNames(2);
 
       // create a table to write some data to metadata table
@@ -100,7 +100,7 @@ public void testFlushAndCompact() throws Exception {
 
   @Test
   public void mergeMeta() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String[] names = getUniqueNames(5);
       SortedSet<Text> splits = new TreeSet<>();
       for (String id : "1 2 3 4 5".split(" ")) {
@@ -123,7 +123,7 @@ public void mergeMeta() throws Exception {
 
   @Test
   public void batchScanTest() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
 
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/PermissionsIT.java b/test/src/main/java/org/apache/accumulo/test/functional/PermissionsIT.java
index 61dd99e1ac..5b7e249570 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/PermissionsIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/PermissionsIT.java
@@ -78,7 +78,7 @@ public int defaultTimeoutSeconds() {
   @Before
   public void limitToMini() throws Exception {
     Assume.assumeTrue(ClusterType.MINI == getClusterType());
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       Set<String> users = c.securityOperations().listLocalUsers();
       ClusterUser user = getUser(0);
       if (users.contains(user.getPrincipal())) {
@@ -97,7 +97,7 @@ public void systemPermissionsTest() throws Exception {
     ClusterUser testUser = getUser(0), rootUser = getAdminUser();
 
     // verify that the test is being run by root
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       verifyHasOnlyTheseSystemPermissions(c, c.whoami(), SystemPermission.values());
 
       // create the test user
@@ -569,7 +569,7 @@ public void tablePermissionTest() throws Exception {
       passwordToken = (PasswordToken) token;
     }
     loginAs(rootUser);
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.securityOperations().createLocalUser(principal, passwordToken);
       loginAs(testUser);
       try (AccumuloClient test_user_client = Accumulo.newClient().from(c.properties())
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ReadWriteIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ReadWriteIT.java
index df3a5a85ba..3976e3cfbc 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ReadWriteIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ReadWriteIT.java
@@ -139,7 +139,7 @@ public void sunnyDay() throws Exception {
     // Shutdown cleanly.
     log.debug("Starting Monitor");
     cluster.getClusterControl().startAllServers(ServerType.MONITOR);
-    try (AccumuloClient accumuloClient = getAccumuloClient()) {
+    try (AccumuloClient accumuloClient = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       ingest(accumuloClient, getClientInfo(), ROWS, COLS, 50, 0, tableName);
       verify(accumuloClient, getClientInfo(), ROWS, COLS, 50, 0, tableName);
@@ -323,7 +323,7 @@ public void multiTableTest() throws Exception {
   @Test
   public void largeTest() throws Exception {
     // write a few large values
-    try (AccumuloClient accumuloClient = getAccumuloClient()) {
+    try (AccumuloClient accumuloClient = createAccumuloClient()) {
       String table = getUniqueNames(1)[0];
       ingest(accumuloClient, getClientInfo(), 2, 1, 500000, 0, table);
       verify(accumuloClient, getClientInfo(), 2, 1, 500000, 0, table);
@@ -333,7 +333,7 @@ public void largeTest() throws Exception {
   @Test
   public void interleaved() throws Exception {
     // read and write concurrently
-    try (AccumuloClient accumuloClient = getAccumuloClient()) {
+    try (AccumuloClient accumuloClient = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       interleaveTest(accumuloClient, tableName);
     }
@@ -378,7 +378,7 @@ public static Mutation m(String row, String cf, String cq, String value) {
   @Test
   public void localityGroupPerf() throws Exception {
     // verify that locality groups can make look-ups faster
-    try (AccumuloClient accumuloClient = getAccumuloClient()) {
+    try (AccumuloClient accumuloClient = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       accumuloClient.tableOperations().create(tableName);
       accumuloClient.tableOperations().setProperty(tableName, "table.group.g1", "colf");
@@ -411,7 +411,7 @@ public void localityGroupPerf() throws Exception {
    */
   @Test
   public void sunnyLG() throws Exception {
-    try (AccumuloClient accumuloClient = getAccumuloClient()) {
+    try (AccumuloClient accumuloClient = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       accumuloClient.tableOperations().create(tableName);
       Map<String,Set<Text>> groups = new TreeMap<>();
@@ -428,7 +428,7 @@ public void sunnyLG() throws Exception {
   @Test
   public void sunnyLGUsingNewTableConfiguration() throws Exception {
     // create a locality group, write to it and ensure it exists in the RFiles that result
-    try (AccumuloClient accumuloClient = getAccumuloClient()) {
+    try (AccumuloClient accumuloClient = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       NewTableConfiguration ntc = new NewTableConfiguration();
       Map<String,Set<Text>> groups = new HashMap<>();
@@ -486,7 +486,7 @@ private void verifyLocalityGroupsInRFile(final AccumuloClient accumuloClient,
   @Test
   public void localityGroupChange() throws Exception {
     // Make changes to locality groups and ensure nothing is lost
-    try (AccumuloClient accumuloClient = getAccumuloClient()) {
+    try (AccumuloClient accumuloClient = createAccumuloClient()) {
       String table = getUniqueNames(1)[0];
       TableOperations to = accumuloClient.tableOperations();
       to.create(table);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/RenameIT.java b/test/src/main/java/org/apache/accumulo/test/functional/RenameIT.java
index 4f2e16ad1e..d43a12e396 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/RenameIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/RenameIT.java
@@ -43,7 +43,7 @@ public void renameTest() throws Exception {
     opts.setTableName(name1);
     opts.setClientProperties(cluster.getClientProperties());
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       TestIngest.ingest(c, opts, bwOpts);
       c.tableOperations().rename(name1, name2);
       TestIngest.ingest(c, opts, bwOpts);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/RestartIT.java b/test/src/main/java/org/apache/accumulo/test/functional/RestartIT.java
index c0264b9e82..26be49c2e0 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/RestartIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/RestartIT.java
@@ -107,7 +107,7 @@ public void teardown() throws Exception {
 
   @Test
   public void restartMaster() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       OPTS.setTableName(tableName);
       VOPTS.setTableName(tableName);
@@ -149,7 +149,7 @@ public void restartMaster() throws Exception {
 
   @Test
   public void restartMasterRecovery() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       OPTS.setTableName(tableName);
@@ -200,7 +200,7 @@ public void restartMasterRecovery() throws Exception {
 
   @Test
   public void restartMasterSplit() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       final AuthenticationToken token = getAdminToken();
       final ClusterControl control = getCluster().getClusterControl();
@@ -257,7 +257,7 @@ public void restartMasterSplit() throws Exception {
 
   @Test
   public void killedTabletServer() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       OPTS.setTableName(tableName);
@@ -274,7 +274,7 @@ public void killedTabletServer() throws Exception {
 
   @Test
   public void killedTabletServer2() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       final String[] names = getUniqueNames(2);
       final String tableName = names[0];
       final ClusterControl control = getCluster().getClusterControl();
@@ -290,7 +290,7 @@ public void killedTabletServer2() throws Exception {
 
   @Test
   public void killedTabletServerDuringShutdown() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       OPTS.setTableName(tableName);
@@ -307,7 +307,7 @@ public void killedTabletServerDuringShutdown() throws Exception {
 
   @Test
   public void shutdownDuringCompactingSplitting() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       VOPTS.setTableName(tableName);
       OPTS.setClientProperties(getClientProperties());
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/RestartStressIT.java b/test/src/main/java/org/apache/accumulo/test/functional/RestartStressIT.java
index 8e0e26b37b..e707c808fb 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/RestartStressIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/RestartStressIT.java
@@ -98,7 +98,7 @@ public void teardown() throws Exception {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       final AuthenticationToken token = getAdminToken();
       c.tableOperations().create(tableName);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/RowDeleteIT.java b/test/src/main/java/org/apache/accumulo/test/functional/RowDeleteIT.java
index e43c6c66c9..70cec192d4 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/RowDeleteIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/RowDeleteIT.java
@@ -59,7 +59,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void run() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       Map<String,Set<Text>> groups = new HashMap<>();
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ScanIdIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ScanIdIT.java
index fbca5d5362..2c8d60259c 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ScanIdIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ScanIdIT.java
@@ -109,7 +109,7 @@ protected int defaultTimeoutSeconds() {
   public void testScanId() throws Exception {
 
     final String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       client.tableOperations().create(tableName);
 
       addSplits(client, tableName);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ScanIteratorIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ScanIteratorIT.java
index d24b2f8150..7003476541 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ScanIteratorIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ScanIteratorIT.java
@@ -68,7 +68,7 @@ protected int defaultTimeoutSeconds() {
 
   @Before
   public void setup() throws Exception {
-    accumuloClient = getAccumuloClient();
+    accumuloClient = createAccumuloClient();
     tableName = getUniqueNames(1)[0];
 
     accumuloClient.tableOperations().create(tableName);
@@ -110,7 +110,7 @@ public void tearDown() throws Exception {
   @Test
   public void run() throws Exception {
     String tableName = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
 
       BatchWriter bw = c.createBatchWriter(tableName, new BatchWriterConfig());
 
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ScanRangeIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ScanRangeIT.java
index 3183e6693b..79c6a08e73 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ScanRangeIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ScanRangeIT.java
@@ -48,7 +48,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void run() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String[] tableNames = getUniqueNames(2);
       String table1 = tableNames[0];
       c.tableOperations().create(table1);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ScanSessionTimeOutIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ScanSessionTimeOutIT.java
index 60bc51240a..8fbf11d2b5 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ScanSessionTimeOutIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ScanSessionTimeOutIT.java
@@ -64,7 +64,7 @@ protected int defaultTimeoutSeconds() {
 
   @Before
   public void reduceSessionIdle() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       InstanceOperations ops = client.instanceOperations();
       sessionIdle = ops.getSystemConfiguration().get(Property.TSERV_SESSION_MAXIDLE.getKey());
       ops.setProperty(Property.TSERV_SESSION_MAXIDLE.getKey(), getMaxIdleTimeString());
@@ -86,7 +86,7 @@ protected String getMaxIdleTimeString() {
   @After
   public void resetSessionIdle() throws Exception {
     if (null != sessionIdle) {
-      try (AccumuloClient client = getAccumuloClient()) {
+      try (AccumuloClient client = createAccumuloClient()) {
         client.instanceOperations().setProperty(Property.TSERV_SESSION_MAXIDLE.getKey(),
             sessionIdle);
       }
@@ -95,7 +95,7 @@ public void resetSessionIdle() throws Exception {
 
   @Test
   public void run() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
 
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ScannerContextIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ScannerContextIT.java
index f121ee1fbc..e3c9cfe6f3 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ScannerContextIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ScannerContextIT.java
@@ -87,7 +87,7 @@ private Path copyTestIteratorsJarToTmp() throws IOException {
   @Test
   public void test() throws Exception {
     Path dstPath = copyTestIteratorsJarToTmp();
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       // Set the classloader context property on the table to point to the test iterators jar file.
       c.instanceOperations().setProperty(CONTEXT_PROPERTY, CONTEXT_CLASSPATH);
 
@@ -136,7 +136,7 @@ public void test() throws Exception {
   @Test
   public void testScanContextOverridesTableContext() throws Exception {
     Path dstPath = copyTestIteratorsJarToTmp();
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       // Create two contexts FOO and ScanContextIT. The FOO context will point to a classpath
       // that contains nothing. The ScanContextIT context will point to the test iterators jar
       String tableContext = "FOO";
@@ -192,7 +192,7 @@ public void testScanContextOverridesTableContext() throws Exception {
   @Test
   public void testOneScannerDoesntInterfereWithAnother() throws Exception {
     Path dstPath = copyTestIteratorsJarToTmp();
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       // Set the classloader context property on the table to point to the test iterators jar file.
       c.instanceOperations().setProperty(CONTEXT_PROPERTY, CONTEXT_CLASSPATH);
 
@@ -238,7 +238,7 @@ public void testOneScannerDoesntInterfereWithAnother() throws Exception {
   @Test
   public void testClearContext() throws Exception {
     Path dstPath = copyTestIteratorsJarToTmp();
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       // Set the classloader context property on the table to point to the test iterators jar file.
       c.instanceOperations().setProperty(CONTEXT_PROPERTY, CONTEXT_CLASSPATH);
 
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ScannerIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ScannerIT.java
index 55f0c921d2..c681354fc8 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ScannerIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ScannerIT.java
@@ -48,7 +48,7 @@ protected int defaultTimeoutSeconds() {
   @Test
   public void testScannerReadaheadConfiguration() throws Exception {
     final String table = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(table);
 
       BatchWriter bw = c.createBatchWriter(table, new BatchWriterConfig());
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ServerSideErrorIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ServerSideErrorIT.java
index 2b98bfc217..968fa307b2 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ServerSideErrorIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ServerSideErrorIT.java
@@ -48,7 +48,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void run() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       IteratorSetting is = new IteratorSetting(5, "Bad Aggregator", BadCombiner.class);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/SessionBlockVerifyIT.java b/test/src/main/java/org/apache/accumulo/test/functional/SessionBlockVerifyIT.java
index 0deabb00d8..ce41366b09 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/SessionBlockVerifyIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/SessionBlockVerifyIT.java
@@ -82,7 +82,7 @@ protected String getMaxIdleTimeString() {
   @Test
   @Override
   public void run() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
 
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/SparseColumnFamilyIT.java b/test/src/main/java/org/apache/accumulo/test/functional/SparseColumnFamilyIT.java
index 5e92e797b3..6d11f11ef0 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/SparseColumnFamilyIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/SparseColumnFamilyIT.java
@@ -45,7 +45,7 @@ protected int defaultTimeoutSeconds() {
   @Test
   public void sparceColumnFamily() throws Exception {
     String scftt = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(scftt);
 
       BatchWriter bw = c.createBatchWriter(scftt, new BatchWriterConfig());
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/SplitIT.java b/test/src/main/java/org/apache/accumulo/test/functional/SplitIT.java
index f59ed5a4c0..35b4ba31ae 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/SplitIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/SplitIT.java
@@ -74,7 +74,7 @@ protected int defaultTimeoutSeconds() {
   @Before
   public void alterConfig() throws Exception {
     Assume.assumeTrue(ClusterType.MINI == getClusterType());
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       InstanceOperations iops = client.instanceOperations();
       Map<String,String> config = iops.getSystemConfiguration();
       tservMaxMem = config.get(Property.TSERV_MAXMEM.getKey());
@@ -105,7 +105,7 @@ public void alterConfig() throws Exception {
 
   @After
   public void resetConfig() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       if (null != tservMaxMem) {
         log.info("Resetting {}={}", Property.TSERV_MAXMEM.getKey(), tservMaxMem);
         client.instanceOperations().setProperty(Property.TSERV_MAXMEM.getKey(), tservMaxMem);
@@ -123,7 +123,7 @@ public void resetConfig() throws Exception {
 
   @Test
   public void tabletShouldSplit() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String table = getUniqueNames(1)[0];
       c.tableOperations().create(table);
       c.tableOperations().setProperty(table, Property.TABLE_SPLIT_THRESHOLD.getKey(), "256K");
@@ -178,7 +178,7 @@ public void tabletShouldSplit() throws Exception {
 
   @Test
   public void interleaveSplit() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       c.tableOperations().setProperty(tableName, Property.TABLE_SPLIT_THRESHOLD.getKey(), "10K");
@@ -199,7 +199,7 @@ public void interleaveSplit() throws Exception {
 
   @Test
   public void deleteSplit() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       c.tableOperations().setProperty(tableName, Property.TABLE_SPLIT_THRESHOLD.getKey(), "10K");
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/SummaryIT.java b/test/src/main/java/org/apache/accumulo/test/functional/SummaryIT.java
index 4d6a8e805b..9b6c6f37a0 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/SummaryIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/SummaryIT.java
@@ -139,7 +139,7 @@ private void addSplits(final String table, AccumuloClient c, String... splits)
   @Test
   public void basicSummaryTest() throws Exception {
     final String table = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       NewTableConfiguration ntc = new NewTableConfiguration();
       SummarizerConfiguration sc1 = SummarizerConfiguration.builder(BasicSummarizer.class.getName())
           .build();
@@ -316,7 +316,7 @@ private static void checkSummary(Collection<Summary> summaries, SummarizerConfig
   @Test
   public void selectionTest() throws Exception {
     final String table = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       NewTableConfiguration ntc = new NewTableConfiguration();
       SummarizerConfiguration sc1 = SummarizerConfiguration.builder(BasicSummarizer.class).build();
       SummarizerConfiguration sc2 = SummarizerConfiguration.builder(KeySizeSummarizer.class)
@@ -480,7 +480,7 @@ public CompactionPlan getCompactionPlan(MajorCompactionRequest request) throws I
   @Test
   public void compactionTest() throws Exception {
     final String table = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       NewTableConfiguration ntc = new NewTableConfiguration();
       SummarizerConfiguration sc1 = SummarizerConfiguration.builder(FooCounter.class.getName())
           .build();
@@ -550,7 +550,7 @@ public Combiner combiner(SummarizerConfiguration sc) {
   @Test
   public void testBuggySummarizer() throws Exception {
     final String table = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       NewTableConfiguration ntc = new NewTableConfiguration();
       SummarizerConfiguration sc1 = SummarizerConfiguration.builder(BuggySummarizer.class).build();
       ntc.enableSummarization(sc1);
@@ -577,7 +577,7 @@ public void testBuggySummarizer() throws Exception {
   @Test
   public void testPermissions() throws Exception {
     final String table = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       NewTableConfiguration ntc = new NewTableConfiguration();
       SummarizerConfiguration sc1 = SummarizerConfiguration.builder(FooCounter.class).build();
       ntc.enableSummarization(sc1);
@@ -653,7 +653,7 @@ public Combiner combiner(SummarizerConfiguration sc) {
   @Test
   public void tooLargeTest() throws Exception {
     final String table = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       NewTableConfiguration ntc = new NewTableConfiguration();
       SummarizerConfiguration sc1 = SummarizerConfiguration.builder(BigSummarizer.class).build();
       ntc.enableSummarization(sc1);
@@ -724,7 +724,7 @@ private void write(BatchWriter bw, Map<Key,Value> expected, String row, String f
   @Test
   public void testLocalityGroups() throws Exception {
     final String table = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       NewTableConfiguration ntc = new NewTableConfiguration();
       SummarizerConfiguration sc1 = SummarizerConfiguration.builder(FamilySummarizer.class).build();
       SummarizerConfiguration sc2 = SummarizerConfiguration.builder(BasicSummarizer.class).build();
@@ -787,7 +787,7 @@ public void testLocalityGroups() throws Exception {
 
   @Test
   public void testExceptions() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
 
       try {
         c.tableOperations().summaries("foo").retrieve();
@@ -845,7 +845,7 @@ public void testExceptions() throws Exception {
   @Test
   public void testManyFiles() throws Exception {
     final String table = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       NewTableConfiguration ntc = new NewTableConfiguration();
       ntc.enableSummarization(SummarizerConfiguration.builder(FamilySummarizer.class).build());
       c.tableOperations().create(table, ntc);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/TableChangeStateIT.java b/test/src/main/java/org/apache/accumulo/test/functional/TableChangeStateIT.java
index 6d8db420c4..a9de9f485c 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/TableChangeStateIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/TableChangeStateIT.java
@@ -80,7 +80,7 @@
 
   @Before
   public void setup() {
-    accumuloClient = getAccumuloClient();
+    accumuloClient = createAccumuloClient();
     context = new ClientContext(accumuloClient);
   }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/TableIT.java b/test/src/main/java/org/apache/accumulo/test/functional/TableIT.java
index 24120ff1b0..97e629d1a9 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/TableIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/TableIT.java
@@ -63,7 +63,7 @@ public void test() throws Exception {
     MiniAccumuloClusterImpl mac = (MiniAccumuloClusterImpl) cluster;
     String rootPath = mac.getConfig().getDir().getAbsolutePath();
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       TableOperations to = c.tableOperations();
       String tableName = getUniqueNames(1)[0];
       to.create(tableName);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/TabletIT.java b/test/src/main/java/org/apache/accumulo/test/functional/TabletIT.java
index ed913c0a4f..bc72450b26 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/TabletIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/TabletIT.java
@@ -58,7 +58,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void createTableTest() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       createTableTest(client, tableName, false);
       createTableTest(client, tableName, true);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/TabletStateChangeIteratorIT.java b/test/src/main/java/org/apache/accumulo/test/functional/TabletStateChangeIteratorIT.java
index df09bed212..e2bbea6d7f 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/TabletStateChangeIteratorIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/TabletStateChangeIteratorIT.java
@@ -81,7 +81,7 @@ public int defaultTimeoutSeconds() {
   public void test() throws AccumuloException, AccumuloSecurityException, TableExistsException,
       TableNotFoundException {
 
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
 
       String[] tables = getUniqueNames(4);
       final String t1 = tables[0];
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/TimeoutIT.java b/test/src/main/java/org/apache/accumulo/test/functional/TimeoutIT.java
index ebd6db988a..57aba52c7b 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/TimeoutIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/TimeoutIT.java
@@ -47,7 +47,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void run() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String[] tableNames = getUniqueNames(2);
       testBatchWriterTimeout(client, tableNames[0]);
       testBatchScannerTimeout(client, tableNames[1]);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/TooManyDeletesIT.java b/test/src/main/java/org/apache/accumulo/test/functional/TooManyDeletesIT.java
index 050a176eea..b14e4c5692 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/TooManyDeletesIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/TooManyDeletesIT.java
@@ -39,7 +39,7 @@
 public class TooManyDeletesIT extends AccumuloClusterHarness {
   @Test
   public void tooManyDeletesCompactionStrategyIT() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
 
       String table = getUniqueNames(1)[0];
 
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/VisibilityIT.java b/test/src/main/java/org/apache/accumulo/test/functional/VisibilityIT.java
index c7b09a9dbc..094c06396c 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/VisibilityIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/VisibilityIT.java
@@ -62,14 +62,14 @@ protected int defaultTimeoutSeconds() {
 
   @Before
   public void emptyAuths() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       origAuths = c.securityOperations().getUserAuthorizations(getAdminPrincipal());
     }
   }
 
   @After
   public void resetAuths() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       if (null != origAuths) {
         c.securityOperations().changeUserAuthorizations(getAdminPrincipal(), origAuths);
       }
@@ -78,7 +78,7 @@ public void resetAuths() throws Exception {
 
   @Test
   public void run() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String[] tableNames = getUniqueNames(2);
       String table = tableNames[0];
       c.tableOperations().create(table);
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/WriteAheadLogEncryptedIT.java b/test/src/main/java/org/apache/accumulo/test/functional/WriteAheadLogEncryptedIT.java
index 6fe46bfc6f..c301e12530 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/WriteAheadLogEncryptedIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/WriteAheadLogEncryptedIT.java
@@ -82,7 +82,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       c.tableOperations().setProperty(tableName, Property.TABLE_SPLIT_THRESHOLD.getKey(), "750K");
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/WriteAheadLogIT.java b/test/src/main/java/org/apache/accumulo/test/functional/WriteAheadLogIT.java
index 93cbc581b9..614a77f303 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/WriteAheadLogIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/WriteAheadLogIT.java
@@ -49,7 +49,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       c.tableOperations().setProperty(tableName, Property.TABLE_SPLIT_THRESHOLD.getKey(), "750K");
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/WriteLotsIT.java b/test/src/main/java/org/apache/accumulo/test/functional/WriteLotsIT.java
index 029c0de854..299490bba5 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/WriteLotsIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/WriteLotsIT.java
@@ -38,7 +38,7 @@ protected int defaultTimeoutSeconds() {
 
   @Test
   public void writeLots() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       final String tableName = getUniqueNames(1)[0];
       c.tableOperations().create(tableName);
       final AtomicReference<Exception> ref = new AtomicReference<>();
diff --git a/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloFileOutputFormatIT.java b/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloFileOutputFormatIT.java
index 0da90167ff..a69ab45ce1 100644
--- a/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloFileOutputFormatIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloFileOutputFormatIT.java
@@ -82,7 +82,7 @@
 
   @Test
   public void testEmptyWrite() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(EMPTY_TABLE);
       handleWriteTests(false);
     }
@@ -90,7 +90,7 @@ public void testEmptyWrite() throws Exception {
 
   @Test
   public void testRealWrite() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(TEST_TABLE);
       BatchWriter bw = c.createBatchWriter(TEST_TABLE, new BatchWriterConfig());
       Mutation m = new Mutation("Key");
@@ -207,7 +207,7 @@ private void handleWriteTests(boolean content) throws Exception {
 
   @Test
   public void writeBadVisibility() throws Exception {
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(BAD_TABLE);
       BatchWriter bw = c.createBatchWriter(BAD_TABLE, new BatchWriterConfig());
       Mutation m = new Mutation("r1");
diff --git a/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloInputFormatIT.java b/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloInputFormatIT.java
index d605e1bcdc..bee8f0c3fd 100644
--- a/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloInputFormatIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloInputFormatIT.java
@@ -152,7 +152,7 @@ public static void main(String... args) throws Exception {
   @Test
   public void testMap() throws Exception {
     String table = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(table);
       BatchWriter bw = c.createBatchWriter(table, new BatchWriterConfig());
       for (int i = 0; i < 100; i++) {
@@ -178,7 +178,7 @@ public void testMap() throws Exception {
   public void testSample() throws Exception {
     final String TEST_TABLE_3 = getUniqueNames(1)[0];
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(TEST_TABLE_3,
           new NewTableConfiguration().enableSampling(SAMPLER_CONFIG));
       BatchWriter bw = c.createBatchWriter(TEST_TABLE_3, new BatchWriterConfig());
@@ -216,7 +216,7 @@ public void testCorrectRangeInputSplits() throws Exception {
     boolean isolated = true, localIters = true;
     Level level = Level.WARN;
 
-    try (AccumuloClient accumuloClient = getAccumuloClient()) {
+    try (AccumuloClient accumuloClient = createAccumuloClient()) {
       accumuloClient.tableOperations().create(table);
 
       AccumuloInputFormat.setClientProperties(job, getClientProperties());
diff --git a/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloMultiTableInputFormatIT.java b/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloMultiTableInputFormatIT.java
index b4a6063bca..77fa0e517d 100644
--- a/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloMultiTableInputFormatIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloMultiTableInputFormatIT.java
@@ -139,7 +139,7 @@ public void testMap() throws Exception {
     String[] tableNames = getUniqueNames(2);
     String table1 = tableNames[0];
     String table2 = tableNames[1];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(table1);
       c.tableOperations().create(table2);
       BatchWriter bw = c.createBatchWriter(table1, new BatchWriterConfig());
diff --git a/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloRowInputFormatIT.java b/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloRowInputFormatIT.java
index 0754edce72..2c2716560c 100644
--- a/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloRowInputFormatIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/mapred/AccumuloRowInputFormatIT.java
@@ -183,7 +183,7 @@ public static void main(String[] args) throws Exception {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
       BatchWriter writer = null;
diff --git a/test/src/main/java/org/apache/accumulo/test/mapred/TokenFileIT.java b/test/src/main/java/org/apache/accumulo/test/mapred/TokenFileIT.java
index 4e7a3a6a4d..5e3356bad2 100644
--- a/test/src/main/java/org/apache/accumulo/test/mapred/TokenFileIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/mapred/TokenFileIT.java
@@ -150,7 +150,7 @@ public void testMR() throws Exception {
     String[] tableNames = getUniqueNames(2);
     String table1 = tableNames[0];
     String table2 = tableNames[1];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(table1);
       c.tableOperations().create(table2);
       BatchWriter bw = c.createBatchWriter(table1, new BatchWriterConfig());
diff --git a/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloFileOutputFormatIT.java b/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloFileOutputFormatIT.java
index 550edb927d..b933c0f1ae 100644
--- a/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloFileOutputFormatIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloFileOutputFormatIT.java
@@ -83,7 +83,7 @@ public void setup() throws Exception {
     TEST_TABLE = PREFIX + "_mapreduce_test_table";
     EMPTY_TABLE = PREFIX + "_mapreduce_empty_table";
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(EMPTY_TABLE);
       c.tableOperations().create(TEST_TABLE);
       c.tableOperations().create(BAD_TABLE);
diff --git a/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloInputFormatIT.java b/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloInputFormatIT.java
index af5ffb0463..271e50da00 100644
--- a/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloInputFormatIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloInputFormatIT.java
@@ -94,7 +94,7 @@ public void before() {
    */
   @Test
   public void testGetSplits() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String table = getUniqueNames(1)[0];
       client.tableOperations().create(table);
       insertData(client, table, currentTimeMillis());
@@ -315,7 +315,7 @@ public static int main(String[] args) throws Exception {
   public void testMap() throws Exception {
     final String TEST_TABLE_1 = getUniqueNames(1)[0];
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(TEST_TABLE_1);
       BatchWriter bw = c.createBatchWriter(TEST_TABLE_1, new BatchWriterConfig());
       for (int i = 0; i < 100; i++) {
@@ -339,7 +339,7 @@ public void testMap() throws Exception {
   public void testSample() throws Exception {
     final String TEST_TABLE_3 = getUniqueNames(1)[0];
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(TEST_TABLE_3,
           new NewTableConfiguration().enableSampling(SAMPLER_CONFIG));
       BatchWriter bw = c.createBatchWriter(TEST_TABLE_3, new BatchWriterConfig());
@@ -373,7 +373,7 @@ public void testSample() throws Exception {
   public void testMapWithBatchScanner() throws Exception {
     final String TEST_TABLE_2 = getUniqueNames(1)[0];
 
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(TEST_TABLE_2);
       BatchWriter bw = c.createBatchWriter(TEST_TABLE_2, new BatchWriterConfig());
       for (int i = 0; i < 100; i++) {
@@ -401,7 +401,7 @@ public void testCorrectRangeInputSplits() throws Exception {
     boolean isolated = true, localIters = true;
     Level level = Level.WARN;
 
-    try (AccumuloClient accumuloClient = getAccumuloClient()) {
+    try (AccumuloClient accumuloClient = createAccumuloClient()) {
       accumuloClient.tableOperations().create(table);
 
       AccumuloInputFormat.setClientProperties(job, getClientProperties());
@@ -435,7 +435,7 @@ public void testCorrectRangeInputSplits() throws Exception {
   @Test
   public void testPartialInputSplitDelegationToConfiguration() throws Exception {
     String table = getUniqueNames(1)[0];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(table);
       BatchWriter bw = c.createBatchWriter(table, new BatchWriterConfig());
       for (int i = 0; i < 100; i++) {
diff --git a/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloMultiTableInputFormatIT.java b/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloMultiTableInputFormatIT.java
index 2a2e5b78a8..b996a70240 100644
--- a/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloMultiTableInputFormatIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloMultiTableInputFormatIT.java
@@ -138,7 +138,7 @@ public void testMap() throws Exception {
     String[] tableNames = getUniqueNames(2);
     String table1 = tableNames[0];
     String table2 = tableNames[1];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(table1);
       c.tableOperations().create(table2);
       BatchWriter bw = c.createBatchWriter(table1, new BatchWriterConfig());
diff --git a/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloOutputFormatIT.java b/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloOutputFormatIT.java
index 55ab3ccbf9..d135b2b524 100644
--- a/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloOutputFormatIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloOutputFormatIT.java
@@ -128,7 +128,7 @@ public void testMR() throws Exception {
     String[] tableNames = getUniqueNames(2);
     String table1 = tableNames[0];
     String table2 = tableNames[1];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(table1);
       c.tableOperations().create(table2);
       BatchWriter bw = c.createBatchWriter(table1, new BatchWriterConfig());
diff --git a/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloRowInputFormatIT.java b/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloRowInputFormatIT.java
index 49fb3f570b..5d7c08d2b3 100644
--- a/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloRowInputFormatIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/mapreduce/AccumuloRowInputFormatIT.java
@@ -180,7 +180,7 @@ public static void main(String[] args) throws Exception {
 
   @Test
   public void test() throws Exception {
-    try (AccumuloClient client = getAccumuloClient()) {
+    try (AccumuloClient client = createAccumuloClient()) {
       String tableName = getUniqueNames(1)[0];
       client.tableOperations().create(tableName);
       BatchWriter writer = null;
diff --git a/test/src/main/java/org/apache/accumulo/test/mapreduce/TokenFileIT.java b/test/src/main/java/org/apache/accumulo/test/mapreduce/TokenFileIT.java
index 98d33729b6..ee65c690e4 100644
--- a/test/src/main/java/org/apache/accumulo/test/mapreduce/TokenFileIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/mapreduce/TokenFileIT.java
@@ -143,7 +143,7 @@ public void testMR() throws Exception {
     String[] tableNames = getUniqueNames(2);
     String table1 = tableNames[0];
     String table2 = tableNames[1];
-    try (AccumuloClient c = getAccumuloClient()) {
+    try (AccumuloClient c = createAccumuloClient()) {
       c.tableOperations().create(table1);
       c.tableOperations().create(table2);
       BatchWriter bw = c.createBatchWriter(table1, new BatchWriterConfig());


 

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


With regards,
Apache Git Services