You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by mw...@apache.org on 2018/12/19 23:35:11 UTC

[accumulo] branch master updated: Remove unnecessary exceptions in test module (#846)

This is an automated email from the ASF dual-hosted git repository.

mwalch pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/accumulo.git


The following commit(s) were added to refs/heads/master by this push:
     new ad996b6  Remove unnecessary exceptions in test module (#846)
ad996b6 is described below

commit ad996b636fbabc710b8f54655056399249968436
Author: Mike Walch <mw...@apache.org>
AuthorDate: Wed Dec 19 18:35:07 2018 -0500

    Remove unnecessary exceptions in test module (#846)
---
 .../accumulo/harness/AccumuloClusterHarness.java   |  4 +-
 .../accumulo/harness/MiniClusterHarness.java       |  2 +-
 .../accumulo/harness/SharedMiniClusterBase.java    |  2 +-
 .../org/apache/accumulo/harness/TestingKdc.java    |  2 +-
 .../accumulo/test/ArbitraryTablePropertiesIT.java  |  2 +-
 .../org/apache/accumulo/test/AuditMessageIT.java   | 20 ++++---
 .../apache/accumulo/test/ClientSideIteratorIT.java |  2 +-
 .../java/org/apache/accumulo/test/CloneIT.java     |  4 +-
 .../apache/accumulo/test/ConditionalWriterIT.java  |  5 +-
 .../test/ConfigurableMajorCompactionIT.java        |  5 +-
 .../accumulo/test/GenerateSequentialRFile.java     |  2 +-
 .../org/apache/accumulo/test/HardListIterator.java |  8 ++-
 .../org/apache/accumulo/test/InMemoryMapIT.java    |  5 +-
 .../accumulo/test/MultiTableBatchWriterIT.java     |  4 +-
 .../org/apache/accumulo/test/NamespacesIT.java     |  4 +-
 .../accumulo/test/NewTableConfigurationIT.java     | 26 +++++----
 .../java/org/apache/accumulo/test/ShellIT.java     |  8 +--
 .../org/apache/accumulo/test/ShellServerIT.java    |  2 +-
 .../accumulo/test/SizeCompactionStrategy.java      |  5 +-
 .../apache/accumulo/test/SplitCancelsMajCIT.java   |  2 +-
 .../apache/accumulo/test/TableOperationsIT.java    |  5 +-
 .../accumulo/test/TestCompactionStrategy.java      |  5 +-
 .../java/org/apache/accumulo/test/TestIngest.java  |  2 +-
 .../accumulo/test/functional/AddSplitIT.java       |  4 +-
 .../accumulo/test/functional/BulkLoadIT.java       |  2 +-
 .../apache/accumulo/test/functional/CleanUpIT.java |  2 +-
 .../test/functional/ConfigurableCompactionIT.java  |  4 +-
 .../test/functional/ConfigurableMacBase.java       |  4 +-
 .../accumulo/test/functional/CreateAndUseIT.java   |  2 +-
 .../test/functional/DeletedTablesDontFlushIT.java  |  2 +-
 .../test/functional/GarbageCollectorIT.java        |  5 +-
 .../accumulo/test/functional/KerberosIT.java       |  2 +-
 .../accumulo/test/functional/KerberosProxyIT.java  |  2 +-
 .../test/functional/KerberosRenewalIT.java         |  2 +-
 .../accumulo/test/functional/MonitorSslIT.java     |  7 +--
 .../accumulo/test/functional/PermissionsIT.java    |  5 +-
 .../accumulo/test/functional/ReadWriteIT.java      |  9 ++--
 .../test/functional/RegexGroupBalanceIT.java       |  2 +-
 .../apache/accumulo/test/functional/RestartIT.java |  2 +-
 .../accumulo/test/functional/RestartStressIT.java  |  2 +-
 .../accumulo/test/functional/ScanIteratorIT.java   |  7 +--
 .../apache/accumulo/test/functional/SummaryIT.java |  7 ++-
 .../accumulo/test/functional/ZombieTServer.java    |  8 +--
 .../test/mapred/AccumuloFileOutputFormatIT.java    |  6 +--
 .../test/mapred/AccumuloInputFormatIT.java         |  6 +--
 .../mapred/AccumuloMultiTableInputFormatIT.java    |  6 +--
 .../test/mapred/AccumuloRowInputFormatIT.java      |  5 +-
 .../apache/accumulo/test/mapred/TokenFileIT.java   |  3 +-
 .../test/mapreduce/AccumuloFileOutputFormatIT.java |  6 +--
 .../test/mapreduce/AccumuloInputFormatIT.java      |  7 ++-
 .../mapreduce/AccumuloMultiTableInputFormatIT.java |  5 +-
 .../test/mapreduce/AccumuloOutputFormatIT.java     |  2 +-
 .../test/mapreduce/AccumuloRowInputFormatIT.java   |  6 +--
 .../apache/accumulo/test/mapreduce/RowHash.java    |  3 +-
 .../accumulo/test/mapreduce/TokenFileIT.java       |  2 +-
 .../accumulo/test/master/SuspendedTabletsIT.java   |  2 +-
 .../test/mrit/IntegrationTestMapReduce.java        |  6 +--
 .../accumulo/test/performance/NullTserver.java     | 63 ++++++++--------------
 .../test/performance/scan/CollectTabletStats.java  |  3 +-
 .../test/replication/FinishedWorkUpdaterIT.java    |  2 +-
 .../test/replication/KerberosReplicationIT.java    |  2 +-
 .../accumulo/test/replication/ReplicationIT.java   |  2 +-
 .../replication/ReplicationOperationsImplIT.java   | 12 ++---
 .../test/replication/StatusCombinerMacIT.java      |  2 +-
 .../java/org/apache/accumulo/test/rpc/Mocket.java  |  9 ++--
 .../apache/accumulo/test/rpc/ThriftBehaviorIT.java |  4 +-
 .../test/rpc/thrift/SimpleThriftService.java       | 54 +++++++++----------
 .../apache/accumulo/test/start/KeywordStartIT.java |  7 ++-
 .../org/apache/accumulo/test/util/CertUtils.java   | 20 ++++---
 .../test/functional/ValueReversingIterator.java    |  2 +-
 .../apache/accumulo/test/iterator/RegExTest.java   |  2 +-
 .../security/KerberosTokenEmbeddedKDCTest.java     |  2 +-
 72 files changed, 189 insertions(+), 268 deletions(-)

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 3f6749b..7f4ba00 100644
--- a/test/src/main/java/org/apache/accumulo/harness/AccumuloClusterHarness.java
+++ b/test/src/main/java/org/apache/accumulo/harness/AccumuloClusterHarness.java
@@ -97,7 +97,7 @@ public abstract class AccumuloClusterHarness extends AccumuloITBase
   }
 
   @AfterClass
-  public static void tearDownHarness() throws Exception {
+  public static void tearDownHarness() {
     if (krb != null) {
       krb.stop();
     }
@@ -381,7 +381,7 @@ public abstract class AccumuloClusterHarness extends AccumuloITBase
    *
    * @return A directory which can be expected to exist on the Cluster's FileSystem
    */
-  public Path getUsableDir() throws IllegalArgumentException, IOException {
+  public Path getUsableDir() throws IllegalArgumentException {
     return cluster.getTemporaryPath();
   }
 }
diff --git a/test/src/main/java/org/apache/accumulo/harness/MiniClusterHarness.java b/test/src/main/java/org/apache/accumulo/harness/MiniClusterHarness.java
index 84f359f..dc11d03 100644
--- a/test/src/main/java/org/apache/accumulo/harness/MiniClusterHarness.java
+++ b/test/src/main/java/org/apache/accumulo/harness/MiniClusterHarness.java
@@ -239,7 +239,7 @@ public class MiniClusterHarness {
   }
 
   protected void configureForKerberos(MiniAccumuloConfigImpl cfg, File folder,
-      Configuration coreSite, TestingKdc kdc) throws Exception {
+      Configuration coreSite, TestingKdc kdc) {
     Map<String,String> siteConfig = cfg.getSiteConfig();
     if (TRUE.equals(siteConfig.get(Property.INSTANCE_RPC_SSL_ENABLED.getKey()))) {
       throw new RuntimeException("Cannot use both SSL and SASL/Kerberos");
diff --git a/test/src/main/java/org/apache/accumulo/harness/SharedMiniClusterBase.java b/test/src/main/java/org/apache/accumulo/harness/SharedMiniClusterBase.java
index a88da08..efe0ce2 100644
--- a/test/src/main/java/org/apache/accumulo/harness/SharedMiniClusterBase.java
+++ b/test/src/main/java/org/apache/accumulo/harness/SharedMiniClusterBase.java
@@ -146,7 +146,7 @@ public abstract class SharedMiniClusterBase extends AccumuloITBase implements Cl
   /**
    * Stops the MiniAccumuloCluster and related services if they are running.
    */
-  public static void stopMiniCluster() throws Exception {
+  public static void stopMiniCluster() {
     if (cluster != null) {
       try {
         cluster.stop();
diff --git a/test/src/main/java/org/apache/accumulo/harness/TestingKdc.java b/test/src/main/java/org/apache/accumulo/harness/TestingKdc.java
index 9cd25c9..47dbd99 100644
--- a/test/src/main/java/org/apache/accumulo/harness/TestingKdc.java
+++ b/test/src/main/java/org/apache/accumulo/harness/TestingKdc.java
@@ -149,7 +149,7 @@ public class TestingKdc {
     started = true;
   }
 
-  public synchronized void stop() throws Exception {
+  public synchronized void stop() {
     checkArgument(started, "KDC is not started");
     kdc.stop();
     started = false;
diff --git a/test/src/main/java/org/apache/accumulo/test/ArbitraryTablePropertiesIT.java b/test/src/main/java/org/apache/accumulo/test/ArbitraryTablePropertiesIT.java
index 2a064ab..02003fc 100644
--- a/test/src/main/java/org/apache/accumulo/test/ArbitraryTablePropertiesIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ArbitraryTablePropertiesIT.java
@@ -51,7 +51,7 @@ public class ArbitraryTablePropertiesIT extends SharedMiniClusterBase {
   }
 
   @AfterClass
-  public static void teardown() throws Exception {
+  public static void teardown() {
     SharedMiniClusterBase.stopMiniCluster();
   }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/AuditMessageIT.java b/test/src/main/java/org/apache/accumulo/test/AuditMessageIT.java
index 523f928..9a37ee9 100644
--- a/test/src/main/java/org/apache/accumulo/test/AuditMessageIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/AuditMessageIT.java
@@ -83,7 +83,7 @@ public class AuditMessageIT extends ConfigurableMacBase {
   }
 
   @Override
-  public void beforeClusterStart(MiniAccumuloConfigImpl cfg) throws Exception {
+  public void beforeClusterStart(MiniAccumuloConfigImpl cfg) {
     cfg.setNumTservers(1);
   }
 
@@ -199,7 +199,7 @@ public class AuditMessageIT extends ConfigurableMacBase {
 
   @Test
   public void testTableOperationsAudits() throws AccumuloException, AccumuloSecurityException,
-      TableExistsException, TableNotFoundException, IOException, InterruptedException {
+      TableExistsException, TableNotFoundException, IOException {
 
     client.securityOperations().createLocalUser(AUDIT_USER_1, new PasswordToken(PASSWORD));
     client.securityOperations().grantSystemPermission(AUDIT_USER_1, SystemPermission.SYSTEM);
@@ -238,8 +238,8 @@ public class AuditMessageIT extends ConfigurableMacBase {
   }
 
   @Test
-  public void testUserOperationsAudits() throws AccumuloSecurityException, AccumuloException,
-      TableExistsException, InterruptedException, IOException {
+  public void testUserOperationsAudits()
+      throws AccumuloSecurityException, AccumuloException, TableExistsException, IOException {
 
     client.securityOperations().createLocalUser(AUDIT_USER_1, new PasswordToken(PASSWORD));
     client.securityOperations().grantSystemPermission(AUDIT_USER_1, SystemPermission.SYSTEM);
@@ -293,9 +293,8 @@ public class AuditMessageIT extends ConfigurableMacBase {
 
   @SuppressFBWarnings(value = "PATH_TRAVERSAL_IN", justification = "paths provided by test")
   @Test
-  public void testImportExportOperationsAudits()
-      throws AccumuloSecurityException, AccumuloException, TableExistsException,
-      TableNotFoundException, IOException, InterruptedException {
+  public void testImportExportOperationsAudits() throws AccumuloSecurityException,
+      AccumuloException, TableExistsException, TableNotFoundException, IOException {
 
     client.securityOperations().createLocalUser(AUDIT_USER_1, new PasswordToken(PASSWORD));
     client.securityOperations().grantSystemPermission(AUDIT_USER_1, SystemPermission.SYSTEM);
@@ -384,7 +383,7 @@ public class AuditMessageIT extends ConfigurableMacBase {
 
   @Test
   public void testDataOperationsAudits() throws AccumuloSecurityException, AccumuloException,
-      TableExistsException, TableNotFoundException, IOException, InterruptedException {
+      TableExistsException, TableNotFoundException, IOException {
 
     client.securityOperations().createLocalUser(AUDIT_USER_1, new PasswordToken(PASSWORD));
     client.securityOperations().grantSystemPermission(AUDIT_USER_1, SystemPermission.SYSTEM);
@@ -443,7 +442,7 @@ public class AuditMessageIT extends ConfigurableMacBase {
 
   @Test
   public void testDeniedAudits() throws AccumuloSecurityException, AccumuloException,
-      TableExistsException, TableNotFoundException, IOException, InterruptedException {
+      TableExistsException, TableNotFoundException, IOException {
 
     // Create our user with no privs
     client.securityOperations().createLocalUser(AUDIT_USER_1, new PasswordToken(PASSWORD));
@@ -513,8 +512,7 @@ public class AuditMessageIT extends ConfigurableMacBase {
   }
 
   @Test
-  public void testFailedAudits() throws AccumuloSecurityException, AccumuloException,
-      TableExistsException, TableNotFoundException, IOException, InterruptedException {
+  public void testFailedAudits() throws AccumuloException, IOException {
 
     // Start testing activities
     // Test that we get a few "failed" audit messages come through when we tell it to do dumb stuff
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 82a2c22..c727e68 100644
--- a/test/src/main/java/org/apache/accumulo/test/ClientSideIteratorIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ClientSideIteratorIT.java
@@ -76,7 +76,7 @@ public class ClientSideIteratorIT extends AccumuloClusterHarness {
   private String tableName;
 
   @Before
-  public void setupInstance() throws Exception {
+  public void setupInstance() {
     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 8f9a938..1afc409 100644
--- a/test/src/main/java/org/apache/accumulo/test/CloneIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/CloneIT.java
@@ -226,7 +226,7 @@ public class CloneIT extends AccumuloClusterHarness {
   }
 
   private static Mutation deleteTablet(String tid, String endRow, String prevRow, String dir,
-      String file) throws Exception {
+      String file) {
     KeyExtent ke = new KeyExtent(Table.ID.of(tid), endRow == null ? null : new Text(endRow),
         prevRow == null ? null : new Text(prevRow));
     Mutation mut = new Mutation(ke.getMetadataEntry());
@@ -239,7 +239,7 @@ public class CloneIT extends AccumuloClusterHarness {
   }
 
   private static Mutation createTablet(String tid, String endRow, String prevRow, String dir,
-      String file) throws Exception {
+      String file) {
     KeyExtent ke = new KeyExtent(Table.ID.of(tid), endRow == null ? null : new Text(endRow),
         prevRow == null ? null : new Text(prevRow));
     Mutation mut = ke.getPrevRowUpdateMutation();
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 cd8c605..0bc2b95 100644
--- a/test/src/main/java/org/apache/accumulo/test/ConditionalWriterIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ConditionalWriterIT.java
@@ -24,7 +24,6 @@ import static org.junit.Assert.assertFalse;
 import static org.junit.Assert.assertTrue;
 import static org.junit.Assert.fail;
 
-import java.io.IOException;
 import java.security.SecureRandom;
 import java.util.ArrayList;
 import java.util.Arrays;
@@ -618,7 +617,7 @@ public class ConditionalWriterIT extends AccumuloClusterHarness {
 
     @Override
     public void init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options,
-        IteratorEnvironment env) throws IOException {
+        IteratorEnvironment env) {
       this.setSource(source);
       amount = Long.parseLong(options.get("amount"));
     }
@@ -637,7 +636,7 @@ public class ConditionalWriterIT extends AccumuloClusterHarness {
 
     @Override
     public void init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options,
-        IteratorEnvironment env) throws IOException {
+        IteratorEnvironment env) {
       this.setSource(source);
       amount = Long.parseLong(options.get("amount"));
     }
diff --git a/test/src/main/java/org/apache/accumulo/test/ConfigurableMajorCompactionIT.java b/test/src/main/java/org/apache/accumulo/test/ConfigurableMajorCompactionIT.java
index 34c107e..a042af8 100644
--- a/test/src/main/java/org/apache/accumulo/test/ConfigurableMajorCompactionIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ConfigurableMajorCompactionIT.java
@@ -19,7 +19,6 @@ package org.apache.accumulo.test;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertTrue;
 
-import java.io.IOException;
 import java.util.HashMap;
 import java.util.Map;
 
@@ -61,12 +60,12 @@ public class ConfigurableMajorCompactionIT extends ConfigurableMacBase {
   public static class TestCompactionStrategy extends CompactionStrategy {
 
     @Override
-    public boolean shouldCompact(MajorCompactionRequest request) throws IOException {
+    public boolean shouldCompact(MajorCompactionRequest request) {
       return request.getFiles().size() == 5;
     }
 
     @Override
-    public CompactionPlan getCompactionPlan(MajorCompactionRequest request) throws IOException {
+    public CompactionPlan getCompactionPlan(MajorCompactionRequest request) {
       CompactionPlan plan = new CompactionPlan();
       plan.inputFiles.addAll(request.getFiles().keySet());
       plan.writeParameters = new WriteParameters();
diff --git a/test/src/main/java/org/apache/accumulo/test/GenerateSequentialRFile.java b/test/src/main/java/org/apache/accumulo/test/GenerateSequentialRFile.java
index a1f5568..a580b77 100644
--- a/test/src/main/java/org/apache/accumulo/test/GenerateSequentialRFile.java
+++ b/test/src/main/java/org/apache/accumulo/test/GenerateSequentialRFile.java
@@ -81,7 +81,7 @@ public class GenerateSequentialRFile implements Runnable {
     }
   }
 
-  public static void main(String[] args) throws Exception {
+  public static void main(String[] args) {
     Opts opts = new Opts();
     opts.parseArgs(GenerateSequentialRFile.class.getName(), args);
     new GenerateSequentialRFile(opts).run();
diff --git a/test/src/main/java/org/apache/accumulo/test/HardListIterator.java b/test/src/main/java/org/apache/accumulo/test/HardListIterator.java
index f373d0b..3f70553 100644
--- a/test/src/main/java/org/apache/accumulo/test/HardListIterator.java
+++ b/test/src/main/java/org/apache/accumulo/test/HardListIterator.java
@@ -16,7 +16,6 @@
  */
 package org.apache.accumulo.test;
 
-import java.io.IOException;
 import java.util.Collection;
 import java.util.Collections;
 import java.util.Map;
@@ -57,7 +56,7 @@ public class HardListIterator implements SortedKeyValueIterator<Key,Value> {
 
   @Override
   public void init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options,
-      IteratorEnvironment env) throws IOException {
+      IteratorEnvironment env) {
     if (source != null)
       log.info("HardListIterator ignores/replaces parent source passed in init(): " + source);
 
@@ -93,13 +92,12 @@ public class HardListIterator implements SortedKeyValueIterator<Key,Value> {
   }
 
   @Override
-  public void next() throws IOException {
+  public void next() {
     inner.next();
   }
 
   @Override
-  public void seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
-      throws IOException {
+  public void seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive) {
     seekRng = range;
     // seek to first entry inside range
     if (range.isInfiniteStartKey())
diff --git a/test/src/main/java/org/apache/accumulo/test/InMemoryMapIT.java b/test/src/main/java/org/apache/accumulo/test/InMemoryMapIT.java
index 99aa185..9483966 100644
--- a/test/src/main/java/org/apache/accumulo/test/InMemoryMapIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/InMemoryMapIT.java
@@ -20,7 +20,6 @@ import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.fail;
 
 import java.io.File;
-import java.io.FileNotFoundException;
 import java.io.IOException;
 import java.util.ArrayList;
 import java.util.Arrays;
@@ -91,7 +90,7 @@ public class InMemoryMapIT {
       new File(System.getProperty("user.dir") + "/target"));
 
   @BeforeClass
-  public static void ensureNativeLibrary() throws FileNotFoundException {
+  public static void ensureNativeLibrary() {
     File nativeMapLocation = NativeMapIT.nativeMapLocation();
     System.setProperty("accumulo.native.lib.path", nativeMapLocation.getAbsolutePath());
     if (!NativeMap.isLoaded()) {
@@ -119,7 +118,7 @@ public class InMemoryMapIT {
   }
 
   @Test
-  public void testOneMutationManyKeys() throws IOException {
+  public void testOneMutationManyKeys() {
     Mutation m = new Mutation("a");
     for (int i = 1; i < 6; i++) {
       m.put(new Text("2cf" + i), new Text("2cq" + i), new Value(Integer.toString(i).getBytes()));
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 d5aedaf..a5ba515 100644
--- a/test/src/main/java/org/apache/accumulo/test/MultiTableBatchWriterIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/MultiTableBatchWriterIT.java
@@ -26,8 +26,6 @@ import java.util.Map;
 import java.util.Map.Entry;
 
 import org.apache.accumulo.core.client.AccumuloClient;
-import org.apache.accumulo.core.client.AccumuloException;
-import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.BatchWriter;
 import org.apache.accumulo.core.client.MultiTableBatchWriter;
 import org.apache.accumulo.core.client.MutationsRejectedException;
@@ -57,7 +55,7 @@ public class MultiTableBatchWriterIT extends AccumuloClusterHarness {
   }
 
   @Before
-  public void setUpArgs() throws AccumuloException, AccumuloSecurityException {
+  public void setUpArgs() {
     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 9b38252..79beeb4 100644
--- a/test/src/main/java/org/apache/accumulo/test/NamespacesIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/NamespacesIT.java
@@ -102,7 +102,7 @@ public class NamespacesIT extends AccumuloClusterHarness {
   }
 
   @Before
-  public void setupConnectorAndNamespace() throws Exception {
+  public void setupConnectorAndNamespace() {
     Assume.assumeTrue(getClusterType() == ClusterType.MINI);
 
     // prepare a unique namespace and get a new root client for each test
@@ -133,7 +133,7 @@ public class NamespacesIT extends AccumuloClusterHarness {
   }
 
   @Test
-  public void checkReservedNamespaces() throws Exception {
+  public void checkReservedNamespaces() {
     assertEquals(c.namespaceOperations().defaultNamespace(), Namespace.DEFAULT);
     assertEquals(c.namespaceOperations().systemNamespace(), Namespace.ACCUMULO);
   }
diff --git a/test/src/main/java/org/apache/accumulo/test/NewTableConfigurationIT.java b/test/src/main/java/org/apache/accumulo/test/NewTableConfigurationIT.java
index df9d92b..88677e8 100644
--- a/test/src/main/java/org/apache/accumulo/test/NewTableConfigurationIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/NewTableConfigurationIT.java
@@ -57,7 +57,7 @@ public class NewTableConfigurationIT extends SharedMiniClusterBase {
   }
 
   @AfterClass
-  public static void teardown() throws Exception {
+  public static void teardown() {
     SharedMiniClusterBase.stopMiniCluster();
   }
 
@@ -65,8 +65,8 @@ public class NewTableConfigurationIT extends SharedMiniClusterBase {
    * Test that setting properties more than once overwrites the previous property settings.
    */
   @Test
-  public void testSetPropertiesOverwriteOlderProperties() throws AccumuloSecurityException,
-      AccumuloException, TableExistsException, TableNotFoundException {
+  public void testSetPropertiesOverwriteOlderProperties()
+      throws AccumuloSecurityException, AccumuloException, TableExistsException {
     try (AccumuloClient client = createClient()) {
       String tableName = getUniqueNames(2)[0];
       NewTableConfiguration ntc = new NewTableConfiguration();
@@ -98,8 +98,7 @@ public class NewTableConfigurationIT extends SharedMiniClusterBase {
    * IllegalArgumentException indicating that groups overlap.
    */
   @Test(expected = IllegalArgumentException.class)
-  public void testOverlappingGroupsFail()
-      throws AccumuloSecurityException, AccumuloException, TableExistsException {
+  public void testOverlappingGroupsFail() {
     NewTableConfiguration ntc = new NewTableConfiguration();
     Map<String,Set<Text>> lgroups = new HashMap<>();
     lgroups.put("lg1", ImmutableSet.of(new Text("colFamA"), new Text("colFamB")));
@@ -212,8 +211,7 @@ public class NewTableConfigurationIT extends SharedMiniClusterBase {
    * Verify that properties set using NewTableConfiguration must be table properties.
    */
   @Test(expected = IllegalArgumentException.class)
-  public void testInvalidTablePropertiesSet() throws AccumuloSecurityException, AccumuloException,
-      TableExistsException, TableNotFoundException {
+  public void testInvalidTablePropertiesSet() {
     NewTableConfiguration ntc = new NewTableConfiguration();
     Map<String,String> props = new HashMap<>();
 
@@ -436,8 +434,8 @@ public class NewTableConfigurationIT extends SharedMiniClusterBase {
    * Verify iterator conflicts are discovered
    */
   @Test(expected = IllegalArgumentException.class)
-  public void testIteratorConflictFound1() throws AccumuloException, TableNotFoundException,
-      AccumuloSecurityException, TableExistsException {
+  public void testIteratorConflictFound1()
+      throws AccumuloException, AccumuloSecurityException, TableExistsException {
     try (AccumuloClient client = createClient()) {
       String tableName = getUniqueNames(2)[0];
 
@@ -451,8 +449,8 @@ public class NewTableConfigurationIT extends SharedMiniClusterBase {
   }
 
   @Test(expected = IllegalArgumentException.class)
-  public void testIteratorConflictFound2() throws AccumuloException, TableNotFoundException,
-      AccumuloSecurityException, TableExistsException {
+  public void testIteratorConflictFound2()
+      throws AccumuloException, AccumuloSecurityException, TableExistsException {
     try (AccumuloClient client = createClient()) {
       String tableName = getUniqueNames(2)[0];
 
@@ -466,8 +464,8 @@ public class NewTableConfigurationIT extends SharedMiniClusterBase {
   }
 
   @Test(expected = IllegalArgumentException.class)
-  public void testIteratorConflictFound3() throws AccumuloException, TableNotFoundException,
-      AccumuloSecurityException, TableExistsException {
+  public void testIteratorConflictFound3()
+      throws AccumuloException, AccumuloSecurityException, TableExistsException {
     try (AccumuloClient client = createClient()) {
       String tableName = getUniqueNames(2)[0];
 
@@ -639,7 +637,7 @@ public class NewTableConfigurationIT extends SharedMiniClusterBase {
    * Verify checkDisjoint works with iterators groups.
    */
   @Test(expected = IllegalArgumentException.class)
-  public void testAttachIteratorDisjointCheck() throws AccumuloException {
+  public void testAttachIteratorDisjointCheck() {
     NewTableConfiguration ntc = new NewTableConfiguration();
 
     Map<String,String> props = new HashMap<>();
diff --git a/test/src/main/java/org/apache/accumulo/test/ShellIT.java b/test/src/main/java/org/apache/accumulo/test/ShellIT.java
index a837a51..fc5f3ab 100644
--- a/test/src/main/java/org/apache/accumulo/test/ShellIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ShellIT.java
@@ -61,7 +61,7 @@ public class ShellIT extends SharedMiniClusterBase {
   }
 
   @AfterClass
-  public static void teardown() throws Exception {
+  public static void teardown() {
     SharedMiniClusterBase.stopMiniCluster();
   }
 
@@ -71,7 +71,7 @@ public class ShellIT extends SharedMiniClusterBase {
     StringBuilder sb = new StringBuilder();
 
     @Override
-    public void write(int b) throws IOException {
+    public void write(int b) {
       sb.append((char) (0xff & b));
     }
 
@@ -89,7 +89,7 @@ public class ShellIT extends SharedMiniClusterBase {
     private int offset = 0;
 
     @Override
-    public int read() throws IOException {
+    public int read() {
       if (offset == source.length())
         return '\n';
       else
@@ -280,7 +280,7 @@ public class ShellIT extends SharedMiniClusterBase {
   }
 
   @Test
-  public void userTest() throws Exception {
+  public void userTest() {
     Shell.log.debug("Starting user test --------------------------");
     // Test cannot be done via junit because createuser only prompts for password
     // exec("createuser root", false, "user exists");
diff --git a/test/src/main/java/org/apache/accumulo/test/ShellServerIT.java b/test/src/main/java/org/apache/accumulo/test/ShellServerIT.java
index 2fdbaff..2b6e30e 100644
--- a/test/src/main/java/org/apache/accumulo/test/ShellServerIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ShellServerIT.java
@@ -321,7 +321,7 @@ public class ShellServerIT extends SharedMiniClusterBase {
   }
 
   @AfterClass
-  public static void tearDownAfterClass() throws Exception {
+  public static void tearDownAfterClass() {
     if (traceProcess != null) {
       traceProcess.destroy();
     }
diff --git a/test/src/main/java/org/apache/accumulo/test/SizeCompactionStrategy.java b/test/src/main/java/org/apache/accumulo/test/SizeCompactionStrategy.java
index b0c2b29..99be88f 100644
--- a/test/src/main/java/org/apache/accumulo/test/SizeCompactionStrategy.java
+++ b/test/src/main/java/org/apache/accumulo/test/SizeCompactionStrategy.java
@@ -16,7 +16,6 @@
  */
 package org.apache.accumulo.test;
 
-import java.io.IOException;
 import java.util.Map;
 import java.util.Map.Entry;
 
@@ -36,7 +35,7 @@ public class SizeCompactionStrategy extends CompactionStrategy {
   }
 
   @Override
-  public boolean shouldCompact(MajorCompactionRequest request) throws IOException {
+  public boolean shouldCompact(MajorCompactionRequest request) {
 
     for (DataFileValue dfv : request.getFiles().values())
       if (dfv.getSize() < size)
@@ -46,7 +45,7 @@ public class SizeCompactionStrategy extends CompactionStrategy {
   }
 
   @Override
-  public CompactionPlan getCompactionPlan(MajorCompactionRequest request) throws IOException {
+  public CompactionPlan getCompactionPlan(MajorCompactionRequest request) {
     CompactionPlan plan = new CompactionPlan();
 
     for (Entry<FileRef,DataFileValue> entry : request.getFiles().entrySet())
diff --git a/test/src/main/java/org/apache/accumulo/test/SplitCancelsMajCIT.java b/test/src/main/java/org/apache/accumulo/test/SplitCancelsMajCIT.java
index b474df5..c4ef963 100644
--- a/test/src/main/java/org/apache/accumulo/test/SplitCancelsMajCIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/SplitCancelsMajCIT.java
@@ -53,7 +53,7 @@ public class SplitCancelsMajCIT extends SharedMiniClusterBase {
   }
 
   @AfterClass
-  public static void teardown() throws Exception {
+  public static void teardown() {
     SharedMiniClusterBase.stopMiniCluster();
   }
 
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 ce48f2d..a2312eb 100644
--- a/test/src/main/java/org/apache/accumulo/test/TableOperationsIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/TableOperationsIT.java
@@ -62,7 +62,6 @@ import org.apache.accumulo.harness.AccumuloClusterHarness;
 import org.apache.accumulo.test.functional.BadIterator;
 import org.apache.accumulo.test.functional.FunctionalTestUtils;
 import org.apache.hadoop.io.Text;
-import org.apache.thrift.TException;
 import org.junit.After;
 import org.junit.Before;
 import org.junit.Test;
@@ -92,7 +91,7 @@ public class TableOperationsIT extends AccumuloClusterHarness {
 
   @Test
   public void getDiskUsageErrors() throws TableExistsException, AccumuloException,
-      AccumuloSecurityException, TableNotFoundException, TException {
+      AccumuloSecurityException, TableNotFoundException {
     String tableName = getUniqueNames(1)[0];
     accumuloClient.tableOperations().create(tableName);
     List<DiskUsage> diskUsage = accumuloClient.tableOperations()
@@ -117,7 +116,7 @@ public class TableOperationsIT extends AccumuloClusterHarness {
 
   @Test
   public void getDiskUsage() throws TableExistsException, AccumuloException,
-      AccumuloSecurityException, TableNotFoundException, TException {
+      AccumuloSecurityException, TableNotFoundException {
     final String[] names = getUniqueNames(2);
     String tableName = names[0];
     accumuloClient.tableOperations().create(tableName);
diff --git a/test/src/main/java/org/apache/accumulo/test/TestCompactionStrategy.java b/test/src/main/java/org/apache/accumulo/test/TestCompactionStrategy.java
index df82040..3959ebb 100644
--- a/test/src/main/java/org/apache/accumulo/test/TestCompactionStrategy.java
+++ b/test/src/main/java/org/apache/accumulo/test/TestCompactionStrategy.java
@@ -16,7 +16,6 @@
  */
 package org.apache.accumulo.test;
 
-import java.io.IOException;
 import java.util.Map;
 
 import org.apache.accumulo.server.fs.FileRef;
@@ -41,7 +40,7 @@ public class TestCompactionStrategy extends CompactionStrategy {
   }
 
   @Override
-  public boolean shouldCompact(MajorCompactionRequest request) throws IOException {
+  public boolean shouldCompact(MajorCompactionRequest request) {
     if (shouldCompact)
       return true;
 
@@ -56,7 +55,7 @@ public class TestCompactionStrategy extends CompactionStrategy {
   }
 
   @Override
-  public CompactionPlan getCompactionPlan(MajorCompactionRequest request) throws IOException {
+  public CompactionPlan getCompactionPlan(MajorCompactionRequest request) {
     CompactionPlan plan = new CompactionPlan();
 
     for (FileRef fref : request.getFiles().keySet()) {
diff --git a/test/src/main/java/org/apache/accumulo/test/TestIngest.java b/test/src/main/java/org/apache/accumulo/test/TestIngest.java
index 34df52c..ea53eb2 100644
--- a/test/src/main/java/org/apache/accumulo/test/TestIngest.java
+++ b/test/src/main/java/org/apache/accumulo/test/TestIngest.java
@@ -183,7 +183,7 @@ public class TestIngest {
     }
   }
 
-  public static void main(String[] args) throws Exception {
+  public static void main(String[] args) {
 
     Opts opts = new Opts();
     BatchWriterOpts bwOpts = new BatchWriterOpts();
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 3baf99c..50e7ad3 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
@@ -27,7 +27,6 @@ import java.util.concurrent.TimeUnit;
 
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.AccumuloException;
-import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.BatchWriter;
 import org.apache.accumulo.core.client.MutationsRejectedException;
 import org.apache.accumulo.core.client.Scanner;
@@ -128,8 +127,7 @@ public class AddSplitIT extends AccumuloClusterHarness {
   }
 
   private void insertData(AccumuloClient client, String tableName, long ts)
-      throws AccumuloException, AccumuloSecurityException, TableNotFoundException,
-      MutationsRejectedException {
+      throws AccumuloException, TableNotFoundException, MutationsRejectedException {
     BatchWriter bw = client.createBatchWriter(tableName, null);
 
     for (int i = 0; i < 10000; i++) {
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 f066121..501aec5 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
@@ -371,7 +371,7 @@ public class BulkLoadIT extends AccumuloClusterHarness {
   }
 
   private void verifyMetadata(AccumuloClient client, String tableName,
-      Map<String,Set<String>> expectedHashes) throws Exception {
+      Map<String,Set<String>> expectedHashes) {
 
     Set<String> endRowsSeen = new HashSet<>();
 
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/CleanUpIT.java b/test/src/main/java/org/apache/accumulo/test/functional/CleanUpIT.java
index 2dbcb0e..9cf0eeb 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/CleanUpIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/CleanUpIT.java
@@ -60,7 +60,7 @@ public class CleanUpIT extends SharedMiniClusterBase {
   }
 
   @AfterClass
-  public static void teardown() throws Exception {
+  public static void teardown() {
     SharedMiniClusterBase.stopMiniCluster();
   }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ConfigurableCompactionIT.java b/test/src/main/java/org/apache/accumulo/test/functional/ConfigurableCompactionIT.java
index 03bf219..e47e467 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ConfigurableCompactionIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ConfigurableCompactionIT.java
@@ -75,13 +75,13 @@ public class ConfigurableCompactionIT extends ConfigurableMacBase {
     int count = 3;
 
     @Override
-    public boolean shouldCompact(MajorCompactionRequest request) throws IOException {
+    public boolean shouldCompact(MajorCompactionRequest request) {
       return request.getFiles().size() == count;
 
     }
 
     @Override
-    public CompactionPlan getCompactionPlan(MajorCompactionRequest request) throws IOException {
+    public CompactionPlan getCompactionPlan(MajorCompactionRequest request) {
       CompactionPlan result = new CompactionPlan();
       result.inputFiles.addAll(request.getFiles().keySet());
       return result;
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ConfigurableMacBase.java b/test/src/main/java/org/apache/accumulo/test/functional/ConfigurableMacBase.java
index 40b5474..a790250 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ConfigurableMacBase.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ConfigurableMacBase.java
@@ -67,7 +67,7 @@ public class ConfigurableMacBase extends AccumuloITBase {
 
   protected void configure(MiniAccumuloConfigImpl cfg, Configuration hadoopCoreSite) {}
 
-  protected void beforeClusterStart(MiniAccumuloConfigImpl cfg) throws Exception {}
+  protected void beforeClusterStart(MiniAccumuloConfigImpl cfg) {}
 
   protected static final String ROOT_PASSWORD = "testRootPassword1";
 
@@ -176,7 +176,7 @@ public class ConfigurableMacBase extends AccumuloITBase {
   }
 
   @After
-  public void tearDown() throws Exception {
+  public void tearDown() {
     if (cluster != null) {
       try {
         cluster.stop();
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 e52c680..6a32a2a 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
@@ -52,7 +52,7 @@ public class CreateAndUseIT extends AccumuloClusterHarness {
   private static SortedSet<Text> splits;
 
   @BeforeClass
-  public static void createData() throws Exception {
+  public static void createData() {
     splits = new TreeSet<>();
 
     for (int i = 1; i < 256; i++) {
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/DeletedTablesDontFlushIT.java b/test/src/main/java/org/apache/accumulo/test/functional/DeletedTablesDontFlushIT.java
index ab6ea0f..899f3af 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/DeletedTablesDontFlushIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/DeletedTablesDontFlushIT.java
@@ -45,7 +45,7 @@ public class DeletedTablesDontFlushIT extends SharedMiniClusterBase {
   }
 
   @AfterClass
-  public static void teardown() throws Exception {
+  public static void teardown() {
     SharedMiniClusterBase.stopMiniCluster();
   }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/GarbageCollectorIT.java b/test/src/main/java/org/apache/accumulo/test/functional/GarbageCollectorIT.java
index 4182a57..4aaf3f8 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/GarbageCollectorIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/GarbageCollectorIT.java
@@ -37,8 +37,6 @@ import org.apache.accumulo.core.Constants;
 import org.apache.accumulo.core.cli.BatchWriterOpts;
 import org.apache.accumulo.core.cli.ScannerOpts;
 import org.apache.accumulo.core.client.AccumuloClient;
-import org.apache.accumulo.core.client.AccumuloException;
-import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.BatchWriter;
 import org.apache.accumulo.core.client.BatchWriterConfig;
 import org.apache.accumulo.core.client.Scanner;
@@ -95,8 +93,7 @@ public class GarbageCollectorIT extends ConfigurableMacBase {
     hadoopCoreSite.set("fs.file.impl", RawLocalFileSystem.class.getName());
   }
 
-  private void killMacGc() throws ProcessNotFoundException, InterruptedException, KeeperException,
-      AccumuloSecurityException, AccumuloException {
+  private void killMacGc() throws ProcessNotFoundException, InterruptedException, KeeperException {
     // kill gc started by MAC
     getCluster().killProcess(ServerType.GARBAGE_COLLECTOR,
         getCluster().getProcesses().get(ServerType.GARBAGE_COLLECTOR).iterator().next());
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/KerberosIT.java b/test/src/main/java/org/apache/accumulo/test/functional/KerberosIT.java
index 6deb0b7..a62daa9 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/KerberosIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/KerberosIT.java
@@ -111,7 +111,7 @@ public class KerberosIT extends AccumuloITBase {
   }
 
   @AfterClass
-  public static void stopKdc() throws Exception {
+  public static void stopKdc() {
     if (kdc != null) {
       kdc.stop();
     }
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/KerberosProxyIT.java b/test/src/main/java/org/apache/accumulo/test/functional/KerberosProxyIT.java
index 3d4c63f..a7b5fdd 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/KerberosProxyIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/KerberosProxyIT.java
@@ -136,7 +136,7 @@ public class KerberosProxyIT extends AccumuloITBase {
   }
 
   @AfterClass
-  public static void stopKdc() throws Exception {
+  public static void stopKdc() {
     if (kdc != null) {
       kdc.stop();
     }
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/KerberosRenewalIT.java b/test/src/main/java/org/apache/accumulo/test/functional/KerberosRenewalIT.java
index e27baac..17ffde1 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/KerberosRenewalIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/KerberosRenewalIT.java
@@ -93,7 +93,7 @@ public class KerberosRenewalIT extends AccumuloITBase {
   }
 
   @AfterClass
-  public static void stopKdc() throws Exception {
+  public static void stopKdc() {
     if (kdc != null) {
       kdc.stop();
     }
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/MonitorSslIT.java b/test/src/main/java/org/apache/accumulo/test/functional/MonitorSslIT.java
index ddda7e2..f4e50fa 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/MonitorSslIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/MonitorSslIT.java
@@ -23,7 +23,6 @@ import java.net.URL;
 import java.security.KeyManagementException;
 import java.security.NoSuchAlgorithmException;
 import java.security.SecureRandom;
-import java.security.cert.CertificateException;
 import java.security.cert.X509Certificate;
 import java.util.Map;
 
@@ -65,12 +64,10 @@ public class MonitorSslIT extends ConfigurableMacBase {
       justification = "trust manager is okay for testing")
   private static class TestTrustManager implements X509TrustManager {
     @Override
-    public void checkClientTrusted(X509Certificate[] arg0, String arg1)
-        throws CertificateException {}
+    public void checkClientTrusted(X509Certificate[] arg0, String arg1) {}
 
     @Override
-    public void checkServerTrusted(X509Certificate[] arg0, String arg1)
-        throws CertificateException {}
+    public void checkServerTrusted(X509Certificate[] arg0, String arg1) {}
 
     @Override
     public X509Certificate[] getAcceptedIssuers() {
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 39db95e..1f8df69 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
@@ -38,7 +38,6 @@ import org.apache.accumulo.core.client.BatchWriter;
 import org.apache.accumulo.core.client.BatchWriterConfig;
 import org.apache.accumulo.core.client.MutationsRejectedException;
 import org.apache.accumulo.core.client.Scanner;
-import org.apache.accumulo.core.client.TableExistsException;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.client.security.SecurityErrorCode;
 import org.apache.accumulo.core.client.security.tokens.AuthenticationToken;
@@ -714,8 +713,8 @@ public class PermissionsIT extends AccumuloClusterHarness {
   }
 
   private void testGrantedTablePermission(AccumuloClient test_user_client, ClusterUser normalUser,
-      TablePermission perm, String tableName) throws AccumuloException, TableExistsException,
-      AccumuloSecurityException, TableNotFoundException, MutationsRejectedException {
+      TablePermission perm, String tableName) throws AccumuloException, AccumuloSecurityException,
+      TableNotFoundException, MutationsRejectedException {
     BatchWriter writer;
     Mutation m;
     log.debug("Confirming that the presence of the {} permission properly permits the user", perm);
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 508c111..ef5e41c 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
@@ -28,7 +28,6 @@ import java.io.IOException;
 import java.io.PrintStream;
 import java.net.URL;
 import java.security.SecureRandom;
-import java.security.cert.CertificateException;
 import java.security.cert.X509Certificate;
 import java.util.ArrayList;
 import java.util.Collections;
@@ -127,7 +126,7 @@ public class ReadWriteIT extends AccumuloClusterHarness {
   }
 
   @Test(expected = RuntimeException.class)
-  public void invalidInstanceName() throws Exception {
+  public void invalidInstanceName() {
     try (AccumuloClient client = Accumulo.newClient()
         .to("fake_instance_name", cluster.getZooKeepers()).as(getAdminPrincipal(), getAdminToken())
         .build()) {
@@ -538,12 +537,10 @@ public class ReadWriteIT extends AccumuloClusterHarness {
       justification = "trust manager is okay for testing")
   private static class TestTrustManager implements X509TrustManager {
     @Override
-    public void checkClientTrusted(X509Certificate[] arg0, String arg1)
-        throws CertificateException {}
+    public void checkClientTrusted(X509Certificate[] arg0, String arg1) {}
 
     @Override
-    public void checkServerTrusted(X509Certificate[] arg0, String arg1)
-        throws CertificateException {}
+    public void checkServerTrusted(X509Certificate[] arg0, String arg1) {}
 
     @Override
     public X509Certificate[] getAcceptedIssuers() {
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/RegexGroupBalanceIT.java b/test/src/main/java/org/apache/accumulo/test/functional/RegexGroupBalanceIT.java
index 4a17262..7141bab 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/RegexGroupBalanceIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/RegexGroupBalanceIT.java
@@ -47,7 +47,7 @@ import com.google.common.collect.Table;
 public class RegexGroupBalanceIT extends ConfigurableMacBase {
 
   @Override
-  public void beforeClusterStart(MiniAccumuloConfigImpl cfg) throws Exception {
+  public void beforeClusterStart(MiniAccumuloConfigImpl cfg) {
     cfg.setNumTservers(4);
   }
 
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 12d925e..e55ec26 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
@@ -86,7 +86,7 @@ public class RestartIT extends AccumuloClusterHarness {
   private ExecutorService svc;
 
   @Before
-  public void setup() throws Exception {
+  public void setup() {
     svc = Executors.newFixedThreadPool(1);
   }
 
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 fa54510..811125f 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
@@ -70,7 +70,7 @@ public class RestartStressIT extends AccumuloClusterHarness {
   private ExecutorService svc;
 
   @Before
-  public void setup() throws Exception {
+  public void setup() {
     svc = Executors.newFixedThreadPool(1);
   }
 
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 24d853b..07d6d53 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
@@ -27,8 +27,6 @@ import java.util.Map.Entry;
 
 import org.apache.accumulo.cluster.ClusterUser;
 import org.apache.accumulo.core.client.AccumuloClient;
-import org.apache.accumulo.core.client.AccumuloException;
-import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.BatchScanner;
 import org.apache.accumulo.core.client.BatchWriter;
 import org.apache.accumulo.core.client.BatchWriterConfig;
@@ -189,7 +187,7 @@ public class ScanIteratorIT extends AccumuloClusterHarness {
     }
   }
 
-  private void setupIter(ScannerBase scanner) throws Exception {
+  private void setupIter(ScannerBase scanner) {
     IteratorSetting dropMod = new IteratorSetting(50, "dropMod",
         "org.apache.accumulo.test.functional.DropModIter");
     dropMod.addOption("mod", "2");
@@ -212,8 +210,7 @@ public class ScanIteratorIT extends AccumuloClusterHarness {
     runTest(Authorizations.EMPTY, true);
   }
 
-  private void runTest(ScannerBase scanner, Authorizations auths, boolean shouldFail)
-      throws AccumuloSecurityException, AccumuloException, TableNotFoundException {
+  private void runTest(ScannerBase scanner, Authorizations auths, boolean shouldFail) {
     int count = 0;
     for (Map.Entry<Key,Value> entry : scanner) {
       assertEquals(shouldFail ? AuthsIterator.FAIL : AuthsIterator.SUCCESS,
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 9b6c6f3..e927fab 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
@@ -33,7 +33,6 @@ import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertTrue;
 import static org.junit.Assert.fail;
 
-import java.io.IOException;
 import java.security.SecureRandom;
 import java.util.Arrays;
 import java.util.Collection;
@@ -448,12 +447,12 @@ public class SummaryIT extends AccumuloClusterHarness {
     private boolean compact = false;
 
     @Override
-    public boolean shouldCompact(MajorCompactionRequest request) throws IOException {
+    public boolean shouldCompact(MajorCompactionRequest request) {
       return true;
     }
 
     @Override
-    public void gatherInformation(MajorCompactionRequest request) throws IOException {
+    public void gatherInformation(MajorCompactionRequest request) {
       List<Summary> summaries = request.getSummaries(request.getFiles().keySet(),
           conf -> conf.getClassName().contains("FooCounter"));
       if (summaries.size() == 1) {
@@ -466,7 +465,7 @@ public class SummaryIT extends AccumuloClusterHarness {
     }
 
     @Override
-    public CompactionPlan getCompactionPlan(MajorCompactionRequest request) throws IOException {
+    public CompactionPlan getCompactionPlan(MajorCompactionRequest request) {
       if (compact) {
         CompactionPlan cp = new CompactionPlan();
         cp.inputFiles.addAll(request.getFiles().keySet());
diff --git a/test/src/main/java/org/apache/accumulo/test/functional/ZombieTServer.java b/test/src/main/java/org/apache/accumulo/test/functional/ZombieTServer.java
index b5c2b62..0c4280a 100644
--- a/test/src/main/java/org/apache/accumulo/test/functional/ZombieTServer.java
+++ b/test/src/main/java/org/apache/accumulo/test/functional/ZombieTServer.java
@@ -25,7 +25,6 @@ import java.util.Random;
 import java.util.concurrent.TimeUnit;
 
 import org.apache.accumulo.core.Constants;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.conf.SiteConfiguration;
 import org.apache.accumulo.core.master.thrift.TabletServerStatus;
 import org.apache.accumulo.core.securityImpl.thrift.TCredentials;
@@ -46,7 +45,6 @@ import org.apache.accumulo.server.rpc.ServerAddress;
 import org.apache.accumulo.server.rpc.TServerUtils;
 import org.apache.accumulo.server.rpc.ThriftServerType;
 import org.apache.accumulo.server.zookeeper.TransactionWatcher;
-import org.apache.thrift.TException;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -76,8 +74,7 @@ public class ZombieTServer {
     }
 
     @Override
-    public TabletServerStatus getTabletServerStatus(TInfo tinfo, TCredentials credentials)
-        throws ThriftSecurityException, TException {
+    public TabletServerStatus getTabletServerStatus(TInfo tinfo, TCredentials credentials) {
       synchronized (this) {
         if (statusCount++ < 1) {
           TabletServerStatus result = new TabletServerStatus();
@@ -90,8 +87,7 @@ public class ZombieTServer {
     }
 
     @Override
-    public synchronized void halt(TInfo tinfo, TCredentials credentials, String lock)
-        throws ThriftSecurityException, TException {
+    public synchronized void halt(TInfo tinfo, TCredentials credentials, String lock) {
       halted = true;
       notifyAll();
     }
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 187ca11..decec32 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
@@ -23,7 +23,6 @@ import static org.junit.Assert.assertTrue;
 import static org.junit.Assert.fail;
 
 import java.io.File;
-import java.io.IOException;
 
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.BatchWriter;
@@ -107,8 +106,7 @@ public class AccumuloFileOutputFormatIT extends AccumuloClusterHarness {
       int index = 0;
 
       @Override
-      public void map(Key key, Value value, OutputCollector<Key,Value> output, Reporter reporter)
-          throws IOException {
+      public void map(Key key, Value value, OutputCollector<Key,Value> output, Reporter reporter) {
         try {
           try {
             output.collect(key, value);
@@ -128,7 +126,7 @@ public class AccumuloFileOutputFormatIT extends AccumuloClusterHarness {
       public void configure(JobConf job) {}
 
       @Override
-      public void close() throws IOException {
+      public void close() {
         try {
           assertEquals(2, index);
         } catch (AssertionError e) {
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 3cb14be..0b3c0da 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
@@ -20,7 +20,6 @@ import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertNull;
 
 import java.io.File;
-import java.io.IOException;
 import java.util.Collection;
 import java.util.Collections;
 
@@ -75,8 +74,7 @@ public class AccumuloInputFormatIT extends AccumuloClusterHarness {
       int count = 0;
 
       @Override
-      public void map(Key k, Value v, OutputCollector<Key,Value> output, Reporter reporter)
-          throws IOException {
+      public void map(Key k, Value v, OutputCollector<Key,Value> output, Reporter reporter) {
         try {
           if (key != null)
             assertEquals(key.getRow().toString(), new String(v.get()));
@@ -94,7 +92,7 @@ public class AccumuloInputFormatIT extends AccumuloClusterHarness {
       public void configure(JobConf job) {}
 
       @Override
-      public void close() throws IOException {
+      public void close() {
         try {
           assertEquals(100, count);
         } catch (AssertionError e) {
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 a1ced8c..47b4823 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
@@ -20,7 +20,6 @@ import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertNull;
 
 import java.io.File;
-import java.io.IOException;
 import java.util.HashMap;
 import java.util.Map;
 
@@ -60,8 +59,7 @@ public class AccumuloMultiTableInputFormatIT extends AccumuloClusterHarness {
       int count = 0;
 
       @Override
-      public void map(Key k, Value v, OutputCollector<Key,Value> output, Reporter reporter)
-          throws IOException {
+      public void map(Key k, Value v, OutputCollector<Key,Value> output, Reporter reporter) {
         try {
           String tableName = ((org.apache.accumulo.core.client.mapred.RangeInputSplit) reporter
               .getInputSplit()).getTableName();
@@ -80,7 +78,7 @@ public class AccumuloMultiTableInputFormatIT extends AccumuloClusterHarness {
       public void configure(JobConf job) {}
 
       @Override
-      public void close() throws IOException {
+      public void close() {
         try {
           assertEquals(100, count);
         } catch (AssertionError e) {
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 4e608ea..ae2b318 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
@@ -21,7 +21,6 @@ import static org.junit.Assert.assertNull;
 import static org.junit.Assert.fail;
 
 import java.io.File;
-import java.io.IOException;
 import java.util.ArrayList;
 import java.util.Iterator;
 import java.util.List;
@@ -111,7 +110,7 @@ public class AccumuloRowInputFormatIT extends AccumuloClusterHarness {
 
       @Override
       public void map(Text k, PeekingIterator<Entry<Key,Value>> v,
-          OutputCollector<Key,Value> output, Reporter reporter) throws IOException {
+          OutputCollector<Key,Value> output, Reporter reporter) {
         try {
           switch (count) {
             case 0:
@@ -139,7 +138,7 @@ public class AccumuloRowInputFormatIT extends AccumuloClusterHarness {
       public void configure(JobConf job) {}
 
       @Override
-      public void close() throws IOException {
+      public void close() {
         try {
           assertEquals(3, count);
         } catch (AssertionError e) {
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 326afb2..7e105aa 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
@@ -68,8 +68,7 @@ public class TokenFileIT extends AccumuloClusterHarness {
       OutputCollector<Text,Mutation> finalOutput;
 
       @Override
-      public void map(Key k, Value v, OutputCollector<Text,Mutation> output, Reporter reporter)
-          throws IOException {
+      public void map(Key k, Value v, OutputCollector<Text,Mutation> output, Reporter reporter) {
         finalOutput = output;
         try {
           if (key != null)
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 6dd9d9b..c21f327 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
@@ -22,7 +22,6 @@ import static org.junit.Assert.assertTrue;
 import static org.junit.Assert.fail;
 
 import java.io.File;
-import java.io.IOException;
 
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.BatchWriter;
@@ -120,8 +119,7 @@ public class AccumuloFileOutputFormatIT extends AccumuloClusterHarness {
       int index = 0;
 
       @Override
-      protected void map(Key key, Value value, Context context)
-          throws IOException, InterruptedException {
+      protected void map(Key key, Value value, Context context) {
         String table = context.getConfiguration().get("MRTester_tableName");
         assertNotNull(table);
         try {
@@ -139,7 +137,7 @@ public class AccumuloFileOutputFormatIT extends AccumuloClusterHarness {
       }
 
       @Override
-      protected void cleanup(Context context) throws IOException, InterruptedException {
+      protected void cleanup(Context context) {
         String table = context.getConfiguration().get("MRTester_tableName");
         assertNotNull(table);
         try {
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 877017f..a04c30d 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
@@ -33,7 +33,6 @@ import java.util.concurrent.TimeUnit;
 
 import org.apache.accumulo.core.client.AccumuloClient;
 import org.apache.accumulo.core.client.AccumuloException;
-import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.BatchWriter;
 import org.apache.accumulo.core.client.BatchWriterConfig;
 import org.apache.accumulo.core.client.TableNotFoundException;
@@ -205,7 +204,7 @@ public class AccumuloInputFormatIT extends AccumuloClusterHarness {
   }
 
   private void insertData(AccumuloClient client, String tableName, long ts)
-      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+      throws AccumuloException, TableNotFoundException {
     BatchWriter bw = client.createBatchWriter(tableName, null);
 
     for (int i = 0; i < 10000; i++) {
@@ -230,7 +229,7 @@ public class AccumuloInputFormatIT extends AccumuloClusterHarness {
       int count = 0;
 
       @Override
-      protected void map(Key k, Value v, Context context) throws IOException, InterruptedException {
+      protected void map(Key k, Value v, Context context) {
         String table = context.getConfiguration().get("MRTester_tableName");
         assertNotNull(table);
         try {
@@ -246,7 +245,7 @@ public class AccumuloInputFormatIT extends AccumuloClusterHarness {
       }
 
       @Override
-      protected void cleanup(Context context) throws IOException, InterruptedException {
+      protected void cleanup(Context context) {
         String table = context.getConfiguration().get("MRTester_tableName");
         assertNotNull(table);
         try {
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 2d20e49..91b8e76 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
@@ -20,7 +20,6 @@ import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertNull;
 
 import java.io.File;
-import java.io.IOException;
 import java.util.HashMap;
 import java.util.Map;
 
@@ -58,7 +57,7 @@ public class AccumuloMultiTableInputFormatIT extends AccumuloClusterHarness {
       int count = 0;
 
       @Override
-      protected void map(Key k, Value v, Context context) throws IOException, InterruptedException {
+      protected void map(Key k, Value v, Context context) {
         try {
           String tableName = ((org.apache.accumulo.core.client.mapreduce.RangeInputSplit) context
               .getInputSplit()).getTableName();
@@ -74,7 +73,7 @@ public class AccumuloMultiTableInputFormatIT extends AccumuloClusterHarness {
       }
 
       @Override
-      protected void cleanup(Context context) throws IOException, InterruptedException {
+      protected void cleanup(Context context) {
         try {
           assertEquals(100, count);
         } catch (AssertionError e) {
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 ebc954a..821f925 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
@@ -58,7 +58,7 @@ public class AccumuloOutputFormatIT extends AccumuloClusterHarness {
       int count = 0;
 
       @Override
-      protected void map(Key k, Value v, Context context) throws IOException, InterruptedException {
+      protected void map(Key k, Value v, Context context) {
         try {
           if (key != null)
             assertEquals(key.getRow().toString(), new String(v.get()));
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 3849a91..e83ef0e 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
@@ -21,7 +21,6 @@ import static org.junit.Assert.assertNull;
 import static org.junit.Assert.fail;
 
 import java.io.File;
-import java.io.IOException;
 import java.util.ArrayList;
 import java.util.Iterator;
 import java.util.List;
@@ -107,8 +106,7 @@ public class AccumuloRowInputFormatIT extends AccumuloClusterHarness {
       int count = 0;
 
       @Override
-      protected void map(Text k, PeekingIterator<Entry<Key,Value>> v, Context context)
-          throws IOException, InterruptedException {
+      protected void map(Text k, PeekingIterator<Entry<Key,Value>> v, Context context) {
         try {
           switch (count) {
             case 0:
@@ -133,7 +131,7 @@ public class AccumuloRowInputFormatIT extends AccumuloClusterHarness {
       }
 
       @Override
-      protected void cleanup(Context context) throws IOException, InterruptedException {
+      protected void cleanup(Context context) {
         try {
           assertEquals(3, count);
         } catch (AssertionError e) {
diff --git a/test/src/main/java/org/apache/accumulo/test/mapreduce/RowHash.java b/test/src/main/java/org/apache/accumulo/test/mapreduce/RowHash.java
index a11218b..56b8fd3 100644
--- a/test/src/main/java/org/apache/accumulo/test/mapreduce/RowHash.java
+++ b/test/src/main/java/org/apache/accumulo/test/mapreduce/RowHash.java
@@ -23,7 +23,6 @@ import java.util.Collections;
 import org.apache.accumulo.core.cli.ClientOpts;
 import org.apache.accumulo.core.client.Accumulo;
 import org.apache.accumulo.core.client.AccumuloClient;
-import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.admin.DelegationTokenConfig;
 import org.apache.accumulo.core.client.security.tokens.AuthenticationToken;
 import org.apache.accumulo.core.client.security.tokens.KerberosToken;
@@ -81,7 +80,7 @@ public class RowHash extends Configured implements Tool {
       return tableName;
     }
 
-    public void setAccumuloConfigs(Job job) throws AccumuloSecurityException {
+    public void setAccumuloConfigs(Job job) {
       org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator.setClientProperties(
           org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat.class,
           job.getConfiguration(), this.getClientProperties());
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 2baebf0..1e8917c 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
@@ -64,7 +64,7 @@ public class TokenFileIT extends AccumuloClusterHarness {
       int count = 0;
 
       @Override
-      protected void map(Key k, Value v, Context context) throws IOException, InterruptedException {
+      protected void map(Key k, Value v, Context context) {
         try {
           if (key != null)
             assertEquals(key.getRow().toString(), new String(v.get()));
diff --git a/test/src/main/java/org/apache/accumulo/test/master/SuspendedTabletsIT.java b/test/src/main/java/org/apache/accumulo/test/master/SuspendedTabletsIT.java
index ed306f5..1bdc7e9 100644
--- a/test/src/main/java/org/apache/accumulo/test/master/SuspendedTabletsIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/master/SuspendedTabletsIT.java
@@ -313,7 +313,7 @@ public class SuspendedTabletsIT extends ConfigurableMacBase {
       }
     }
 
-    private void scan(ClientContext ctx, String tableName) throws Exception {
+    private void scan(ClientContext ctx, String tableName) {
       Map<String,String> idMap = ctx.tableOperations().tableIdMap();
       String tableId = Objects.requireNonNull(idMap.get(tableName));
       try (MetaDataTableScanner scanner = new MetaDataTableScanner(ctx, new Range())) {
diff --git a/test/src/main/java/org/apache/accumulo/test/mrit/IntegrationTestMapReduce.java b/test/src/main/java/org/apache/accumulo/test/mrit/IntegrationTestMapReduce.java
index fc68266..bdd02cb 100644
--- a/test/src/main/java/org/apache/accumulo/test/mrit/IntegrationTestMapReduce.java
+++ b/test/src/main/java/org/apache/accumulo/test/mrit/IntegrationTestMapReduce.java
@@ -117,19 +117,19 @@ public class IntegrationTestMapReduce extends Configured implements Tool {
       core.addListener(new RunListener() {
 
         @Override
-        public void testStarted(Description description) throws Exception {
+        public void testStarted(Description description) {
           log.info("Starting {}", description);
           context.progress();
         }
 
         @Override
-        public void testFinished(Description description) throws Exception {
+        public void testFinished(Description description) {
           log.info("Finished {}", description);
           context.progress();
         }
 
         @Override
-        public void testFailure(Failure failure) throws Exception {
+        public void testFailure(Failure failure) {
           log.info("Test failed: {}", failure.getDescription(), failure.getException());
           failures.add(failure.getDescription().getMethodName());
           context.progress();
diff --git a/test/src/main/java/org/apache/accumulo/test/performance/NullTserver.java b/test/src/main/java/org/apache/accumulo/test/performance/NullTserver.java
index 84fa2c7..4a97105 100644
--- a/test/src/main/java/org/apache/accumulo/test/performance/NullTserver.java
+++ b/test/src/main/java/org/apache/accumulo/test/performance/NullTserver.java
@@ -29,8 +29,6 @@ import java.util.concurrent.TimeUnit;
 import org.apache.accumulo.core.cli.Help;
 import org.apache.accumulo.core.clientImpl.Table;
 import org.apache.accumulo.core.clientImpl.Tables;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException;
 import org.apache.accumulo.core.conf.DefaultConfiguration;
 import org.apache.accumulo.core.conf.Property;
 import org.apache.accumulo.core.conf.SiteConfiguration;
@@ -57,7 +55,6 @@ import org.apache.accumulo.core.master.thrift.TabletServerStatus;
 import org.apache.accumulo.core.securityImpl.thrift.TCredentials;
 import org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction;
 import org.apache.accumulo.core.tabletserver.thrift.ActiveScan;
-import org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException;
 import org.apache.accumulo.core.tabletserver.thrift.TDurability;
 import org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration;
 import org.apache.accumulo.core.tabletserver.thrift.TUnloadTabletGoal;
@@ -77,7 +74,6 @@ import org.apache.accumulo.server.master.state.TabletLocationState;
 import org.apache.accumulo.server.rpc.TServerUtils;
 import org.apache.accumulo.server.rpc.ThriftServerType;
 import org.apache.accumulo.server.zookeeper.TransactionWatcher;
-import org.apache.thrift.TException;
 
 import com.beust.jcommander.Parameter;
 
@@ -168,125 +164,110 @@ public class NullTserver {
     }
 
     @Override
-    public TabletServerStatus getTabletServerStatus(TInfo tinfo, TCredentials credentials)
-        throws ThriftSecurityException, TException {
+    public TabletServerStatus getTabletServerStatus(TInfo tinfo, TCredentials credentials) {
       return null;
     }
 
     @Override
-    public List<TabletStats> getTabletStats(TInfo tinfo, TCredentials credentials, String tableId)
-        throws ThriftSecurityException, TException {
+    public List<TabletStats> getTabletStats(TInfo tinfo, TCredentials credentials, String tableId) {
       return null;
     }
 
     @Override
-    public TabletStats getHistoricalStats(TInfo tinfo, TCredentials credentials)
-        throws ThriftSecurityException, TException {
+    public TabletStats getHistoricalStats(TInfo tinfo, TCredentials credentials) {
       return null;
     }
 
     @Override
-    public void halt(TInfo tinfo, TCredentials credentials, String lock)
-        throws ThriftSecurityException, TException {}
+    public void halt(TInfo tinfo, TCredentials credentials, String lock) {}
 
     @Override
     public void fastHalt(TInfo tinfo, TCredentials credentials, String lock) {}
 
     @Override
-    public void loadTablet(TInfo tinfo, TCredentials credentials, String lock, TKeyExtent extent)
-        throws TException {}
+    public void loadTablet(TInfo tinfo, TCredentials credentials, String lock, TKeyExtent extent) {}
 
     @Override
     public void unloadTablet(TInfo tinfo, TCredentials credentials, String lock, TKeyExtent extent,
-        TUnloadTabletGoal goal, long requestTime) throws TException {}
+        TUnloadTabletGoal goal, long requestTime) {}
 
     @Override
-    public List<ActiveScan> getActiveScans(TInfo tinfo, TCredentials credentials)
-        throws ThriftSecurityException, TException {
+    public List<ActiveScan> getActiveScans(TInfo tinfo, TCredentials credentials) {
       return new ArrayList<>();
     }
 
     @Override
-    public void chop(TInfo tinfo, TCredentials credentials, String lock, TKeyExtent extent)
-        throws TException {}
+    public void chop(TInfo tinfo, TCredentials credentials, String lock, TKeyExtent extent) {}
 
     @Override
-    public void flushTablet(TInfo tinfo, TCredentials credentials, String lock, TKeyExtent extent)
-        throws TException {
+    public void flushTablet(TInfo tinfo, TCredentials credentials, String lock, TKeyExtent extent) {
 
     }
 
     @Override
     public void compact(TInfo tinfo, TCredentials credentials, String lock, String tableId,
-        ByteBuffer startRow, ByteBuffer endRow) throws TException {
+        ByteBuffer startRow, ByteBuffer endRow) {
 
     }
 
     @Override
     public void flush(TInfo tinfo, TCredentials credentials, String lock, String tableId,
-        ByteBuffer startRow, ByteBuffer endRow) throws TException {
+        ByteBuffer startRow, ByteBuffer endRow) {
 
     }
 
     @Override
-    public List<ActiveCompaction> getActiveCompactions(TInfo tinfo, TCredentials credentials)
-        throws ThriftSecurityException, TException {
+    public List<ActiveCompaction> getActiveCompactions(TInfo tinfo, TCredentials credentials) {
       return new ArrayList<>();
     }
 
     @Override
     public TConditionalSession startConditionalUpdate(TInfo tinfo, TCredentials credentials,
         List<ByteBuffer> authorizations, String tableID, TDurability durability,
-        String classLoaderContext) throws ThriftSecurityException, TException {
+        String classLoaderContext) {
       return null;
     }
 
     @Override
     public List<TCMResult> conditionalUpdate(TInfo tinfo, long sessID,
-        Map<TKeyExtent,List<TConditionalMutation>> mutations, List<String> symbols)
-        throws NoSuchScanIDException, TException {
+        Map<TKeyExtent,List<TConditionalMutation>> mutations, List<String> symbols) {
       return null;
     }
 
     @Override
-    public void invalidateConditionalUpdate(TInfo tinfo, long sessID) throws TException {}
+    public void invalidateConditionalUpdate(TInfo tinfo, long sessID) {}
 
     @Override
-    public void closeConditionalUpdate(TInfo tinfo, long sessID) throws TException {}
+    public void closeConditionalUpdate(TInfo tinfo, long sessID) {}
 
     @Override
-    public List<String> getActiveLogs(TInfo tinfo, TCredentials credentials) throws TException {
+    public List<String> getActiveLogs(TInfo tinfo, TCredentials credentials) {
       return null;
     }
 
     @Override
-    public void removeLogs(TInfo tinfo, TCredentials credentials, List<String> filenames)
-        throws TException {}
+    public void removeLogs(TInfo tinfo, TCredentials credentials, List<String> filenames) {}
 
     @Override
     public TSummaries startGetSummaries(TInfo tinfo, TCredentials credentials,
-        TSummaryRequest request) throws ThriftSecurityException, ThriftTableOperationException,
-        NoSuchScanIDException, TException {
+        TSummaryRequest request) {
       return null;
     }
 
     @Override
     public TSummaries startGetSummariesForPartition(TInfo tinfo, TCredentials credentials,
-        TSummaryRequest request, int modulus, int remainder)
-        throws ThriftSecurityException, NoSuchScanIDException, TException {
+        TSummaryRequest request, int modulus, int remainder) {
       return null;
     }
 
     @Override
     public TSummaries startGetSummariesFromFiles(TInfo tinfo, TCredentials credentials,
-        TSummaryRequest request, Map<String,List<TRowRange>> files)
-        throws ThriftSecurityException, NoSuchScanIDException, TException {
+        TSummaryRequest request, Map<String,List<TRowRange>> files) {
       return null;
     }
 
     @Override
-    public TSummaries contiuneGetSummaries(TInfo tinfo, long sessionId)
-        throws NoSuchScanIDException, TException {
+    public TSummaries contiuneGetSummaries(TInfo tinfo, long sessionId) {
       return null;
     }
   }
diff --git a/test/src/main/java/org/apache/accumulo/test/performance/scan/CollectTabletStats.java b/test/src/main/java/org/apache/accumulo/test/performance/scan/CollectTabletStats.java
index 5dfc098..664a797 100644
--- a/test/src/main/java/org/apache/accumulo/test/performance/scan/CollectTabletStats.java
+++ b/test/src/main/java/org/apache/accumulo/test/performance/scan/CollectTabletStats.java
@@ -387,8 +387,7 @@ public class CollectTabletStats {
     return tabletsToTest;
   }
 
-  private static List<FileRef> getTabletFiles(ServerContext context, KeyExtent ke)
-      throws IOException {
+  private static List<FileRef> getTabletFiles(ServerContext context, KeyExtent ke) {
     return new ArrayList<>(MetadataTableUtil.getDataFileSizes(ke, context).keySet());
   }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/replication/FinishedWorkUpdaterIT.java b/test/src/main/java/org/apache/accumulo/test/replication/FinishedWorkUpdaterIT.java
index 1644332..8e77e38 100644
--- a/test/src/main/java/org/apache/accumulo/test/replication/FinishedWorkUpdaterIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/replication/FinishedWorkUpdaterIT.java
@@ -49,7 +49,7 @@ public class FinishedWorkUpdaterIT extends ConfigurableMacBase {
   private FinishedWorkUpdater updater;
 
   @Before
-  public void configureUpdater() throws Exception {
+  public void configureUpdater() {
     client = createClient();
     updater = new FinishedWorkUpdater(client);
   }
diff --git a/test/src/main/java/org/apache/accumulo/test/replication/KerberosReplicationIT.java b/test/src/main/java/org/apache/accumulo/test/replication/KerberosReplicationIT.java
index 3655fb6..cd6ed1e 100644
--- a/test/src/main/java/org/apache/accumulo/test/replication/KerberosReplicationIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/replication/KerberosReplicationIT.java
@@ -90,7 +90,7 @@ public class KerberosReplicationIT extends AccumuloITBase {
   }
 
   @AfterClass
-  public static void stopKdc() throws Exception {
+  public static void stopKdc() {
     if (kdc != null) {
       kdc.stop();
     }
diff --git a/test/src/main/java/org/apache/accumulo/test/replication/ReplicationIT.java b/test/src/main/java/org/apache/accumulo/test/replication/ReplicationIT.java
index 6ae7569..5ed0573 100644
--- a/test/src/main/java/org/apache/accumulo/test/replication/ReplicationIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/replication/ReplicationIT.java
@@ -213,7 +213,7 @@ public class ReplicationIT extends ConfigurableMacBase {
   }
 
   @Test
-  public void replicationTableCreated() throws AccumuloException, AccumuloSecurityException {
+  public void replicationTableCreated() {
     try (AccumuloClient client = createClient()) {
       assertTrue(client.tableOperations().exists(ReplicationTable.NAME));
       assertEquals(ReplicationTable.ID.canonicalID(),
diff --git a/test/src/main/java/org/apache/accumulo/test/replication/ReplicationOperationsImplIT.java b/test/src/main/java/org/apache/accumulo/test/replication/ReplicationOperationsImplIT.java
index b4d9c30..4d6f78d 100644
--- a/test/src/main/java/org/apache/accumulo/test/replication/ReplicationOperationsImplIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/replication/ReplicationOperationsImplIT.java
@@ -26,15 +26,11 @@ import java.util.UUID;
 import java.util.concurrent.atomic.AtomicBoolean;
 
 import org.apache.accumulo.core.client.AccumuloClient;
-import org.apache.accumulo.core.client.AccumuloException;
-import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.BatchWriter;
 import org.apache.accumulo.core.client.BatchWriterConfig;
-import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.clientImpl.ClientContext;
 import org.apache.accumulo.core.clientImpl.ReplicationOperationsImpl;
 import org.apache.accumulo.core.clientImpl.Table;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.Value;
@@ -84,15 +80,14 @@ public class ReplicationOperationsImplIT extends ConfigurableMacBase {
   /**
    * Spoof out the Master so we can call the implementation without starting a full instance.
    */
-  private ReplicationOperationsImpl getReplicationOperations() throws Exception {
+  private ReplicationOperationsImpl getReplicationOperations() {
     Master master = EasyMock.createMock(Master.class);
     EasyMock.expect(master.getContext()).andReturn(serverContext).anyTimes();
     EasyMock.replay(master);
 
     final MasterClientServiceHandler mcsh = new MasterClientServiceHandler(master) {
       @Override
-      protected Table.ID getTableId(ClientContext context, String tableName)
-          throws ThriftTableOperationException {
+      protected Table.ID getTableId(ClientContext context, String tableName) {
         try {
           return Table.ID.of(client.tableOperations().tableIdMap().get(tableName));
         } catch (Exception e) {
@@ -105,8 +100,7 @@ public class ReplicationOperationsImplIT extends ConfigurableMacBase {
     return new ReplicationOperationsImpl(context) {
       @Override
       protected boolean getMasterDrain(final TInfo tinfo, final TCredentials rpcCreds,
-          final String tableName, final Set<String> wals)
-          throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+          final String tableName, final Set<String> wals) {
         try {
           return mcsh.drainReplicationTable(tinfo, rpcCreds, tableName, wals);
         } catch (TException e) {
diff --git a/test/src/main/java/org/apache/accumulo/test/replication/StatusCombinerMacIT.java b/test/src/main/java/org/apache/accumulo/test/replication/StatusCombinerMacIT.java
index d5affb1..ce73b60 100644
--- a/test/src/main/java/org/apache/accumulo/test/replication/StatusCombinerMacIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/replication/StatusCombinerMacIT.java
@@ -64,7 +64,7 @@ public class StatusCombinerMacIT extends SharedMiniClusterBase {
   }
 
   @AfterClass
-  public static void teardown() throws Exception {
+  public static void teardown() {
     SharedMiniClusterBase.stopMiniCluster();
   }
 
diff --git a/test/src/main/java/org/apache/accumulo/test/rpc/Mocket.java b/test/src/main/java/org/apache/accumulo/test/rpc/Mocket.java
index 7f2e245..24d36ff 100644
--- a/test/src/main/java/org/apache/accumulo/test/rpc/Mocket.java
+++ b/test/src/main/java/org/apache/accumulo/test/rpc/Mocket.java
@@ -23,7 +23,6 @@ import java.util.concurrent.atomic.AtomicBoolean;
 
 import org.apache.thrift.transport.TServerTransport;
 import org.apache.thrift.transport.TTransport;
-import org.apache.thrift.transport.TTransportException;
 
 import com.google.common.base.Preconditions;
 
@@ -139,7 +138,7 @@ public class Mocket {
     }
 
     @Override
-    public void listen() throws TTransportException {}
+    public void listen() {}
 
     @Override
     public void close() {
@@ -169,17 +168,17 @@ public class Mocket {
     }
 
     @Override
-    public void write(byte[] buf, int off, int len) throws TTransportException {
+    public void write(byte[] buf, int off, int len) {
       output.write(buf, off, len);
     }
 
     @Override
-    public int read(byte[] buf, int off, int len) throws TTransportException {
+    public int read(byte[] buf, int off, int len) {
       return input.read(buf, off, len);
     }
 
     @Override
-    public void open() throws TTransportException {}
+    public void open() {}
 
     @Override
     public boolean isOpen() {
diff --git a/test/src/main/java/org/apache/accumulo/test/rpc/ThriftBehaviorIT.java b/test/src/main/java/org/apache/accumulo/test/rpc/ThriftBehaviorIT.java
index 6612a66..85cccf8 100644
--- a/test/src/main/java/org/apache/accumulo/test/rpc/ThriftBehaviorIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/rpc/ThriftBehaviorIT.java
@@ -124,7 +124,7 @@ public class ThriftBehaviorIT {
   }
 
   @Test
-  public void echoRuntimeFailHandler() throws TException {
+  public void echoRuntimeFailHandler() {
     exception.expect(UnsupportedOperationException.class);
     handler.echoRuntimeFail(KITTY_MSG);
   }
@@ -166,7 +166,7 @@ public class ThriftBehaviorIT {
   }
 
   @Test
-  public void onewayRuntimeFailHandler() throws TException {
+  public void onewayRuntimeFailHandler() {
     exception.expect(UnsupportedOperationException.class);
     handler.onewayRuntimeFail(KITTY_MSG);
   }
diff --git a/test/src/main/java/org/apache/accumulo/test/rpc/thrift/SimpleThriftService.java b/test/src/main/java/org/apache/accumulo/test/rpc/thrift/SimpleThriftService.java
index 0523268..0c6af57 100644
--- a/test/src/main/java/org/apache/accumulo/test/rpc/thrift/SimpleThriftService.java
+++ b/test/src/main/java/org/apache/accumulo/test/rpc/thrift/SimpleThriftService.java
@@ -210,7 +210,7 @@ public class SimpleThriftService {
 
     public static class echoPass_call extends org.apache.thrift.async.TAsyncMethodCall<java.lang.String> {
       private java.lang.String value;
-      public echoPass_call(java.lang.String value, org.apache.thrift.async.AsyncMethodCallback<java.lang.String> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public echoPass_call(java.lang.String value, org.apache.thrift.async.AsyncMethodCallback<java.lang.String> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) {
         super(client, protocolFactory, transport, resultHandler, false);
         this.value = value;
       }
@@ -242,7 +242,7 @@ public class SimpleThriftService {
 
     public static class onewayPass_call extends org.apache.thrift.async.TAsyncMethodCall<Void> {
       private java.lang.String value;
-      public onewayPass_call(java.lang.String value, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public onewayPass_call(java.lang.String value, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) {
         super(client, protocolFactory, transport, resultHandler, true);
         this.value = value;
       }
@@ -255,7 +255,7 @@ public class SimpleThriftService {
         prot.writeMessageEnd();
       }
 
-      public Void getResult() throws org.apache.thrift.TException {
+      public Void getResult() {
         if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) {
           throw new java.lang.IllegalStateException("Method call not finished!");
         }
@@ -274,7 +274,7 @@ public class SimpleThriftService {
 
     public static class echoFail_call extends org.apache.thrift.async.TAsyncMethodCall<java.lang.String> {
       private java.lang.String value;
-      public echoFail_call(java.lang.String value, org.apache.thrift.async.AsyncMethodCallback<java.lang.String> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public echoFail_call(java.lang.String value, org.apache.thrift.async.AsyncMethodCallback<java.lang.String> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) {
         super(client, protocolFactory, transport, resultHandler, false);
         this.value = value;
       }
@@ -306,7 +306,7 @@ public class SimpleThriftService {
 
     public static class onewayFail_call extends org.apache.thrift.async.TAsyncMethodCall<Void> {
       private java.lang.String value;
-      public onewayFail_call(java.lang.String value, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public onewayFail_call(java.lang.String value, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) {
         super(client, protocolFactory, transport, resultHandler, true);
         this.value = value;
       }
@@ -319,7 +319,7 @@ public class SimpleThriftService {
         prot.writeMessageEnd();
       }
 
-      public Void getResult() throws org.apache.thrift.TException {
+      public Void getResult() {
         if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) {
           throw new java.lang.IllegalStateException("Method call not finished!");
         }
@@ -338,7 +338,7 @@ public class SimpleThriftService {
 
     public static class echoRuntimeFail_call extends org.apache.thrift.async.TAsyncMethodCall<java.lang.String> {
       private java.lang.String value;
-      public echoRuntimeFail_call(java.lang.String value, org.apache.thrift.async.AsyncMethodCallback<java.lang.String> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public echoRuntimeFail_call(java.lang.String value, org.apache.thrift.async.AsyncMethodCallback<java.lang.String> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) {
         super(client, protocolFactory, transport, resultHandler, false);
         this.value = value;
       }
@@ -370,7 +370,7 @@ public class SimpleThriftService {
 
     public static class onewayRuntimeFail_call extends org.apache.thrift.async.TAsyncMethodCall<Void> {
       private java.lang.String value;
-      public onewayRuntimeFail_call(java.lang.String value, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public onewayRuntimeFail_call(java.lang.String value, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) {
         super(client, protocolFactory, transport, resultHandler, true);
         this.value = value;
       }
@@ -383,7 +383,7 @@ public class SimpleThriftService {
         prot.writeMessageEnd();
       }
 
-      public Void getResult() throws org.apache.thrift.TException {
+      public Void getResult() {
         if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) {
           throw new java.lang.IllegalStateException("Method call not finished!");
         }
@@ -1123,7 +1123,7 @@ public class SimpleThriftService {
       return sb.toString();
     }
 
-    public void validate() throws org.apache.thrift.TException {
+    public void validate() {
       // check for required fields
       // check for sub-struct validity
     }
@@ -1136,7 +1136,7 @@ public class SimpleThriftService {
       }
     }
 
-    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, java.lang.ClassNotFoundException {
+    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException {
       try {
         read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
       } catch (org.apache.thrift.TException te) {
@@ -1485,7 +1485,7 @@ public class SimpleThriftService {
       return sb.toString();
     }
 
-    public void validate() throws org.apache.thrift.TException {
+    public void validate() {
       // check for required fields
       // check for sub-struct validity
     }
@@ -1498,7 +1498,7 @@ public class SimpleThriftService {
       }
     }
 
-    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, java.lang.ClassNotFoundException {
+    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException {
       try {
         read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
       } catch (org.apache.thrift.TException te) {
@@ -1847,7 +1847,7 @@ public class SimpleThriftService {
       return sb.toString();
     }
 
-    public void validate() throws org.apache.thrift.TException {
+    public void validate() {
       // check for required fields
       // check for sub-struct validity
     }
@@ -1860,7 +1860,7 @@ public class SimpleThriftService {
       }
     }
 
-    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, java.lang.ClassNotFoundException {
+    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException {
       try {
         read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
       } catch (org.apache.thrift.TException te) {
@@ -2209,7 +2209,7 @@ public class SimpleThriftService {
       return sb.toString();
     }
 
-    public void validate() throws org.apache.thrift.TException {
+    public void validate() {
       // check for required fields
       // check for sub-struct validity
     }
@@ -2222,7 +2222,7 @@ public class SimpleThriftService {
       }
     }
 
-    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, java.lang.ClassNotFoundException {
+    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException {
       try {
         read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
       } catch (org.apache.thrift.TException te) {
@@ -2571,7 +2571,7 @@ public class SimpleThriftService {
       return sb.toString();
     }
 
-    public void validate() throws org.apache.thrift.TException {
+    public void validate() {
       // check for required fields
       // check for sub-struct validity
     }
@@ -2584,7 +2584,7 @@ public class SimpleThriftService {
       }
     }
 
-    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, java.lang.ClassNotFoundException {
+    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException {
       try {
         read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
       } catch (org.apache.thrift.TException te) {
@@ -2933,7 +2933,7 @@ public class SimpleThriftService {
       return sb.toString();
     }
 
-    public void validate() throws org.apache.thrift.TException {
+    public void validate() {
       // check for required fields
       // check for sub-struct validity
     }
@@ -2946,7 +2946,7 @@ public class SimpleThriftService {
       }
     }
 
-    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, java.lang.ClassNotFoundException {
+    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException {
       try {
         read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
       } catch (org.apache.thrift.TException te) {
@@ -3295,7 +3295,7 @@ public class SimpleThriftService {
       return sb.toString();
     }
 
-    public void validate() throws org.apache.thrift.TException {
+    public void validate() {
       // check for required fields
       // check for sub-struct validity
     }
@@ -3308,7 +3308,7 @@ public class SimpleThriftService {
       }
     }
 
-    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, java.lang.ClassNotFoundException {
+    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException {
       try {
         read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
       } catch (org.apache.thrift.TException te) {
@@ -3657,7 +3657,7 @@ public class SimpleThriftService {
       return sb.toString();
     }
 
-    public void validate() throws org.apache.thrift.TException {
+    public void validate() {
       // check for required fields
       // check for sub-struct validity
     }
@@ -3670,7 +3670,7 @@ public class SimpleThriftService {
       }
     }
 
-    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, java.lang.ClassNotFoundException {
+    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException {
       try {
         read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
       } catch (org.apache.thrift.TException te) {
@@ -4019,7 +4019,7 @@ public class SimpleThriftService {
       return sb.toString();
     }
 
-    public void validate() throws org.apache.thrift.TException {
+    public void validate() {
       // check for required fields
       // check for sub-struct validity
     }
@@ -4032,7 +4032,7 @@ public class SimpleThriftService {
       }
     }
 
-    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, java.lang.ClassNotFoundException {
+    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException {
       try {
         read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
       } catch (org.apache.thrift.TException te) {
diff --git a/test/src/main/java/org/apache/accumulo/test/start/KeywordStartIT.java b/test/src/main/java/org/apache/accumulo/test/start/KeywordStartIT.java
index 14b36e8..4bfa41e 100644
--- a/test/src/main/java/org/apache/accumulo/test/start/KeywordStartIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/start/KeywordStartIT.java
@@ -22,7 +22,6 @@ import static org.junit.Assert.assertTrue;
 import static org.junit.Assume.assumeTrue;
 
 import java.io.File;
-import java.io.IOException;
 import java.lang.reflect.Method;
 import java.lang.reflect.Modifier;
 import java.util.Arrays;
@@ -73,7 +72,7 @@ public class KeywordStartIT {
   private final Logger log = LoggerFactory.getLogger(getClass());
 
   @Test
-  public void testKeywordsMatch() throws IOException {
+  public void testKeywordsMatch() {
     for (Entry<String,KeywordExecutable> entry : Main.getExecutables(getClass().getClassLoader())
         .entrySet()) {
       assertEquals(entry.getKey(), entry.getValue().keyword());
@@ -99,7 +98,7 @@ public class KeywordStartIT {
   // Note: this test may fail in Eclipse, if the services files haven't been generated by the
   // AutoService annotation processor
   @Test
-  public void testExpectedClasses() throws IOException {
+  public void testExpectedClasses() {
     assumeTrue(new File(System.getProperty("user.dir") + "/src").exists());
     TreeMap<String,Class<? extends KeywordExecutable>> expectSet = new TreeMap<>();
     expectSet.put("admin", Admin.class);
@@ -210,7 +209,7 @@ public class KeywordStartIT {
     }
 
     @Override
-    public void execute(String[] args) throws Exception {}
+    public void execute(String[] args) {}
 
   }
 }
diff --git a/test/src/main/java/org/apache/accumulo/test/util/CertUtils.java b/test/src/main/java/org/apache/accumulo/test/util/CertUtils.java
index b392eaf..f035c3b 100644
--- a/test/src/main/java/org/apache/accumulo/test/util/CertUtils.java
+++ b/test/src/main/java/org/apache/accumulo/test/util/CertUtils.java
@@ -39,7 +39,6 @@ import java.util.Enumeration;
 import java.util.List;
 
 import org.apache.accumulo.core.cli.Help;
-import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.conf.Property;
 import org.apache.accumulo.core.conf.SiteConfiguration;
 import org.apache.commons.io.FileExistsException;
@@ -191,8 +190,8 @@ public class CertUtils {
   public void createAll(File rootKeystoreFile, File localKeystoreFile, File trustStoreFile,
       String keyNamePrefix, String rootKeystorePassword, String keystorePassword,
       String truststorePassword) throws KeyStoreException, CertificateException,
-      NoSuchAlgorithmException, IOException, OperatorCreationException, AccumuloSecurityException,
-      NoSuchProviderException, UnrecoverableKeyException, FileNotFoundException {
+      NoSuchAlgorithmException, IOException, OperatorCreationException, NoSuchProviderException,
+      UnrecoverableKeyException, FileNotFoundException {
     createSelfSignedCert(rootKeystoreFile, keyNamePrefix + "-root", rootKeystorePassword);
     createSignedCert(localKeystoreFile, keyNamePrefix + "-local", keystorePassword,
         rootKeystoreFile.getAbsolutePath(), rootKeystorePassword);
@@ -202,9 +201,8 @@ public class CertUtils {
 
   @SuppressFBWarnings(value = "PATH_TRAVERSAL_IN", justification = "path provided by test")
   public void createPublicCert(File targetKeystoreFile, String keyName, String rootKeystorePath,
-      String rootKeystorePassword, String truststorePassword)
-      throws NoSuchAlgorithmException, CertificateException, FileNotFoundException, IOException,
-      KeyStoreException, UnrecoverableKeyException {
+      String rootKeystorePassword, String truststorePassword) throws NoSuchAlgorithmException,
+      CertificateException, FileNotFoundException, IOException, KeyStoreException {
     KeyStore signerKeystore = KeyStore.getInstance(keystoreType);
     char[] signerPasswordArray = rootKeystorePassword.toCharArray();
     try (FileInputStream fis = new FileInputStream(rootKeystorePath)) {
@@ -222,9 +220,9 @@ public class CertUtils {
 
   @SuppressFBWarnings(value = "PATH_TRAVERSAL_IN", justification = "path provided by test")
   public void createSignedCert(File targetKeystoreFile, String keyName, String keystorePassword,
-      String signerKeystorePath, String signerKeystorePassword) throws KeyStoreException,
-      CertificateException, NoSuchAlgorithmException, IOException, OperatorCreationException,
-      AccumuloSecurityException, UnrecoverableKeyException, NoSuchProviderException {
+      String signerKeystorePath, String signerKeystorePassword)
+      throws KeyStoreException, CertificateException, NoSuchAlgorithmException, IOException,
+      OperatorCreationException, UnrecoverableKeyException {
     KeyStore signerKeystore = KeyStore.getInstance(keystoreType);
     char[] signerPasswordArray = signerKeystorePassword.toCharArray();
     try (FileInputStream fis = new FileInputStream(signerKeystorePath)) {
@@ -249,7 +247,7 @@ public class CertUtils {
 
   public void createSelfSignedCert(File targetKeystoreFile, String keyName, String keystorePassword)
       throws KeyStoreException, CertificateException, NoSuchAlgorithmException, IOException,
-      OperatorCreationException, AccumuloSecurityException, NoSuchProviderException {
+      OperatorCreationException {
     if (targetKeystoreFile.exists()) {
       throw new FileExistsException(targetKeystoreFile);
     }
@@ -268,7 +266,7 @@ public class CertUtils {
     }
   }
 
-  private KeyPair generateKeyPair() throws NoSuchAlgorithmException, NoSuchProviderException {
+  private KeyPair generateKeyPair() throws NoSuchAlgorithmException {
     KeyPairGenerator gen = KeyPairGenerator.getInstance(encryptionAlgorithm);
     gen.initialize(keysize);
     return gen.generateKeyPair();
diff --git a/test/src/test/java/org/apache/accumulo/test/functional/ValueReversingIterator.java b/test/src/test/java/org/apache/accumulo/test/functional/ValueReversingIterator.java
index 12705be..dac8059 100644
--- a/test/src/test/java/org/apache/accumulo/test/functional/ValueReversingIterator.java
+++ b/test/src/test/java/org/apache/accumulo/test/functional/ValueReversingIterator.java
@@ -54,7 +54,7 @@ public class ValueReversingIterator implements SortedKeyValueIterator<Key,Value>
   }
 
   public void init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options,
-      IteratorEnvironment env) throws IOException {
+      IteratorEnvironment env) {
     this.source = source;
   }
 
diff --git a/test/src/test/java/org/apache/accumulo/test/iterator/RegExTest.java b/test/src/test/java/org/apache/accumulo/test/iterator/RegExTest.java
index 722a184..890b823 100644
--- a/test/src/test/java/org/apache/accumulo/test/iterator/RegExTest.java
+++ b/test/src/test/java/org/apache/accumulo/test/iterator/RegExTest.java
@@ -39,7 +39,7 @@ public class RegExTest {
   private static TreeMap<Key,Value> data = new TreeMap<>();
 
   @BeforeClass
-  public static void setupTests() throws Exception {
+  public static void setupTests() {
 
     ArrayList<Character> chars = new ArrayList<>();
     for (char c = 'a'; c <= 'z'; c++)
diff --git a/test/src/test/java/org/apache/accumulo/test/security/KerberosTokenEmbeddedKDCTest.java b/test/src/test/java/org/apache/accumulo/test/security/KerberosTokenEmbeddedKDCTest.java
index 61d623f..91e6058 100644
--- a/test/src/test/java/org/apache/accumulo/test/security/KerberosTokenEmbeddedKDCTest.java
+++ b/test/src/test/java/org/apache/accumulo/test/security/KerberosTokenEmbeddedKDCTest.java
@@ -54,7 +54,7 @@ public class KerberosTokenEmbeddedKDCTest {
   }
 
   @AfterClass
-  public static void stopKdc() throws Exception {
+  public static void stopKdc() {
     if (null != kdc) {
       kdc.stop();
     }