You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by mw...@apache.org on 2018/05/10 14:20:26 UTC

[accumulo] branch master updated: Removed unnecessary interface modifiers (#482)

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

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


The following commit(s) were added to refs/heads/master by this push:
     new 874e126  Removed unnecessary interface modifiers (#482)
874e126 is described below

commit 874e1261690bbc5fb43c79217e853234f9426ed7
Author: Mike Walch <mw...@apache.org>
AuthorDate: Thu May 10 10:20:23 2018 -0400

    Removed unnecessary interface modifiers (#482)
---
 .../accumulo/core/client/ConditionalWriter.java    |  2 +-
 .../accumulo/core/client/IsolatedScanner.java      |  4 +-
 .../accumulo/core/client/admin/Locations.java      |  6 +-
 .../core/client/admin/ReplicationOperations.java   | 10 ++--
 .../core/client/admin/TableOperations.java         |  6 +-
 .../core/client/impl/TabletLocatorImpl.java        |  2 +-
 .../apache/accumulo/core/client/rfile/RFile.java   | 50 ++++++++--------
 .../security/tokens/AuthenticationToken.java       | 10 ++--
 .../core/client/summary/CountingSummarizer.java    |  4 +-
 .../accumulo/core/client/summary/Summarizer.java   | 16 ++---
 .../org/apache/accumulo/core/data/TabletId.java    |  8 +--
 .../apache/accumulo/core/file/FileOperations.java  | 68 +++++++++++-----------
 .../core/file/blockfile/cache/BlockCache.java      |  2 +-
 .../file/blockfile/cache/BlockCacheManager.java    |  2 +-
 .../core/file/blockfile/cache/CacheEntry.java      |  2 +-
 .../file/blockfile/impl/CachableBlockFile.java     |  2 +-
 .../core/file/streams/PositionedOutput.java        |  2 +-
 .../accumulo/core/iterators/OptionDescriber.java   |  2 +-
 .../core/metadata/schema/MetadataScanner.java      | 18 +++---
 .../replication/AccumuloReplicationReplayer.java   |  4 +-
 .../org/apache/accumulo/core/summary/Gatherer.java |  2 +-
 .../accumulo/core/summary/SummaryReader.java       |  2 +-
 .../accumulo/core/util/ratelimit/RateLimiter.java  |  4 +-
 .../util/ratelimit/SharedRateLimiterFactory.java   |  4 +-
 .../org/apache/accumulo/core/volume/Volume.java    | 10 ++--
 .../apache/accumulo/server/fs/VolumeChooser.java   |  2 +-
 .../apache/accumulo/server/fs/VolumeManager.java   |  6 +-
 .../accumulo/server/metrics/ThriftMetricsKeys.java |  4 +-
 .../accumulo/server/replication/ReplicaSystem.java |  6 +-
 .../accumulo/server/replication/WorkAssigner.java  |  6 +-
 .../accumulo/server/util/MetadataTableUtil.java    |  2 +-
 .../master/metrics/ReplicationMetricsMBean.java    |  6 +-
 .../master/tableOps/bulkVer2/PrepBulkImport.java   |  2 +-
 .../accumulo/tserver/log/CloseableIterator.java    |  2 +-
 .../metrics/TabletServerUpdateMetricsKeys.java     | 14 ++---
 .../accumulo/start/spi/KeywordExecutable.java      |  2 +-
 start/src/test/java/test/Test.java                 |  4 +-
 .../harness/MiniClusterConfigurationCallback.java  |  4 +-
 .../accumulo/test/master/SuspendedTabletsIT.java   |  4 +-
 39 files changed, 153 insertions(+), 153 deletions(-)

diff --git a/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriter.java b/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriter.java
index 667e5a0..e7e0ac7 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriter.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/ConditionalWriter.java
@@ -90,7 +90,7 @@ public interface ConditionalWriter extends AutoCloseable {
     }
   }
 
-  public static enum Status {
+  enum Status {
     /**
      * conditions were met and mutation was written
      */
diff --git a/core/src/main/java/org/apache/accumulo/core/client/IsolatedScanner.java b/core/src/main/java/org/apache/accumulo/core/client/IsolatedScanner.java
index f823680..78b22ba 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/IsolatedScanner.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/IsolatedScanner.java
@@ -171,11 +171,11 @@ public class IsolatedScanner extends ScannerOptions implements Scanner {
 
   }
 
-  public static interface RowBufferFactory {
+  public interface RowBufferFactory {
     RowBuffer newBuffer();
   }
 
-  public static interface RowBuffer extends Iterable<Entry<Key,Value>> {
+  public interface RowBuffer extends Iterable<Entry<Key,Value>> {
     void add(Entry<Key,Value> entry);
 
     @Override
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/Locations.java b/core/src/main/java/org/apache/accumulo/core/client/admin/Locations.java
index d42d988..4a599ca 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/Locations.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/Locations.java
@@ -35,13 +35,13 @@ public interface Locations {
    * For all of the ranges passed to {@link TableOperations#locate(String, java.util.Collection)},
    * return a map of the tablets each range overlaps.
    */
-  public Map<Range,List<TabletId>> groupByRange();
+  Map<Range,List<TabletId>> groupByRange();
 
   /**
    * For all of the ranges passed to {@link TableOperations#locate(String, java.util.Collection)},
    * return a map of the ranges each tablet overlaps.
    */
-  public Map<TabletId,List<Range>> groupByTablet();
+  Map<TabletId,List<Range>> groupByTablet();
 
   /**
    * For any {@link TabletId} known to this object, the method will return the tablet server
@@ -49,5 +49,5 @@ public interface Locations {
    *
    * @return A tablet server location in the form of {@code <host>:<port>}
    */
-  public String getTabletLocation(TabletId tabletId);
+  String getTabletLocation(TabletId tabletId);
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/ReplicationOperations.java b/core/src/main/java/org/apache/accumulo/core/client/admin/ReplicationOperations.java
index 7b47f8b..369b0d0 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/ReplicationOperations.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/ReplicationOperations.java
@@ -39,7 +39,7 @@ public interface ReplicationOperations {
    * @param replicaType
    *          Class name to use to replicate the data
    */
-  public void addPeer(String name, String replicaType)
+  void addPeer(String name, String replicaType)
       throws AccumuloException, AccumuloSecurityException, PeerExistsException;
 
   /**
@@ -48,7 +48,7 @@ public interface ReplicationOperations {
    * @param name
    *          Name of the cluster to remove
    */
-  public void removePeer(String name)
+  void removePeer(String name)
       throws AccumuloException, AccumuloSecurityException, PeerNotFoundException;
 
   /**
@@ -58,7 +58,7 @@ public interface ReplicationOperations {
    * @param tableName
    *          The table to wait for
    */
-  public void drain(String tableName)
+  void drain(String tableName)
       throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 
   /**
@@ -69,7 +69,7 @@ public interface ReplicationOperations {
    * @param tableName
    *          The table to wait for
    */
-  public void drain(String tableName, Set<String> files)
+  void drain(String tableName, Set<String> files)
       throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 
   /**
@@ -81,6 +81,6 @@ public interface ReplicationOperations {
    * provide that {@link Set} to {@link #drain(String,Set)} to wait for all of those files to be
    * replicated.
    */
-  public Set<String> referencedFiles(String tableName)
+  Set<String> referencedFiles(String tableName)
       throws AccumuloException, AccumuloSecurityException, TableNotFoundException;
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperations.java b/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperations.java
index 8694343..1c09dcd 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperations.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperations.java
@@ -620,7 +620,7 @@ public interface TableOperations {
   /**
    * @since 2.0.0
    */
-  public static interface ImportSourceOptions {
+  interface ImportSourceOptions {
     ImportSourceOptions settingLogicalTime();
 
     void load()
@@ -630,7 +630,7 @@ public interface TableOperations {
   /**
    * @since 2.0.0
    */
-  public static interface ImportExecutorOptions extends ImportSourceOptions {
+  interface ImportExecutorOptions extends ImportSourceOptions {
     /**
      * Files are examined to determine where to load them. This examination is done in the current
      * process using multiple threads. If this property is not set, then the client property
@@ -657,7 +657,7 @@ public interface TableOperations {
   /**
    * @since 2.0.0
    */
-  public static interface ImportSourceArguments {
+  interface ImportSourceArguments {
     /**
      *
      * @param directory
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletLocatorImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletLocatorImpl.java
index cc46d50..6a296d6 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletLocatorImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletLocatorImpl.java
@@ -112,7 +112,7 @@ public class TabletLocatorImpl extends TabletLocator {
         throws AccumuloSecurityException, AccumuloException;
   }
 
-  public static interface TabletServerLockChecker {
+  public interface TabletServerLockChecker {
     boolean isLockHeld(String tserver, String session);
 
     void invalidateCache(String server);
diff --git a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFile.java b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFile.java
index f686e70..b32df0d 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/rfile/RFile.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/rfile/RFile.java
@@ -56,7 +56,7 @@ public class RFile {
    *
    * @since 1.8.0
    */
-  public static interface InputArguments {
+  public interface InputArguments {
     /**
      * Specify RFiles to read from. When multiple inputs are specified the {@link Scanner}
      * constructed will present a merged view.
@@ -84,7 +84,7 @@ public class RFile {
    *
    * @since 1.8.0
    */
-  public static interface ScannerFSOptions extends ScannerOptions {
+  public interface ScannerFSOptions extends ScannerOptions {
     /**
      * Optionally provide a FileSystem to open RFiles. If not specified, the FileSystem will be
      * constructed using configuration on the classpath.
@@ -102,7 +102,7 @@ public class RFile {
    *
    * @since 1.8.0
    */
-  public static interface ScannerOptions {
+  public interface ScannerOptions {
 
     /**
      * By default the {@link Scanner} created will setup the default Accumulo system iterators. The
@@ -127,7 +127,7 @@ public class RFile {
      *
      * @return this
      */
-    public ScannerOptions withoutSystemIterators();
+    ScannerOptions withoutSystemIterators();
 
     /**
      * The authorizations passed here will be used to filter Keys, from the {@link Scanner}, based
@@ -137,7 +137,7 @@ public class RFile {
      *          scan with these authorizations
      * @return this
      */
-    public ScannerOptions withAuthorizations(Authorizations auths);
+    ScannerOptions withAuthorizations(Authorizations auths);
 
     /**
      * Enabling this option will cache RFiles data in memory. This option is useful when doing lots
@@ -147,7 +147,7 @@ public class RFile {
      *          the size of the data cache in bytes.
      * @return this
      */
-    public ScannerOptions withDataCache(long cacheSize);
+    ScannerOptions withDataCache(long cacheSize);
 
     /**
      * Enabling this option will cache RFiles indexes in memory. Index data within a RFile is used
@@ -158,7 +158,7 @@ public class RFile {
      *          the size of the index cache in bytes.
      * @return this
      */
-    public ScannerOptions withIndexCache(long cacheSize);
+    ScannerOptions withIndexCache(long cacheSize);
 
     /**
      * This option allows limiting the {@link Scanner} from reading data outside of a given range. A
@@ -167,7 +167,7 @@ public class RFile {
      *
      * @return this
      */
-    public ScannerOptions withBounds(Range range);
+    ScannerOptions withBounds(Range range);
 
     /**
      * Construct the {@link Scanner} with iterators specified in a tables properties. Properties for
@@ -177,7 +177,7 @@ public class RFile {
      *          iterable over Accumulo table key value properties.
      * @return this
      */
-    public ScannerOptions withTableProperties(Iterable<Entry<String,String>> props);
+    ScannerOptions withTableProperties(Iterable<Entry<String, String>> props);
 
     /**
      * @see #withTableProperties(Iterable)
@@ -185,12 +185,12 @@ public class RFile {
      *          a map instead of an Iterable
      * @return this
      */
-    public ScannerOptions withTableProperties(Map<String,String> props);
+    ScannerOptions withTableProperties(Map<String, String> props);
 
     /**
      * @return a Scanner over RFile using the specified options.
      */
-    public Scanner build();
+    Scanner build();
   }
 
   /**
@@ -206,7 +206,7 @@ public class RFile {
    *
    * @since 2.0.0
    */
-  public static interface SummaryInputArguments {
+  public interface SummaryInputArguments {
     /**
      * Specify RFiles to read from. When multiple inputs are specified the summary data will be
      * merged.
@@ -233,7 +233,7 @@ public class RFile {
    *
    * @since 2.0.0
    */
-  public static interface SummaryFSOptions extends SummaryOptions {
+  public interface SummaryFSOptions extends SummaryOptions {
     /**
      * Optionally provide a FileSystem to open RFiles. If not specified, the FileSystem will be
      * constructed using configuration on the classpath.
@@ -251,7 +251,7 @@ public class RFile {
    *
    * @since 2.0.0
    */
-  public static interface SummaryOptions {
+  public interface SummaryOptions {
     /**
      * This method allows retrieving a subset of summary data from a file. If a file has lots of
      * separate summaries, reading a subset may be faster.
@@ -330,20 +330,20 @@ public class RFile {
    *
    * @since 1.8.0
    */
-  public static interface OutputArguments {
+  public interface OutputArguments {
     /**
      * @param filename
      *          name of file to write RFile data
      * @return this
      */
-    public WriterFSOptions to(String filename);
+    WriterFSOptions to(String filename);
 
     /**
      * @param out
      *          output stream to write RFile data
      * @return this
      */
-    public WriterOptions to(OutputStream out);
+    WriterOptions to(OutputStream out);
   }
 
   /**
@@ -352,7 +352,7 @@ public class RFile {
    *
    * @since 1.8.0
    */
-  public static interface WriterFSOptions extends WriterOptions {
+  public interface WriterFSOptions extends WriterOptions {
     /**
      * Optionally provide a FileSystem to open a file to write a RFile. If not specified, the
      * FileSystem will be constructed using configuration on the classpath.
@@ -370,7 +370,7 @@ public class RFile {
    *
    * @since 1.8.0
    */
-  public static interface WriterOptions {
+  public interface WriterOptions {
 
     /**
      * Enable generating summary data in the created RFile by running {@link Summarizer}'s based on
@@ -380,7 +380,7 @@ public class RFile {
      *          Configuration for summarizer to run.
      * @since 2.0.0
      */
-    public WriterOptions withSummarizers(SummarizerConfiguration... summarizerConf);
+    WriterOptions withSummarizers(SummarizerConfiguration... summarizerConf);
 
     /**
      * An option to store sample data in the generated RFile.
@@ -392,7 +392,7 @@ public class RFile {
      *           a sampler.
      * @return this
      */
-    public WriterOptions withSampler(SamplerConfiguration samplerConf);
+    WriterOptions withSampler(SamplerConfiguration samplerConf);
 
     /**
      * Create an RFile using the same configuration as an Accumulo table. Properties for a table can
@@ -405,12 +405,12 @@ public class RFile {
      *           sampler.
      * @return this
      */
-    public WriterOptions withTableProperties(Iterable<Entry<String,String>> props);
+    WriterOptions withTableProperties(Iterable<Entry<String, String>> props);
 
     /**
      * @see #withTableProperties(Iterable)
      */
-    public WriterOptions withTableProperties(Map<String,String> props);
+    WriterOptions withTableProperties(Map<String, String> props);
 
     /**
      * @param maxSize
@@ -420,12 +420,12 @@ public class RFile {
      *          cache.
      * @return this
      */
-    public WriterOptions withVisibilityCacheSize(int maxSize);
+    WriterOptions withVisibilityCacheSize(int maxSize);
 
     /**
      * @return a new RfileWriter created with the options previously specified.
      */
-    public RFileWriter build() throws IOException;
+    RFileWriter build() throws IOException;
   }
 
   /**
diff --git a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/AuthenticationToken.java b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/AuthenticationToken.java
index 4cf86fe..f45b263 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/security/tokens/AuthenticationToken.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/security/tokens/AuthenticationToken.java
@@ -44,7 +44,7 @@ public interface AuthenticationToken extends Writable, Destroyable, Cloneable {
    *
    * @since 1.6.0
    */
-  public static final class AuthenticationTokenSerializer {
+  final class AuthenticationTokenSerializer {
     /**
      * A convenience method to create tokens from serialized bytes, created by
      * {@link #serialize(AuthenticationToken)}
@@ -252,7 +252,7 @@ public interface AuthenticationToken extends Writable, Destroyable, Cloneable {
     }
   }
 
-  static class TokenProperty implements Comparable<TokenProperty> {
+  class TokenProperty implements Comparable<TokenProperty> {
     private String key, description;
     private boolean masked;
 
@@ -297,9 +297,9 @@ public interface AuthenticationToken extends Writable, Destroyable, Cloneable {
     }
   }
 
-  public void init(Properties properties);
+  void init(Properties properties);
 
-  public Set<TokenProperty> getProperties();
+  Set<TokenProperty> getProperties();
 
-  public AuthenticationToken clone();
+  AuthenticationToken clone();
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/client/summary/CountingSummarizer.java b/core/src/main/java/org/apache/accumulo/core/client/summary/CountingSummarizer.java
index b39b0c7..fda7cd3 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/summary/CountingSummarizer.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/summary/CountingSummarizer.java
@@ -174,12 +174,12 @@ public abstract class CountingSummarizer<K> implements Summarizer {
    *
    * @since 2.0.0
    */
-  public static interface Converter<K> {
+  public interface Converter<K> {
     /**
      * @param consumer
      *          emit counter objects derived from key and value to this consumer
      */
-    public void convert(Key k, Value v, Consumer<K> consumer);
+    void convert(Key k, Value v, Consumer<K> consumer);
   }
 
   /**
diff --git a/core/src/main/java/org/apache/accumulo/core/client/summary/Summarizer.java b/core/src/main/java/org/apache/accumulo/core/client/summary/Summarizer.java
index 5d42d48..869d087 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/summary/Summarizer.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/summary/Summarizer.java
@@ -167,8 +167,8 @@ import org.apache.accumulo.core.data.Value;
  */
 public interface Summarizer {
 
-  public static interface StatisticConsumer {
-    public void accept(String statistic, long value);
+  interface StatisticConsumer {
+    void accept(String statistic, long value);
   }
 
   /**
@@ -179,7 +179,7 @@ public interface Summarizer {
    *
    * @since 2.0.0
    */
-  public static interface Collector {
+  interface Collector {
     /**
      * During compactions, Accumulo passes each Key Value written to the file to this method.
      */
@@ -201,7 +201,7 @@ public interface Summarizer {
      * @param sc
      *          Emit statistics to this Object.
      */
-    public void summarize(StatisticConsumer sc);
+    void summarize(StatisticConsumer sc);
   }
 
   /**
@@ -211,7 +211,7 @@ public interface Summarizer {
    *
    * @since 2.0.0
    */
-  public static interface Combiner {
+  interface Combiner {
     /**
      * This method should merge the statistics in the second map into the first map. Both maps may
      * have statistics produced by a {@link Collector} or previous calls to this method.
@@ -220,7 +220,7 @@ public interface Summarizer {
      * If first map is too large after this call, then it may not be stored. See the comment on
      * {@link Collector#summarize(Summarizer.StatisticConsumer)}
      */
-    public void merge(Map<String,Long> statistics1, Map<String,Long> statistics2);
+    void merge(Map<String, Long> statistics1, Map<String, Long> statistics2);
   }
 
   /**
@@ -228,11 +228,11 @@ public interface Summarizer {
    * created by this method should be independent and have its own internal state. Accumulo uses a
    * Collector to generate summary statistics about a sequence of key values written to a file.
    */
-  public Collector collector(SummarizerConfiguration sc);
+  Collector collector(SummarizerConfiguration sc);
 
   /**
    * Factory method that creates a {@link Combiner}. Accumulo will only use the created Combiner to
    * merge data from {@link Collector}s created using the same {@link SummarizerConfiguration}.
    */
-  public Combiner combiner(SummarizerConfiguration sc);
+  Combiner combiner(SummarizerConfiguration sc);
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/data/TabletId.java b/core/src/main/java/org/apache/accumulo/core/data/TabletId.java
index 7c2712b..1a7b6f1 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/TabletId.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/TabletId.java
@@ -25,17 +25,17 @@ import org.apache.hadoop.io.Text;
  * @since 1.7.0
  */
 public interface TabletId extends Comparable<TabletId> {
-  public Text getTableId();
+  Text getTableId();
 
-  public Text getEndRow();
+  Text getEndRow();
 
-  public Text getPrevEndRow();
+  Text getPrevEndRow();
 
   /**
    * @return a range based on the row range of the tablet. The range will cover
    *         {@code (<prev end row>, <end row>]}.
    * @since 1.8.0
    */
-  public Range toRange();
+  Range toRange();
 
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/file/FileOperations.java b/core/src/main/java/org/apache/accumulo/core/file/FileOperations.java
index 6246d23..83395e1 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/FileOperations.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/FileOperations.java
@@ -253,7 +253,7 @@ public abstract class FileOperations {
   }
 
   /** Builder interface parallel to {@link FileAccessOperation}. */
-  protected static interface FileAccessOperationBuilder<SubbuilderType>
+  protected interface FileAccessOperationBuilder<SubbuilderType>
       extends NeedsFile<SubbuilderType>, NeedsFileSystem<SubbuilderType>,
       NeedsTableConfiguration<SubbuilderType> {
     // no optional/generic methods.
@@ -276,10 +276,10 @@ public abstract class FileOperations {
    * Builder interface for {@link GetFileSizeOperation}, allowing execution of {@code getFileSize()}
    * operations.
    */
-  public static interface GetFileSizeOperationBuilder
+  public interface GetFileSizeOperationBuilder
       extends FileAccessOperationBuilder<GetFileSizeOperationBuilder> {
     /** Return the size of the file. */
-    public long execute() throws IOException;
+    long execute() throws IOException;
   }
 
   /**
@@ -302,10 +302,10 @@ public abstract class FileOperations {
   }
 
   /** Builder interface parallel to {@link FileIOOperation}. */
-  protected static interface FileIOOperationBuilder<SubbuilderType>
+  protected interface FileIOOperationBuilder<SubbuilderType>
       extends FileAccessOperationBuilder<SubbuilderType> {
     /** Specify a rate limiter for this operation. */
-    public SubbuilderType withRateLimiter(RateLimiter rateLimiter);
+    SubbuilderType withRateLimiter(RateLimiter rateLimiter);
   }
 
   /**
@@ -368,10 +368,10 @@ public abstract class FileOperations {
   }
 
   /** Builder interface parallel to {@link OpenWriterOperation}. */
-  public static interface OpenWriterOperationBuilder
+  public interface OpenWriterOperationBuilder
       extends FileIOOperationBuilder<OpenWriterOperationBuilder> {
     /** Set the compression type. */
-    public OpenWriterOperationBuilder withCompression(String compression);
+    OpenWriterOperationBuilder withCompression(String compression);
 
     /**
      * Classes may be instantiated as part of a write operation. For example if BloomFilters,
@@ -380,10 +380,10 @@ public abstract class FileOperations {
      * start should not be used. This method makes it possible to specify if Accumulo Start should
      * be used to load classes. Calling this method is optional and the default is true.
      */
-    public OpenWriterOperationBuilder setAccumuloStartEnabled(boolean enableAccumuloStart);
+    OpenWriterOperationBuilder setAccumuloStartEnabled(boolean enableAccumuloStart);
 
     /** Construct the writer. */
-    public FileSKVWriter build() throws IOException;
+    FileSKVWriter build() throws IOException;
   }
 
   /**
@@ -431,21 +431,21 @@ public abstract class FileOperations {
   }
 
   /** Builder interface parallel to {@link FileReaderOperation}. */
-  protected static interface FileReaderOperationBuilder<SubbuilderType>
+  protected interface FileReaderOperationBuilder<SubbuilderType>
       extends FileIOOperationBuilder<SubbuilderType> {
     /**
      * (Optional) Set the block cache pair to be used to optimize reads within the constructed
      * reader.
      */
-    public SubbuilderType withBlockCache(BlockCache dataCache, BlockCache indexCache);
+    SubbuilderType withBlockCache(BlockCache dataCache, BlockCache indexCache);
 
     /** (Optional) set the data cache to be used to optimize reads within the constructed reader. */
-    public SubbuilderType withDataCache(BlockCache dataCache);
+    SubbuilderType withDataCache(BlockCache dataCache);
 
     /**
      * (Optional) set the index cache to be used to optimize reads within the constructed reader.
      */
-    public SubbuilderType withIndexCache(BlockCache indexCache);
+    SubbuilderType withIndexCache(BlockCache indexCache);
   }
 
   /**
@@ -461,10 +461,10 @@ public abstract class FileOperations {
   }
 
   /** Builder interface parallel to {@link OpenIndexOperation}. */
-  public static interface OpenIndexOperationBuilder
+  public interface OpenIndexOperationBuilder
       extends FileReaderOperationBuilder<OpenIndexOperationBuilder> {
     /** Construct the reader. */
-    public FileSKVIterator build() throws IOException;
+    FileSKVIterator build() throws IOException;
   }
 
   /** Operation object for opening a scan reader. */
@@ -514,11 +514,11 @@ public abstract class FileOperations {
   }
 
   /** Builder interface parallel to {@link OpenScanReaderOperation}. */
-  public static interface OpenScanReaderOperationBuilder
+  public interface OpenScanReaderOperationBuilder
       extends FileReaderOperationBuilder<OpenScanReaderOperationBuilder>,
       NeedsRange<OpenScanReaderOperationBuilder> {
     /** Execute the operation, constructing a scan iterator. */
-    public FileSKVIterator build() throws IOException;
+    FileSKVIterator build() throws IOException;
   }
 
   /** Operation object for opening a full reader. */
@@ -555,64 +555,64 @@ public abstract class FileOperations {
   }
 
   /** Builder parallel to {@link OpenReaderOperation}. */
-  public static interface OpenReaderOperationBuilder
+  public interface OpenReaderOperationBuilder
       extends FileReaderOperationBuilder<OpenReaderOperationBuilder> {
     /**
      * Seek the constructed iterator to the beginning of its domain before returning. Equivalent to
      * {@code seekToBeginning(true)}.
      */
-    public OpenReaderOperationBuilder seekToBeginning();
+    OpenReaderOperationBuilder seekToBeginning();
 
     /** If true, seek the constructed iterator to the beginning of its domain before returning. */
-    public OpenReaderOperationBuilder seekToBeginning(boolean seekToBeginning);
+    OpenReaderOperationBuilder seekToBeginning(boolean seekToBeginning);
 
     /** Execute the operation, constructing the specified file reader. */
-    public FileSKVIterator build() throws IOException;
+    FileSKVIterator build() throws IOException;
   }
 
   /**
    * Type wrapper to ensure that {@code forFile(...)} is called before other methods.
    */
-  public static interface NeedsFile<ReturnType> {
+  public interface NeedsFile<ReturnType> {
     /** Specify the file this operation should apply to. */
-    public NeedsTableConfiguration<ReturnType> forFile(String filename, FileSystem fs,
-        Configuration fsConf);
+    NeedsTableConfiguration<ReturnType> forFile(String filename, FileSystem fs,
+                                                Configuration fsConf);
 
     /** Specify the file this operation should apply to. */
-    public NeedsFileSystem<ReturnType> forFile(String filename);
+    NeedsFileSystem<ReturnType> forFile(String filename);
   }
 
-  public static interface NeedsFileOrOuputStream<ReturnType> extends NeedsFile<ReturnType> {
+  public interface NeedsFileOrOuputStream<ReturnType> extends NeedsFile<ReturnType> {
     /** Specify the file this operation should apply to. */
-    public NeedsTableConfiguration<ReturnType> forOutputStream(String extenstion,
-        FSDataOutputStream out, Configuration fsConf);
+    NeedsTableConfiguration<ReturnType> forOutputStream(String extenstion,
+                                                        FSDataOutputStream out, Configuration fsConf);
   }
 
   /**
    * Type wrapper to ensure that {@code inFileSystem(...)} is called before other methods.
    */
-  public static interface NeedsFileSystem<ReturnType> {
+  public interface NeedsFileSystem<ReturnType> {
     /**
      * Specify the {@link FileSystem} that this operation operates on, along with an alternate
      * configuration.
      */
-    public NeedsTableConfiguration<ReturnType> inFileSystem(FileSystem fs, Configuration fsConf);
+    NeedsTableConfiguration<ReturnType> inFileSystem(FileSystem fs, Configuration fsConf);
   }
 
   /**
    * Type wrapper to ensure that {@code withTableConfiguration(...)} is called before other methods.
    */
-  public static interface NeedsTableConfiguration<ReturnType> {
+  public interface NeedsTableConfiguration<ReturnType> {
     /** Specify the table configuration defining access to this file. */
-    public ReturnType withTableConfiguration(AccumuloConfiguration tableConfiguration);
+    ReturnType withTableConfiguration(AccumuloConfiguration tableConfiguration);
   }
 
   /**
    * Type wrapper to ensure that {@code overRange(...)} is called before other methods.
    */
-  public static interface NeedsRange<ReturnType> {
+  public interface NeedsRange<ReturnType> {
     /** Set the range over which the constructed iterator will search. */
-    public ReturnType overRange(Range range, Set<ByteSequence> columnFamilies, boolean inclusive);
+    ReturnType overRange(Range range, Set<ByteSequence> columnFamilies, boolean inclusive);
   }
 
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/BlockCache.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/BlockCache.java
index 706c4f5..7719ca6 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/BlockCache.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/BlockCache.java
@@ -45,7 +45,7 @@ public interface BlockCache {
    */
   CacheEntry getBlock(String blockName);
 
-  public static interface Loader {
+  interface Loader {
     /**
      * The cache blocks that this loader depends on. If a loader has no dependencies, then it should
      * return an empty map. All dependencies must be loaded before calling {@link #load(int, Map)}.
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/BlockCacheManager.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/BlockCacheManager.java
index 4994771..1155bac 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/BlockCacheManager.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/BlockCacheManager.java
@@ -32,7 +32,7 @@ public abstract class BlockCacheManager {
 
   public static final String CACHE_PROPERTY_BASE = Property.TSERV_PREFIX + "cache.config.";
 
-  public static interface Configuration {
+  public interface Configuration {
 
     /**
      * Before Accumulo's cache implementation was configurable, its built in caches had a
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CacheEntry.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CacheEntry.java
index 0533502..e7fe572 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CacheEntry.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CacheEntry.java
@@ -20,7 +20,7 @@ import java.util.function.Supplier;
 
 public interface CacheEntry {
 
-  public static interface Weighbable {
+  interface Weighbable {
     int weight();
   }
 
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/CachableBlockFile.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/CachableBlockFile.java
index aaec9f3..f7451e3 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/CachableBlockFile.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/CachableBlockFile.java
@@ -148,7 +148,7 @@ public class CachableBlockFile {
 
   }
 
-  private static interface IoeSupplier<T> {
+  private interface IoeSupplier<T> {
     T get() throws IOException;
   }
 
diff --git a/core/src/main/java/org/apache/accumulo/core/file/streams/PositionedOutput.java b/core/src/main/java/org/apache/accumulo/core/file/streams/PositionedOutput.java
index bed2579..aa3122d 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/streams/PositionedOutput.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/streams/PositionedOutput.java
@@ -23,5 +23,5 @@ import java.io.IOException;
  * sunk.
  */
 public interface PositionedOutput {
-  public long position() throws IOException;
+  long position() throws IOException;
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/OptionDescriber.java b/core/src/main/java/org/apache/accumulo/core/iterators/OptionDescriber.java
index a2b22cf..78924a3 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/OptionDescriber.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/OptionDescriber.java
@@ -33,7 +33,7 @@ import java.util.Map;
  * is intended to throw an exception or return false if the options are not acceptable.
  */
 public interface OptionDescriber {
-  public class IteratorOptions {
+  class IteratorOptions {
     public LinkedHashMap<String,String> namedOptions;
     public ArrayList<String> unnamedOptionDescriptions;
     public String name;
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataScanner.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataScanner.java
index 0516051..44b7611 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataScanner.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataScanner.java
@@ -48,13 +48,13 @@ import com.google.common.base.Preconditions;
 
 public class MetadataScanner {
 
-  public static interface SourceOptions {
+  public interface SourceOptions {
     TableOptions from(Scanner scanner);
 
     TableOptions from(ClientContext ctx);
   }
 
-  public static interface TableOptions {
+  public interface TableOptions {
     ColumnOptions overRootTable();
 
     ColumnOptions overMetadataTable();
@@ -64,18 +64,18 @@ public class MetadataScanner {
     ColumnOptions overUserTableId(Table.ID tableId, Text startRow, Text endRow);
   }
 
-  public static interface ColumnOptions {
-    public ColumnOptions fetchFiles();
+  public interface ColumnOptions {
+    ColumnOptions fetchFiles();
 
-    public ColumnOptions fetchLoaded();
+    ColumnOptions fetchLoaded();
 
-    public ColumnOptions fetchLocation();
+    ColumnOptions fetchLocation();
 
-    public ColumnOptions fetchPrev();
+    ColumnOptions fetchPrev();
 
-    public ColumnOptions fetchLast();
+    ColumnOptions fetchLast();
 
-    public Iterable<TabletMetadata> build()
+    Iterable<TabletMetadata> build()
         throws TableNotFoundException, AccumuloException, AccumuloSecurityException;
   }
 
diff --git a/core/src/main/java/org/apache/accumulo/core/replication/AccumuloReplicationReplayer.java b/core/src/main/java/org/apache/accumulo/core/replication/AccumuloReplicationReplayer.java
index 93468ca..eaa108d 100644
--- a/core/src/main/java/org/apache/accumulo/core/replication/AccumuloReplicationReplayer.java
+++ b/core/src/main/java/org/apache/accumulo/core/replication/AccumuloReplicationReplayer.java
@@ -25,10 +25,10 @@ import org.apache.accumulo.core.replication.thrift.WalEdits;
 
 public interface AccumuloReplicationReplayer {
 
-  public long replicateLog(ClientContext context, String tableName, WalEdits data)
+  long replicateLog(ClientContext context, String tableName, WalEdits data)
       throws RemoteReplicationException, AccumuloException, AccumuloSecurityException;
 
-  public long replicateKeyValues(ClientContext context, String tableName, KeyValues kvs)
+  long replicateKeyValues(ClientContext context, String tableName, KeyValues kvs)
       throws RemoteReplicationException;
 
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/summary/Gatherer.java b/core/src/main/java/org/apache/accumulo/core/summary/Gatherer.java
index 9d99078..9df6cef 100644
--- a/core/src/main/java/org/apache/accumulo/core/summary/Gatherer.java
+++ b/core/src/main/java/org/apache/accumulo/core/summary/Gatherer.java
@@ -497,7 +497,7 @@ public class Gatherer {
     return future;
   }
 
-  public static interface FileSystemResolver {
+  public interface FileSystemResolver {
     FileSystem get(Path file);
   }
 
diff --git a/core/src/main/java/org/apache/accumulo/core/summary/SummaryReader.java b/core/src/main/java/org/apache/accumulo/core/summary/SummaryReader.java
index 74d0d16..ab026c5 100644
--- a/core/src/main/java/org/apache/accumulo/core/summary/SummaryReader.java
+++ b/core/src/main/java/org/apache/accumulo/core/summary/SummaryReader.java
@@ -46,7 +46,7 @@ import org.apache.hadoop.io.WritableUtils;
 
 public class SummaryReader {
 
-  private static interface BlockReader {
+  private interface BlockReader {
     DataInputStream getMetaBlock(String name) throws IOException;
   }
 
diff --git a/core/src/main/java/org/apache/accumulo/core/util/ratelimit/RateLimiter.java b/core/src/main/java/org/apache/accumulo/core/util/ratelimit/RateLimiter.java
index ff64840..ab4db84 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/ratelimit/RateLimiter.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/ratelimit/RateLimiter.java
@@ -20,8 +20,8 @@ public interface RateLimiter {
   /**
    * Get current QPS of the rate limiter, with a nonpositive rate indicating no limit.
    */
-  public long getRate();
+  long getRate();
 
   /** Sleep until the specified number of queries are available. */
-  public void acquire(long permits);
+  void acquire(long permits);
 }
diff --git a/core/src/main/java/org/apache/accumulo/core/util/ratelimit/SharedRateLimiterFactory.java b/core/src/main/java/org/apache/accumulo/core/util/ratelimit/SharedRateLimiterFactory.java
index 85a93f1..bf94743 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/ratelimit/SharedRateLimiterFactory.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/ratelimit/SharedRateLimiterFactory.java
@@ -68,14 +68,14 @@ public class SharedRateLimiterFactory {
   /**
    * A callback which provides the current rate for a {@link RateLimiter}.
    */
-  public static interface RateProvider {
+  public interface RateProvider {
     /**
      * Calculate the current rate for the {@link RateLimiter}.
      *
      * @return Count of permits which should be provided per second. A nonpositive count is taken to
      *         indicate that no rate limiting should be performed.
      */
-    public long getDesiredRate();
+    long getDesiredRate();
   }
 
   /**
diff --git a/core/src/main/java/org/apache/accumulo/core/volume/Volume.java b/core/src/main/java/org/apache/accumulo/core/volume/Volume.java
index c76c549..2f3b5a4 100644
--- a/core/src/main/java/org/apache/accumulo/core/volume/Volume.java
+++ b/core/src/main/java/org/apache/accumulo/core/volume/Volume.java
@@ -28,12 +28,12 @@ public interface Volume {
   /**
    * A {@link FileSystem} that Accumulo will use
    */
-  public FileSystem getFileSystem();
+  FileSystem getFileSystem();
 
   /**
    * The base path which Accumulo will use within the given {@link FileSystem}
    */
-  public String getBasePath();
+  String getBasePath();
 
   /**
    * Convert the given Path into a Path that is relative to the base path for this Volume
@@ -42,7 +42,7 @@ public interface Volume {
    *          The suffix to use
    * @return A Path for this Volume with the provided suffix
    */
-  public Path prefixChild(Path p);
+  Path prefixChild(Path p);
 
   /**
    * Convert the given child path into a Path that is relative to the base path for this Volume
@@ -51,11 +51,11 @@ public interface Volume {
    *          The suffix to use
    * @return A Path for this Volume with the provided suffix
    */
-  public Path prefixChild(String p);
+  Path prefixChild(String p);
 
   /**
    * Determine if the Path is valid on this Volume. A Path is valid if it is contained in the
    * Volume's FileSystem and is rooted beneath the basePath
    */
-  public boolean isValidPath(Path p);
+  boolean isValidPath(Path p);
 }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeChooser.java b/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeChooser.java
index 9e7cc8d..631c162 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeChooser.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/fs/VolumeChooser.java
@@ -44,7 +44,7 @@ public interface VolumeChooser {
    */
   String choose(VolumeChooserEnvironment env, String[] options) throws VolumeChooserException;
 
-  public static class VolumeChooserException extends RuntimeException {
+  class VolumeChooserException extends RuntimeException {
 
     private static final long serialVersionUID = 1L;
 
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 0481e08..76cc6f3 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
@@ -37,7 +37,7 @@ import org.apache.hadoop.fs.permission.FsPermission;
  */
 public interface VolumeManager {
 
-  public static enum FileType {
+  enum FileType {
     TABLE(ServerConstants.TABLE_DIR),
     WAL(ServerConstants.WAL_DIR),
     RECOVERY(ServerConstants.RECOVERY_DIR);
@@ -172,11 +172,11 @@ public interface VolumeManager {
   /**
    * Fetch the default Volume
    */
-  public Volume getDefaultVolume();
+  Volume getDefaultVolume();
 
   /**
    * Fetch the configured Volumes, excluding the default Volume
    */
-  public Collection<Volume> getVolumes();
+  Collection<Volume> getVolumes();
 
 }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/metrics/ThriftMetricsKeys.java b/server/base/src/main/java/org/apache/accumulo/server/metrics/ThriftMetricsKeys.java
index f83499e..8adefdb 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/metrics/ThriftMetricsKeys.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/metrics/ThriftMetricsKeys.java
@@ -18,7 +18,7 @@ package org.apache.accumulo.server.metrics;
 
 public interface ThriftMetricsKeys {
 
-  static String idle = "idle";
-  static String execute = "execute";
+  String idle = "idle";
+  String execute = "execute";
 
 }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicaSystem.java b/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicaSystem.java
index 38670d4..1294b5b 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicaSystem.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/replication/ReplicaSystem.java
@@ -38,8 +38,8 @@ public interface ReplicaSystem {
    *          Instance of ReplicaSystemHelper
    * @return A new Status for the progress that was made
    */
-  public Status replicate(Path p, Status status, ReplicationTarget target,
-      ReplicaSystemHelper helper);
+  Status replicate(Path p, Status status, ReplicationTarget target,
+                   ReplicaSystemHelper helper);
 
   /**
    * Configure the implementation with necessary information from the system configuration
@@ -47,5 +47,5 @@ public interface ReplicaSystem {
    * For example, we only need one implementation for Accumulo, but, for each peer, we have a ZK
    * quorum and instance name
    */
-  public void configure(String configuration);
+  void configure(String configuration);
 }
diff --git a/server/base/src/main/java/org/apache/accumulo/server/replication/WorkAssigner.java b/server/base/src/main/java/org/apache/accumulo/server/replication/WorkAssigner.java
index da52354..f8a89b7 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/replication/WorkAssigner.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/replication/WorkAssigner.java
@@ -27,15 +27,15 @@ public interface WorkAssigner {
   /**
    * @return The name for this WorkAssigner
    */
-  public String getName();
+  String getName();
 
   /**
    * Configure the WorkAssigner implementation
    */
-  public void configure(AccumuloConfiguration conf, Connector conn);
+  void configure(AccumuloConfiguration conf, Connector conn);
 
   /**
    * Assign work for replication
    */
-  public void assignWork();
+  void assignWork();
 }
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 3d38e94..d93de1b 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
@@ -257,7 +257,7 @@ public class MetadataTableUtil {
     }
   }
 
-  private static interface ZooOperation {
+  private interface ZooOperation {
     void run(IZooReaderWriter rw) throws KeeperException, InterruptedException, IOException;
   }
 
diff --git a/server/master/src/main/java/org/apache/accumulo/master/metrics/ReplicationMetricsMBean.java b/server/master/src/main/java/org/apache/accumulo/master/metrics/ReplicationMetricsMBean.java
index fb2e703..b5d5d16 100644
--- a/server/master/src/main/java/org/apache/accumulo/master/metrics/ReplicationMetricsMBean.java
+++ b/server/master/src/main/java/org/apache/accumulo/master/metrics/ReplicationMetricsMBean.java
@@ -24,7 +24,7 @@ public interface ReplicationMetricsMBean {
    *
    * @return The number of files pending replication across all targets
    */
-  public int getNumFilesPendingReplication();
+  int getNumFilesPendingReplication();
 
   /**
    * The total number of threads available to replicate data to peers. Each TabletServer has a
@@ -33,7 +33,7 @@ public interface ReplicationMetricsMBean {
    *
    * @return The number of threads available to replicate data across the instance
    */
-  public int getMaxReplicationThreads();
+  int getMaxReplicationThreads();
 
   /**
    * Peers are systems which data can be replicated to. This is the number of peers that are
@@ -42,6 +42,6 @@ public interface ReplicationMetricsMBean {
    *
    * @return The number of peers/targets which are defined for data to be replicated to.
    */
-  public int getNumConfiguredPeers();
+  int getNumConfiguredPeers();
 
 }
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 d4df1c2..345aa20 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
@@ -100,7 +100,7 @@ public class PrepBulkImport extends MasterRepo {
   }
 
   @VisibleForTesting
-  static interface TabletIterFactory {
+  interface TabletIterFactory {
     Iterator<KeyExtent> newTabletIter(Text startRow) throws Exception;
   }
 
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/CloseableIterator.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/CloseableIterator.java
index 59623dc..bb1a13e 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/log/CloseableIterator.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/log/CloseableIterator.java
@@ -21,5 +21,5 @@ import java.util.Iterator;
 
 public interface CloseableIterator<T> extends Iterator<T>, AutoCloseable {
   @Override
-  public void close() throws IOException;
+  void close() throws IOException;
 }
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/metrics/TabletServerUpdateMetricsKeys.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/metrics/TabletServerUpdateMetricsKeys.java
index f06751b..5df2a56 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/metrics/TabletServerUpdateMetricsKeys.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/metrics/TabletServerUpdateMetricsKeys.java
@@ -21,12 +21,12 @@ package org.apache.accumulo.tserver.metrics;
  */
 public interface TabletServerUpdateMetricsKeys {
 
-  static String PERMISSION_ERRORS = "permissionErrors";
-  static String UNKNOWN_TABLET_ERRORS = "unknownTabletErrors";
-  static String MUTATION_ARRAY_SIZE = "mutationArraysSize";
-  static String COMMIT_PREP = "commitPrep";
-  static String CONSTRAINT_VIOLATIONS = "constraintViolations";
-  static String WALOG_WRITE_TIME = "waLogWriteTime";
-  static String COMMIT_TIME = "commitTime";
+  String PERMISSION_ERRORS = "permissionErrors";
+  String UNKNOWN_TABLET_ERRORS = "unknownTabletErrors";
+  String MUTATION_ARRAY_SIZE = "mutationArraysSize";
+  String COMMIT_PREP = "commitPrep";
+  String CONSTRAINT_VIOLATIONS = "constraintViolations";
+  String WALOG_WRITE_TIME = "waLogWriteTime";
+  String COMMIT_TIME = "commitTime";
 
 }
diff --git a/start/src/main/java/org/apache/accumulo/start/spi/KeywordExecutable.java b/start/src/main/java/org/apache/accumulo/start/spi/KeywordExecutable.java
index 9723368..dfa8f00 100644
--- a/start/src/main/java/org/apache/accumulo/start/spi/KeywordExecutable.java
+++ b/start/src/main/java/org/apache/accumulo/start/spi/KeywordExecutable.java
@@ -41,7 +41,7 @@ import java.util.ServiceLoader;
  */
 public interface KeywordExecutable {
 
-  public static enum UsageGroup {
+  enum UsageGroup {
     CORE, PROCESS, OTHER;
   }
 
diff --git a/start/src/test/java/test/Test.java b/start/src/test/java/test/Test.java
index 849199f..6567940 100644
--- a/start/src/test/java/test/Test.java
+++ b/start/src/test/java/test/Test.java
@@ -18,8 +18,8 @@ package test;
 
 public interface Test {
 
-  public String hello();
+  String hello();
 
-  public int add();
+  int add();
 
 }
diff --git a/test/src/main/java/org/apache/accumulo/harness/MiniClusterConfigurationCallback.java b/test/src/main/java/org/apache/accumulo/harness/MiniClusterConfigurationCallback.java
index 1d3fef5..cd60eb4 100644
--- a/test/src/main/java/org/apache/accumulo/harness/MiniClusterConfigurationCallback.java
+++ b/test/src/main/java/org/apache/accumulo/harness/MiniClusterConfigurationCallback.java
@@ -25,7 +25,7 @@ import org.apache.hadoop.conf.Configuration;
  */
 public interface MiniClusterConfigurationCallback {
 
-  public static class NoCallback implements MiniClusterConfigurationCallback {
+  class NoCallback implements MiniClusterConfigurationCallback {
 
     private NoCallback() {}
 
@@ -35,7 +35,7 @@ public interface MiniClusterConfigurationCallback {
     }
   }
 
-  public static final MiniClusterConfigurationCallback NO_CALLBACK = new NoCallback();
+  MiniClusterConfigurationCallback NO_CALLBACK = new NoCallback();
 
   void configureMiniCluster(MiniAccumuloConfigImpl cfg, Configuration coreSite);
 
diff --git a/test/src/main/java/org/apache/accumulo/test/master/SuspendedTabletsIT.java b/test/src/main/java/org/apache/accumulo/test/master/SuspendedTabletsIT.java
index a9feede..dd951a7 100644
--- a/test/src/main/java/org/apache/accumulo/test/master/SuspendedTabletsIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/master/SuspendedTabletsIT.java
@@ -255,8 +255,8 @@ public class SuspendedTabletsIT extends ConfigurableMacBase {
         .assertTrue(recoverTime - killTime >= NANOSECONDS.convert(SUSPEND_DURATION, MILLISECONDS));
   }
 
-  private static interface TServerKiller {
-    public void eliminateTabletServers(ClientContext ctx, TabletLocations locs, int count)
+  private interface TServerKiller {
+    void eliminateTabletServers(ClientContext ctx, TabletLocations locs, int count)
         throws Exception;
   }
 

-- 
To stop receiving notification emails like this one, please contact
mwalch@apache.org.