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

[GitHub] mikewalch closed pull request #844: Remove unnecessary exceptions

mikewalch closed pull request #844: Remove unnecessary exceptions
URL: https://github.com/apache/accumulo/pull/844
 
 
   

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

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

diff --git a/proxy/src/test/java/org/apache/accumulo/proxy/ProxyServerTest.java b/proxy/src/test/java/org/apache/accumulo/proxy/ProxyServerTest.java
index 76ef4be026..fcae2cff76 100644
--- a/proxy/src/test/java/org/apache/accumulo/proxy/ProxyServerTest.java
+++ b/proxy/src/test/java/org/apache/accumulo/proxy/ProxyServerTest.java
@@ -32,9 +32,6 @@
 import org.easymock.EasyMock;
 import org.junit.Test;
 
-/**
- *
- */
 public class ProxyServerTest {
 
   @Test
diff --git a/server/base/src/main/java/org/apache/accumulo/server/client/BulkImporter.java b/server/base/src/main/java/org/apache/accumulo/server/client/BulkImporter.java
index 1b9323a56c..3ac6bcdda0 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/client/BulkImporter.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/client/BulkImporter.java
@@ -45,7 +45,6 @@
 import org.apache.accumulo.core.clientImpl.Translators;
 import org.apache.accumulo.core.clientImpl.thrift.ClientService;
 import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException;
 import org.apache.accumulo.core.conf.AccumuloConfiguration;
 import org.apache.accumulo.core.conf.Property;
 import org.apache.accumulo.core.data.ByteSequence;
@@ -81,8 +80,7 @@
   private static final Logger log = LoggerFactory.getLogger(BulkImporter.class);
 
   public static List<String> bulkLoad(ServerContext context, long tid, String tableId,
-      List<String> files, String errorDir, boolean setTime) throws IOException, AccumuloException,
-      AccumuloSecurityException, ThriftTableOperationException {
+      List<String> files, String errorDir, boolean setTime) throws IOException {
     AssignmentStats stats = new BulkImporter(context, tid, tableId, setTime).importFiles(files,
         new Path(errorDir));
     List<String> result = new ArrayList<>();
@@ -110,8 +108,7 @@ public BulkImporter(ServerContext context, long tid, String tableId, boolean set
     this.setTime = setTime;
   }
 
-  public AssignmentStats importFiles(List<String> files, Path failureDir) throws IOException,
-      AccumuloException, AccumuloSecurityException, ThriftTableOperationException {
+  public AssignmentStats importFiles(List<String> files, Path failureDir) throws IOException {
 
     int numThreads = context.getConfiguration().getCount(Property.TSERV_BULK_PROCESS_THREADS);
     int numAssignThreads = context.getConfiguration()
diff --git a/server/base/src/main/java/org/apache/accumulo/server/client/ClientServiceHandler.java b/server/base/src/main/java/org/apache/accumulo/server/client/ClientServiceHandler.java
index e6a13991d0..f2d49810f8 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/client/ClientServiceHandler.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/client/ClientServiceHandler.java
@@ -355,7 +355,7 @@ public void revokeNamespacePermission(TInfo tinfo, TCredentials credentials, Str
   }
 
   @Override
-  public boolean isActive(TInfo tinfo, long tid) throws TException {
+  public boolean isActive(TInfo tinfo, long tid) {
     return transactionWatcher.isActive(tid);
   }
 
diff --git a/server/base/src/main/java/org/apache/accumulo/server/conf/ConfigSanityCheck.java b/server/base/src/main/java/org/apache/accumulo/server/conf/ConfigSanityCheck.java
index ff5402c349..fcffcfb1b2 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/conf/ConfigSanityCheck.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/conf/ConfigSanityCheck.java
@@ -42,7 +42,7 @@ public String description() {
   }
 
   @Override
-  public void execute(String[] args) throws Exception {
+  public void execute(String[] args) {
     main(args);
   }
 
diff --git a/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeManager.java b/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeManager.java
index b9b8c96043..3e728292d9 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeManager.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeManager.java
@@ -158,7 +158,7 @@ FSDataOutputStream createSyncable(Path logPath, int buffersize, short replicatio
   Path getFullPath(Table.ID tableId, String path);
 
   // Given a filename, figure out the qualified path given multiple namespaces
-  Path getFullPath(FileType fileType, String fileName) throws IOException;
+  Path getFullPath(FileType fileType, String fileName);
 
   // forward to the appropriate FileSystem object
   ContentSummary getContentSummary(Path dir) throws IOException;
diff --git a/server/base/src/main/java/org/apache/accumulo/server/init/Initialize.java b/server/base/src/main/java/org/apache/accumulo/server/init/Initialize.java
index 64889f6090..f3cecc13e9 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/init/Initialize.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/init/Initialize.java
@@ -42,7 +42,6 @@
 import org.apache.accumulo.core.client.IteratorSetting.Column;
 import org.apache.accumulo.core.clientImpl.Namespace;
 import org.apache.accumulo.core.clientImpl.Table;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.conf.AccumuloConfiguration;
 import org.apache.accumulo.core.conf.DefaultConfiguration;
 import org.apache.accumulo.core.conf.Property;
@@ -777,7 +776,7 @@ private String getInitialPasswordWarning(SiteConfiguration siteConfig) {
   }
 
   private static void initSecurity(ServerContext context, Opts opts, String iid, String rootUser)
-      throws AccumuloSecurityException, ThriftSecurityException, IOException {
+      throws AccumuloSecurityException {
     AuditedSecurityOperation.getInstance(context, true).initializeSecurity(context.rpcCreds(),
         rootUser, opts.rootpass);
   }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/master/LiveTServerSet.java b/server/base/src/main/java/org/apache/accumulo/server/master/LiveTServerSet.java
index c7ad9ef55f..58dca14a10 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/master/LiveTServerSet.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/master/LiveTServerSet.java
@@ -72,7 +72,7 @@
   public class TServerConnection {
     private final HostAndPort address;
 
-    public TServerConnection(HostAndPort addr) throws TException {
+    public TServerConnection(HostAndPort addr) {
       address = addr;
     }
 
@@ -295,7 +295,7 @@ private void deleteServerNode(String serverNode) throws InterruptedException, Ke
 
   private synchronized void checkServer(final Set<TServerInstance> updates,
       final Set<TServerInstance> doomed, final String path, final String zPath)
-      throws TException, InterruptedException, KeeperException {
+      throws InterruptedException, KeeperException {
 
     TServerInfo info = current.get(zPath);
 
diff --git a/server/base/src/main/java/org/apache/accumulo/server/master/recovery/MapRLogCloser.java b/server/base/src/main/java/org/apache/accumulo/server/master/recovery/MapRLogCloser.java
index 6701b14e17..043bf15e74 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/master/recovery/MapRLogCloser.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/master/recovery/MapRLogCloser.java
@@ -31,7 +31,7 @@
   private static final Logger log = LoggerFactory.getLogger(MapRLogCloser.class);
 
   @Override
-  public long close(AccumuloConfiguration conf, VolumeManager fs, Path path) throws IOException {
+  public long close(AccumuloConfiguration conf, VolumeManager fs, Path path) {
     log.info("Recovering file {} by changing permission to readonly", path);
     FileSystem ns = fs.getVolumeByPath(path).getFileSystem();
     FsPermission roPerm = new FsPermission((short) 0444);
diff --git a/server/base/src/main/java/org/apache/accumulo/server/master/recovery/RecoveryPath.java b/server/base/src/main/java/org/apache/accumulo/server/master/recovery/RecoveryPath.java
index 3cdd569d77..e519731344 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/master/recovery/RecoveryPath.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/master/recovery/RecoveryPath.java
@@ -16,8 +16,6 @@
  */
 package org.apache.accumulo.server.master.recovery;
 
-import java.io.IOException;
-
 import org.apache.accumulo.server.fs.VolumeManager;
 import org.apache.accumulo.server.fs.VolumeManager.FileType;
 import org.apache.hadoop.fs.Path;
@@ -25,7 +23,7 @@
 public class RecoveryPath {
 
   // given a wal path, transform it to a recovery path
-  public static Path getRecoveryPath(VolumeManager fs, Path walPath) throws IOException {
+  public static Path getRecoveryPath(VolumeManager fs, Path walPath) {
     if (walPath.depth() >= 3 && walPath.toUri().getScheme() != null) {
       // its a fully qualified path
       String uuid = walPath.getName();
diff --git a/server/base/src/main/java/org/apache/accumulo/server/master/state/TabletStateStore.java b/server/base/src/main/java/org/apache/accumulo/server/master/state/TabletStateStore.java
index e50502762b..4b67163f23 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/master/state/TabletStateStore.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/master/state/TabletStateStore.java
@@ -100,8 +100,7 @@ public static void setLocation(ServerContext context, Assignment assignment)
         .setLocations(Collections.singletonList(assignment));
   }
 
-  protected static TabletStateStore getStoreForTablet(KeyExtent extent, ServerContext context)
-      throws DistributedStoreException {
+  protected static TabletStateStore getStoreForTablet(KeyExtent extent, ServerContext context) {
     if (extent.isRootTablet()) {
       return new ZooTabletStateStore(context);
     } else if (extent.isMeta()) {
diff --git a/server/base/src/main/java/org/apache/accumulo/server/master/state/ZooStore.java b/server/base/src/main/java/org/apache/accumulo/server/master/state/ZooStore.java
index f7e1cc8a4c..73bcdd685b 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/master/state/ZooStore.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/master/state/ZooStore.java
@@ -18,7 +18,6 @@
 
 import static java.nio.charset.StandardCharsets.UTF_8;
 
-import java.io.IOException;
 import java.util.List;
 
 import org.apache.accumulo.fate.zookeeper.IZooReaderWriter;
@@ -37,7 +36,7 @@
   private String basePath;
   private ZooCache cache;
 
-  public ZooStore(ServerContext context) throws IOException {
+  public ZooStore(ServerContext context) {
     this.context = context;
     cache = new ZooCache(context.getZooReaderWriter(), null);
     String zkRoot = context.getZooKeeperRoot();
diff --git a/server/base/src/main/java/org/apache/accumulo/server/master/state/ZooTabletStateStore.java b/server/base/src/main/java/org/apache/accumulo/server/master/state/ZooTabletStateStore.java
index 5dd981ceaf..3389ea9774 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/master/state/ZooTabletStateStore.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/master/state/ZooTabletStateStore.java
@@ -44,12 +44,8 @@ public ZooTabletStateStore(DistributedStore store) {
     this.store = store;
   }
 
-  public ZooTabletStateStore(ServerContext context) throws DistributedStoreException {
-    try {
-      store = new ZooStore(context);
-    } catch (IOException ex) {
-      throw new DistributedStoreException(ex);
-    }
+  public ZooTabletStateStore(ServerContext context) {
+    store = new ZooStore(context);
   }
 
   @Override
@@ -204,7 +200,7 @@ public void suspend(Collection<TabletLocationState> tablets,
   }
 
   @Override
-  public void unsuspend(Collection<TabletLocationState> tablets) throws DistributedStoreException {
+  public void unsuspend(Collection<TabletLocationState> tablets) {
     // no support for suspending root tablet.
   }
 
diff --git a/server/base/src/main/java/org/apache/accumulo/server/problems/ProblemReportingIterator.java b/server/base/src/main/java/org/apache/accumulo/server/problems/ProblemReportingIterator.java
index 55717d69a5..6e7e72f0a1 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/problems/ProblemReportingIterator.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/problems/ProblemReportingIterator.java
@@ -74,7 +74,7 @@ public boolean hasTop() {
 
   @Override
   public void init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options,
-      IteratorEnvironment env) throws IOException {
+      IteratorEnvironment env) {
     throw new UnsupportedOperationException();
   }
 
diff --git a/server/base/src/main/java/org/apache/accumulo/server/problems/ProblemReports.java b/server/base/src/main/java/org/apache/accumulo/server/problems/ProblemReports.java
index 7893cce80e..d9f683f62d 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/problems/ProblemReports.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/problems/ProblemReports.java
@@ -118,7 +118,7 @@ public void run() {
 
   }
 
-  public void printProblems() throws Exception {
+  public void printProblems() {
     for (ProblemReport pr : this) {
       System.out.println(pr.getTableId() + " " + pr.getProblemType() + " " + pr.getResource() + " "
           + pr.getException());
@@ -295,7 +295,7 @@ public static synchronized ProblemReports getInstance(ServerContext context) {
     return instance;
   }
 
-  public static void main(String args[]) throws Exception {
+  public static void main(String args[]) {
     ServerContext context = new ServerContext(new SiteConfiguration());
     getInstance(context).printProblems();
   }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicaSystemHelper.java b/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicaSystemHelper.java
index 4f602244a6..64661ea790 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicaSystemHelper.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicaSystemHelper.java
@@ -19,7 +19,6 @@
 import static java.util.Objects.requireNonNull;
 
 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;
@@ -55,7 +54,7 @@ public ReplicaSystemHelper(ClientContext context) {
    *          Peer that was replicated to
    */
   public void recordNewStatus(Path filePath, Status status, ReplicationTarget target)
-      throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+      throws AccumuloException, TableNotFoundException {
     try (BatchWriter bw = context.createBatchWriter(ReplicationTable.NAME,
         new BatchWriterConfig())) {
       log.debug("Recording new status for {}, {}", filePath, ProtobufUtil.toString(status));
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java b/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java
index 510ae7e63a..fc33a3f123 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java
@@ -134,7 +134,7 @@ public SecurityOperation(ServerContext context, Authorizor author, Authenticator
   }
 
   public void initializeSecurity(TCredentials credentials, String rootPrincipal, byte[] token)
-      throws AccumuloSecurityException, ThriftSecurityException {
+      throws AccumuloSecurityException {
     if (!isSystemUser(credentials))
       throw new AccumuloSecurityException(credentials.getPrincipal(),
           SecurityErrorCode.PERMISSION_DENIED);
@@ -193,28 +193,23 @@ protected void authenticate(TCredentials credentials) throws ThriftSecurityExcep
       if (isKerberos) {
         // If we have kerberos credentials for a user from the network but no account
         // in the system, we need to make one before proceeding
-        try {
-          if (!authenticator.userExists(creds.getPrincipal())) {
-            // If we call the normal createUser method, it will loop back into this method
-            // when it tries to check if the user has permission to create users
-            try {
-              _createUser(credentials, creds, Authorizations.EMPTY);
-            } catch (ThriftSecurityException e) {
-              if (e.getCode() != SecurityErrorCode.USER_EXISTS) {
-                // For Kerberos, a user acct is automatically created because there is no notion of
-                // a password
-                // in the traditional sense of Accumulo users. As such, if a user acct already
-                // exists when we
-                // try to automatically create a user account, we should avoid returning this
-                // exception back to the user.
-                // We want to let USER_EXISTS code pass through and continue
-                throw e;
-              }
+        if (!authenticator.userExists(creds.getPrincipal())) {
+          // If we call the normal createUser method, it will loop back into this method
+          // when it tries to check if the user has permission to create users
+          try {
+            _createUser(credentials, creds, Authorizations.EMPTY);
+          } catch (ThriftSecurityException e) {
+            if (e.getCode() != SecurityErrorCode.USER_EXISTS) {
+              // For Kerberos, a user acct is automatically created because there is no notion of
+              // a password
+              // in the traditional sense of Accumulo users. As such, if a user acct already
+              // exists when we
+              // try to automatically create a user account, we should avoid returning this
+              // exception back to the user.
+              // We want to let USER_EXISTS code pass through and continue
+              throw e;
             }
           }
-        } catch (AccumuloSecurityException e) {
-          log.debug("Failed to determine if user exists", e);
-          throw e.asThriftException();
         }
       }
 
@@ -278,11 +273,7 @@ public Authorizations getUserAuthorizations(TCredentials credentials, String use
       throw new ThriftSecurityException(credentials.getPrincipal(),
           SecurityErrorCode.PERMISSION_DENIED);
 
-    try {
-      return authorizor.getCachedUserAuthorizations(user);
-    } catch (AccumuloSecurityException e) {
-      throw e.asThriftException();
-    }
+    return authorizor.getCachedUserAuthorizations(user);
   }
 
   public Authorizations getUserAuthorizations(TCredentials credentials)
@@ -298,18 +289,13 @@ public Authorizations getUserAuthorizations(TCredentials credentials)
   /**
    * Check if an already authenticated user has specified authorizations.
    */
-  public boolean authenticatedUserHasAuthorizations(TCredentials credentials, List<ByteBuffer> list)
-      throws ThriftSecurityException {
+  public boolean authenticatedUserHasAuthorizations(TCredentials credentials,
+      List<ByteBuffer> list) {
     if (isSystemUser(credentials)) {
       // system user doesn't need record-level authorizations for the tables it reads (for now)
       return list.isEmpty();
     }
-
-    try {
-      return authorizor.isValidAuthorizations(credentials.getPrincipal(), list);
-    } catch (AccumuloSecurityException e) {
-      throw e.asThriftException();
-    }
+    return authorizor.isValidAuthorizations(credentials.getPrincipal(), list);
   }
 
   private boolean hasSystemPermission(TCredentials credentials, SystemPermission permission,
@@ -351,13 +337,9 @@ private boolean _hasSystemPermission(String user, SystemPermission permission, b
 
     targetUserExists(user);
 
-    try {
-      if (useCached)
-        return permHandle.hasCachedSystemPermission(user, permission);
-      return permHandle.hasSystemPermission(user, permission);
-    } catch (AccumuloSecurityException e) {
-      throw e.asThriftException();
-    }
+    if (useCached)
+      return permHandle.hasCachedSystemPermission(user, permission);
+    return permHandle.hasSystemPermission(user, permission);
   }
 
   /**
@@ -393,8 +375,6 @@ protected boolean _hasTablePermission(String user, Table.ID table, TablePermissi
       if (useCached)
         return permHandle.hasCachedTablePermission(user, table.canonicalID(), permission);
       return permHandle.hasTablePermission(user, table.canonicalID(), permission);
-    } catch (AccumuloSecurityException e) {
-      throw e.asThriftException();
     } catch (TableNotFoundException e) {
       throw new ThriftSecurityException(user, SecurityErrorCode.TABLE_DOESNT_EXIST);
     }
@@ -420,8 +400,6 @@ protected boolean _hasNamespacePermission(String user, Namespace.ID namespace,
       if (useCached)
         return permHandle.hasCachedNamespacePermission(user, namespace, permission);
       return permHandle.hasNamespacePermission(user, namespace, permission);
-    } catch (AccumuloSecurityException e) {
-      throw e.asThriftException();
     } catch (NamespaceNotFoundException e) {
       throw new ThriftSecurityException(user, SecurityErrorCode.NAMESPACE_DOESNT_EXIST);
     }
@@ -441,12 +419,8 @@ private boolean canAskAboutOtherUsers(TCredentials credentials, String user)
   private void targetUserExists(String user) throws ThriftSecurityException {
     if (user.equals(getRootUsername()))
       return;
-    try {
-      if (!authenticator.userExists(user))
-        throw new ThriftSecurityException(user, SecurityErrorCode.USER_DOESNT_EXIST);
-    } catch (AccumuloSecurityException e) {
-      throw e.asThriftException();
-    }
+    if (!authenticator.userExists(user))
+      throw new ThriftSecurityException(user, SecurityErrorCode.USER_DOESNT_EXIST);
   }
 
   public boolean canScan(TCredentials credentials, Table.ID tableId, Namespace.ID namespaceId)
@@ -872,11 +846,7 @@ public boolean hasNamespacePermission(TCredentials credentials, String user,
 
   public Set<String> listUsers(TCredentials credentials) throws ThriftSecurityException {
     authenticate(credentials);
-    try {
-      return authenticator.listUsers();
-    } catch (AccumuloSecurityException e) {
-      throw e.asThriftException();
-    }
+    return authenticator.listUsers();
   }
 
   public void deleteTable(TCredentials credentials, Table.ID tableId, Namespace.ID namespaceId)
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/handler/Authenticator.java b/server/base/src/main/java/org/apache/accumulo/server/security/handler/Authenticator.java
index 8022bade0d..07b3102e65 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/handler/Authenticator.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/handler/Authenticator.java
@@ -20,7 +20,6 @@
 
 import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.security.tokens.AuthenticationToken;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.securityImpl.thrift.TCredentials;
 import org.apache.accumulo.server.ServerContext;
 
@@ -35,13 +34,12 @@
 
   boolean validSecurityHandlers(Authorizor auth, PermissionHandler pm);
 
-  void initializeSecurity(TCredentials credentials, String principal, byte[] token)
-      throws AccumuloSecurityException, ThriftSecurityException;
+  void initializeSecurity(TCredentials credentials, String principal, byte[] token);
 
   boolean authenticateUser(String principal, AuthenticationToken token)
       throws AccumuloSecurityException;
 
-  Set<String> listUsers() throws AccumuloSecurityException;
+  Set<String> listUsers();
 
   /**
    * Creates a user with no initial permissions whatsoever
@@ -55,7 +53,7 @@ boolean authenticateUser(String principal, AuthenticationToken token)
   /**
    * Checks if a user exists
    */
-  boolean userExists(String user) throws AccumuloSecurityException;
+  boolean userExists(String user);
 
   Set<Class<? extends AuthenticationToken>> getSupportedTokenTypes();
 
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/handler/Authorizor.java b/server/base/src/main/java/org/apache/accumulo/server/security/handler/Authorizor.java
index 864cffc4b6..8609d9c7fa 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/handler/Authorizor.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/handler/Authorizor.java
@@ -20,7 +20,6 @@
 import java.util.List;
 
 import org.apache.accumulo.core.client.AccumuloSecurityException;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.security.Authorizations;
 import org.apache.accumulo.core.securityImpl.thrift.TCredentials;
 import org.apache.accumulo.server.ServerContext;
@@ -46,7 +45,7 @@
    * Used to initialize security for the root user
    */
   void initializeSecurity(TCredentials credentials, String rootuser)
-      throws AccumuloSecurityException, ThriftSecurityException;
+      throws AccumuloSecurityException;
 
   /**
    * Used to change the authorizations for the user
@@ -57,13 +56,12 @@ void changeAuthorizations(String user, Authorizations authorizations)
   /**
    * Used to get the authorizations for the user
    */
-  Authorizations getCachedUserAuthorizations(String user) throws AccumuloSecurityException;
+  Authorizations getCachedUserAuthorizations(String user);
 
   /**
    * Used to check if a user has valid auths.
    */
-  boolean isValidAuthorizations(String user, List<ByteBuffer> list)
-      throws AccumuloSecurityException;
+  boolean isValidAuthorizations(String user, List<ByteBuffer> list);
 
   /**
    * Initializes a new user
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/handler/InsecureAuthenticator.java b/server/base/src/main/java/org/apache/accumulo/server/security/handler/InsecureAuthenticator.java
index 14113ec3c3..aed4b4a76b 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/handler/InsecureAuthenticator.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/handler/InsecureAuthenticator.java
@@ -20,7 +20,6 @@
 import java.util.HashSet;
 import java.util.Set;
 
-import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.security.tokens.AuthenticationToken;
 import org.apache.accumulo.core.client.security.tokens.NullToken;
 import org.apache.accumulo.core.securityImpl.thrift.TCredentials;
@@ -42,8 +41,7 @@ public boolean validSecurityHandlers(Authorizor auth, PermissionHandler pm) {
   }
 
   @Override
-  public void initializeSecurity(TCredentials credentials, String principal, byte[] token)
-      throws AccumuloSecurityException {}
+  public void initializeSecurity(TCredentials credentials, String principal, byte[] token) {}
 
   @Override
   public boolean authenticateUser(String principal, AuthenticationToken token) {
@@ -51,20 +49,18 @@ public boolean authenticateUser(String principal, AuthenticationToken token) {
   }
 
   @Override
-  public Set<String> listUsers() throws AccumuloSecurityException {
+  public Set<String> listUsers() {
     return Collections.emptySet();
   }
 
   @Override
-  public void createUser(String principal, AuthenticationToken token)
-      throws AccumuloSecurityException {}
+  public void createUser(String principal, AuthenticationToken token) {}
 
   @Override
-  public void dropUser(String user) throws AccumuloSecurityException {}
+  public void dropUser(String user) {}
 
   @Override
-  public void changePassword(String user, AuthenticationToken token)
-      throws AccumuloSecurityException {}
+  public void changePassword(String user, AuthenticationToken token) {}
 
   @Override
   public boolean userExists(String user) {
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/handler/InsecurePermHandler.java b/server/base/src/main/java/org/apache/accumulo/server/security/handler/InsecurePermHandler.java
index 624654f0b8..fcd7158548 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/handler/InsecurePermHandler.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/handler/InsecurePermHandler.java
@@ -16,9 +16,6 @@
  */
 package org.apache.accumulo.server.security.handler;
 
-import org.apache.accumulo.core.client.AccumuloSecurityException;
-import org.apache.accumulo.core.client.NamespaceNotFoundException;
-import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.clientImpl.Namespace;
 import org.apache.accumulo.core.security.NamespacePermission;
 import org.apache.accumulo.core.security.SystemPermission;
@@ -41,86 +38,73 @@ public boolean validSecurityHandlers(Authenticator authent, Authorizor author) {
   }
 
   @Override
-  public void initializeSecurity(TCredentials token, String rootuser)
-      throws AccumuloSecurityException {}
+  public void initializeSecurity(TCredentials token, String rootuser) {}
 
   @Override
-  public boolean hasSystemPermission(String user, SystemPermission permission)
-      throws AccumuloSecurityException {
+  public boolean hasSystemPermission(String user, SystemPermission permission) {
     return true;
   }
 
   @Override
-  public boolean hasCachedSystemPermission(String user, SystemPermission permission)
-      throws AccumuloSecurityException {
+  public boolean hasCachedSystemPermission(String user, SystemPermission permission) {
     return true;
   }
 
   @Override
-  public boolean hasTablePermission(String user, String table, TablePermission permission)
-      throws AccumuloSecurityException, TableNotFoundException {
+  public boolean hasTablePermission(String user, String table, TablePermission permission) {
     return true;
   }
 
   @Override
-  public boolean hasCachedTablePermission(String user, String table, TablePermission permission)
-      throws AccumuloSecurityException, TableNotFoundException {
+  public boolean hasCachedTablePermission(String user, String table, TablePermission permission) {
     return true;
   }
 
   @Override
-  public void grantSystemPermission(String user, SystemPermission permission)
-      throws AccumuloSecurityException {}
+  public void grantSystemPermission(String user, SystemPermission permission) {}
 
   @Override
-  public void revokeSystemPermission(String user, SystemPermission permission)
-      throws AccumuloSecurityException {}
+  public void revokeSystemPermission(String user, SystemPermission permission) {}
 
   @Override
-  public void grantTablePermission(String user, String table, TablePermission permission)
-      throws AccumuloSecurityException, TableNotFoundException {}
+  public void grantTablePermission(String user, String table, TablePermission permission) {}
 
   @Override
-  public void revokeTablePermission(String user, String table, TablePermission permission)
-      throws AccumuloSecurityException, TableNotFoundException {}
+  public void revokeTablePermission(String user, String table, TablePermission permission) {}
 
   @Override
-  public void cleanTablePermissions(String table)
-      throws AccumuloSecurityException, TableNotFoundException {}
+  public void cleanTablePermissions(String table) {}
 
   @Override
-  public void initUser(String user) throws AccumuloSecurityException {}
+  public void initUser(String user) {}
 
   @Override
-  public void cleanUser(String user) throws AccumuloSecurityException {}
+  public void cleanUser(String user) {}
 
   @Override
-  public void initTable(String table) throws AccumuloSecurityException {}
+  public void initTable(String table) {}
 
   @Override
   public boolean hasNamespacePermission(String user, Namespace.ID namespace,
-      NamespacePermission permission) throws AccumuloSecurityException, NamespaceNotFoundException {
+      NamespacePermission permission) {
     return true;
   }
 
   @Override
   public boolean hasCachedNamespacePermission(String user, Namespace.ID namespace,
-      NamespacePermission permission) throws AccumuloSecurityException, NamespaceNotFoundException {
+      NamespacePermission permission) {
     return true;
   }
 
   @Override
   public void grantNamespacePermission(String user, Namespace.ID namespace,
-      NamespacePermission permission)
-      throws AccumuloSecurityException, NamespaceNotFoundException {}
+      NamespacePermission permission) {}
 
   @Override
   public void revokeNamespacePermission(String user, Namespace.ID namespace,
-      NamespacePermission permission)
-      throws AccumuloSecurityException, NamespaceNotFoundException {}
+      NamespacePermission permission) {}
 
   @Override
-  public void cleanNamespacePermissions(Namespace.ID namespace)
-      throws AccumuloSecurityException, NamespaceNotFoundException {}
+  public void cleanNamespacePermissions(Namespace.ID namespace) {}
 
 }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java b/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java
index 2783536e48..49345ec236 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java
@@ -29,7 +29,6 @@
 import org.apache.accumulo.core.client.security.tokens.KerberosToken;
 import org.apache.accumulo.core.clientImpl.DelegationTokenImpl;
 import org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.securityImpl.thrift.TCredentials;
 import org.apache.accumulo.fate.zookeeper.IZooReaderWriter;
 import org.apache.accumulo.fate.zookeeper.ZooCache;
@@ -84,8 +83,7 @@ private void createUserNodeInZk(String principal) throws KeeperException, Interr
   }
 
   @Override
-  public void initializeSecurity(TCredentials credentials, String principal, byte[] token)
-      throws AccumuloSecurityException, ThriftSecurityException {
+  public void initializeSecurity(TCredentials credentials, String principal, byte[] token) {
     try {
       // remove old settings from zookeeper first, if any
       IZooReaderWriter zoo = context.getZooReaderWriter();
@@ -136,7 +134,7 @@ public boolean authenticateUser(String principal, AuthenticationToken token)
   }
 
   @Override
-  public Set<String> listUsers() throws AccumuloSecurityException {
+  public Set<String> listUsers() {
     Set<String> base64Users = zkAuthenticator.listUsers();
     Set<String> readableUsers = new HashSet<>();
     for (String base64User : base64Users) {
@@ -178,13 +176,12 @@ public synchronized void dropUser(String user) throws AccumuloSecurityException
   }
 
   @Override
-  public void changePassword(String principal, AuthenticationToken token)
-      throws AccumuloSecurityException {
+  public void changePassword(String principal, AuthenticationToken token) {
     throw new UnsupportedOperationException("Cannot change password with Kerberos authenticaton");
   }
 
   @Override
-  public synchronized boolean userExists(String user) throws AccumuloSecurityException {
+  public synchronized boolean userExists(String user) {
     user = Base64.getEncoder().encodeToString(user.getBytes(UTF_8));
     return zkAuthenticator.userExists(user);
   }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthorizor.java b/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthorizor.java
index 29047cb08a..9e77a08d9c 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthorizor.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthorizor.java
@@ -23,7 +23,6 @@
 import java.util.List;
 
 import org.apache.accumulo.core.client.AccumuloSecurityException;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.security.Authorizations;
 import org.apache.accumulo.core.securityImpl.thrift.TCredentials;
 import org.apache.accumulo.server.ServerContext;
@@ -52,7 +51,7 @@ public boolean validSecurityHandlers(Authenticator auth, PermissionHandler pm) {
 
   @Override
   public void initializeSecurity(TCredentials credentials, String rootuser)
-      throws AccumuloSecurityException, ThriftSecurityException {
+      throws AccumuloSecurityException {
     zkAuthorizor.initializeSecurity(credentials,
         Base64.getEncoder().encodeToString(rootuser.getBytes(UTF_8)));
   }
@@ -65,14 +64,13 @@ public void changeAuthorizations(String user, Authorizations authorizations)
   }
 
   @Override
-  public Authorizations getCachedUserAuthorizations(String user) throws AccumuloSecurityException {
+  public Authorizations getCachedUserAuthorizations(String user) {
     return zkAuthorizor
         .getCachedUserAuthorizations(Base64.getEncoder().encodeToString(user.getBytes(UTF_8)));
   }
 
   @Override
-  public boolean isValidAuthorizations(String user, List<ByteBuffer> list)
-      throws AccumuloSecurityException {
+  public boolean isValidAuthorizations(String user, List<ByteBuffer> list) {
     return zkAuthorizor
         .isValidAuthorizations(Base64.getEncoder().encodeToString(user.getBytes(UTF_8)), list);
   }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosPermissionHandler.java b/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosPermissionHandler.java
index 7049ead6b7..288f743ae1 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosPermissionHandler.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosPermissionHandler.java
@@ -24,7 +24,6 @@
 import org.apache.accumulo.core.client.NamespaceNotFoundException;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.clientImpl.Namespace;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.security.NamespacePermission;
 import org.apache.accumulo.core.security.SystemPermission;
 import org.apache.accumulo.core.security.TablePermission;
@@ -55,49 +54,46 @@ public boolean validSecurityHandlers(Authenticator authent, Authorizor author) {
 
   @Override
   public void initializeSecurity(TCredentials credentials, String rootuser)
-      throws AccumuloSecurityException, ThriftSecurityException {
+      throws AccumuloSecurityException {
     zkPermissionHandler.initializeSecurity(credentials,
         Base64.getEncoder().encodeToString(rootuser.getBytes(UTF_8)));
   }
 
   @Override
-  public boolean hasSystemPermission(String user, SystemPermission permission)
-      throws AccumuloSecurityException {
+  public boolean hasSystemPermission(String user, SystemPermission permission) {
     return zkPermissionHandler
         .hasSystemPermission(Base64.getEncoder().encodeToString(user.getBytes(UTF_8)), permission);
   }
 
   @Override
-  public boolean hasCachedSystemPermission(String user, SystemPermission permission)
-      throws AccumuloSecurityException {
+  public boolean hasCachedSystemPermission(String user, SystemPermission permission) {
     return zkPermissionHandler.hasCachedSystemPermission(
         Base64.getEncoder().encodeToString(user.getBytes(UTF_8)), permission);
   }
 
   @Override
   public boolean hasTablePermission(String user, String table, TablePermission permission)
-      throws AccumuloSecurityException, TableNotFoundException {
+      throws TableNotFoundException {
     return zkPermissionHandler.hasTablePermission(
         Base64.getEncoder().encodeToString(user.getBytes(UTF_8)), table, permission);
   }
 
   @Override
-  public boolean hasCachedTablePermission(String user, String table, TablePermission permission)
-      throws AccumuloSecurityException, TableNotFoundException {
+  public boolean hasCachedTablePermission(String user, String table, TablePermission permission) {
     return zkPermissionHandler.hasCachedTablePermission(
         Base64.getEncoder().encodeToString(user.getBytes(UTF_8)), table, permission);
   }
 
   @Override
   public boolean hasNamespacePermission(String user, Namespace.ID namespace,
-      NamespacePermission permission) throws AccumuloSecurityException, NamespaceNotFoundException {
+      NamespacePermission permission) throws NamespaceNotFoundException {
     return zkPermissionHandler.hasNamespacePermission(
         Base64.getEncoder().encodeToString(user.getBytes(UTF_8)), namespace, permission);
   }
 
   @Override
   public boolean hasCachedNamespacePermission(String user, Namespace.ID namespace,
-      NamespacePermission permission) throws AccumuloSecurityException, NamespaceNotFoundException {
+      NamespacePermission permission) {
     return zkPermissionHandler.hasCachedNamespacePermission(
         Base64.getEncoder().encodeToString(user.getBytes(UTF_8)), namespace, permission);
   }
@@ -162,7 +158,7 @@ public void initUser(String user) throws AccumuloSecurityException {
   }
 
   @Override
-  public void initTable(String table) throws AccumuloSecurityException {
+  public void initTable(String table) {
     zkPermissionHandler.initTable(table);
   }
 
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/handler/PermissionHandler.java b/server/base/src/main/java/org/apache/accumulo/server/security/handler/PermissionHandler.java
index e81298f976..0b1cd24774 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/handler/PermissionHandler.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/handler/PermissionHandler.java
@@ -20,7 +20,6 @@
 import org.apache.accumulo.core.client.NamespaceNotFoundException;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.clientImpl.Namespace;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.security.NamespacePermission;
 import org.apache.accumulo.core.security.SystemPermission;
 import org.apache.accumulo.core.security.TablePermission;
@@ -48,47 +47,44 @@
    * Used to initialize security for the root user
    */
   void initializeSecurity(TCredentials credentials, String rootuser)
-      throws AccumuloSecurityException, ThriftSecurityException;
+      throws AccumuloSecurityException;
 
   /**
    * Used to get the system permission for the user
    */
-  boolean hasSystemPermission(String user, SystemPermission permission)
-      throws AccumuloSecurityException;
+  boolean hasSystemPermission(String user, SystemPermission permission);
 
   /**
    * Used to get the system permission for the user, with caching due to high frequency operation.
    * NOTE: At this time, this method is unused but is included just in case we need it in the
    * future.
    */
-  boolean hasCachedSystemPermission(String user, SystemPermission permission)
-      throws AccumuloSecurityException;
+  boolean hasCachedSystemPermission(String user, SystemPermission permission);
 
   /**
    * Used to get the table permission of a user for a table
    */
   boolean hasTablePermission(String user, String table, TablePermission permission)
-      throws AccumuloSecurityException, TableNotFoundException;
+      throws TableNotFoundException;
 
   /**
    * Used to get the table permission of a user for a table, with caching. This method is for high
    * frequency operations
    */
-  boolean hasCachedTablePermission(String user, String table, TablePermission permission)
-      throws AccumuloSecurityException, TableNotFoundException;
+  boolean hasCachedTablePermission(String user, String table, TablePermission permission);
 
   /**
    * Used to get the namespace permission of a user for a namespace
    */
   boolean hasNamespacePermission(String user, Namespace.ID namespace,
-      NamespacePermission permission) throws AccumuloSecurityException, NamespaceNotFoundException;
+      NamespacePermission permission) throws NamespaceNotFoundException;
 
   /**
    * Used to get the namespace permission of a user for a namespace, with caching. This method is
    * for high frequency operations
    */
   boolean hasCachedNamespacePermission(String user, Namespace.ID namespace,
-      NamespacePermission permission) throws AccumuloSecurityException, NamespaceNotFoundException;
+      NamespacePermission permission);
 
   /**
    * Gives the user the given system permission
@@ -145,7 +141,7 @@ void cleanNamespacePermissions(Namespace.ID namespace)
   /**
    * Initializes a new user
    */
-  void initTable(String table) throws AccumuloSecurityException;
+  void initTable(String table);
 
   /**
    * Deletes a user
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKAuthenticator.java b/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKAuthenticator.java
index a0ba2805f3..c186bd6305 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKAuthenticator.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKAuthenticator.java
@@ -61,8 +61,7 @@ public void initialize(ServerContext context, boolean initialize) {
   }
 
   @Override
-  public void initializeSecurity(TCredentials credentials, String principal, byte[] token)
-      throws AccumuloSecurityException {
+  public void initializeSecurity(TCredentials credentials, String principal, byte[] token) {
     try {
       // remove old settings from zookeeper first, if any
       IZooReaderWriter zoo = context.getZooReaderWriter();
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKAuthorizor.java b/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKAuthorizor.java
index e11ee42e77..914ae6ad08 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKAuthorizor.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKAuthorizor.java
@@ -164,8 +164,7 @@ public void changeAuthorizations(String user, Authorizations authorizations)
   }
 
   @Override
-  public boolean isValidAuthorizations(String user, List<ByteBuffer> auths)
-      throws AccumuloSecurityException {
+  public boolean isValidAuthorizations(String user, List<ByteBuffer> auths) {
     if (auths.isEmpty()) {
       // avoid deserializing auths from ZK cache
       return true;
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKPermHandler.java b/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKPermHandler.java
index 600c8d34fb..4ae95b28df 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKPermHandler.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/handler/ZKPermHandler.java
@@ -117,8 +117,7 @@ public boolean hasTablePermission(String user, String table, TablePermission per
   }
 
   @Override
-  public boolean hasCachedTablePermission(String user, String table, TablePermission permission)
-      throws AccumuloSecurityException, TableNotFoundException {
+  public boolean hasCachedTablePermission(String user, String table, TablePermission permission) {
     byte[] serializedPerms = zooCache.get(ZKUserPath + "/" + user + ZKUserTablePerms + "/" + table);
     if (serializedPerms != null) {
       return ZKSecurityTool.convertTablePermissions(serializedPerms).contains(permission);
@@ -170,7 +169,7 @@ public boolean hasNamespacePermission(String user, Namespace.ID namespace,
 
   @Override
   public boolean hasCachedNamespacePermission(String user, Namespace.ID namespace,
-      NamespacePermission permission) throws AccumuloSecurityException, NamespaceNotFoundException {
+      NamespacePermission permission) {
     byte[] serializedPerms = zooCache
         .get(ZKUserPath + "/" + user + ZKUserNamespacePerms + "/" + namespace);
     if (serializedPerms != null) {
@@ -491,8 +490,7 @@ public void cleanUser(String user) throws AccumuloSecurityException {
   }
 
   @Override
-  public boolean hasSystemPermission(String user, SystemPermission permission)
-      throws AccumuloSecurityException {
+  public boolean hasSystemPermission(String user, SystemPermission permission) {
     byte[] perms;
     try {
       String path = ZKUserPath + "/" + user + ZKUserSysPerms;
@@ -515,8 +513,7 @@ public boolean hasSystemPermission(String user, SystemPermission permission)
   }
 
   @Override
-  public boolean hasCachedSystemPermission(String user, SystemPermission permission)
-      throws AccumuloSecurityException {
+  public boolean hasCachedSystemPermission(String user, SystemPermission permission) {
     byte[] perms = zooCache.get(ZKUserPath + "/" + user + ZKUserSysPerms);
     if (perms == null)
       return false;
@@ -529,7 +526,7 @@ public boolean validSecurityHandlers(Authenticator authent, Authorizor author) {
   }
 
   @Override
-  public void initTable(String table) throws AccumuloSecurityException {
+  public void initTable(String table) {
     // All proper housekeeping is done on delete and permission granting, no work needs to be done
     // here
   }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/tablets/UniqueNameAllocator.java b/server/base/src/main/java/org/apache/accumulo/server/tablets/UniqueNameAllocator.java
index ae5d6d823a..ce4e6584fa 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/tablets/UniqueNameAllocator.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/tablets/UniqueNameAllocator.java
@@ -56,7 +56,7 @@ public synchronized String getNextName() {
         byte[] max = context.getZooReaderWriter().mutate(nextNamePath, null, ZooUtil.PRIVATE,
             new ZooReaderWriter.Mutator() {
               @Override
-              public byte[] mutate(byte[] currentValue) throws Exception {
+              public byte[] mutate(byte[] currentValue) {
                 long l = Long.parseLong(new String(currentValue, UTF_8), Character.MAX_RADIX);
                 l += allocate;
                 return Long.toString(l, Character.MAX_RADIX).getBytes(UTF_8);
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/Admin.java b/server/base/src/main/java/org/apache/accumulo/server/util/Admin.java
index d982d89b57..f581461db8 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/Admin.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/Admin.java
@@ -563,8 +563,7 @@ private static void printUserConfiguration(AccumuloClient accumuloClient, String
     userWriter.close();
   }
 
-  private void printSystemConfiguration(File outputDirectory)
-      throws IOException, AccumuloException, AccumuloSecurityException {
+  private void printSystemConfiguration(File outputDirectory) throws IOException {
     TreeMap<String,String> conf = new TreeMap<>();
     TreeMap<String,String> site = new TreeMap<>(siteConfig);
     for (Entry<String,String> prop : site.entrySet()) {
@@ -591,8 +590,7 @@ private void printSystemConfiguration(File outputDirectory)
   @SuppressFBWarnings(value = "PATH_TRAVERSAL_IN",
       justification = "code runs in same security context as user who provided input")
   private void printTableConfiguration(AccumuloClient accumuloClient, String tableName,
-      File outputDirectory)
-      throws AccumuloException, TableNotFoundException, IOException, AccumuloSecurityException {
+      File outputDirectory) throws AccumuloException, TableNotFoundException, IOException {
     File tableBackup = new File(outputDirectory, tableName + ".cfg");
     FileWriter writer = new FileWriter(tableBackup);
     writer.write(createTableFormat.format(new String[] {tableName}));
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/CheckForMetadataProblems.java b/server/base/src/main/java/org/apache/accumulo/server/util/CheckForMetadataProblems.java
index 1bcfabdb5e..961bbecd99 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/CheckForMetadataProblems.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/CheckForMetadataProblems.java
@@ -24,7 +24,6 @@
 import java.util.TreeSet;
 
 import org.apache.accumulo.core.client.AccumuloClient;
-import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.Scanner;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Value;
@@ -41,8 +40,7 @@
 public class CheckForMetadataProblems {
   private static boolean sawProblems = false;
 
-  public static void checkTable(String tablename, TreeSet<KeyExtent> tablets, ServerUtilOpts opts)
-      throws AccumuloSecurityException {
+  public static void checkTable(String tablename, TreeSet<KeyExtent> tablets, ServerUtilOpts opts) {
     // sanity check of metadata table entries
     // make sure tablets has no holes, and that it starts and ends w/ null
 
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/DumpZookeeper.java b/server/base/src/main/java/org/apache/accumulo/server/util/DumpZookeeper.java
index a27de3b1f7..24329ff7b3 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/DumpZookeeper.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/DumpZookeeper.java
@@ -19,7 +19,6 @@
 import static java.nio.charset.StandardCharsets.UTF_8;
 
 import java.io.PrintStream;
-import java.io.UnsupportedEncodingException;
 import java.util.Base64;
 
 import org.apache.accumulo.core.cli.Help;
@@ -74,7 +73,7 @@ public static void main(String[] args) {
   }
 
   private static void dump(PrintStream out, String root, String child, int indent)
-      throws KeeperException, InterruptedException, UnsupportedEncodingException {
+      throws KeeperException, InterruptedException {
     String path = root + "/" + child;
     if (root.endsWith("/"))
       path = root + child;
@@ -108,8 +107,7 @@ private static void dump(PrintStream out, String root, String child, int indent)
     }
   }
 
-  private static Encoded value(String path)
-      throws KeeperException, InterruptedException, UnsupportedEncodingException {
+  private static Encoded value(String path) throws KeeperException, InterruptedException {
     byte[] data = zk.getData(path, null);
     for (int i = 0; i < data.length; i++) {
       // does this look like simple ascii?
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/FindOfflineTablets.java b/server/base/src/main/java/org/apache/accumulo/server/util/FindOfflineTablets.java
index 471c8da560..016888a3ab 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/FindOfflineTablets.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/FindOfflineTablets.java
@@ -20,7 +20,6 @@
 import java.util.Set;
 import java.util.concurrent.atomic.AtomicBoolean;
 
-import org.apache.accumulo.core.client.AccumuloException;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.clientImpl.Table;
 import org.apache.accumulo.core.clientImpl.Tables;
@@ -34,7 +33,6 @@
 import org.apache.accumulo.server.cli.ServerUtilOpts;
 import org.apache.accumulo.server.master.LiveTServerSet;
 import org.apache.accumulo.server.master.LiveTServerSet.Listener;
-import org.apache.accumulo.server.master.state.DistributedStoreException;
 import org.apache.accumulo.server.master.state.MetaDataTableScanner;
 import org.apache.accumulo.server.master.state.TServerInstance;
 import org.apache.accumulo.server.master.state.TabletLocationState;
@@ -53,8 +51,7 @@ public static void main(String[] args) throws Exception {
     findOffline(context, null);
   }
 
-  static int findOffline(ServerContext context, String tableName)
-      throws AccumuloException, TableNotFoundException {
+  static int findOffline(ServerContext context, String tableName) throws TableNotFoundException {
 
     final AtomicBoolean scanning = new AtomicBoolean(false);
 
@@ -71,12 +68,7 @@ public void update(LiveTServerSet current, Set<TServerInstance> deleted,
     tservers.startListeningForTabletServerChanges();
     scanning.set(true);
 
-    Iterator<TabletLocationState> zooScanner;
-    try {
-      zooScanner = new ZooTabletStateStore(context).iterator();
-    } catch (DistributedStoreException e) {
-      throw new AccumuloException(e);
-    }
+    Iterator<TabletLocationState> zooScanner = new ZooTabletStateStore(context).iterator();
 
     int offline = 0;
 
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/MasterMetadataUtil.java b/server/base/src/main/java/org/apache/accumulo/server/util/MasterMetadataUtil.java
index f7739a7015..41ce2ea680 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/MasterMetadataUtil.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/MasterMetadataUtil.java
@@ -19,7 +19,6 @@
 import static java.nio.charset.StandardCharsets.UTF_8;
 import static org.apache.accumulo.fate.util.UtilWaitThread.sleepUninterruptibly;
 
-import java.io.IOException;
 import java.util.ArrayList;
 import java.util.Collection;
 import java.util.HashMap;
@@ -100,7 +99,7 @@ public static void addNewTablet(ServerContext context, KeyExtent extent, String
 
   public static KeyExtent fixSplit(ServerContext context, Text metadataEntry,
       SortedMap<ColumnFQ,Value> columns, TServerInstance tserver, ZooLock lock)
-      throws AccumuloException, IOException {
+      throws AccumuloException {
     log.info("Incomplete split {} attempting to fix", metadataEntry);
 
     Value oper = columns.get(TabletsSection.TabletColumnFamily.OLD_PREV_ROW_COLUMN);
@@ -147,7 +146,7 @@ public static KeyExtent fixSplit(ServerContext context, Text metadataEntry,
 
   private static KeyExtent fixSplit(ServerContext context, Table.ID tableId, Text metadataEntry,
       Text metadataPrevEndRow, Value oper, double splitRatio, TServerInstance tserver, String time,
-      long initFlushID, long initCompactID, ZooLock lock) throws AccumuloException, IOException {
+      long initFlushID, long initCompactID, ZooLock lock) throws AccumuloException {
     if (metadataPrevEndRow == null)
       // something is wrong, this should not happen... if a tablet is split, it will always have a
       // prev end row....
@@ -212,8 +211,7 @@ private static TServerInstance getTServerInstance(String address, ZooLock zooLoc
 
   public static void replaceDatafiles(ServerContext context, KeyExtent extent,
       Set<FileRef> datafilesToDelete, Set<FileRef> scanFiles, FileRef path, Long compactionId,
-      DataFileValue size, String address, TServerInstance lastLocation, ZooLock zooLock)
-      throws IOException {
+      DataFileValue size, String address, TServerInstance lastLocation, ZooLock zooLock) {
     replaceDatafiles(context, extent, datafilesToDelete, scanFiles, path, compactionId, size,
         address, lastLocation, zooLock, true);
   }
@@ -221,7 +219,7 @@ public static void replaceDatafiles(ServerContext context, KeyExtent extent,
   public static void replaceDatafiles(ServerContext context, KeyExtent extent,
       Set<FileRef> datafilesToDelete, Set<FileRef> scanFiles, FileRef path, Long compactionId,
       DataFileValue size, String address, TServerInstance lastLocation, ZooLock zooLock,
-      boolean insertDeleteFlags) throws IOException {
+      boolean insertDeleteFlags) {
 
     if (insertDeleteFlags) {
       // add delete flags for those paths before the data file reference is removed
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/MetadataTableUtil.java b/server/base/src/main/java/org/apache/accumulo/server/util/MetadataTableUtil.java
index a5594214b8..b54948594a 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/MetadataTableUtil.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/MetadataTableUtil.java
@@ -290,7 +290,7 @@ public void run(IZooReaderWriter rw)
   }
 
   public static SortedMap<FileRef,DataFileValue> getDataFileSizes(KeyExtent extent,
-      ServerContext context) throws IOException {
+      ServerContext context) {
     TreeMap<FileRef,DataFileValue> sizes = new TreeMap<>();
 
     try (Scanner mdScanner = new ScannerImpl(context, MetadataTable.ID, Authorizations.EMPTY)) {
@@ -359,7 +359,7 @@ public static void finishSplit(KeyExtent extent, Map<FileRef,DataFileValue> data
   }
 
   public static void addDeleteEntries(KeyExtent extent, Set<FileRef> datafilesToDelete,
-      ServerContext context) throws IOException {
+      ServerContext context) {
 
     Table.ID tableId = extent.getTableId();
 
@@ -371,14 +371,13 @@ public static void addDeleteEntries(KeyExtent extent, Set<FileRef> datafilesToDe
     }
   }
 
-  public static void addDeleteEntry(ServerContext context, Table.ID tableId, String path)
-      throws IOException {
+  public static void addDeleteEntry(ServerContext context, Table.ID tableId, String path) {
     update(context, createDeleteMutation(context, tableId, path),
         new KeyExtent(tableId, null, null));
   }
 
   public static Mutation createDeleteMutation(ServerContext context, Table.ID tableId,
-      String pathToRemove) throws IOException {
+      String pathToRemove) {
     Path path = context.getVolumeManager().getFullPath(tableId, pathToRemove);
     Mutation delFlag = new Mutation(new Text(MetadataSchema.DeletesSection.getRowPrefix() + path));
     delFlag.put(EMPTY_TEXT, EMPTY_TEXT, new Value(new byte[] {}));
@@ -445,7 +444,7 @@ public static void splitDatafiles(Text midRow, double splitRatio,
   }
 
   public static void deleteTable(Table.ID tableId, boolean insertDeletes, ServerContext context,
-      ZooLock lock) throws AccumuloException, IOException {
+      ZooLock lock) throws AccumuloException {
     try (Scanner ms = new ScannerImpl(context, MetadataTable.ID, Authorizations.EMPTY);
         BatchWriter bw = new BatchWriterImpl(context, MetadataTable.ID,
             new BatchWriterConfig().setMaxMemory(1000000)
@@ -686,8 +685,7 @@ public static void removeUnusedWALEntries(ServerContext context, KeyExtent exten
     if (extent.isRootTablet()) {
       retryZooKeeperUpdate(context, zooLock, new ZooOperation() {
         @Override
-        public void run(IZooReaderWriter rw)
-            throws KeeperException, InterruptedException, IOException {
+        public void run(IZooReaderWriter rw) throws KeeperException, InterruptedException {
           String root = getZookeeperLogLocation(context);
           for (LogEntry entry : entries) {
             String path = root + "/" + entry.getUniqueID();
@@ -957,7 +955,7 @@ public static void removeBulkLoadEntries(AccumuloClient client, Table.ID tableId
   }
 
   public static List<FileRef> getBulkFilesLoaded(ServerContext context, AccumuloClient client,
-      KeyExtent extent, long tid) throws IOException {
+      KeyExtent extent, long tid) {
     List<FileRef> result = new ArrayList<>();
     try (Scanner mscanner = new IsolatedScanner(client.createScanner(
         extent.isMeta() ? RootTable.NAME : MetadataTable.NAME, Authorizations.EMPTY))) {
@@ -978,7 +976,7 @@ public static void removeBulkLoadEntries(AccumuloClient client, Table.ID tableId
   }
 
   public static Map<Long,? extends Collection<FileRef>> getBulkFilesLoaded(ServerContext context,
-      KeyExtent extent) throws IOException {
+      KeyExtent extent) {
     Text metadataRow = extent.getMetadataEntry();
     Map<Long,List<FileRef>> result = new HashMap<>();
 
@@ -1024,7 +1022,7 @@ public static void removeBulkLoadInProgressFlag(ServerContext context, String pa
   /**
    * During an upgrade from 1.6 to 1.7, we need to add the replication table
    */
-  public static void createReplicationTable(ServerContext context) throws IOException {
+  public static void createReplicationTable(ServerContext context) {
 
     VolumeChooserEnvironment chooserEnv = new VolumeChooserEnvironment(ReplicationTable.ID,
         context);
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/RestoreZookeeper.java b/server/base/src/main/java/org/apache/accumulo/server/util/RestoreZookeeper.java
index 5f781cff52..7dffb213a9 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/RestoreZookeeper.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/RestoreZookeeper.java
@@ -35,7 +35,6 @@
 import org.apache.log4j.Logger;
 import org.apache.zookeeper.KeeperException;
 import org.xml.sax.Attributes;
-import org.xml.sax.SAXException;
 import org.xml.sax.helpers.DefaultHandler;
 
 import com.beust.jcommander.Parameter;
@@ -55,8 +54,7 @@
     }
 
     @Override
-    public void startElement(String uri, String localName, String name, Attributes attributes)
-        throws SAXException {
+    public void startElement(String uri, String localName, String name, Attributes attributes) {
       if ("node".equals(name)) {
         String child = attributes.getValue("name");
         if (child == null)
@@ -81,7 +79,7 @@ public void startElement(String uri, String localName, String name, Attributes a
     }
 
     @Override
-    public void endElement(String uri, String localName, String name) throws SAXException {
+    public void endElement(String uri, String localName, String name) {
       cwd.pop();
     }
 
diff --git a/server/base/src/test/java/org/apache/accumulo/server/AccumuloTest.java b/server/base/src/test/java/org/apache/accumulo/server/AccumuloTest.java
index abf10cd5b6..2bea34e5de 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/AccumuloTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/AccumuloTest.java
@@ -39,7 +39,7 @@
   private Path path;
 
   @Before
-  public void setUp() throws Exception {
+  public void setUp() {
     fs = createMock(FileSystem.class);
     path = createMock(Path.class);
   }
diff --git a/server/base/src/test/java/org/apache/accumulo/server/ServerOptsTest.java b/server/base/src/test/java/org/apache/accumulo/server/ServerOptsTest.java
index 2ab0da01f7..3722eec971 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/ServerOptsTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/ServerOptsTest.java
@@ -28,7 +28,7 @@
   private ServerOpts opts;
 
   @Before
-  public void setUp() throws Exception {
+  public void setUp() {
     opts = new ServerOpts();
   }
 
diff --git a/server/base/src/test/java/org/apache/accumulo/server/client/BulkImporterTest.java b/server/base/src/test/java/org/apache/accumulo/server/client/BulkImporterTest.java
index 75eb277078..4ed13446cf 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/client/BulkImporterTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/client/BulkImporterTest.java
@@ -26,9 +26,6 @@
 import java.util.SortedSet;
 import java.util.TreeSet;
 
-import org.apache.accumulo.core.client.AccumuloException;
-import org.apache.accumulo.core.client.AccumuloSecurityException;
-import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.clientImpl.ClientContext;
 import org.apache.accumulo.core.clientImpl.Table;
 import org.apache.accumulo.core.clientImpl.TabletLocator;
@@ -72,22 +69,20 @@
 
     @Override
     public TabletLocation locateTablet(ClientContext context, Text row, boolean skipRow,
-        boolean retry) throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+        boolean retry) {
       return new TabletLocation(fakeMetaData.tailSet(new KeyExtent(tableId, row, null)).first(),
           "localhost", "1");
     }
 
     @Override
     public <T extends Mutation> void binMutations(ClientContext context, List<T> mutations,
-        Map<String,TabletServerMutations<T>> binnedMutations, List<T> failures)
-        throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+        Map<String,TabletServerMutations<T>> binnedMutations, List<T> failures) {
       throw new NotImplementedException();
     }
 
     @Override
     public List<Range> binRanges(ClientContext context, List<Range> ranges,
-        Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
-        throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+        Map<String,Map<KeyExtent,List<Range>>> binnedRanges) {
       throw new NotImplementedException();
     }
 
@@ -177,7 +172,7 @@ public void testFindOverlappingTablets() throws Exception {
   }
 
   @Test
-  public void testSequentialTablets() throws Exception {
+  public void testSequentialTablets() {
     // ACCUMULO-3967 make sure that the startRow we compute in BulkImporter is actually giving
     // a correct startRow so that findOverlappingTablets works as intended.
 
diff --git a/server/base/src/test/java/org/apache/accumulo/server/conf/ServerConfigurationFactoryTest.java b/server/base/src/test/java/org/apache/accumulo/server/conf/ServerConfigurationFactoryTest.java
index 627648ec5c..83b708f73a 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/conf/ServerConfigurationFactoryTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/conf/ServerConfigurationFactoryTest.java
@@ -53,7 +53,7 @@
   private static SiteConfiguration siteConfig = new SiteConfiguration();
 
   @BeforeClass
-  public static void setUpClass() throws Exception {
+  public static void setUpClass() {
     zcf = createMock(ZooCacheFactory.class);
     zc = createMock(ZooCache.class);
     expect(zcf.getZooCache(eq(ZK_HOST), eq(ZK_TIMEOUT), anyObject(NamespaceConfWatcher.class)))
@@ -74,7 +74,7 @@ public static void setUpClass() throws Exception {
   private ServerConfigurationFactory scf;
 
   @Before
-  public void setUp() throws Exception {
+  public void setUp() {
     context = createMock(ServerContext.class);
     expect(context.getInstanceID()).andReturn(IID).anyTimes();
     expect(context.getProperties()).andReturn(new Properties()).anyTimes();
@@ -83,7 +83,7 @@ public void setUp() throws Exception {
   }
 
   @After
-  public void tearDown() throws Exception {
+  public void tearDown() {
     ServerConfigurationFactory.clearCachedConfigurations();
   }
 
diff --git a/server/base/src/test/java/org/apache/accumulo/server/constraints/MetadataConstraintsTest.java b/server/base/src/test/java/org/apache/accumulo/server/constraints/MetadataConstraintsTest.java
index 2dfce17467..8db6d75bd0 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/constraints/MetadataConstraintsTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/constraints/MetadataConstraintsTest.java
@@ -44,14 +44,14 @@ protected Arbitrator getArbitrator(ServerContext context) {
       return new Arbitrator() {
 
         @Override
-        public boolean transactionAlive(String type, long tid) throws Exception {
+        public boolean transactionAlive(String type, long tid) {
           if (tid == 9)
             throw new RuntimeException("txid 9 reserved for future use");
           return tid == 5 || tid == 7;
         }
 
         @Override
-        public boolean transactionComplete(String type, long tid) throws Exception {
+        public boolean transactionComplete(String type, long tid) {
           return tid != 5 && tid != 7;
         }
       };
diff --git a/server/base/src/test/java/org/apache/accumulo/server/fs/PerTableVolumeChooserTest.java b/server/base/src/test/java/org/apache/accumulo/server/fs/PerTableVolumeChooserTest.java
index a177493fe6..89e8f9efd3 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/fs/PerTableVolumeChooserTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/fs/PerTableVolumeChooserTest.java
@@ -73,7 +73,7 @@ String getTableContext(TableConfiguration tableConf) {
   }
 
   @After
-  public void after() throws Exception {
+  public void after() {
     verify(confFactory, tableConf, systemConf);
   }
 
@@ -88,14 +88,14 @@ private VolumeChooser getDelegate(ChooserScope scope) {
   }
 
   @Test
-  public void testInitScopeSelectsRandomChooser() throws Exception {
+  public void testInitScopeSelectsRandomChooser() {
     replay(confFactory, tableConf, systemConf);
     VolumeChooser delegate = getDelegate(ChooserScope.INIT);
     assertSame(RandomVolumeChooser.class, delegate.getClass());
   }
 
   @Test
-  public void testTableScopeUsingTableProperty() throws Exception {
+  public void testTableScopeUsingTableProperty() {
     expect(tableConf.get(PerTableVolumeChooser.TABLE_VOLUME_CHOOSER))
         .andReturn(MockChooser1.class.getName());
     replay(confFactory, tableConf, systemConf);
@@ -105,7 +105,7 @@ public void testTableScopeUsingTableProperty() throws Exception {
   }
 
   @Test
-  public void testTableScopeUsingDefaultScopeProperty() throws Exception {
+  public void testTableScopeUsingDefaultScopeProperty() {
     expect(tableConf.get(PerTableVolumeChooser.TABLE_VOLUME_CHOOSER)).andReturn(null).once();
     expect(systemConf.get(PerTableVolumeChooser.getPropertyNameForScope(ChooserScope.DEFAULT)))
         .andReturn(MockChooser2.class.getName()).once();
@@ -116,7 +116,7 @@ public void testTableScopeUsingDefaultScopeProperty() throws Exception {
   }
 
   @Test
-  public void testTableScopeWithNoConfig() throws Exception {
+  public void testTableScopeWithNoConfig() {
     expect(tableConf.get(PerTableVolumeChooser.TABLE_VOLUME_CHOOSER)).andReturn(null).once();
     expect(systemConf.get(PerTableVolumeChooser.getPropertyNameForScope(ChooserScope.DEFAULT)))
         .andReturn(null).once();
@@ -128,7 +128,7 @@ public void testTableScopeWithNoConfig() throws Exception {
   }
 
   @Test
-  public void testTableScopeWithBadDelegate() throws Exception {
+  public void testTableScopeWithBadDelegate() {
     expect(tableConf.get(PerTableVolumeChooser.TABLE_VOLUME_CHOOSER)).andReturn(null).once();
     expect(systemConf.get(PerTableVolumeChooser.getPropertyNameForScope(ChooserScope.DEFAULT)))
         .andReturn("not a valid class name").once();
@@ -140,7 +140,7 @@ public void testTableScopeWithBadDelegate() throws Exception {
   }
 
   @Test
-  public void testLoggerScopeUsingLoggerProperty() throws Exception {
+  public void testLoggerScopeUsingLoggerProperty() {
     expect(systemConf.get(PerTableVolumeChooser.getPropertyNameForScope(ChooserScope.LOGGER)))
         .andReturn(MockChooser1.class.getName()).once();
     replay(confFactory, tableConf, systemConf);
@@ -150,7 +150,7 @@ public void testLoggerScopeUsingLoggerProperty() throws Exception {
   }
 
   @Test
-  public void testLoggerScopeUsingDefaultProperty() throws Exception {
+  public void testLoggerScopeUsingDefaultProperty() {
     expect(systemConf.get(PerTableVolumeChooser.getPropertyNameForScope(ChooserScope.LOGGER)))
         .andReturn(null).once();
     expect(systemConf.get(PerTableVolumeChooser.getPropertyNameForScope(ChooserScope.DEFAULT)))
@@ -162,7 +162,7 @@ public void testLoggerScopeUsingDefaultProperty() throws Exception {
   }
 
   @Test
-  public void testLoggerScopeWithNoConfig() throws Exception {
+  public void testLoggerScopeWithNoConfig() {
     expect(systemConf.get(PerTableVolumeChooser.getPropertyNameForScope(ChooserScope.LOGGER)))
         .andReturn(null).once();
     expect(systemConf.get(PerTableVolumeChooser.getPropertyNameForScope(ChooserScope.DEFAULT)))
@@ -175,7 +175,7 @@ public void testLoggerScopeWithNoConfig() throws Exception {
   }
 
   @Test
-  public void testLoggerScopeWithBadDelegate() throws Exception {
+  public void testLoggerScopeWithBadDelegate() {
     expect(systemConf.get(PerTableVolumeChooser.getPropertyNameForScope(ChooserScope.LOGGER)))
         .andReturn(null).once();
     expect(systemConf.get(PerTableVolumeChooser.getPropertyNameForScope(ChooserScope.DEFAULT)))
diff --git a/server/base/src/test/java/org/apache/accumulo/server/fs/PreferredVolumeChooserTest.java b/server/base/src/test/java/org/apache/accumulo/server/fs/PreferredVolumeChooserTest.java
index a745ad6b5a..076b29a131 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/fs/PreferredVolumeChooserTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/fs/PreferredVolumeChooserTest.java
@@ -69,7 +69,7 @@ ServerConfigurationFactory loadConfFactory(VolumeChooserEnvironment env) {
   }
 
   @After
-  public void after() throws Exception {
+  public void after() {
     verify(confFactory, tableConf, systemConf);
   }
 
@@ -84,14 +84,14 @@ public void after() throws Exception {
   }
 
   @Test
-  public void testInitScopeSelectsRandomlyFromAll() throws Exception {
+  public void testInitScopeSelectsRandomlyFromAll() {
     replay(confFactory, tableConf, systemConf);
     String[] volumes = choose(ChooserScope.INIT);
     assertSame(ALL_OPTIONS, volumes);
   }
 
   @Test
-  public void testTableScopeUsingTableProperty() throws Exception {
+  public void testTableScopeUsingTableProperty() {
     expect(tableConf.get(PreferredVolumeChooser.TABLE_PREFERRED_VOLUMES)).andReturn("2,1");
     replay(confFactory, tableConf, systemConf);
 
@@ -101,7 +101,7 @@ public void testTableScopeUsingTableProperty() throws Exception {
   }
 
   @Test
-  public void testTableScopeUsingDefaultScopeProperty() throws Exception {
+  public void testTableScopeUsingDefaultScopeProperty() {
     expect(tableConf.get(PreferredVolumeChooser.TABLE_PREFERRED_VOLUMES)).andReturn(null).once();
     expect(systemConf.get(PreferredVolumeChooser.getPropertyNameForScope(ChooserScope.DEFAULT)))
         .andReturn("3,2").once();
@@ -113,7 +113,7 @@ public void testTableScopeUsingDefaultScopeProperty() throws Exception {
   }
 
   @Test
-  public void testTableScopeWithNoConfig() throws Exception {
+  public void testTableScopeWithNoConfig() {
     expect(tableConf.get(PreferredVolumeChooser.TABLE_PREFERRED_VOLUMES)).andReturn(null).once();
     expect(systemConf.get(PreferredVolumeChooser.getPropertyNameForScope(ChooserScope.DEFAULT)))
         .andReturn(null).once();
@@ -125,7 +125,7 @@ public void testTableScopeWithNoConfig() throws Exception {
   }
 
   @Test
-  public void testTableScopeWithEmptySet() throws Exception {
+  public void testTableScopeWithEmptySet() {
     expect(tableConf.get(PreferredVolumeChooser.TABLE_PREFERRED_VOLUMES)).andReturn(",").once();
     replay(confFactory, tableConf, systemConf);
 
@@ -135,7 +135,7 @@ public void testTableScopeWithEmptySet() throws Exception {
   }
 
   @Test
-  public void testTableScopeWithUnrecognizedVolumes() throws Exception {
+  public void testTableScopeWithUnrecognizedVolumes() {
     expect(tableConf.get(PreferredVolumeChooser.TABLE_PREFERRED_VOLUMES)).andReturn(null).once();
     expect(systemConf.get(PreferredVolumeChooser.getPropertyNameForScope(ChooserScope.DEFAULT)))
         .andReturn("4").once();
@@ -147,7 +147,7 @@ public void testTableScopeWithUnrecognizedVolumes() throws Exception {
   }
 
   @Test
-  public void testLoggerScopeUsingLoggerProperty() throws Exception {
+  public void testLoggerScopeUsingLoggerProperty() {
     expect(systemConf.get(PreferredVolumeChooser.getPropertyNameForScope(ChooserScope.LOGGER)))
         .andReturn("2,1").once();
     replay(confFactory, tableConf, systemConf);
@@ -158,7 +158,7 @@ public void testLoggerScopeUsingLoggerProperty() throws Exception {
   }
 
   @Test
-  public void testLoggerScopeUsingDefaultProperty() throws Exception {
+  public void testLoggerScopeUsingDefaultProperty() {
     expect(systemConf.get(PreferredVolumeChooser.getPropertyNameForScope(ChooserScope.LOGGER)))
         .andReturn(null).once();
     expect(systemConf.get(PreferredVolumeChooser.getPropertyNameForScope(ChooserScope.DEFAULT)))
@@ -171,7 +171,7 @@ public void testLoggerScopeUsingDefaultProperty() throws Exception {
   }
 
   @Test
-  public void testLoggerScopeWithNoConfig() throws Exception {
+  public void testLoggerScopeWithNoConfig() {
     expect(systemConf.get(PreferredVolumeChooser.getPropertyNameForScope(ChooserScope.LOGGER)))
         .andReturn(null).once();
     expect(systemConf.get(PreferredVolumeChooser.getPropertyNameForScope(ChooserScope.DEFAULT)))
@@ -184,7 +184,7 @@ public void testLoggerScopeWithNoConfig() throws Exception {
   }
 
   @Test
-  public void testLoggerScopeWithEmptySet() throws Exception {
+  public void testLoggerScopeWithEmptySet() {
     expect(systemConf.get(PreferredVolumeChooser.getPropertyNameForScope(ChooserScope.LOGGER)))
         .andReturn(",").once();
     replay(confFactory, tableConf, systemConf);
@@ -195,7 +195,7 @@ public void testLoggerScopeWithEmptySet() throws Exception {
   }
 
   @Test
-  public void testLoggerScopeWithUnrecognizedVolumes() throws Exception {
+  public void testLoggerScopeWithUnrecognizedVolumes() {
     expect(systemConf.get(PreferredVolumeChooser.getPropertyNameForScope(ChooserScope.LOGGER)))
         .andReturn(null).once();
     expect(systemConf.get(PreferredVolumeChooser.getPropertyNameForScope(ChooserScope.DEFAULT)))
diff --git a/server/base/src/test/java/org/apache/accumulo/server/fs/VolumeManagerImplTest.java b/server/base/src/test/java/org/apache/accumulo/server/fs/VolumeManagerImplTest.java
index e7a1a5a6f2..5a01a8382f 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/fs/VolumeManagerImplTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/fs/VolumeManagerImplTest.java
@@ -46,25 +46,25 @@ public void setup() throws Exception {
   }
 
   @Test
-  public void defaultTabletDirWithoutTableId() throws Exception {
+  public void defaultTabletDirWithoutTableId() {
     thrown.expect(IllegalArgumentException.class);
     fs.getFullPath(FileType.TABLE, "/default_tablet/");
   }
 
   @Test
-  public void tabletDirWithoutTableId() throws Exception {
+  public void tabletDirWithoutTableId() {
     thrown.expect(IllegalArgumentException.class);
     fs.getFullPath(FileType.TABLE, "/t-0000001/");
   }
 
   @Test
-  public void defaultTabletFileWithoutTableId() throws Exception {
+  public void defaultTabletFileWithoutTableId() {
     thrown.expect(IllegalArgumentException.class);
     fs.getFullPath(FileType.TABLE, "/default_tablet/C0000001.rf");
   }
 
   @Test
-  public void tabletFileWithoutTableId() throws Exception {
+  public void tabletFileWithoutTableId() {
     thrown.expect(IllegalArgumentException.class);
     fs.getFullPath(FileType.TABLE, "/t-0000001/C0000001.rf");
   }
diff --git a/server/base/src/test/java/org/apache/accumulo/server/fs/VolumeUtilTest.java b/server/base/src/test/java/org/apache/accumulo/server/fs/VolumeUtilTest.java
index b0ea26ad53..5444ea5415 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/fs/VolumeUtilTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/fs/VolumeUtilTest.java
@@ -226,7 +226,7 @@ public void testSame() throws Exception {
   }
 
   @Test
-  public void testRootTableReplacement() throws IOException {
+  public void testRootTableReplacement() {
     List<Pair<Path,Path>> replacements = new ArrayList<>();
     replacements.add(new Pair<>(new Path("file:/foo/v1"), new Path("file:/foo/v8")));
     replacements.add(new Pair<>(new Path("file:/foo/v2"), new Path("file:/foo/v9")));
diff --git a/server/base/src/test/java/org/apache/accumulo/server/init/InitializeTest.java b/server/base/src/test/java/org/apache/accumulo/server/init/InitializeTest.java
index 2ef34b6f5d..674a942c94 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/init/InitializeTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/init/InitializeTest.java
@@ -49,7 +49,7 @@
 
   @SuppressWarnings("deprecation")
   @Before
-  public void setUp() throws Exception {
+  public void setUp() {
     conf = createMock(Configuration.class);
     fs = createMock(VolumeManager.class);
     sconf = createMock(SiteConfiguration.class);
diff --git a/server/base/src/test/java/org/apache/accumulo/server/iterators/MetadataBulkLoadFilterTest.java b/server/base/src/test/java/org/apache/accumulo/server/iterators/MetadataBulkLoadFilterTest.java
index 1fb6577e93..b70acc8760 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/iterators/MetadataBulkLoadFilterTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/iterators/MetadataBulkLoadFilterTest.java
@@ -41,12 +41,12 @@
 public class MetadataBulkLoadFilterTest {
   static class TestArbitrator implements Arbitrator {
     @Override
-    public boolean transactionAlive(String type, long tid) throws Exception {
+    public boolean transactionAlive(String type, long tid) {
       return tid == 5;
     }
 
     @Override
-    public boolean transactionComplete(String type, long tid) throws Exception {
+    public boolean transactionComplete(String type, long tid) {
       if (tid == 9)
         throw new RuntimeException();
       return tid != 5 && tid != 7;
diff --git a/server/base/src/test/java/org/apache/accumulo/server/master/balancer/BaseHostRegexTableLoadBalancerTest.java b/server/base/src/test/java/org/apache/accumulo/server/master/balancer/BaseHostRegexTableLoadBalancerTest.java
index d5c661d0b9..3fadbe4f40 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/master/balancer/BaseHostRegexTableLoadBalancerTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/master/balancer/BaseHostRegexTableLoadBalancerTest.java
@@ -37,7 +37,6 @@
 import org.apache.accumulo.core.clientImpl.Namespace;
 import org.apache.accumulo.core.clientImpl.Table;
 import org.apache.accumulo.core.clientImpl.TableOperationsImpl;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.conf.AccumuloConfiguration;
 import org.apache.accumulo.core.conf.ConfigurationCopy;
 import org.apache.accumulo.core.conf.DefaultConfiguration;
@@ -53,7 +52,6 @@
 import org.apache.accumulo.server.conf.TableConfiguration;
 import org.apache.accumulo.server.master.state.TServerInstance;
 import org.apache.hadoop.io.Text;
-import org.apache.thrift.TException;
 import org.easymock.EasyMock;
 
 public abstract class BaseHostRegexTableLoadBalancerTest extends HostRegexTableLoadBalancer {
@@ -142,8 +140,7 @@ public long getUpdateCount() {
 
   protected class TestDefaultBalancer extends DefaultLoadBalancer {
     @Override
-    public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, Table.ID tableId)
-        throws ThriftSecurityException, TException {
+    public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, Table.ID tableId) {
       String tableName = idToTableName(tableId);
       TServerInstance initialLocation = initialTableLocation.get(tableName);
       if (tserver.equals(initialLocation)) {
diff --git a/server/base/src/test/java/org/apache/accumulo/server/master/balancer/ChaoticLoadBalancerTest.java b/server/base/src/test/java/org/apache/accumulo/server/master/balancer/ChaoticLoadBalancerTest.java
index 0abb1dceac..9d5a1239d6 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/master/balancer/ChaoticLoadBalancerTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/master/balancer/ChaoticLoadBalancerTest.java
@@ -29,7 +29,6 @@
 import java.util.TreeMap;
 
 import org.apache.accumulo.core.clientImpl.Table;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.dataImpl.KeyExtent;
 import org.apache.accumulo.core.master.thrift.TableInfo;
 import org.apache.accumulo.core.master.thrift.TabletServerStatus;
@@ -38,7 +37,6 @@
 import org.apache.accumulo.server.master.state.TServerInstance;
 import org.apache.accumulo.server.master.state.TabletMigration;
 import org.apache.hadoop.io.Text;
-import org.apache.thrift.TException;
 import org.junit.Test;
 
 public class ChaoticLoadBalancerTest {
@@ -68,8 +66,7 @@ TabletServerStatus getStatus(TServerInstance server) {
   class TestChaoticLoadBalancer extends ChaoticLoadBalancer {
 
     @Override
-    public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, Table.ID table)
-        throws ThriftSecurityException, TException {
+    public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, Table.ID table) {
       List<TabletStats> result = new ArrayList<>();
       for (KeyExtent extent : servers.get(tserver).extents) {
         if (extent.getTableId().equals(table)) {
diff --git a/server/base/src/test/java/org/apache/accumulo/server/master/balancer/DefaultLoadBalancerTest.java b/server/base/src/test/java/org/apache/accumulo/server/master/balancer/DefaultLoadBalancerTest.java
index 3096e8a4a1..045e93aa74 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/master/balancer/DefaultLoadBalancerTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/master/balancer/DefaultLoadBalancerTest.java
@@ -32,7 +32,6 @@
 import java.util.TreeMap;
 
 import org.apache.accumulo.core.clientImpl.Table;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.dataImpl.KeyExtent;
 import org.apache.accumulo.core.master.thrift.TableInfo;
 import org.apache.accumulo.core.master.thrift.TabletServerStatus;
@@ -41,7 +40,6 @@
 import org.apache.accumulo.server.master.state.TServerInstance;
 import org.apache.accumulo.server.master.state.TabletMigration;
 import org.apache.hadoop.io.Text;
-import org.apache.thrift.TException;
 import org.junit.Before;
 import org.junit.Test;
 
@@ -73,8 +71,7 @@ TabletServerStatus getStatus(TServerInstance server) {
   class TestDefaultLoadBalancer extends DefaultLoadBalancer {
 
     @Override
-    public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, Table.ID table)
-        throws ThriftSecurityException, TException {
+    public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, Table.ID table) {
       List<TabletStats> result = new ArrayList<>();
       for (KeyExtent extent : servers.get(tserver).extents) {
         if (extent.getTableId().equals(table)) {
diff --git a/server/base/src/test/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancerReconfigurationTest.java b/server/base/src/test/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancerReconfigurationTest.java
index 5222a300c3..06c21fa6aa 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancerReconfigurationTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancerReconfigurationTest.java
@@ -32,14 +32,12 @@
 import java.util.Set;
 
 import org.apache.accumulo.core.clientImpl.Table;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.dataImpl.KeyExtent;
 import org.apache.accumulo.core.tabletserver.thrift.TabletStats;
 import org.apache.accumulo.fate.util.UtilWaitThread;
 import org.apache.accumulo.server.ServerContext;
 import org.apache.accumulo.server.master.state.TServerInstance;
 import org.apache.accumulo.server.master.state.TabletMigration;
-import org.apache.thrift.TException;
 import org.junit.Test;
 
 public class HostRegexTableLoadBalancerReconfigurationTest
@@ -108,8 +106,7 @@ public void testConfigurationChanges() {
   }
 
   @Override
-  public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, Table.ID tableId)
-      throws ThriftSecurityException, TException {
+  public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, Table.ID tableId) {
     List<TabletStats> tablets = new ArrayList<>();
     // Report assignment information
     for (Entry<KeyExtent,TServerInstance> e : this.assignments.entrySet()) {
diff --git a/server/base/src/test/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancerTest.java b/server/base/src/test/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancerTest.java
index 995bc482a0..776b39f302 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancerTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/master/balancer/HostRegexTableLoadBalancerTest.java
@@ -52,7 +52,6 @@
 import org.apache.accumulo.server.conf.TableConfiguration;
 import org.apache.accumulo.server.master.state.TServerInstance;
 import org.apache.accumulo.server.master.state.TabletMigration;
-import org.apache.thrift.TException;
 import org.junit.Test;
 
 public class HostRegexTableLoadBalancerTest extends BaseHostRegexTableLoadBalancerTest {
@@ -512,8 +511,7 @@ public void testOutOfBoundsTablets() {
   }
 
   @Override
-  public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, Table.ID tableId)
-      throws TException {
+  public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, Table.ID tableId) {
     // Report incorrect information so that balance will create an assignment
     List<TabletStats> tablets = new ArrayList<>();
     if (tableId.equals(BAR.getId()) && tserver.host().equals("192.168.0.1")) {
diff --git a/server/base/src/test/java/org/apache/accumulo/server/master/balancer/TableLoadBalancerTest.java b/server/base/src/test/java/org/apache/accumulo/server/master/balancer/TableLoadBalancerTest.java
index 94cc5fab23..f0749ec1c7 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/master/balancer/TableLoadBalancerTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/master/balancer/TableLoadBalancerTest.java
@@ -32,7 +32,6 @@
 
 import org.apache.accumulo.core.client.admin.TableOperations;
 import org.apache.accumulo.core.clientImpl.Table;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.conf.DefaultConfiguration;
 import org.apache.accumulo.core.conf.Property;
 import org.apache.accumulo.core.conf.SiteConfiguration;
@@ -48,7 +47,6 @@
 import org.apache.accumulo.server.master.state.TServerInstance;
 import org.apache.accumulo.server.master.state.TabletMigration;
 import org.apache.hadoop.io.Text;
-import org.apache.thrift.TException;
 import org.easymock.EasyMock;
 import org.junit.Test;
 
@@ -59,7 +57,7 @@
   private static Map<String,String> TABLE_ID_MAP = ImmutableMap.of("t1", "a1", "t2", "b12", "t3",
       "c4");
 
-  private static TServerInstance mkts(String address, String session) throws Exception {
+  private static TServerInstance mkts(String address, String session) {
     return new TServerInstance(HostAndPort.fromParts(address, 1234), session);
   }
 
@@ -107,8 +105,7 @@ public DefaultLoadBalancer(Table.ID table) {
     public void init(ServerContext context) {}
 
     @Override
-    public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, Table.ID tableId)
-        throws ThriftSecurityException, TException {
+    public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, Table.ID tableId) {
       return generateFakeTablets(tserver, tableId);
     }
   }
@@ -124,8 +121,7 @@ protected String getLoadBalancerClassNameForTable(Table.ID table) {
 
     // we don't have real tablet servers to ask: invent some online tablets
     @Override
-    public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, Table.ID tableId)
-        throws ThriftSecurityException, TException {
+    public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, Table.ID tableId) {
       return generateFakeTablets(tserver, tableId);
     }
 
@@ -151,7 +147,7 @@ private ServerContext createMockContext() {
   }
 
   @Test
-  public void test() throws Exception {
+  public void test() {
     final ServerContext context = createMockContext();
     replay(context);
     ServerConfigurationFactory confFactory = new ServerConfigurationFactory(context,
diff --git a/server/base/src/test/java/org/apache/accumulo/server/master/state/MergeInfoTest.java b/server/base/src/test/java/org/apache/accumulo/server/master/state/MergeInfoTest.java
index 293c8e6e55..b702c45128 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/master/state/MergeInfoTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/master/state/MergeInfoTest.java
@@ -45,7 +45,7 @@
   private MergeInfo mi;
 
   @Before
-  public void setUp() throws Exception {
+  public void setUp() {
     keyExtent = createMock(KeyExtent.class);
   }
 
@@ -204,7 +204,7 @@ public void testWritable() throws Exception {
   }
 
   @Test
-  public void testNeedsToBeChopped() throws Exception {
+  public void testNeedsToBeChopped() {
     MergeInfo info = new MergeInfo(ke("x", "b", "a"), MergeInfo.Operation.DELETE);
     assertTrue(info.needsToBeChopped(ke("x", "c", "b")));
     assertTrue(info.overlaps(ke("x", "c", "b")));
diff --git a/server/base/src/test/java/org/apache/accumulo/server/master/state/TabletLocationStateTest.java b/server/base/src/test/java/org/apache/accumulo/server/master/state/TabletLocationStateTest.java
index 28c8ae82a2..ea084ae9bb 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/master/state/TabletLocationStateTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/master/state/TabletLocationStateTest.java
@@ -51,7 +51,7 @@ public static void setUpClass() {
   private TabletLocationState tls;
 
   @Before
-  public void setUp() throws Exception {
+  public void setUp() {
     keyExtent = createMock(KeyExtent.class);
     future = createMock(TServerInstance.class);
     current = createMock(TServerInstance.class);
diff --git a/server/base/src/test/java/org/apache/accumulo/server/problems/ProblemReportTest.java b/server/base/src/test/java/org/apache/accumulo/server/problems/ProblemReportTest.java
index 16d6b11bb0..88085676eb 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/problems/ProblemReportTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/problems/ProblemReportTest.java
@@ -53,7 +53,7 @@
   private ProblemReport r;
 
   @Before
-  public void setUp() throws Exception {
+  public void setUp() {
     context = createMock(ServerContext.class);
     zoorw = createMock(ZooReaderWriter.class);
     expect(context.getZooKeeperRoot()).andReturn("/accumulo/instance");
diff --git a/server/base/src/test/java/org/apache/accumulo/server/problems/ProblemReportingIteratorTest.java b/server/base/src/test/java/org/apache/accumulo/server/problems/ProblemReportingIteratorTest.java
index 245789d338..ff84d5a857 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/problems/ProblemReportingIteratorTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/problems/ProblemReportingIteratorTest.java
@@ -45,7 +45,7 @@
   private ProblemReportingIterator pri;
 
   @Before
-  public void setUp() throws Exception {
+  public void setUp() {
     ii = EasyMock.createMock(InterruptibleIterator.class);
     pri = new ProblemReportingIterator(null, TABLE_ID, RESOURCE, false, ii);
   }
@@ -66,7 +66,7 @@ public void testBasicGetters() {
   }
 
   @Test(expected = UnsupportedOperationException.class)
-  public void testInit() throws Exception {
+  public void testInit() {
     pri.init(null, null, null);
   }
 
diff --git a/server/base/src/test/java/org/apache/accumulo/server/rpc/SaslDigestCallbackHandlerTest.java b/server/base/src/test/java/org/apache/accumulo/server/rpc/SaslDigestCallbackHandlerTest.java
index 74f753d25a..b1006e564f 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/rpc/SaslDigestCallbackHandlerTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/rpc/SaslDigestCallbackHandlerTest.java
@@ -26,7 +26,6 @@
 
 import javax.crypto.KeyGenerator;
 import javax.security.auth.callback.Callback;
-import javax.security.auth.callback.UnsupportedCallbackException;
 
 import org.apache.accumulo.core.client.admin.DelegationTokenConfig;
 import org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier;
@@ -45,7 +44,7 @@
    */
   private static class SaslTestDigestCallbackHandler extends SaslDigestCallbackHandler {
     @Override
-    public void handle(Callback[] callbacks) throws IOException, UnsupportedCallbackException {
+    public void handle(Callback[] callbacks) {
       throw new UnsupportedOperationException();
     }
   }
diff --git a/server/base/src/test/java/org/apache/accumulo/server/security/UserImpersonationTest.java b/server/base/src/test/java/org/apache/accumulo/server/security/UserImpersonationTest.java
index c76e54bd10..72535cd004 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/security/UserImpersonationTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/security/UserImpersonationTest.java
@@ -275,7 +275,7 @@ public void testMultipleAllowedImpersonators() {
   }
 
   @Test
-  public void testSingleUser() throws Exception {
+  public void testSingleUser() {
     final String server = "server/hostname@EXAMPLE.COM", client = "client@EXAMPLE.COM";
     cc.set(Property.INSTANCE_RPC_SASL_ALLOWED_USER_IMPERSONATION, server + ":" + client);
     cc.set(Property.INSTANCE_RPC_SASL_ALLOWED_HOST_IMPERSONATION, "*");
diff --git a/server/base/src/test/java/org/apache/accumulo/server/security/delegation/ZooAuthenticationKeyWatcherTest.java b/server/base/src/test/java/org/apache/accumulo/server/security/delegation/ZooAuthenticationKeyWatcherTest.java
index b0e379c3a2..156cd7ea0f 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/security/delegation/ZooAuthenticationKeyWatcherTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/security/delegation/ZooAuthenticationKeyWatcherTest.java
@@ -132,7 +132,7 @@ public void testBaseNodeChildrenChanged() throws Exception {
   }
 
   @Test
-  public void testBaseNodeDeleted() throws Exception {
+  public void testBaseNodeDeleted() {
     WatchedEvent event = new WatchedEvent(EventType.NodeDeleted, null, baseNode);
     AuthenticationKey key1 = new AuthenticationKey(1, 0L, 10000L, keyGen.generateKey()),
         key2 = new AuthenticationKey(2, key1.getExpirationDate(), 20000L, keyGen.generateKey());
@@ -151,7 +151,7 @@ public void testBaseNodeDeleted() throws Exception {
   }
 
   @Test
-  public void testBaseNodeDataChanged() throws Exception {
+  public void testBaseNodeDataChanged() {
     WatchedEvent event = new WatchedEvent(EventType.NodeDataChanged, null, baseNode);
 
     replay(zk);
@@ -185,7 +185,7 @@ public void testChildChanged() throws Exception {
   }
 
   @Test
-  public void testChildDeleted() throws Exception {
+  public void testChildDeleted() {
     WatchedEvent event = new WatchedEvent(EventType.NodeDeleted, null, baseNode + "/1");
     AuthenticationKey key1 = new AuthenticationKey(1, 0L, 10000L, keyGen.generateKey()),
         key2 = new AuthenticationKey(2, key1.getExpirationDate(), 20000L, keyGen.generateKey());
@@ -204,7 +204,7 @@ public void testChildDeleted() throws Exception {
   }
 
   @Test
-  public void testChildChildrenChanged() throws Exception {
+  public void testChildChildrenChanged() {
     WatchedEvent event = new WatchedEvent(EventType.NodeChildrenChanged, null, baseNode + "/2");
     AuthenticationKey key1 = new AuthenticationKey(1, 0L, 10000L, keyGen.generateKey()),
         key2 = new AuthenticationKey(2, key1.getExpirationDate(), 20000L, keyGen.generateKey());
diff --git a/server/base/src/test/java/org/apache/accumulo/server/tablets/LogicalTimeTest.java b/server/base/src/test/java/org/apache/accumulo/server/tablets/LogicalTimeTest.java
index 10762493e7..defb7dafd7 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/tablets/LogicalTimeTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/tablets/LogicalTimeTest.java
@@ -34,7 +34,7 @@
   private LogicalTime ltime;
 
   @Before
-  public void setUp() throws Exception {
+  public void setUp() {
     ltime = (LogicalTime) TabletTime.getInstance("L1234");
   }
 
diff --git a/server/base/src/test/java/org/apache/accumulo/server/tablets/MillisTimeTest.java b/server/base/src/test/java/org/apache/accumulo/server/tablets/MillisTimeTest.java
index 49f5913548..1fee2a0539 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/tablets/MillisTimeTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/tablets/MillisTimeTest.java
@@ -36,7 +36,7 @@
   private MillisTime mtime;
 
   @Before
-  public void setUp() throws Exception {
+  public void setUp() {
     mtime = new MillisTime(TIME);
   }
 
diff --git a/server/base/src/test/java/org/apache/accumulo/server/tablets/TabletTimeTest.java b/server/base/src/test/java/org/apache/accumulo/server/tablets/TabletTimeTest.java
index 46068e3e7b..e8fff7c6c2 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/tablets/TabletTimeTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/tablets/TabletTimeTest.java
@@ -34,7 +34,7 @@
   private MillisTime mtime;
 
   @Before
-  public void setUp() throws Exception {
+  public void setUp() {
     mtime = new MillisTime(TIME);
   }
 
diff --git a/server/base/src/test/java/org/apache/accumulo/server/zookeeper/TransactionWatcherTest.java b/server/base/src/test/java/org/apache/accumulo/server/zookeeper/TransactionWatcherTest.java
index 633f27dabf..d607250328 100644
--- a/server/base/src/test/java/org/apache/accumulo/server/zookeeper/TransactionWatcherTest.java
+++ b/server/base/src/test/java/org/apache/accumulo/server/zookeeper/TransactionWatcherTest.java
@@ -70,7 +70,7 @@ public synchronized void cleanup(String txType, Long txid) throws Exception {
     }
 
     @Override
-    public synchronized boolean transactionAlive(String txType, long tid) throws Exception {
+    public synchronized boolean transactionAlive(String txType, long tid) {
       List<Long> txids = started.get(txType);
       if (txids == null)
         return false;
@@ -78,7 +78,7 @@ public synchronized boolean transactionAlive(String txType, long tid) throws Exc
     }
 
     @Override
-    public boolean transactionComplete(String txType, long tid) throws Exception {
+    public boolean transactionComplete(String txType, long tid) {
       List<Long> txids = cleanedUp.get(txType);
       if (txids == null)
         return true;
diff --git a/server/gc/src/main/java/org/apache/accumulo/gc/GCExecutable.java b/server/gc/src/main/java/org/apache/accumulo/gc/GCExecutable.java
index 0f8d3976c0..8bc45bdaee 100644
--- a/server/gc/src/main/java/org/apache/accumulo/gc/GCExecutable.java
+++ b/server/gc/src/main/java/org/apache/accumulo/gc/GCExecutable.java
@@ -16,8 +16,6 @@
  */
 package org.apache.accumulo.gc;
 
-import java.io.IOException;
-
 import org.apache.accumulo.start.spi.KeywordExecutable;
 
 import com.google.auto.service.AutoService;
@@ -40,7 +38,7 @@ public String description() {
   }
 
   @Override
-  public void execute(final String[] args) throws IOException {
+  public void execute(final String[] args) {
     SimpleGarbageCollector.main(args);
   }
 }
diff --git a/server/gc/src/main/java/org/apache/accumulo/gc/GarbageCollectWriteAheadLogs.java b/server/gc/src/main/java/org/apache/accumulo/gc/GarbageCollectWriteAheadLogs.java
index ef8f486d87..06044d08b5 100644
--- a/server/gc/src/main/java/org/apache/accumulo/gc/GarbageCollectWriteAheadLogs.java
+++ b/server/gc/src/main/java/org/apache/accumulo/gc/GarbageCollectWriteAheadLogs.java
@@ -58,7 +58,6 @@
 import org.apache.hadoop.fs.FileStatus;
 import org.apache.hadoop.fs.Path;
 import org.apache.hadoop.io.Text;
-import org.apache.zookeeper.KeeperException;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -85,8 +84,7 @@
    * @param useTrash
    *          true to move files to trash rather than delete them
    */
-  GarbageCollectWriteAheadLogs(final ServerContext context, VolumeManager fs, boolean useTrash)
-      throws IOException {
+  GarbageCollectWriteAheadLogs(final ServerContext context, VolumeManager fs, boolean useTrash) {
     this.context = context;
     this.fs = fs;
     this.useTrash = useTrash;
@@ -114,8 +112,8 @@
    */
   @VisibleForTesting
   GarbageCollectWriteAheadLogs(ServerContext context, VolumeManager fs, boolean useTrash,
-      LiveTServerSet liveTServerSet, WalStateManager walMarker, Iterable<TabletLocationState> store)
-      throws IOException {
+      LiveTServerSet liveTServerSet, WalStateManager walMarker,
+      Iterable<TabletLocationState> store) {
     this.context = context;
     this.fs = fs;
     this.useTrash = useTrash;
@@ -276,7 +274,7 @@ private UUID path2uuid(Path path) {
 
   private Map<UUID,TServerInstance> removeEntriesInUse(Map<TServerInstance,Set<UUID>> candidates,
       Set<TServerInstance> liveServers, Map<UUID,Pair<WalState,Path>> logsState,
-      Map<UUID,Path> recoveryLogs) throws IOException, KeeperException, InterruptedException {
+      Map<UUID,Path> recoveryLogs) {
 
     Map<UUID,TServerInstance> result = new HashMap<>();
     for (Entry<TServerInstance,Set<UUID>> entry : candidates.entrySet()) {
@@ -335,8 +333,7 @@ private UUID path2uuid(Path path) {
     return result;
   }
 
-  protected int removeReplicationEntries(Map<UUID,TServerInstance> candidates)
-      throws IOException, KeeperException, InterruptedException {
+  protected int removeReplicationEntries(Map<UUID,TServerInstance> candidates) {
     try {
       try {
         final Scanner s = ReplicationTable.getScanner(context);
diff --git a/server/gc/src/main/java/org/apache/accumulo/gc/GarbageCollectionAlgorithm.java b/server/gc/src/main/java/org/apache/accumulo/gc/GarbageCollectionAlgorithm.java
index 532ee285e7..d1938404ce 100644
--- a/server/gc/src/main/java/org/apache/accumulo/gc/GarbageCollectionAlgorithm.java
+++ b/server/gc/src/main/java/org/apache/accumulo/gc/GarbageCollectionAlgorithm.java
@@ -29,8 +29,6 @@
 import java.util.TreeMap;
 
 import org.apache.accumulo.core.Constants;
-import org.apache.accumulo.core.client.AccumuloException;
-import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.clientImpl.Table;
 import org.apache.accumulo.core.trace.Span;
@@ -126,8 +124,7 @@ private String makeRelative(String path, int expectedLen) {
   }
 
   private void confirmDeletes(GarbageCollectionEnvironment gce,
-      SortedMap<String,String> candidateMap)
-      throws TableNotFoundException, AccumuloException, AccumuloSecurityException {
+      SortedMap<String,String> candidateMap) throws TableNotFoundException {
     boolean checkForBulkProcessingFiles = false;
     Iterator<String> relativePaths = candidateMap.keySet().iterator();
     while (!checkForBulkProcessingFiles && relativePaths.hasNext())
@@ -268,8 +265,7 @@ private void cleanUpDeletedTableDirs(GarbageCollectionEnvironment gce,
   }
 
   private boolean getCandidates(GarbageCollectionEnvironment gce, String lastCandidate,
-      List<String> candidates)
-      throws TableNotFoundException, AccumuloException, AccumuloSecurityException {
+      List<String> candidates) throws TableNotFoundException {
     Span candidatesSpan = Trace.start("getCandidates");
     try {
       return gce.getCandidates(lastCandidate, candidates);
@@ -279,8 +275,7 @@ private boolean getCandidates(GarbageCollectionEnvironment gce, String lastCandi
   }
 
   private void confirmDeletesTrace(GarbageCollectionEnvironment gce,
-      SortedMap<String,String> candidateMap)
-      throws TableNotFoundException, AccumuloException, AccumuloSecurityException {
+      SortedMap<String,String> candidateMap) throws TableNotFoundException {
     Span confirmDeletesSpan = Trace.start("confirmDeletes");
     try {
       confirmDeletes(gce, candidateMap);
@@ -290,8 +285,7 @@ private void confirmDeletesTrace(GarbageCollectionEnvironment gce,
   }
 
   private void deleteConfirmed(GarbageCollectionEnvironment gce,
-      SortedMap<String,String> candidateMap)
-      throws IOException, AccumuloException, AccumuloSecurityException, TableNotFoundException {
+      SortedMap<String,String> candidateMap) throws IOException, TableNotFoundException {
     Span deleteSpan = Trace.start("deleteFiles");
     try {
       gce.delete(candidateMap);
@@ -302,8 +296,7 @@ private void deleteConfirmed(GarbageCollectionEnvironment gce,
     cleanUpDeletedTableDirs(gce, candidateMap);
   }
 
-  public void collect(GarbageCollectionEnvironment gce)
-      throws TableNotFoundException, AccumuloException, AccumuloSecurityException, IOException {
+  public void collect(GarbageCollectionEnvironment gce) throws TableNotFoundException, IOException {
 
     String lastCandidate = "";
 
diff --git a/server/gc/src/main/java/org/apache/accumulo/gc/GarbageCollectionEnvironment.java b/server/gc/src/main/java/org/apache/accumulo/gc/GarbageCollectionEnvironment.java
index a7ec9fe6d5..4f59a60478 100644
--- a/server/gc/src/main/java/org/apache/accumulo/gc/GarbageCollectionEnvironment.java
+++ b/server/gc/src/main/java/org/apache/accumulo/gc/GarbageCollectionEnvironment.java
@@ -25,8 +25,6 @@
 import java.util.SortedMap;
 import java.util.stream.Stream;
 
-import org.apache.accumulo.core.client.AccumuloException;
-import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.clientImpl.Table;
 import org.apache.accumulo.core.clientImpl.Table.ID;
@@ -53,7 +51,7 @@
    * @return true if the results are short due to insufficient memory, otherwise false
    */
   boolean getCandidates(String continuePoint, List<String> candidates)
-      throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
+      throws TableNotFoundException;
 
   /**
    * Fetch a list of paths for all bulk loads in progress (blip) from a given table,
@@ -61,8 +59,7 @@ boolean getCandidates(String continuePoint, List<String> candidates)
    *
    * @return The list of files for each bulk load currently in progress.
    */
-  Iterator<String> getBlipIterator()
-      throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
+  Iterator<String> getBlipIterator() throws TableNotFoundException;
 
   static class Reference {
     public final ID id;
@@ -83,8 +80,7 @@ boolean getCandidates(String continuePoint, List<String> candidates)
    * @return An {@link Iterator} of {@link Entry}&lt;{@link Key}, {@link Value}&gt; which constitute
    *         a reference to a file.
    */
-  Stream<Reference> getReferences()
-      throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
+  Stream<Reference> getReferences();
 
   /**
    * Return the set of tableIDs for the given instance this GarbageCollector is running over
@@ -100,8 +96,7 @@ boolean getCandidates(String continuePoint, List<String> candidates)
    * @param candidateMap
    *          A Map from relative path to absolute path for files to be deleted.
    */
-  void delete(SortedMap<String,String> candidateMap)
-      throws IOException, AccumuloException, AccumuloSecurityException, TableNotFoundException;
+  void delete(SortedMap<String,String> candidateMap) throws TableNotFoundException;
 
   /**
    * Delete a table's directory if it is empty.
@@ -132,6 +127,5 @@ void delete(SortedMap<String,String> candidateMap)
    *
    * @return True if the file still needs to be replicated
    */
-  Iterator<Entry<String,Status>> getReplicationNeededIterator()
-      throws AccumuloException, AccumuloSecurityException;
+  Iterator<Entry<String,Status>> getReplicationNeededIterator();
 }
diff --git a/server/gc/src/main/java/org/apache/accumulo/gc/SimpleGarbageCollector.java b/server/gc/src/main/java/org/apache/accumulo/gc/SimpleGarbageCollector.java
index 9eab1c869b..07f8eb0ca0 100644
--- a/server/gc/src/main/java/org/apache/accumulo/gc/SimpleGarbageCollector.java
+++ b/server/gc/src/main/java/org/apache/accumulo/gc/SimpleGarbageCollector.java
@@ -20,7 +20,6 @@
 
 import java.io.FileNotFoundException;
 import java.io.IOException;
-import java.net.UnknownHostException;
 import java.util.Collections;
 import java.util.Iterator;
 import java.util.List;
@@ -34,8 +33,6 @@
 
 import org.apache.accumulo.core.Constants;
 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.IsolatedScanner;
@@ -234,7 +231,7 @@ int getNumDeleteThreads() {
 
     @Override
     public boolean getCandidates(String continuePoint, List<String> result)
-        throws TableNotFoundException, AccumuloException, AccumuloSecurityException {
+        throws TableNotFoundException {
       // want to ensure GC makes progress... if the 1st N deletes are stable and we keep processing
       // them,
       // then will never inspect deletes after N
@@ -264,8 +261,7 @@ public boolean getCandidates(String continuePoint, List<String> result)
     }
 
     @Override
-    public Iterator<String> getBlipIterator()
-        throws TableNotFoundException, AccumuloException, AccumuloSecurityException {
+    public Iterator<String> getBlipIterator() throws TableNotFoundException {
       @SuppressWarnings("resource")
       IsolatedScanner scanner = new IsolatedScanner(
           getClient().createScanner(tableName, Authorizations.EMPTY));
@@ -277,8 +273,7 @@ public boolean getCandidates(String continuePoint, List<String> result)
     }
 
     @Override
-    public Stream<Reference> getReferences()
-        throws TableNotFoundException, AccumuloException, AccumuloSecurityException {
+    public Stream<Reference> getReferences() {
 
       Stream<TabletMetadata> tabletStream = TabletsMetadata.builder().scanTable(tableName)
           .checkConsistency().fetchDir().fetchFiles().fetchScans().build(getClient()).stream();
@@ -301,8 +296,7 @@ public boolean getCandidates(String continuePoint, List<String> result)
     }
 
     @Override
-    public void delete(SortedMap<String,String> confirmedDeletes)
-        throws IOException, AccumuloException, AccumuloSecurityException, TableNotFoundException {
+    public void delete(SortedMap<String,String> confirmedDeletes) throws TableNotFoundException {
 
       if (opts.safeMode) {
         if (opts.verbose)
@@ -482,8 +476,7 @@ public void incrementInUseStat(long i) {
     }
 
     @Override
-    public Iterator<Entry<String,Status>> getReplicationNeededIterator()
-        throws AccumuloException, AccumuloSecurityException {
+    public Iterator<Entry<String,Status>> getReplicationNeededIterator() {
       AccumuloClient client = getClient();
       try {
         Scanner s = ReplicationTable.getScanner(client);
@@ -664,7 +657,7 @@ public void run() {
     }
   }
 
-  private HostAndPort startStatsService() throws UnknownHostException {
+  private HostAndPort startStatsService() {
     Iface rpcProxy = TraceWrap.service(this);
     final Processor<Iface> processor;
     if (context.getThriftServerType() == ThriftServerType.SASL) {
diff --git a/server/gc/src/test/java/org/apache/accumulo/gc/GarbageCollectWriteAheadLogsTest.java b/server/gc/src/test/java/org/apache/accumulo/gc/GarbageCollectWriteAheadLogsTest.java
index dfca409802..055479ec5d 100644
--- a/server/gc/src/test/java/org/apache/accumulo/gc/GarbageCollectWriteAheadLogsTest.java
+++ b/server/gc/src/test/java/org/apache/accumulo/gc/GarbageCollectWriteAheadLogsTest.java
@@ -16,7 +16,6 @@
  */
 package org.apache.accumulo.gc;
 
-import java.io.IOException;
 import java.util.Collection;
 import java.util.Collections;
 import java.util.Iterator;
@@ -46,7 +45,6 @@
 import org.apache.accumulo.server.master.state.TabletLocationState;
 import org.apache.hadoop.fs.Path;
 import org.apache.hadoop.io.Text;
-import org.apache.zookeeper.KeeperException;
 import org.easymock.EasyMock;
 import org.junit.Test;
 
@@ -101,13 +99,12 @@ public void testRemoveUnusedLog() throws Exception {
     GarbageCollectWriteAheadLogs gc = new GarbageCollectWriteAheadLogs(context, fs, false,
         tserverSet, marker, tabletOnServer1List) {
       @Override
-      protected int removeReplicationEntries(Map<UUID,TServerInstance> candidates)
-          throws IOException, KeeperException, InterruptedException {
+      protected int removeReplicationEntries(Map<UUID,TServerInstance> candidates) {
         return 0;
       }
 
       @Override
-      protected Map<UUID,Path> getSortedWALogs() throws IOException {
+      protected Map<UUID,Path> getSortedWALogs() {
         return Collections.emptyMap();
       }
     };
@@ -131,13 +128,12 @@ public void testKeepClosedLog() throws Exception {
     GarbageCollectWriteAheadLogs gc = new GarbageCollectWriteAheadLogs(context, fs, false,
         tserverSet, marker, tabletOnServer1List) {
       @Override
-      protected int removeReplicationEntries(Map<UUID,TServerInstance> candidates)
-          throws IOException, KeeperException, InterruptedException {
+      protected int removeReplicationEntries(Map<UUID,TServerInstance> candidates) {
         return 0;
       }
 
       @Override
-      protected Map<UUID,Path> getSortedWALogs() throws IOException {
+      protected Map<UUID,Path> getSortedWALogs() {
         return Collections.emptyMap();
       }
     };
@@ -181,7 +177,7 @@ public void deleteUnreferenceLogOnDeadServer() throws Exception {
     GarbageCollectWriteAheadLogs gc = new GarbageCollectWriteAheadLogs(context, fs, false,
         tserverSet, marker, tabletOnServer1List) {
       @Override
-      protected Map<UUID,Path> getSortedWALogs() throws IOException {
+      protected Map<UUID,Path> getSortedWALogs() {
         return Collections.emptyMap();
       }
     };
@@ -220,7 +216,7 @@ public void ignoreReferenceLogOnDeadServer() throws Exception {
     GarbageCollectWriteAheadLogs gc = new GarbageCollectWriteAheadLogs(context, fs, false,
         tserverSet, marker, tabletOnServer2List) {
       @Override
-      protected Map<UUID,Path> getSortedWALogs() throws IOException {
+      protected Map<UUID,Path> getSortedWALogs() {
         return Collections.emptyMap();
       }
     };
@@ -265,7 +261,7 @@ public void replicationDelaysFileCollection() throws Exception {
     GarbageCollectWriteAheadLogs gc = new GarbageCollectWriteAheadLogs(context, fs, false,
         tserverSet, marker, tabletOnServer1List) {
       @Override
-      protected Map<UUID,Path> getSortedWALogs() throws IOException {
+      protected Map<UUID,Path> getSortedWALogs() {
         return Collections.emptyMap();
       }
     };
diff --git a/server/gc/src/test/java/org/apache/accumulo/gc/GarbageCollectionTest.java b/server/gc/src/test/java/org/apache/accumulo/gc/GarbageCollectionTest.java
index d929995e9c..5e1c17c983 100644
--- a/server/gc/src/test/java/org/apache/accumulo/gc/GarbageCollectionTest.java
+++ b/server/gc/src/test/java/org/apache/accumulo/gc/GarbageCollectionTest.java
@@ -32,8 +32,6 @@
 import java.util.TreeSet;
 import java.util.stream.Stream;
 
-import org.apache.accumulo.core.client.AccumuloException;
-import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.clientImpl.Table;
 import org.apache.accumulo.server.replication.StatusUtil;
 import org.apache.accumulo.server.replication.proto.Replication.Status;
@@ -110,8 +108,7 @@ public void incrementCandidatesStat(long i) {}
     public void incrementInUseStat(long i) {}
 
     @Override
-    public Iterator<Entry<String,Status>> getReplicationNeededIterator()
-        throws AccumuloException, AccumuloSecurityException {
+    public Iterator<Entry<String,Status>> getReplicationNeededIterator() {
       return filesToReplicate.entrySet().iterator();
     }
   }
diff --git a/server/gc/src/test/java/org/apache/accumulo/gc/SimpleGarbageCollectorTest.java b/server/gc/src/test/java/org/apache/accumulo/gc/SimpleGarbageCollectorTest.java
index 8a79477406..376bb59801 100644
--- a/server/gc/src/test/java/org/apache/accumulo/gc/SimpleGarbageCollectorTest.java
+++ b/server/gc/src/test/java/org/apache/accumulo/gc/SimpleGarbageCollectorTest.java
@@ -96,7 +96,7 @@ private ConfigurationCopy createSystemConfig() {
   }
 
   @Test
-  public void testInit() throws Exception {
+  public void testInit() {
     assertSame(volMgr, gc.getVolumeManager());
     assertEquals(credentials, gc.getContext().getCredentials());
     assertTrue(gc.isUsingTrash());
diff --git a/server/master/src/main/java/org/apache/accumulo/master/Master.java b/server/master/src/main/java/org/apache/accumulo/master/Master.java
index 53f3eb2627..4fcde7137e 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/Master.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/Master.java
@@ -42,8 +42,6 @@
 
 import org.apache.accumulo.core.Constants;
 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.Scanner;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.clientImpl.Namespace;
@@ -740,7 +738,7 @@ public MergeInfo getMergeInfo(Table.ID tableId) {
   }
 
   public void setMergeState(MergeInfo info, MergeState state)
-      throws IOException, KeeperException, InterruptedException {
+      throws KeeperException, InterruptedException {
     synchronized (mergeLock) {
       String path = getZooKeeperRoot() + Constants.ZTABLES + "/" + info.getExtent().getTableId()
           + "/merge";
@@ -763,8 +761,7 @@ public void setMergeState(MergeInfo info, MergeState state)
     nextEvent.event("Merge state of %s set to %s", info.getExtent(), state);
   }
 
-  public void clearMergeState(Table.ID tableId)
-      throws IOException, KeeperException, InterruptedException {
+  public void clearMergeState(Table.ID tableId) throws KeeperException, InterruptedException {
     synchronized (mergeLock) {
       String path = getZooKeeperRoot() + Constants.ZTABLES + "/" + tableId + "/merge";
       context.getZooReaderWriter().recursiveDelete(path, NodeMissingPolicy.SKIP);
@@ -945,7 +942,7 @@ public void run() {
      * the metadata table and remove any migrating tablets that no longer exist.
      */
     private void cleanupNonexistentMigrations(final AccumuloClient accumuloClient)
-        throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+        throws TableNotFoundException {
       Scanner scanner = accumuloClient.createScanner(MetadataTable.NAME, Authorizations.EMPTY);
       TabletsSection.TabletColumnFamily.PREV_ROW_COLUMN.fetch(scanner);
       Set<KeyExtent> found = new HashSet<>();
@@ -1085,8 +1082,7 @@ public void run() {
       }
     }
 
-    private long updateStatus()
-        throws AccumuloException, AccumuloSecurityException, TableNotFoundException {
+    private long updateStatus() {
       Set<TServerInstance> currentServers = tserverSet.getCurrentServers();
       tserverStatus = gatherTableInformation(currentServers);
       checkForHeldServer(tserverStatus);
@@ -1401,12 +1397,7 @@ public void run() {
     replicationWorkDriver.start();
 
     // Start the daemon to assign work to tservers to replicate to our peers
-    try {
-      replicationWorkAssigner = new WorkDriver(this);
-    } catch (AccumuloException | AccumuloSecurityException e) {
-      log.error("Caught exception trying to initialize replication WorkDriver", e);
-      throw new RuntimeException(e);
-    }
+    replicationWorkAssigner = new WorkDriver(this);
     replicationWorkAssigner.start();
 
     // Advertise that port we used so peers don't have to be told what it is
diff --git a/server/master/src/main/java/org/apache/accumulo/master/MasterClientServiceHandler.java b/server/master/src/main/java/org/apache/accumulo/master/MasterClientServiceHandler.java
index c6b6d55bb1..47ccf71a96 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/MasterClientServiceHandler.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/MasterClientServiceHandler.java
@@ -122,7 +122,7 @@ public long initiateFlush(TInfo tinfo, TCredentials c, String tableIdStr)
     try {
       fid = zoo.mutate(zTablePath, null, null, new Mutator() {
         @Override
-        public byte[] mutate(byte[] currentValue) throws Exception {
+        public byte[] mutate(byte[] currentValue) {
           long flushID = Long.parseLong(new String(currentValue));
           flushID++;
           return ("" + flushID).getBytes();
@@ -228,8 +228,7 @@ public void waitForFlush(TInfo tinfo, TCredentials c, String tableIdStr, ByteBuf
   }
 
   @Override
-  public MasterMonitorInfo getMasterStats(TInfo info, TCredentials credentials)
-      throws ThriftSecurityException {
+  public MasterMonitorInfo getMasterStats(TInfo info, TCredentials credentials) {
     return master.getMasterMonitorInfo();
   }
 
@@ -451,12 +450,12 @@ private void updatePlugins(String property) {
   }
 
   @Override
-  public void waitForBalance(TInfo tinfo) throws TException {
+  public void waitForBalance(TInfo tinfo) {
     master.waitForBalance(tinfo);
   }
 
   @Override
-  public List<String> getActiveTservers(TInfo tinfo, TCredentials credentials) throws TException {
+  public List<String> getActiveTservers(TInfo tinfo, TCredentials credentials) {
     Set<TServerInstance> tserverInstances = master.onlineTabletServers();
     List<String> servers = new ArrayList<>();
     for (TServerInstance tserverInstance : tserverInstances) {
diff --git a/server/master/src/main/java/org/apache/accumulo/master/TabletGroupWatcher.java b/server/master/src/main/java/org/apache/accumulo/master/TabletGroupWatcher.java
index cea36182a6..100f6f16a2 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/TabletGroupWatcher.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/TabletGroupWatcher.java
@@ -676,7 +676,7 @@ private void deleteTablets(MergeInfo info) throws AccumuloException {
             new KeyExtent(extent.getTableId(), null, extent.getPrevEndRow()), tdir,
             master.getContext(), timeType, this.master.masterLock);
       }
-    } catch (RuntimeException | IOException | TableNotFoundException ex) {
+    } catch (RuntimeException | TableNotFoundException ex) {
       throw new AccumuloException(ex);
     }
   }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/metrics/Metrics2ReplicationMetrics.java b/server/master/src/main/java/org/apache/accumulo/master/metrics/Metrics2ReplicationMetrics.java
index bda9ae6f15..afb1772019 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/metrics/Metrics2ReplicationMetrics.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/metrics/Metrics2ReplicationMetrics.java
@@ -103,7 +103,7 @@ public void getMetrics(MetricsCollector collector, boolean all) {
   }
 
   @Override
-  public void register() throws Exception {
+  public void register() {
     system.register(NAME, DESCRIPTION, this);
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/recovery/RecoveryManager.java b/server/master/src/main/java/org/apache/accumulo/master/recovery/RecoveryManager.java
index 2ba3974f44..b36d9630b4 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/recovery/RecoveryManager.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/recovery/RecoveryManager.java
@@ -117,7 +117,7 @@ public void run() {
   }
 
   private void initiateSort(String sortId, String source, final String destination)
-      throws KeeperException, InterruptedException, IOException {
+      throws KeeperException, InterruptedException {
     String work = source + "|" + destination;
     new DistributedWorkQueue(master.getZooKeeperRoot() + Constants.ZRECOVERY,
         master.getConfiguration()).addWork(sortId, work.getBytes(UTF_8));
diff --git a/server/master/src/main/java/org/apache/accumulo/master/replication/WorkDriver.java b/server/master/src/main/java/org/apache/accumulo/master/replication/WorkDriver.java
index 94937e1b38..0f1eb9bcdb 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/replication/WorkDriver.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/replication/WorkDriver.java
@@ -21,8 +21,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.conf.AccumuloConfiguration;
 import org.apache.accumulo.core.conf.Property;
 import org.apache.accumulo.core.util.Daemon;
@@ -44,7 +42,7 @@
   private WorkAssigner assigner;
   private String assignerImplName;
 
-  public WorkDriver(Master master) throws AccumuloException, AccumuloSecurityException {
+  public WorkDriver(Master master) {
     super();
     this.master = master;
     this.client = master.getContext();
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/ChangeTableState.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/ChangeTableState.java
index 06a021138a..8452009485 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/ChangeTableState.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/ChangeTableState.java
@@ -49,7 +49,7 @@ public long isReady(long tid, Master env) throws Exception {
   }
 
   @Override
-  public Repo<Master> call(long tid, Master env) throws Exception {
+  public Repo<Master> call(long tid, Master env) {
     TableState ts = TableState.ONLINE;
     if (top == TableOperation.OFFLINE)
       ts = TableState.OFFLINE;
@@ -63,7 +63,7 @@ public long isReady(long tid, Master env) throws Exception {
   }
 
   @Override
-  public void undo(long tid, Master env) throws Exception {
+  public void undo(long tid, Master env) {
     Utils.unreserveNamespace(env, namespaceId, tid, false);
     Utils.unreserveTable(env, tableId, tid, true);
   }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/Utils.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/Utils.java
index adbcd3a5be..34f3f35a24 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/Utils.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/Utils.java
@@ -102,15 +102,14 @@ public static long reserveTable(Master env, Table.ID tableId, long tid, boolean
       return 100;
   }
 
-  public static void unreserveTable(Master env, Table.ID tableId, long tid, boolean writeLock)
-      throws Exception {
+  public static void unreserveTable(Master env, Table.ID tableId, long tid, boolean writeLock) {
     getLock(env.getContext(), tableId, tid, writeLock).unlock();
     log.info("table {} ({}) unlocked for ", tableId, Long.toHexString(tid),
         (writeLock ? "write" : "read"));
   }
 
   public static void unreserveNamespace(Master env, Namespace.ID namespaceId, long id,
-      boolean writeLock) throws Exception {
+      boolean writeLock) {
     getLock(env.getContext(), namespaceId, id, writeLock).unlock();
     log.info("namespace {} ({}) unlocked for {}", namespaceId, Long.toHexString(id),
         (writeLock ? "write" : "read"));
@@ -154,8 +153,7 @@ public static void unreserveHdfsDirectory(Master env, String directory, long tid
         String.format("%016x", tid));
   }
 
-  private static Lock getLock(ServerContext context, AbstractId id, long tid, boolean writeLock)
-      throws Exception {
+  private static Lock getLock(ServerContext context, AbstractId id, long tid, boolean writeLock) {
     byte[] lockData = String.format("%016x", tid).getBytes(UTF_8);
     ZooQueueLock qlock = new ZooQueueLock(context.getZooReaderWriter(),
         context.getZooKeeperRoot() + Constants.ZTABLE_LOCKS + "/" + id, false);
@@ -178,7 +176,7 @@ public static Lock getTableNameLock() {
     return tableNameLock;
   }
 
-  public static Lock getReadLock(Master env, AbstractId tableId, long tid) throws Exception {
+  public static Lock getReadLock(Master env, AbstractId tableId, long tid) {
     return Utils.getLock(env.getContext(), tableId, tid, false);
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer1/CopyFailed.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer1/CopyFailed.java
index 191869cebb..51d26e4f3f 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer1/CopyFailed.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer1/CopyFailed.java
@@ -68,7 +68,7 @@ public CopyFailed(Table.ID tableId, String source, String bulk, String error) {
   }
 
   @Override
-  public long isReady(long tid, Master master) throws Exception {
+  public long isReady(long tid, Master master) {
     Set<TServerInstance> finished = new HashSet<>();
     Set<TServerInstance> running = master.onlineTabletServers();
     for (TServerInstance server : running) {
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer1/LoadFiles.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer1/LoadFiles.java
index 2b6b81a38f..1b786af295 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer1/LoadFiles.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer1/LoadFiles.java
@@ -81,7 +81,7 @@ public LoadFiles(Table.ID tableId, String source, String bulk, String errorDir,
   }
 
   @Override
-  public long isReady(long tid, Master master) throws Exception {
+  public long isReady(long tid, Master master) {
     if (master.onlineTabletServers().size() == 0)
       return 500;
     return 0;
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer2/LoadFiles.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer2/LoadFiles.java
index 63a46f4fe4..b65b3892fa 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer2/LoadFiles.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer2/LoadFiles.java
@@ -93,7 +93,7 @@ public long isReady(long tid, Master master) throws Exception {
   }
 
   @Override
-  public Repo<Master> call(final long tid, final Master master) throws Exception {
+  public Repo<Master> call(final long tid, final Master master) {
     if (bulkInfo.tableState == TableState.ONLINE) {
       return new CompleteBulkImport(bulkInfo);
     } else {
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer2/PrepBulkImport.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer2/PrepBulkImport.java
index c608a96ff4..3cecdf404a 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer2/PrepBulkImport.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/bulkVer2/PrepBulkImport.java
@@ -95,7 +95,7 @@ public long isReady(long tid, Master master) throws Exception {
 
   @VisibleForTesting
   interface TabletIterFactory {
-    Iterator<KeyExtent> newTabletIter(Text startRow) throws Exception;
+    Iterator<KeyExtent> newTabletIter(Text startRow);
   }
 
   private static boolean equals(Function<KeyExtent,Text> extractor, KeyExtent ke1, KeyExtent ke2) {
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/CloneMetadata.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/CloneMetadata.java
index 2549f67015..a71f9cf664 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/CloneMetadata.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/CloneMetadata.java
@@ -32,7 +32,7 @@ public CloneMetadata(CloneInfo cloneInfo) {
   }
 
   @Override
-  public long isReady(long tid, Master environment) throws Exception {
+  public long isReady(long tid, Master environment) {
     return 0;
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/ClonePermissions.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/ClonePermissions.java
index 682f1c408c..d5475c51b8 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/ClonePermissions.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/ClonePermissions.java
@@ -39,7 +39,7 @@ public ClonePermissions(CloneInfo cloneInfo) {
   }
 
   @Override
-  public long isReady(long tid, Master environment) throws Exception {
+  public long isReady(long tid, Master environment) {
     return 0;
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/CloneTable.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/CloneTable.java
index dd25f675b9..413adbc1d6 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/CloneTable.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/CloneTable.java
@@ -67,7 +67,7 @@ public long isReady(long tid, Master environment) throws Exception {
   }
 
   @Override
-  public void undo(long tid, Master environment) throws Exception {
+  public void undo(long tid, Master environment) {
     Utils.unreserveNamespace(environment, cloneInfo.srcNamespaceId, tid, false);
     Utils.unreserveTable(environment, cloneInfo.srcTableId, tid, false);
   }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/FinishCloneTable.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/FinishCloneTable.java
index 346bcae500..6957c0021e 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/FinishCloneTable.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/clone/FinishCloneTable.java
@@ -33,12 +33,12 @@ public FinishCloneTable(CloneInfo cloneInfo) {
   }
 
   @Override
-  public long isReady(long tid, Master environment) throws Exception {
+  public long isReady(long tid, Master environment) {
     return 0;
   }
 
   @Override
-  public Repo<Master> call(long tid, Master environment) throws Exception {
+  public Repo<Master> call(long tid, Master environment) {
     // directories are intentionally not created.... this is done because directories should be
     // unique
     // because they occupy a different namespace than normal tablet directories... also some clones
@@ -63,6 +63,6 @@ public long isReady(long tid, Master environment) throws Exception {
   }
 
   @Override
-  public void undo(long tid, Master environment) throws Exception {}
+  public void undo(long tid, Master environment) {}
 
 }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/CompactRange.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/CompactRange.java
index ebfa027109..0f60ac584a 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/CompactRange.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/CompactRange.java
@@ -151,7 +151,7 @@ static void removeIterators(Master environment, final long txid, Table.ID tableI
 
     zoo.mutate(zTablePath, null, null, new Mutator() {
       @Override
-      public byte[] mutate(byte[] currentValue) throws Exception {
+      public byte[] mutate(byte[] currentValue) {
         String cvs = new String(currentValue, UTF_8);
         String[] tokens = cvs.split(",");
         long flushID = Long.parseLong(tokens[0]);
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/CompactionDriver.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/CompactionDriver.java
index 2cb3f23acb..d22efbdc25 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/CompactionDriver.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/CompactionDriver.java
@@ -146,7 +146,7 @@ public long isReady(long tid, Master master) throws Exception {
   }
 
   @Override
-  public void undo(long tid, Master environment) throws Exception {
+  public void undo(long tid, Master environment) {
 
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/cancel/CancelCompactions.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/cancel/CancelCompactions.java
index b567dea1b6..4eb2575f0c 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/cancel/CancelCompactions.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/cancel/CancelCompactions.java
@@ -63,7 +63,7 @@ public long isReady(long tid, Master env) throws Exception {
 
     zoo.mutate(zCancelID, null, null, new Mutator() {
       @Override
-      public byte[] mutate(byte[] currentValue) throws Exception {
+      public byte[] mutate(byte[] currentValue) {
         long cid = Long.parseLong(new String(currentValue, UTF_8));
 
         if (cid < flushID)
@@ -77,7 +77,7 @@ public long isReady(long tid, Master env) throws Exception {
   }
 
   @Override
-  public void undo(long tid, Master env) throws Exception {
+  public void undo(long tid, Master env) {
     Utils.unreserveTable(env, tableId, tid, false);
     Utils.unreserveNamespace(env, namespaceId, tid, false);
   }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/cancel/FinishCancelCompaction.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/cancel/FinishCancelCompaction.java
index 9ad77cc782..83da00deea 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/cancel/FinishCancelCompaction.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/compact/cancel/FinishCancelCompaction.java
@@ -34,14 +34,14 @@ public FinishCancelCompaction(Namespace.ID namespaceId, Table.ID tableId) {
   }
 
   @Override
-  public Repo<Master> call(long tid, Master environment) throws Exception {
+  public Repo<Master> call(long tid, Master environment) {
     Utils.unreserveTable(environment, tableId, tid, false);
     Utils.unreserveNamespace(environment, namespaceId, tid, false);
     return null;
   }
 
   @Override
-  public void undo(long tid, Master environment) throws Exception {
+  public void undo(long tid, Master environment) {
 
   }
 }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/ChooseDir.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/ChooseDir.java
index 7d589309ef..9725f71026 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/ChooseDir.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/ChooseDir.java
@@ -45,7 +45,7 @@
   }
 
   @Override
-  public long isReady(long tid, Master environment) throws Exception {
+  public long isReady(long tid, Master environment) {
     return 0;
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/CreateDir.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/CreateDir.java
index 742af08654..39041495cb 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/CreateDir.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/CreateDir.java
@@ -38,7 +38,7 @@
   }
 
   @Override
-  public long isReady(long tid, Master environment) throws Exception {
+  public long isReady(long tid, Master environment) {
     return 0;
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/CreateTable.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/CreateTable.java
index 7eda253089..3850ba6f89 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/CreateTable.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/CreateTable.java
@@ -76,7 +76,7 @@ public long isReady(long tid, Master environment) throws Exception {
   }
 
   @Override
-  public void undo(long tid, Master env) throws Exception {
+  public void undo(long tid, Master env) {
     Utils.unreserveNamespace(env, tableInfo.getNamespaceId(), tid, false);
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/FinishCreateTable.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/FinishCreateTable.java
index b588e0d407..06afa18ec5 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/FinishCreateTable.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/FinishCreateTable.java
@@ -40,7 +40,7 @@ public FinishCreateTable(TableInfo ti) {
   }
 
   @Override
-  public long isReady(long tid, Master environment) throws Exception {
+  public long isReady(long tid, Master environment) {
     return 0;
   }
 
@@ -79,6 +79,6 @@ public String getReturn() {
   }
 
   @Override
-  public void undo(long tid, Master env) throws Exception {}
+  public void undo(long tid, Master env) {}
 
 }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/PopulateMetadata.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/PopulateMetadata.java
index 26c0b7e9a7..22ff43ff84 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/PopulateMetadata.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/create/PopulateMetadata.java
@@ -53,7 +53,7 @@
   }
 
   @Override
-  public long isReady(long tid, Master environment) throws Exception {
+  public long isReady(long tid, Master environment) {
     return 0;
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/delete/CleanUp.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/delete/CleanUp.java
index 7999f41a80..750b1cf3ea 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/delete/CleanUp.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/delete/CleanUp.java
@@ -117,7 +117,7 @@ public long isReady(long tid, Master master) throws Exception {
   }
 
   @Override
-  public Repo<Master> call(long tid, Master master) throws Exception {
+  public Repo<Master> call(long tid, Master master) {
 
     master.clearMigrations(tableId);
 
@@ -240,7 +240,7 @@ protected void merge(VolumeManager fs, Path src, Path dest) throws IOException {
   }
 
   @Override
-  public void undo(long tid, Master environment) throws Exception {
+  public void undo(long tid, Master environment) {
     // nothing to do
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/delete/DeleteTable.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/delete/DeleteTable.java
index d2e2e20c2e..6e1f661d65 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/delete/DeleteTable.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/delete/DeleteTable.java
@@ -44,14 +44,14 @@ public long isReady(long tid, Master env) throws Exception {
   }
 
   @Override
-  public Repo<Master> call(long tid, Master env) throws Exception {
+  public Repo<Master> call(long tid, Master env) {
     env.getTableManager().transitionTableState(tableId, TableState.DELETING);
     env.getEventCoordinator().event("deleting table %s ", tableId);
     return new CleanUp(tableId, namespaceId);
   }
 
   @Override
-  public void undo(long tid, Master env) throws Exception {
+  public void undo(long tid, Master env) {
     Utils.unreserveTable(env, tableId, tid, true);
     Utils.unreserveNamespace(env, namespaceId, tid, false);
   }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/merge/TableRangeOp.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/merge/TableRangeOp.java
index 8a89deb6f8..ae2f15df9f 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/merge/TableRangeOp.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/merge/TableRangeOp.java
@@ -53,7 +53,7 @@ public long isReady(long tid, Master env) throws Exception {
   }
 
   public TableRangeOp(MergeInfo.Operation op, Namespace.ID namespaceId, Table.ID tableId,
-      Text startRow, Text endRow) throws AcceptableThriftTableOperationException {
+      Text startRow, Text endRow) {
     this.tableId = tableId;
     this.namespaceId = namespaceId;
     this.startRow = TextUtil.getBytes(startRow);
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/merge/TableRangeOpWait.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/merge/TableRangeOpWait.java
index afc8ddd699..5f94b18971 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/merge/TableRangeOpWait.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/merge/TableRangeOpWait.java
@@ -57,7 +57,7 @@ public TableRangeOpWait(Namespace.ID namespaceId, Table.ID tableId) {
   }
 
   @Override
-  public long isReady(long tid, Master env) throws Exception {
+  public long isReady(long tid, Master env) {
     if (!env.getMergeInfo(tableId).getState().equals(MergeState.NONE)) {
       return 50;
     }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/create/CreateNamespace.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/create/CreateNamespace.java
index 8dbb35f056..ccc08a3bf9 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/create/CreateNamespace.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/create/CreateNamespace.java
@@ -37,7 +37,7 @@ public CreateNamespace(String user, String namespaceName, Map<String,String> pro
   }
 
   @Override
-  public long isReady(long tid, Master environment) throws Exception {
+  public long isReady(long tid, Master environment) {
     return 0;
   }
 
@@ -55,7 +55,7 @@ public long isReady(long tid, Master environment) throws Exception {
   }
 
   @Override
-  public void undo(long tid, Master env) throws Exception {
+  public void undo(long tid, Master env) {
     // nothing to do, the namespace id was allocated!
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/create/FinishCreateNamespace.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/create/FinishCreateNamespace.java
index c4a21c2541..f52380df6a 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/create/FinishCreateNamespace.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/create/FinishCreateNamespace.java
@@ -33,12 +33,12 @@ public FinishCreateNamespace(NamespaceInfo ti) {
   }
 
   @Override
-  public long isReady(long tid, Master environment) throws Exception {
+  public long isReady(long tid, Master environment) {
     return 0;
   }
 
   @Override
-  public Repo<Master> call(long id, Master env) throws Exception {
+  public Repo<Master> call(long id, Master env) {
 
     Utils.unreserveNamespace(env, namespaceInfo.namespaceId, id, true);
 
@@ -56,6 +56,6 @@ public String getReturn() {
   }
 
   @Override
-  public void undo(long tid, Master env) throws Exception {}
+  public void undo(long tid, Master env) {}
 
 }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/delete/DeleteNamespace.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/delete/DeleteNamespace.java
index 56e9224101..b9d081bd79 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/delete/DeleteNamespace.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/delete/DeleteNamespace.java
@@ -39,13 +39,13 @@ public long isReady(long id, Master environment) throws Exception {
   }
 
   @Override
-  public Repo<Master> call(long tid, Master environment) throws Exception {
+  public Repo<Master> call(long tid, Master environment) {
     environment.getEventCoordinator().event("deleting namespace %s ", namespaceId);
     return new NamespaceCleanUp(namespaceId);
   }
 
   @Override
-  public void undo(long id, Master environment) throws Exception {
+  public void undo(long id, Master environment) {
     Utils.unreserveNamespace(environment, namespaceId, id, true);
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/delete/NamespaceCleanUp.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/delete/NamespaceCleanUp.java
index cc3e2830b4..483c0391b9 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/delete/NamespaceCleanUp.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/delete/NamespaceCleanUp.java
@@ -40,12 +40,12 @@ public NamespaceCleanUp(Namespace.ID namespaceId) {
   }
 
   @Override
-  public long isReady(long tid, Master master) throws Exception {
+  public long isReady(long tid, Master master) {
     return 0;
   }
 
   @Override
-  public Repo<Master> call(long id, Master master) throws Exception {
+  public Repo<Master> call(long id, Master master) {
 
     // remove from zookeeper
     try {
@@ -71,7 +71,7 @@ public long isReady(long tid, Master master) throws Exception {
   }
 
   @Override
-  public void undo(long tid, Master environment) throws Exception {
+  public void undo(long tid, Master environment) {
     // nothing to do
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/rename/RenameNamespace.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/rename/RenameNamespace.java
index 8d30093172..2697e98618 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/rename/RenameNamespace.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/namespace/rename/RenameNamespace.java
@@ -87,7 +87,7 @@ public RenameNamespace(Namespace.ID namespaceId, String oldName, String newName)
   }
 
   @Override
-  public void undo(long tid, Master env) throws Exception {
+  public void undo(long tid, Master env) {
     Utils.unreserveNamespace(env, namespaceId, tid, true);
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/rename/RenameTable.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/rename/RenameTable.java
index d324121372..0eaac740bd 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/rename/RenameTable.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/rename/RenameTable.java
@@ -107,7 +107,7 @@ public RenameTable(Namespace.ID namespaceId, Table.ID tableId, String oldTableNa
   }
 
   @Override
-  public void undo(long tid, Master env) throws Exception {
+  public void undo(long tid, Master env) {
     Utils.unreserveTable(env, tableId, tid, true);
     Utils.unreserveNamespace(env, namespaceId, tid, false);
   }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableExport/ExportTable.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableExport/ExportTable.java
index ccb49a94fa..faa5cdf39c 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableExport/ExportTable.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableExport/ExportTable.java
@@ -18,7 +18,6 @@
 
 import org.apache.accumulo.core.clientImpl.Namespace;
 import org.apache.accumulo.core.clientImpl.Table;
-import org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException;
 import org.apache.accumulo.fate.Repo;
 import org.apache.accumulo.master.Master;
 import org.apache.accumulo.master.tableOps.MasterRepo;
@@ -30,8 +29,8 @@
 
   private final ExportInfo tableInfo;
 
-  public ExportTable(Namespace.ID namespaceId, String tableName, Table.ID tableId, String exportDir)
-      throws ThriftTableOperationException {
+  public ExportTable(Namespace.ID namespaceId, String tableName, Table.ID tableId,
+      String exportDir) {
     tableInfo = new ExportInfo();
     tableInfo.tableName = tableName;
     tableInfo.exportDir = exportDir;
@@ -45,7 +44,7 @@ public long isReady(long tid, Master environment) throws Exception {
   }
 
   @Override
-  public Repo<Master> call(long tid, Master env) throws Exception {
+  public Repo<Master> call(long tid, Master env) {
     return new WriteExportFiles(tableInfo);
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableExport/WriteExportFiles.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableExport/WriteExportFiles.java
index 68af2fb273..3614588211 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableExport/WriteExportFiles.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableExport/WriteExportFiles.java
@@ -140,7 +140,7 @@ public long isReady(long tid, Master master) throws Exception {
   }
 
   @Override
-  public void undo(long tid, Master env) throws Exception {
+  public void undo(long tid, Master env) {
     Utils.unreserveNamespace(env, tableInfo.namespaceID, tid, false);
     Utils.unreserveTable(env, tableInfo.tableID, tid, false);
   }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableImport/FinishImportTable.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableImport/FinishImportTable.java
index 1c0a48b75c..4345d80d97 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableImport/FinishImportTable.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableImport/FinishImportTable.java
@@ -35,7 +35,7 @@ public FinishImportTable(ImportedTableInfo ti) {
   }
 
   @Override
-  public long isReady(long tid, Master environment) throws Exception {
+  public long isReady(long tid, Master environment) {
     return 0;
   }
 
@@ -65,6 +65,6 @@ public String getReturn() {
   }
 
   @Override
-  public void undo(long tid, Master env) throws Exception {}
+  public void undo(long tid, Master env) {}
 
 }
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableImport/ImportSetupPermissions.java b/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableImport/ImportSetupPermissions.java
index f88708d8e2..6ebdbb17be 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableImport/ImportSetupPermissions.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tableOps/tableImport/ImportSetupPermissions.java
@@ -36,7 +36,7 @@ public ImportSetupPermissions(ImportedTableInfo ti) {
   }
 
   @Override
-  public long isReady(long tid, Master environment) throws Exception {
+  public long isReady(long tid, Master environment) {
     return 0;
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/tserverOps/ShutdownTServer.java b/server/master/src/main/java/org/apache/accumulo/master/tserverOps/ShutdownTServer.java
index 66d22596c5..51f4431b26 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/tserverOps/ShutdownTServer.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/tserverOps/ShutdownTServer.java
@@ -45,7 +45,7 @@ public ShutdownTServer(TServerInstance server, boolean force) {
   }
 
   @Override
-  public long isReady(long tid, Master master) throws Exception {
+  public long isReady(long tid, Master master) {
     // suppress assignment of tablets to the server
     if (force) {
       return 0;
@@ -96,5 +96,5 @@ public long isReady(long tid, Master master) throws Exception {
   }
 
   @Override
-  public void undo(long tid, Master m) throws Exception {}
+  public void undo(long tid, Master m) {}
 }
diff --git a/server/master/src/test/java/org/apache/accumulo/master/replication/SequentialWorkAssignerTest.java b/server/master/src/test/java/org/apache/accumulo/master/replication/SequentialWorkAssignerTest.java
index 603a332a9c..8e6df6a5a3 100644
--- a/server/master/src/test/java/org/apache/accumulo/master/replication/SequentialWorkAssignerTest.java
+++ b/server/master/src/test/java/org/apache/accumulo/master/replication/SequentialWorkAssignerTest.java
@@ -43,14 +43,14 @@
   private SequentialWorkAssigner assigner;
 
   @Before
-  public void init() throws Exception {
+  public void init() {
     AccumuloConfiguration conf = createMock(AccumuloConfiguration.class);
     client = createMock(AccumuloClient.class);
     assigner = new SequentialWorkAssigner(conf, client);
   }
 
   @Test
-  public void basicZooKeeperCleanup() throws Exception {
+  public void basicZooKeeperCleanup() {
     DistributedWorkQueue workQueue = createMock(DistributedWorkQueue.class);
     ZooCache zooCache = createMock(ZooCache.class);
 
diff --git a/server/master/src/test/java/org/apache/accumulo/master/replication/UnorderedWorkAssignerTest.java b/server/master/src/test/java/org/apache/accumulo/master/replication/UnorderedWorkAssignerTest.java
index adcc2f7c28..87e04fecda 100644
--- a/server/master/src/test/java/org/apache/accumulo/master/replication/UnorderedWorkAssignerTest.java
+++ b/server/master/src/test/java/org/apache/accumulo/master/replication/UnorderedWorkAssignerTest.java
@@ -50,7 +50,7 @@
   private UnorderedWorkAssigner assigner;
 
   @Before
-  public void init() throws Exception {
+  public void init() {
     AccumuloConfiguration conf = createMock(AccumuloConfiguration.class);
     client = createMock(AccumuloClient.class);
     assigner = new UnorderedWorkAssigner(conf, client);
diff --git a/server/master/src/test/java/org/apache/accumulo/master/replication/WorkMakerTest.java b/server/master/src/test/java/org/apache/accumulo/master/replication/WorkMakerTest.java
index fffc487706..2be33cb79c 100644
--- a/server/master/src/test/java/org/apache/accumulo/master/replication/WorkMakerTest.java
+++ b/server/master/src/test/java/org/apache/accumulo/master/replication/WorkMakerTest.java
@@ -26,7 +26,7 @@
 public class WorkMakerTest {
 
   @Test
-  public void closedStatusRecordsStillMakeWork() throws Exception {
+  public void closedStatusRecordsStillMakeWork() {
     WorkMaker workMaker = new WorkMaker(null, null);
 
     assertFalse(workMaker.shouldCreateWork(StatusUtil.fileCreated(System.currentTimeMillis())));
diff --git a/server/master/src/test/java/org/apache/accumulo/master/state/RootTabletStateStoreTest.java b/server/master/src/test/java/org/apache/accumulo/master/state/RootTabletStateStoreTest.java
index a2c9a859bc..c14e88ca2f 100644
--- a/server/master/src/test/java/org/apache/accumulo/master/state/RootTabletStateStoreTest.java
+++ b/server/master/src/test/java/org/apache/accumulo/master/state/RootTabletStateStoreTest.java
@@ -78,7 +78,7 @@ private Node navigate(String path) {
     }
 
     @Override
-    public List<String> getChildren(String path) throws DistributedStoreException {
+    public List<String> getChildren(String path) {
       Node node = navigate(path);
       if (node == null)
         return Collections.emptyList();
@@ -89,7 +89,7 @@ private Node navigate(String path) {
     }
 
     @Override
-    public void put(String path, byte[] bs) throws DistributedStoreException {
+    public void put(String path, byte[] bs) {
       create(path).value = bs;
     }
 
@@ -110,7 +110,7 @@ private Node recurseCreate(Node root, String[] path, int index) {
     }
 
     @Override
-    public void remove(String path) throws DistributedStoreException {
+    public void remove(String path) {
       String[] parts = path.split("/");
       String[] parentPath = Arrays.copyOf(parts, parts.length - 1);
       Node parent = recurse(root, parentPath, 1);
@@ -122,7 +122,7 @@ public void remove(String path) throws DistributedStoreException {
     }
 
     @Override
-    public byte[] get(String path) throws DistributedStoreException {
+    public byte[] get(String path) {
       Node node = navigate(path);
       if (node != null)
         return node.value;
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/Monitor.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/Monitor.java
index 3c3d6af683..e05e5f34f4 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/Monitor.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/Monitor.java
@@ -427,7 +427,7 @@ private static GCStatus fetchGcStatus() {
     return result;
   }
 
-  public static void main(String[] args) throws Exception {
+  public static void main(String[] args) {
 
     final String app = "monitor";
     ServerOpts opts = new ServerOpts();
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/MonitorExecutable.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/MonitorExecutable.java
index ddd34c50d6..65c0a31e6f 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/MonitorExecutable.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/MonitorExecutable.java
@@ -39,7 +39,7 @@ public String description() {
   }
 
   @Override
-  public void execute(final String[] args) throws Exception {
+  public void execute(final String[] args) {
     Monitor.main(args);
   }
 
diff --git a/server/monitor/src/test/java/org/apache/accumulo/monitor/util/ParameterValidatorTest.java b/server/monitor/src/test/java/org/apache/accumulo/monitor/util/ParameterValidatorTest.java
index e7edc5051b..65c60b7e6c 100644
--- a/server/monitor/src/test/java/org/apache/accumulo/monitor/util/ParameterValidatorTest.java
+++ b/server/monitor/src/test/java/org/apache/accumulo/monitor/util/ParameterValidatorTest.java
@@ -42,7 +42,7 @@ public void testAlphaNumRegex() {
   }
 
   @Test
-  public void testServerRegex() throws Exception {
+  public void testServerRegex() {
     Pattern p = Pattern.compile(ParameterValidator.HOSTNAME_PORT_REGEX);
     assertTrue("Did not match hostname with dots", p.matcher("ab3cd.12d34.3xyz.net:12").matches());
     assertTrue("Did not match hostname with dash",
diff --git a/server/tracer/src/main/java/org/apache/accumulo/tracer/AsyncSpanReceiver.java b/server/tracer/src/main/java/org/apache/accumulo/tracer/AsyncSpanReceiver.java
index 6105e598db..7531d69451 100644
--- a/server/tracer/src/main/java/org/apache/accumulo/tracer/AsyncSpanReceiver.java
+++ b/server/tracer/src/main/java/org/apache/accumulo/tracer/AsyncSpanReceiver.java
@@ -62,7 +62,7 @@
   protected String host = null;
   protected String service = null;
 
-  protected abstract Destination createDestination(SpanKey key) throws Exception;
+  protected abstract Destination createDestination(SpanKey key);
 
   protected abstract void send(Destination resource, RemoteSpan span) throws Exception;
 
diff --git a/server/tracer/src/main/java/org/apache/accumulo/tracer/SendSpansViaThrift.java b/server/tracer/src/main/java/org/apache/accumulo/tracer/SendSpansViaThrift.java
index 3016a1df26..ea84825aa3 100644
--- a/server/tracer/src/main/java/org/apache/accumulo/tracer/SendSpansViaThrift.java
+++ b/server/tracer/src/main/java/org/apache/accumulo/tracer/SendSpansViaThrift.java
@@ -51,7 +51,7 @@ public SendSpansViaThrift(HTraceConfiguration conf) {
   @SuppressFBWarnings(value = "UNENCRYPTED_SOCKET",
       justification = "insecure, known risk; this is user-configurable to avoid insecure transfer")
   @Override
-  protected Client createDestination(String destination) throws Exception {
+  protected Client createDestination(String destination) {
     if (destination == null)
       return null;
     try {
diff --git a/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceServer.java b/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceServer.java
index eac6d30503..2f7116995a 100644
--- a/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceServer.java
+++ b/server/tracer/src/main/java/org/apache/accumulo/tracer/TraceServer.java
@@ -72,7 +72,6 @@
 import org.apache.thrift.transport.TServerSocket;
 import org.apache.thrift.transport.TServerTransport;
 import org.apache.thrift.transport.TTransport;
-import org.apache.thrift.transport.TTransportException;
 import org.apache.zookeeper.WatchedEvent;
 import org.apache.zookeeper.Watcher;
 import org.apache.zookeeper.Watcher.Event.EventType;
@@ -98,7 +97,7 @@ private static void put(Mutation m, String cf, String cq, byte[] bytes, int len)
   }
 
   @Override
-  public void close() throws Exception {
+  public void close() {
     if (accumuloClient != null) {
       accumuloClient.close();
     }
@@ -113,7 +112,7 @@ public boolean isOpen() {
     }
 
     @Override
-    public void open() throws TTransportException {}
+    public void open() {}
 
     @Override
     public void close() {}
@@ -124,7 +123,7 @@ public int read(byte[] buf, int off, int len) {
     }
 
     @Override
-    public void write(byte[] buf, int off, int len) throws TTransportException {
+    public void write(byte[] buf, int off, int len) {
       out.write(buf, off, len);
     }
 
@@ -303,7 +302,7 @@ private AccumuloClient ensureTraceTableExists(final AccumuloConfiguration conf)
     return accumuloClient;
   }
 
-  public void run() throws Exception {
+  public void run() {
     SimpleTimer.getInstance(serverConfiguration.getSystemConfiguration()).schedule(() -> flush(),
         SCHEDULE_DELAY, SCHEDULE_PERIOD);
     server.serve();
diff --git a/server/tracer/src/test/java/org/apache/accumulo/tracer/AsyncSpanReceiverTest.java b/server/tracer/src/test/java/org/apache/accumulo/tracer/AsyncSpanReceiverTest.java
index 5785c1c2d3..ad58ce36b4 100644
--- a/server/tracer/src/test/java/org/apache/accumulo/tracer/AsyncSpanReceiverTest.java
+++ b/server/tracer/src/test/java/org/apache/accumulo/tracer/AsyncSpanReceiverTest.java
@@ -41,12 +41,12 @@
     }
 
     @Override
-    protected String createDestination(String o) throws Exception {
+    protected String createDestination(String o) {
       return "DEST";
     }
 
     @Override
-    protected void send(String resource, RemoteSpan span) throws Exception {
+    protected void send(String resource, RemoteSpan span) {
       spansSent.incrementAndGet();
     }
 
diff --git a/server/tracer/src/test/java/org/apache/accumulo/tracer/TracerTest.java b/server/tracer/src/test/java/org/apache/accumulo/tracer/TracerTest.java
index ef08361087..02637f1ea2 100644
--- a/server/tracer/src/test/java/org/apache/accumulo/tracer/TracerTest.java
+++ b/server/tracer/src/test/java/org/apache/accumulo/tracer/TracerTest.java
@@ -42,7 +42,6 @@
 import org.apache.htrace.Sampler;
 import org.apache.htrace.SpanReceiver;
 import org.apache.htrace.wrappers.TraceProxy;
-import org.apache.thrift.TException;
 import org.apache.thrift.protocol.TBinaryProtocol;
 import org.apache.thrift.server.TServer;
 import org.apache.thrift.server.TThreadPoolServer;
@@ -99,7 +98,7 @@ public void receiveSpan(org.apache.htrace.Span s) {
     }
 
     @Override
-    public void close() throws IOException {}
+    public void close() {}
   }
 
   @Test
@@ -149,7 +148,7 @@ public void run() {
 
   static class Service implements TestService.Iface {
     @Override
-    public boolean checkTrace(TInfo t, String message) throws TException {
+    public boolean checkTrace(TInfo t, String message) {
       Span trace = Trace.start(message);
       try {
         return Trace.isTracing();
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/CompactionQueue.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/CompactionQueue.java
index 6ad3690aad..17b68a4117 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/CompactionQueue.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/CompactionQueue.java
@@ -72,14 +72,13 @@ public synchronized boolean offer(TraceRunnable e) {
   }
 
   @Override
-  public synchronized void put(TraceRunnable e) throws InterruptedException {
+  public synchronized void put(TraceRunnable e) {
     task.add(e);
     notify();
   }
 
   @Override
-  public synchronized boolean offer(TraceRunnable e, long timeout, TimeUnit unit)
-      throws InterruptedException {
+  public synchronized boolean offer(TraceRunnable e, long timeout, TimeUnit unit) {
     task.add(e);
     notify();
     return true;
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/NativeMap.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/NativeMap.java
index 1023bd0b90..f3224af53a 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/NativeMap.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/NativeMap.java
@@ -17,7 +17,6 @@
 package org.apache.accumulo.tserver;
 
 import java.io.File;
-import java.io.IOException;
 import java.util.AbstractMap.SimpleImmutableEntry;
 import java.util.ArrayList;
 import java.util.Collection;
@@ -708,7 +707,7 @@ public boolean hasTop() {
     }
 
     @Override
-    public void next() throws IOException {
+    public void next() {
 
       if (entry == null)
         throw new IllegalStateException();
@@ -729,8 +728,7 @@ public void next() throws IOException {
     }
 
     @Override
-    public void seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
-        throws IOException {
+    public void seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive) {
 
       if (interruptFlag != null && interruptFlag.get())
         throw new IterationInterruptedException();
@@ -760,7 +758,7 @@ public void seek(Range range, Collection<ByteSequence> columnFamilies, boolean i
 
     @Override
     public void init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options,
-        IteratorEnvironment env) throws IOException {
+        IteratorEnvironment env) {
       throw new UnsupportedOperationException();
     }
 
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
index 6d803471a9..cd7476e253 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
@@ -806,9 +806,6 @@ public InitialMultiScan startMultiScan(TInfo tinfo, TCredentials credentials,
       MultiScanResult result;
       try {
         result = continueMultiScan(tinfo, sid, mss);
-      } catch (NoSuchScanIDException e) {
-        log.error("the impossible happened", e);
-        throw new RuntimeException("the impossible happened", e);
       } finally {
         sessionManager.unreserveSession(sid);
       }
@@ -834,7 +831,7 @@ public MultiScanResult continueMultiScan(TInfo tinfo, long scanID)
     }
 
     private MultiScanResult continueMultiScan(TInfo tinfo, long scanID, MultiScanSession session)
-        throws NoSuchScanIDException, TSampleNotPresentException {
+        throws TSampleNotPresentException {
 
       if (session.lookupTask == null) {
         session.lookupTask = new LookupTask(TabletServer.this, scanID);
@@ -1571,7 +1568,7 @@ public TConditionalSession startConditionalUpdate(TInfo tinfo, TCredentials cred
     }
 
     @Override
-    public void invalidateConditionalUpdate(TInfo tinfo, long sessID) throws TException {
+    public void invalidateConditionalUpdate(TInfo tinfo, long sessID) {
       // this method should wait for any running conditional update to complete
       // after this method returns a conditional update should not be able to start
 
@@ -1585,7 +1582,7 @@ public void invalidateConditionalUpdate(TInfo tinfo, long sessID) throws TExcept
     }
 
     @Override
-    public void closeConditionalUpdate(TInfo tinfo, long sessID) throws TException {
+    public void closeConditionalUpdate(TInfo tinfo, long sessID) {
       sessionManager.removeSession(sessID, false);
     }
 
@@ -1621,14 +1618,12 @@ public void splitTablet(TInfo tinfo, TCredentials credentials, TKeyExtent tkeyEx
     }
 
     @Override
-    public TabletServerStatus getTabletServerStatus(TInfo tinfo, TCredentials credentials)
-        throws ThriftSecurityException, TException {
+    public TabletServerStatus getTabletServerStatus(TInfo tinfo, TCredentials credentials) {
       return getStats(sessionManager.getActiveScansPerTable());
     }
 
     @Override
-    public List<TabletStats> getTabletStats(TInfo tinfo, TCredentials credentials, String tableId)
-        throws ThriftSecurityException, TException {
+    public List<TabletStats> getTabletStats(TInfo tinfo, TCredentials credentials, String tableId) {
       TreeMap<KeyExtent,Tablet> onlineTabletsCopy;
       synchronized (onlineTablets) {
         onlineTabletsCopy = new TreeMap<>(onlineTablets);
@@ -1850,8 +1845,8 @@ public void flush(TInfo tinfo, TCredentials credentials, String lock, String tab
     }
 
     @Override
-    public void flushTablet(TInfo tinfo, TCredentials credentials, String lock, TKeyExtent textent)
-        throws TException {
+    public void flushTablet(TInfo tinfo, TCredentials credentials, String lock,
+        TKeyExtent textent) {
       try {
         checkPermission(credentials, lock, "flushTablet");
       } catch (ThriftSecurityException e) {
@@ -1902,8 +1897,7 @@ public void fastHalt(TInfo info, TCredentials credentials, String lock) {
     }
 
     @Override
-    public TabletStats getHistoricalStats(TInfo tinfo, TCredentials credentials)
-        throws ThriftSecurityException, TException {
+    public TabletStats getHistoricalStats(TInfo tinfo, TCredentials credentials) {
       return statsKeeper.getTabletStats();
     }
 
@@ -1921,8 +1915,7 @@ public TabletStats getHistoricalStats(TInfo tinfo, TCredentials credentials)
     }
 
     @Override
-    public void chop(TInfo tinfo, TCredentials credentials, String lock, TKeyExtent textent)
-        throws TException {
+    public void chop(TInfo tinfo, TCredentials credentials, String lock, TKeyExtent textent) {
       try {
         checkPermission(credentials, lock, "chop");
       } catch (ThriftSecurityException e) {
@@ -1940,7 +1933,7 @@ public void chop(TInfo tinfo, TCredentials credentials, String lock, TKeyExtent
 
     @Override
     public void compact(TInfo tinfo, TCredentials credentials, String lock, String tableId,
-        ByteBuffer startRow, ByteBuffer endRow) throws TException {
+        ByteBuffer startRow, ByteBuffer endRow) {
       try {
         checkPermission(credentials, lock, "compact");
       } catch (ThriftSecurityException e) {
@@ -1996,7 +1989,7 @@ public void compact(TInfo tinfo, TCredentials credentials, String lock, String t
     }
 
     @Override
-    public List<String> getActiveLogs(TInfo tinfo, TCredentials credentials) throws TException {
+    public List<String> getActiveLogs(TInfo tinfo, TCredentials credentials) {
       String log = logger.getLogFile();
       // Might be null if there no active logger
       if (log == null) {
@@ -2006,8 +1999,7 @@ public void compact(TInfo tinfo, TCredentials credentials, String lock, String t
     }
 
     @Override
-    public void removeLogs(TInfo tinfo, TCredentials credentials, List<String> filenames)
-        throws TException {
+    public void removeLogs(TInfo tinfo, TCredentials credentials, List<String> filenames) {
       log.warn("Garbage collector is attempting to remove logs through the tablet server");
       log.warn("This is probably because your file"
           + " Garbage Collector is an older version than your tablet servers.\n"
@@ -2050,8 +2042,8 @@ private TSummaries startSummaryOperation(TCredentials credentials,
 
     @Override
     public TSummaries startGetSummaries(TInfo tinfo, TCredentials credentials,
-        TSummaryRequest request) throws ThriftSecurityException, ThriftTableOperationException,
-        NoSuchScanIDException, TException {
+        TSummaryRequest request)
+        throws ThriftSecurityException, ThriftTableOperationException, TException {
       Namespace.ID namespaceId;
       Table.ID tableId = Table.ID.of(request.getTableId());
       try {
@@ -2077,7 +2069,7 @@ public TSummaries startGetSummaries(TInfo tinfo, TCredentials credentials,
     @Override
     public TSummaries startGetSummariesForPartition(TInfo tinfo, TCredentials credentials,
         TSummaryRequest request, int modulus, int remainder)
-        throws ThriftSecurityException, NoSuchScanIDException, TException {
+        throws ThriftSecurityException, TException {
       // do not expect users to call this directly, expect other tservers to call this method
       if (!security.canPerformSystemActions(credentials)) {
         throw new AccumuloSecurityException(credentials.getPrincipal(),
@@ -2096,7 +2088,7 @@ public TSummaries startGetSummariesForPartition(TInfo tinfo, TCredentials creden
     @Override
     public TSummaries startGetSummariesFromFiles(TInfo tinfo, TCredentials credentials,
         TSummaryRequest request, Map<String,List<TRowRange>> files)
-        throws ThriftSecurityException, NoSuchScanIDException, TException {
+        throws ThriftSecurityException, TException {
       // do not expect users to call this directly, expect other tservers to call this method
       if (!security.canPerformSystemActions(credentials)) {
         throw new AccumuloSecurityException(credentials.getPrincipal(),
@@ -2593,7 +2585,7 @@ public void run() {
     }
   }
 
-  private void acquireRecoveryMemory(KeyExtent extent) throws InterruptedException {
+  private void acquireRecoveryMemory(KeyExtent extent) {
     if (!extent.isMeta()) {
       recoveryLock.lock();
     }
@@ -2978,7 +2970,7 @@ public void run() {
   }
 
   private static Pair<Text,KeyExtent> verifyRootTablet(ServerContext context, KeyExtent extent,
-      TServerInstance instance) throws DistributedStoreException, AccumuloException {
+      TServerInstance instance) throws AccumuloException {
     ZooTabletStateStore store = new ZooTabletStateStore(context);
     if (!store.iterator().hasNext()) {
       throw new AccumuloException("Illegal state: location is not set in zookeeper");
@@ -3001,8 +2993,7 @@ public void run() {
 
   public static Pair<Text,KeyExtent> verifyTabletInformation(ServerContext context,
       KeyExtent extent, TServerInstance instance, final SortedMap<Key,Value> tabletsKeyValues,
-      String clientAddress, ZooLock lock)
-      throws AccumuloSecurityException, DistributedStoreException, AccumuloException {
+      String clientAddress, ZooLock lock) throws DistributedStoreException, AccumuloException {
     Objects.requireNonNull(tabletsKeyValues);
 
     log.debug("verifying extent {}", extent);
@@ -3048,14 +3039,8 @@ public void run() {
       SortedMap<Text,SortedMap<ColumnFQ,Value>> tabletEntries;
       tabletEntries = MetadataTableUtil.getTabletEntries(tabletsKeyValues, columnsToFetch);
 
-      KeyExtent fke;
-      try {
-        fke = MasterMetadataUtil.fixSplit(context, metadataEntry, tabletEntries.get(metadataEntry),
-            instance, lock);
-      } catch (IOException e) {
-        log.error("Error fixing split {}", metadataEntry);
-        throw new AccumuloException(e.toString());
-      }
+      KeyExtent fke = MasterMetadataUtil.fixSplit(context, metadataEntry,
+          tabletEntries.get(metadataEntry), instance, lock);
 
       if (!fke.equals(extent)) {
         return new Pair<>(null, fke);
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/TservConstraintEnv.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/TservConstraintEnv.java
index 3ec6de0c7b..21e8af657c 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/TservConstraintEnv.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/TservConstraintEnv.java
@@ -19,7 +19,6 @@
 import java.nio.ByteBuffer;
 import java.util.Collections;
 
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.data.ByteSequence;
 import org.apache.accumulo.core.dataImpl.KeyExtent;
 import org.apache.accumulo.core.security.AuthorizationContainer;
@@ -60,12 +59,8 @@ public AuthorizationContainer getAuthorizationsContainer() {
     return new AuthorizationContainer() {
       @Override
       public boolean contains(ByteSequence auth) {
-        try {
-          return security.authenticatedUserHasAuthorizations(credentials, Collections.singletonList(
-              ByteBuffer.wrap(auth.getBackingArray(), auth.offset(), auth.length())));
-        } catch (ThriftSecurityException e) {
-          throw new RuntimeException(e);
-        }
+        return security.authenticatedUserHasAuthorizations(credentials, Collections
+            .singletonList(ByteBuffer.wrap(auth.getBackingArray(), auth.offset(), auth.length())));
       }
     };
   }
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/compaction/EverythingCompactionStrategy.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/compaction/EverythingCompactionStrategy.java
index 29729410d9..7ea1ff7107 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/compaction/EverythingCompactionStrategy.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/compaction/EverythingCompactionStrategy.java
@@ -17,8 +17,6 @@
 
 package org.apache.accumulo.tserver.compaction;
 
-import java.io.IOException;
-
 /**
  * The default compaction strategy for user initiated compactions. This strategy will always select
  * all files.
@@ -27,12 +25,12 @@
 public class EverythingCompactionStrategy extends CompactionStrategy {
 
   @Override
-  public boolean shouldCompact(MajorCompactionRequest request) throws IOException {
+  public boolean shouldCompact(MajorCompactionRequest request) {
     return true; // ACCUMULO-3645 compact for empty files too
   }
 
   @Override
-  public CompactionPlan getCompactionPlan(MajorCompactionRequest request) throws IOException {
+  public CompactionPlan getCompactionPlan(MajorCompactionRequest request) {
     CompactionPlan plan = new CompactionPlan();
     plan.inputFiles.addAll(request.getFiles().keySet());
     return plan;
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/compaction/MajorCompactionRequest.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/compaction/MajorCompactionRequest.java
index 44c3b7e61f..be01620bbb 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/compaction/MajorCompactionRequest.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/compaction/MajorCompactionRequest.java
@@ -147,7 +147,7 @@ public MajorCompactionReason getReason() {
    * @see WriterOptions#withSummarizers(SummarizerConfiguration...)
    */
   public List<Summary> getSummaries(Collection<FileRef> files,
-      Predicate<SummarizerConfiguration> summarySelector) throws IOException {
+      Predicate<SummarizerConfiguration> summarySelector) {
     Preconditions.checkState(volumeManager != null,
         "Getting summaries is not" + " supported at this time. It's only supported when"
             + " CompactionStrategy.gatherInformation() is called.");
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/compaction/strategies/ConfigurableCompactionStrategy.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/compaction/strategies/ConfigurableCompactionStrategy.java
index d64ce82b1a..491d73e1ca 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/compaction/strategies/ConfigurableCompactionStrategy.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/compaction/strategies/ConfigurableCompactionStrategy.java
@@ -87,12 +87,8 @@ void gatherInformation(MajorCompactionRequest request) {
         for (FileRef fref : request.getFiles().keySet()) {
           Map<SummarizerConfiguration,Summary> sMap = new HashMap<>();
           Collection<Summary> summaries;
-          try {
-            summaries = request.getSummaries(Collections.singletonList(fref),
-                conf -> configsSet.contains(conf));
-          } catch (IOException e) {
-            throw new UncheckedIOException(e);
-          }
+          summaries = request.getSummaries(Collections.singletonList(fref),
+              conf -> configsSet.contains(conf));
           for (Summary summary : summaries) {
             sMap.put(summary.getSummarizerConfiguration(), summary);
           }
@@ -327,12 +323,12 @@ public String getInput(Path path) {
   }
 
   @Override
-  public boolean shouldCompact(MajorCompactionRequest request) throws IOException {
+  public boolean shouldCompact(MajorCompactionRequest request) {
     return getFilesToCompact(request).size() >= minFiles;
   }
 
   @Override
-  public void gatherInformation(MajorCompactionRequest request) throws IOException {
+  public void gatherInformation(MajorCompactionRequest request) {
     // Gather any information that requires blocking calls here. This is only called before
     // getCompactionPlan() is called.
     for (Test test : tests) {
@@ -341,7 +337,7 @@ public void gatherInformation(MajorCompactionRequest request) throws IOException
   }
 
   @Override
-  public CompactionPlan getCompactionPlan(MajorCompactionRequest request) throws IOException {
+  public CompactionPlan getCompactionPlan(MajorCompactionRequest request) {
     List<FileRef> filesToCompact = getFilesToCompact(request);
     if (filesToCompact.size() >= minFiles) {
       CompactionPlan plan = new CompactionPlan();
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/DfsLogger.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/DfsLogger.java
index 776639e171..fc8e067ace 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/DfsLogger.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/DfsLogger.java
@@ -289,7 +289,7 @@ public NoWaitLoggerOperation() {
     }
 
     @Override
-    public void await() throws IOException {
+    public void await() {
       return;
     }
   }
@@ -335,7 +335,7 @@ private DfsLogger(ServerContext context, ServerResources conf) {
   }
 
   public DfsLogger(ServerContext context, ServerResources conf, AtomicLong syncCounter,
-      AtomicLong flushCounter) throws IOException {
+      AtomicLong flushCounter) {
     this(context, conf);
     this.syncCounter = syncCounter;
     this.flushCounter = flushCounter;
@@ -347,8 +347,7 @@ public DfsLogger(ServerContext context, ServerResources conf, AtomicLong syncCou
    * @param meta
    *          the cq for the "log" entry in +r/!0
    */
-  public DfsLogger(ServerContext context, ServerResources conf, String filename, String meta)
-      throws IOException {
+  public DfsLogger(ServerContext context, ServerResources conf, String filename, String meta) {
     this(context, conf);
     this.logPath = filename;
     metaReference = meta;
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/TabletServerLogger.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/TabletServerLogger.java
index 101521f2fa..ad6f802a10 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/TabletServerLogger.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/TabletServerLogger.java
@@ -171,17 +171,13 @@ boolean test() {
       }
 
       @Override
-      void withWriteLock() throws IOException {
-        try {
-          createLogger();
-          result.set(currentLog);
-          if (currentLog != null)
-            logIdOut.set(logId.get());
-          else
-            logIdOut.set(-1);
-        } catch (IOException e) {
-          log.error("Unable to create loggers", e);
-        }
+      void withWriteLock() {
+        createLogger();
+        result.set(currentLog);
+        if (currentLog != null)
+          logIdOut.set(logId.get());
+        else
+          logIdOut.set(-1);
       }
     });
     return result.get();
@@ -204,7 +200,7 @@ public String getLogFile() {
     }
   }
 
-  private synchronized void createLogger() throws IOException {
+  private synchronized void createLogger() {
     if (!logIdLock.isWriteLockedByCurrentThread()) {
       throw new IllegalStateException("createLoggers should be called with write lock held!");
     }
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystem.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystem.java
index b89e04aeff..f1308f2817 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystem.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystem.java
@@ -840,7 +840,7 @@ protected long writeValueAvoidingReplicationCycles(DataOutputStream out, LogFile
     return mutationsToSend;
   }
 
-  protected DataInputStream getRFileInputStream(Path p) throws IOException {
+  protected DataInputStream getRFileInputStream(Path p) {
     throw new UnsupportedOperationException("Not yet implemented");
   }
 
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/BatchWriterReplicationReplayer.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/BatchWriterReplicationReplayer.java
index d011213898..894657c6c5 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/BatchWriterReplicationReplayer.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/BatchWriterReplicationReplayer.java
@@ -23,8 +23,6 @@
 import java.util.List;
 import java.util.Set;
 
-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.MutationsRejectedException;
@@ -55,7 +53,7 @@
 
   @Override
   public long replicateLog(ClientContext context, String tableName, WalEdits data)
-      throws RemoteReplicationException, AccumuloException, AccumuloSecurityException {
+      throws RemoteReplicationException {
     final LogFileKey key = new LogFileKey();
     final LogFileValue value = new LogFileValue();
     final long memoryInBytes = context.getConfiguration()
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/ReplicationServicerHandler.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/ReplicationServicerHandler.java
index b0d65929ff..0abe464d2b 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/ReplicationServicerHandler.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/replication/ReplicationServicerHandler.java
@@ -119,8 +119,7 @@ public long replicateLog(String tableIdStr, WalEdits data, TCredentials tcreds)
   }
 
   @Override
-  public long replicateKeyValues(String tableId, KeyValues data, TCredentials creds)
-      throws RemoteReplicationException, TException {
+  public long replicateKeyValues(String tableId, KeyValues data, TCredentials creds) {
     throw new UnsupportedOperationException();
   }
 
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/DatafileManager.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/DatafileManager.java
index ae5201d2cd..c46d988e32 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/DatafileManager.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/DatafileManager.java
@@ -344,7 +344,7 @@ void unreserveMergingMinorCompactionFile(FileRef file) {
   }
 
   void bringMinorCompactionOnline(FileRef tmpDatafile, FileRef newDatafile, FileRef absMergeFile,
-      DataFileValue dfv, CommitSession commitSession, long flushId) throws IOException {
+      DataFileValue dfv, CommitSession commitSession, long flushId) {
 
     IZooReaderWriter zoo = tablet.getContext().getZooReaderWriter();
     if (tablet.getExtent().isRootTablet()) {
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java
index facf55d0b2..a769061747 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java
@@ -1745,7 +1745,7 @@ private static int longestCommonLength(Text text, Text beforeMid) {
   }
 
   List<FileRef> findChopFiles(KeyExtent extent, Map<FileRef,Pair<Key,Key>> firstAndLastKeys,
-      Collection<FileRef> allFiles) throws IOException {
+      Collection<FileRef> allFiles) {
     List<FileRef> result = new ArrayList<>();
     if (firstAndLastKeys == null) {
       result.addAll(allFiles);
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/TabletMemory.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/TabletMemory.java
index cf1d1ebe7f..08695dfa8d 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/TabletMemory.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/TabletMemory.java
@@ -17,7 +17,6 @@
 package org.apache.accumulo.tserver.tablet;
 
 import java.io.Closeable;
-import java.io.IOException;
 import java.util.ArrayList;
 import java.util.List;
 
@@ -190,7 +189,7 @@ public ServerContext getContext() {
   }
 
   @Override
-  public void close() throws IOException {
+  public void close() {
     commitSession = null;
   }
 
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/InMemoryMapTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/InMemoryMapTest.java
index 1b828876a9..44465a21dc 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/InMemoryMapTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/InMemoryMapTest.java
@@ -103,7 +103,7 @@ public SamplerConfiguration getSamplerConfiguration() {
   public ExpectedException thrown = ExpectedException.none();
 
   @BeforeClass
-  public static void setUp() throws Exception {
+  public static void setUp() {
     // suppress log messages having to do with not having an instance
     Logger.getLogger(ZooConfiguration.class).setLevel(Level.OFF);
   }
@@ -153,7 +153,7 @@ static void testAndCallNext(SortedKeyValueIterator<Key,Value> dc, String row, St
   }
 
   static void assertEqualsNoNext(SortedKeyValueIterator<Key,Value> dc, String row, String column,
-      int ts, String val) throws IOException {
+      int ts, String val) {
     assertTrue(dc.hasTop());
     assertEquals(newKey(row, column, ts), dc.getTopKey());
     assertEquals(new Value(val.getBytes()), dc.getTopValue());
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/LargestFirstMemoryManagerTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/LargestFirstMemoryManagerTest.java
index 08ccc642a4..f1b9a9320c 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/LargestFirstMemoryManagerTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/LargestFirstMemoryManagerTest.java
@@ -59,7 +59,7 @@ public void mockServerInfo() {
   }
 
   @Test
-  public void test() throws Exception {
+  public void test() {
     LargestFirstMemoryManagerUnderTest mgr = new LargestFirstMemoryManagerUnderTest();
     ServerConfiguration config = new ServerConfiguration() {
       ServerConfigurationFactory delegate = context.getServerConfFactory();
@@ -191,7 +191,7 @@ public NamespaceConfiguration getNamespaceConfiguration(Namespace.ID namespaceId
   }
 
   @Test
-  public void testDeletedTable() throws Exception {
+  public void testDeletedTable() {
     final String deletedTableId = "1";
     Function<Table.ID,Boolean> existenceCheck = tableId -> !deletedTableId
         .contentEquals(tableId.canonicalID());
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/MemValueTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/MemValueTest.java
index 1705e4e4c8..7356bdf302 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/MemValueTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/MemValueTest.java
@@ -26,7 +26,7 @@
 public class MemValueTest {
 
   @Test
-  public void testDecodeDoesntModifyInputValue() throws Exception {
+  public void testDecodeDoesntModifyInputValue() {
     Value v = new Value("2.0".getBytes(Charset.forName("UTF-8")));
     Value encodedValue = MemValue.encode(v, 3);
     MemValue m1 = MemValue.decode(encodedValue);
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/TabletResourceManagerTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/TabletResourceManagerTest.java
index 2a80ccffd3..a63896e040 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/TabletResourceManagerTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/TabletResourceManagerTest.java
@@ -32,7 +32,7 @@
   private TableConfiguration conf;
 
   @Before
-  public void setUp() throws Exception {
+  public void setUp() {
     tsrm = createMock(TabletServerResourceManager.class);
     extent = createMock(KeyExtent.class);
     conf = createMock(TableConfiguration.class);
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/TabletServerSyncCheckTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/TabletServerSyncCheckTest.java
index a775884bbe..646a84de1e 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/TabletServerSyncCheckTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/TabletServerSyncCheckTest.java
@@ -16,7 +16,6 @@
  */
 package org.apache.accumulo.tserver;
 
-import java.io.IOException;
 import java.util.Collections;
 import java.util.Map;
 
@@ -81,54 +80,53 @@ protected void ensureSyncIsEnabled() {
     }
 
     @Override
-    public void close() throws IOException {
+    public void close() {
 
     }
 
     @Override
-    public FSDataOutputStream create(Path dest) throws IOException {
+    public FSDataOutputStream create(Path dest) {
       return null;
     }
 
     @Override
-    public FSDataOutputStream create(Path path, boolean b) throws IOException {
+    public FSDataOutputStream create(Path path, boolean b) {
       return null;
     }
 
     @Override
-    public FSDataOutputStream create(Path path, boolean b, int int1, short int2, long long1)
-        throws IOException {
+    public FSDataOutputStream create(Path path, boolean b, int int1, short int2, long long1) {
       return null;
     }
 
     @Override
-    public boolean createNewFile(Path writable) throws IOException {
+    public boolean createNewFile(Path writable) {
       return false;
     }
 
     @Override
     public FSDataOutputStream createSyncable(Path logPath, int buffersize, short replication,
-        long blockSize) throws IOException {
+        long blockSize) {
       return null;
     }
 
     @Override
-    public boolean delete(Path path) throws IOException {
+    public boolean delete(Path path) {
       return false;
     }
 
     @Override
-    public boolean deleteRecursively(Path path) throws IOException {
+    public boolean deleteRecursively(Path path) {
       return false;
     }
 
     @Override
-    public boolean exists(Path path) throws IOException {
+    public boolean exists(Path path) {
       return false;
     }
 
     @Override
-    public FileStatus getFileStatus(Path path) throws IOException {
+    public FileStatus getFileStatus(Path path) {
       return null;
     }
 
@@ -143,27 +141,27 @@ public Path matchingFileSystem(Path source, String[] options) {
     }
 
     @Override
-    public FileStatus[] listStatus(Path path) throws IOException {
+    public FileStatus[] listStatus(Path path) {
       return null;
     }
 
     @Override
-    public boolean mkdirs(Path directory) throws IOException {
+    public boolean mkdirs(Path directory) {
       return false;
     }
 
     @Override
-    public FSDataInputStream open(Path path) throws IOException {
+    public FSDataInputStream open(Path path) {
       return null;
     }
 
     @Override
-    public boolean rename(Path path, Path newPath) throws IOException {
+    public boolean rename(Path path, Path newPath) {
       return false;
     }
 
     @Override
-    public boolean moveToTrash(Path sourcePath) throws IOException {
+    public boolean moveToTrash(Path sourcePath) {
       return false;
     }
 
@@ -173,12 +171,12 @@ public short getDefaultReplication(Path logPath) {
     }
 
     @Override
-    public boolean isReady() throws IOException {
+    public boolean isReady() {
       return false;
     }
 
     @Override
-    public FileStatus[] globStatus(Path path) throws IOException {
+    public FileStatus[] globStatus(Path path) {
       return null;
     }
 
@@ -198,7 +196,7 @@ public Path getFullPath(FileType fileType, String fileName) {
     }
 
     @Override
-    public ContentSummary getContentSummary(Path dir) throws IOException {
+    public ContentSummary getContentSummary(Path dir) {
       return null;
     }
 
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/TservConstraintEnvTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/TservConstraintEnvTest.java
index 45236eedc9..1f1cd0dcba 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/TservConstraintEnvTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/TservConstraintEnvTest.java
@@ -26,7 +26,6 @@
 import java.util.Collections;
 import java.util.List;
 
-import org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.data.ArrayByteSequence;
 import org.apache.accumulo.core.data.ByteSequence;
 import org.apache.accumulo.core.securityImpl.thrift.TCredentials;
@@ -36,7 +35,7 @@
 public class TservConstraintEnvTest {
 
   @Test
-  public void testGetAuthorizationsContainer() throws ThriftSecurityException {
+  public void testGetAuthorizationsContainer() {
     SecurityOperation security = createMock(SecurityOperation.class);
     TCredentials goodCred = createMock(TCredentials.class);
     TCredentials badCred = createMock(TCredentials.class);
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/WalRemovalOrderTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/WalRemovalOrderTest.java
index 435de4fbf0..eedb0dfbc7 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/WalRemovalOrderTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/WalRemovalOrderTest.java
@@ -18,8 +18,6 @@
 
 import static org.junit.Assert.assertEquals;
 
-import java.io.IOException;
-import java.io.UncheckedIOException;
 import java.util.Collections;
 import java.util.LinkedHashSet;
 import java.util.List;
@@ -49,12 +47,7 @@ public VolumeManager getFileSystem() {
         throw new UnsupportedOperationException();
       }
     };
-
-    try {
-      return new DfsLogger(null, conf, filename, null);
-    } catch (IOException e) {
-      throw new UncheckedIOException(e);
-    }
+    return new DfsLogger(null, conf, filename, null);
   }
 
   private static LinkedHashSet<DfsLogger> mockLoggers(String... logs) {
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/DefaultCompactionStrategyTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/DefaultCompactionStrategyTest.java
index a4efc22d9b..cd0d614c24 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/DefaultCompactionStrategyTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/DefaultCompactionStrategyTest.java
@@ -20,7 +20,6 @@
 import static org.junit.Assert.assertTrue;
 
 import java.io.DataInputStream;
-import java.io.IOException;
 import java.util.Arrays;
 import java.util.Collection;
 import java.util.HashMap;
@@ -38,7 +37,6 @@
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.dataImpl.KeyExtent;
 import org.apache.accumulo.core.file.FileSKVIterator;
-import org.apache.accumulo.core.file.NoSuchMetaStoreException;
 import org.apache.accumulo.core.iterators.IteratorEnvironment;
 import org.apache.accumulo.core.iterators.SortedKeyValueIterator;
 import org.apache.accumulo.core.metadata.schema.DataFileValue;
@@ -92,7 +90,7 @@ public void setInterruptFlag(AtomicBoolean flag) {}
 
     @Override
     public void init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options,
-        IteratorEnvironment env) throws IOException {}
+        IteratorEnvironment env) {}
 
     @Override
     public boolean hasTop() {
@@ -100,11 +98,10 @@ public boolean hasTop() {
     }
 
     @Override
-    public void next() throws IOException {}
+    public void next() {}
 
     @Override
-    public void seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
-        throws IOException {}
+    public void seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive) {}
 
     @Override
     public Key getTopKey() {
@@ -122,7 +119,7 @@ public Value getTopValue() {
     }
 
     @Override
-    public Key getFirstKey() throws IOException {
+    public Key getFirstKey() {
       Pair<Key,Key> pair = fakeFiles.get(filename);
       if (pair == null)
         return null;
@@ -130,7 +127,7 @@ public Key getFirstKey() throws IOException {
     }
 
     @Override
-    public Key getLastKey() throws IOException {
+    public Key getLastKey() {
       Pair<Key,Key> pair = fakeFiles.get(filename);
       if (pair == null)
         return null;
@@ -138,15 +135,15 @@ public Key getLastKey() throws IOException {
     }
 
     @Override
-    public DataInputStream getMetaStore(String name) throws IOException, NoSuchMetaStoreException {
+    public DataInputStream getMetaStore(String name) {
       return null;
     }
 
     @Override
-    public void closeDeepCopies() throws IOException {}
+    public void closeDeepCopies() {}
 
     @Override
-    public void close() throws IOException {}
+    public void close() {}
 
     @Override
     public FileSKVIterator getSample(SamplerConfigurationImpl sampleConfig) {
@@ -159,7 +156,7 @@ public FileSKVIterator getSample(SamplerConfigurationImpl sampleConfig) {
 
   private static class TestCompactionRequest extends MajorCompactionRequest {
     @Override
-    public FileSKVIterator openReader(FileRef ref) throws IOException {
+    public FileSKVIterator openReader(FileRef ref) {
       return new TestFileSKVIterator(ref.toString());
     }
 
@@ -171,13 +168,12 @@ public FileSKVIterator openReader(FileRef ref) throws IOException {
 
   }
 
-  private MajorCompactionRequest createRequest(MajorCompactionReason reason, Object... objs)
-      throws IOException {
+  private MajorCompactionRequest createRequest(MajorCompactionReason reason, Object... objs) {
     return createRequest(new KeyExtent(Table.ID.of("0"), null, null), reason, objs);
   }
 
   private MajorCompactionRequest createRequest(KeyExtent extent, MajorCompactionReason reason,
-      Object... objs) throws IOException {
+      Object... objs) {
     Map<FileRef,DataFileValue> files = new HashMap<>();
     for (int i = 0; i < objs.length; i += 2) {
       files.put(new FileRef("hdfs://nn1/accumulo/tables/5/t-0001/" + objs[i]),
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/SizeLimitCompactionStrategyTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/SizeLimitCompactionStrategyTest.java
index 4e2b91f35e..ded5837db8 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/SizeLimitCompactionStrategyTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/SizeLimitCompactionStrategyTest.java
@@ -21,7 +21,6 @@
 import static org.junit.Assert.assertFalse;
 import static org.junit.Assert.assertTrue;
 
-import java.io.IOException;
 import java.util.HashMap;
 import java.util.HashSet;
 import java.util.Map;
@@ -50,7 +49,7 @@
   }
 
   @Test
-  public void testLimits() throws IOException {
+  public void testLimits() {
     SizeLimitCompactionStrategy slcs = new SizeLimitCompactionStrategy();
     HashMap<String,String> opts = new HashMap<>();
     opts.put(SizeLimitCompactionStrategy.SIZE_LIMIT_OPT, "1G");
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/TwoTierCompactionStrategyTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/TwoTierCompactionStrategyTest.java
index 3eab55c85b..54ebdd9f7c 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/TwoTierCompactionStrategyTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/TwoTierCompactionStrategyTest.java
@@ -22,7 +22,6 @@
 import static org.junit.Assert.assertTrue;
 import static org.junit.Assert.fail;
 
-import java.io.IOException;
 import java.util.HashMap;
 import java.util.HashSet;
 import java.util.List;
@@ -68,7 +67,7 @@ public void setup() {
   }
 
   @Test
-  public void testDefaultCompaction() throws IOException {
+  public void testDefaultCompaction() {
     ttcs.init(opts);
     conf = DefaultConfiguration.getInstance();
     KeyExtent ke = new KeyExtent(Table.ID.of("0"), null, null);
@@ -88,7 +87,7 @@ public void testDefaultCompaction() throws IOException {
   }
 
   @Test
-  public void testLargeCompaction() throws IOException {
+  public void testLargeCompaction() {
     ttcs.init(opts);
     conf = DefaultConfiguration.getInstance();
     KeyExtent ke = new KeyExtent(Table.ID.of("0"), null, null);
@@ -119,7 +118,7 @@ public void testMissingConfigProperties() {
   }
 
   @Test
-  public void testFileSubsetCompaction() throws IOException {
+  public void testFileSubsetCompaction() {
     ttcs.init(opts);
     conf = DefaultConfiguration.getInstance();
     KeyExtent ke = new KeyExtent(Table.ID.of("0"), null, null);
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/strategies/ConfigurableCompactionStrategyTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/strategies/ConfigurableCompactionStrategyTest.java
index 7ff0e32123..5154a8edf7 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/strategies/ConfigurableCompactionStrategyTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/compaction/strategies/ConfigurableCompactionStrategyTest.java
@@ -40,7 +40,7 @@
   // file selection options are adequately tested by ShellServerIT
 
   @Test
-  public void testOutputOptions() throws Exception {
+  public void testOutputOptions() {
     MajorCompactionRequest mcr = new MajorCompactionRequest(
         new KeyExtent(Table.ID.of("1"), null, null), MajorCompactionReason.USER, null,
         getServerContext());
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/constraints/ConstraintCheckerTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/constraints/ConstraintCheckerTest.java
index 8e6505bbeb..6e34722be7 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/constraints/ConstraintCheckerTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/constraints/ConstraintCheckerTest.java
@@ -51,7 +51,7 @@
   private Mutation m;
 
   @Before
-  public void setup() throws NoSuchMethodException, SecurityException {
+  public void setup() throws SecurityException {
     cc = createMockBuilder(ConstraintChecker.class).addMockedMethod("getConstraints").createMock();
     constraints = new ArrayList<>();
     expect(cc.getConstraints()).andReturn(constraints);
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystemTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystemTest.java
index 2fccc7e0f1..335c931596 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystemTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/replication/AccumuloReplicaSystemTest.java
@@ -514,7 +514,7 @@ public void consumedButNotSentDataShouldBeRecorded() throws Exception {
   }
 
   @Test
-  public void testUserPassword() throws Exception {
+  public void testUserPassword() {
     AccumuloReplicaSystem ars = new AccumuloReplicaSystem();
     ReplicationTarget target = new ReplicationTarget("peer", "peer_table", Table.ID.of("1"));
     String user = "user", password = "password";
@@ -529,7 +529,7 @@ public void testUserPassword() throws Exception {
   }
 
   @Test
-  public void testUserKeytab() throws Exception {
+  public void testUserKeytab() {
     AccumuloReplicaSystem ars = new AccumuloReplicaSystem();
     ReplicationTarget target = new ReplicationTarget("peer", "peer_table", Table.ID.of("1"));
     String user = "user", keytab = "/etc/security/keytabs/replication.keytab";
diff --git a/server/tserver/src/test/java/org/apache/accumulo/tserver/tablet/DatafileManagerTest.java b/server/tserver/src/test/java/org/apache/accumulo/tserver/tablet/DatafileManagerTest.java
index 214a92aa49..9cf44959f0 100644
--- a/server/tserver/src/test/java/org/apache/accumulo/tserver/tablet/DatafileManagerTest.java
+++ b/server/tserver/src/test/java/org/apache/accumulo/tserver/tablet/DatafileManagerTest.java
@@ -19,7 +19,6 @@
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertNull;
 
-import java.io.IOException;
 import java.util.SortedMap;
 import java.util.TreeMap;
 
@@ -66,7 +65,7 @@ public void setupMockClasses() {
    * reserveMergingMinorCompactionFile
    */
   @Test
-  public void testReserveMergingMinorCompactionFile_MaxExceeded() throws IOException {
+  public void testReserveMergingMinorCompactionFile_MaxExceeded() {
     String maxMergeFileSize = "1000B";
     EasyMock.expect(tablet.getTableConfiguration()).andReturn(tableConf);
     EasyMock.expect(tableConf.get(Property.TABLE_MINC_MAX_MERGE_FILE_SIZE))
@@ -88,7 +87,7 @@ public void testReserveMergingMinorCompactionFile_MaxExceeded() throws IOExcepti
    * Test max files not reached (table.file.max) when calling reserveMergingMinorCompactionFile
    */
   @Test
-  public void testReserveMergingMinorCompactionFile_MaxFilesNotReached() throws IOException {
+  public void testReserveMergingMinorCompactionFile_MaxFilesNotReached() {
     EasyMock.replay(tablet, tableConf);
 
     SortedMap<FileRef,DataFileValue> testFiles = createFileMap("smallfile", "100B", "file2", "100M",
@@ -106,7 +105,7 @@ public void testReserveMergingMinorCompactionFile_MaxFilesNotReached() throws IO
    * Test the smallest file is chosen for merging minor compaction
    */
   @Test
-  public void testReserveMergingMinorCompactionFile() throws IOException {
+  public void testReserveMergingMinorCompactionFile() {
     String maxMergeFileSize = "1000B";
     EasyMock.expect(tablet.getTableConfiguration()).andReturn(tableConf);
     EasyMock.expect(tableConf.get(Property.TABLE_MINC_MAX_MERGE_FILE_SIZE))
@@ -128,7 +127,7 @@ public void testReserveMergingMinorCompactionFile() throws IOException {
    * Test disabled max file size for merging minor compaction
    */
   @Test
-  public void testReserveMergingMinorCompactionFileDisabled() throws IOException {
+  public void testReserveMergingMinorCompactionFileDisabled() {
     String maxMergeFileSize = "0";
     EasyMock.expect(tablet.getTableConfiguration()).andReturn(tableConf);
     EasyMock.expect(tableConf.get(Property.TABLE_MINC_MAX_MERGE_FILE_SIZE))
diff --git a/test/src/main/java/org/apache/accumulo/test/replication/MockReplicaSystem.java b/test/src/main/java/org/apache/accumulo/test/replication/MockReplicaSystem.java
index dbdab127fb..2d0cb7544f 100644
--- a/test/src/main/java/org/apache/accumulo/test/replication/MockReplicaSystem.java
+++ b/test/src/main/java/org/apache/accumulo/test/replication/MockReplicaSystem.java
@@ -17,7 +17,6 @@
 package org.apache.accumulo.test.replication;
 
 import org.apache.accumulo.core.client.AccumuloException;
-import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.protobuf.ProtobufUtil;
 import org.apache.accumulo.core.replication.ReplicationTarget;
@@ -76,7 +75,7 @@ public Status replicate(Path p, Status status, ReplicationTarget target,
           "Tried to update status in replication table for {} as {}, but the table did not exist",
           p, ProtobufUtil.toString(newStatus), e);
       return status;
-    } catch (AccumuloException | AccumuloSecurityException e) {
+    } catch (AccumuloException e) {
       log.error("Tried to record new status in replication table for {} as {}, but got an error", p,
           ProtobufUtil.toString(newStatus), e);
       return status;


 

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


With regards,
Apache Git Services