You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by ct...@apache.org on 2015/04/18 00:02:53 UTC

[1/2] accumulo git commit: ACCUMULO-3204 Remove unused code

Repository: accumulo
Updated Branches:
  refs/heads/master 956a50ecb -> a194c0b00


http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/util/FileSystemMonitor.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/FileSystemMonitor.java b/server/base/src/main/java/org/apache/accumulo/server/util/FileSystemMonitor.java
index f1ba8dc..9bc37d8 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/FileSystemMonitor.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/FileSystemMonitor.java
@@ -32,7 +32,6 @@ import java.util.TimerTask;
 
 import org.apache.accumulo.core.conf.AccumuloConfiguration;
 import org.apache.accumulo.core.conf.Property;
-import org.apache.log4j.Level;
 import org.apache.log4j.Logger;
 
 public class FileSystemMonitor {
@@ -109,17 +108,6 @@ public class FileSystemMonitor {
 
   }
 
-  protected void logAsync(final Level level, final String msg, final Exception e) {
-    Runnable r = new Runnable() {
-      @Override
-      public void run() {
-        log.log(level, msg, e);
-      }
-    };
-
-    new Thread(r).start();
-  }
-
   protected void checkMounts(String procFile) throws Exception {
     List<Mount> mounts = parse(procFile);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/util/MetadataTableUtil.java
----------------------------------------------------------------------
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 0c0ecc0..0e2a2e7 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
@@ -211,11 +211,6 @@ public class MetadataTableUtil {
     update(context, lock, m, extent);
   }
 
-  public static void updateTabletPrevEndRow(KeyExtent extent, ClientContext context) {
-    Mutation m = extent.getPrevRowUpdateMutation(); //
-    update(context, m, extent);
-  }
-
   public static void updateTabletVolumes(KeyExtent extent, List<LogEntry> logsToRemove, List<LogEntry> logsToAdd, List<FileRef> filesToRemove,
       SortedMap<FileRef,DataFileValue> filesToAdd, String newDir, ZooLock zooLock, AccumuloServerContext context) {
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/util/RestoreZookeeper.java
----------------------------------------------------------------------
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 e5a2add..138d6f7 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
@@ -99,8 +99,6 @@ public class RestoreZookeeper {
   }
 
   static class Opts extends Help {
-    @Parameter(names = {"-z", "--keepers"})
-    String keepers = "localhost:2181";
     @Parameter(names = "--overwrite")
     boolean overwrite = false;
     @Parameter(names = "--file")

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/util/time/RelativeTime.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/time/RelativeTime.java b/server/base/src/main/java/org/apache/accumulo/server/util/time/RelativeTime.java
index bc48b10..3b4ada9 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/time/RelativeTime.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/time/RelativeTime.java
@@ -33,10 +33,6 @@ public class RelativeTime extends BaseRelativeTime {
     return instance;
   }
 
-  public static void setInstance(BaseRelativeTime newInstance) {
-    instance = newInstance;
-  }
-
   public static long currentTimeMillis() {
     return getInstance().currentTime();
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/util/time/SimpleTimer.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/time/SimpleTimer.java b/server/base/src/main/java/org/apache/accumulo/server/util/time/SimpleTimer.java
index cbe021a..0a40432 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/time/SimpleTimer.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/time/SimpleTimer.java
@@ -51,16 +51,6 @@ public class SimpleTimer {
   private static final int DEFAULT_THREAD_POOL_SIZE = 1;
 
   /**
-   * Gets the timer instance.
-   *
-   * @deprecated Use {@link #getInstance(AccumuloConfiguration)} instead to get the configured number of threads.
-   */
-  @Deprecated
-  public static synchronized SimpleTimer getInstance() {
-    return getInstance(null);
-  }
-
-  /**
    * Gets the timer instance. If an instance has already been created, it will have the number of threads supplied when it was constructed, and the size
    * provided here is ignored.
    *

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/zookeeper/ZooCache.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/zookeeper/ZooCache.java b/server/base/src/main/java/org/apache/accumulo/server/zookeeper/ZooCache.java
index aca9c82..9550197 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/zookeeper/ZooCache.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/zookeeper/ZooCache.java
@@ -16,8 +16,6 @@
  */
 package org.apache.accumulo.server.zookeeper;
 
-import org.apache.accumulo.core.conf.AccumuloConfiguration;
-import org.apache.accumulo.core.conf.Property;
 import org.apache.zookeeper.Watcher;
 
 public class ZooCache extends org.apache.accumulo.fate.zookeeper.ZooCache {
@@ -29,7 +27,4 @@ public class ZooCache extends org.apache.accumulo.fate.zookeeper.ZooCache {
     super(ZooReaderWriter.getInstance(), watcher);
   }
 
-  public ZooCache(AccumuloConfiguration conf, Watcher watcher) {
-    super(conf.get(Property.INSTANCE_ZK_HOST), (int) conf.getTimeInMillis(Property.INSTANCE_ZK_TIMEOUT), watcher);
-  }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/gc/src/main/java/org/apache/accumulo/gc/SimpleGarbageCollector.java
----------------------------------------------------------------------
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 ffa59cd..037023a 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
@@ -745,8 +745,6 @@ public class SimpleGarbageCollector extends AccumuloServerContext implements Ifa
     return runtime.totalMemory() - runtime.freeMemory() > CANDIDATE_MEMORY_PERCENTAGE * runtime.maxMemory();
   }
 
-  final static String METADATA_TABLE_DIR = "/" + MetadataTable.ID;
-
   private static void putMarkerDeleteMutation(final String delete, final BatchWriter writer) throws MutationsRejectedException {
     Mutation m = new Mutation(MetadataSchema.DeletesSection.getRowPrefix() + delete);
     m.putDelete(EMPTY_TEXT, EMPTY_TEXT);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/monitor/src/main/java/org/apache/accumulo/monitor/Monitor.java
----------------------------------------------------------------------
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 49d2780..ba977a7 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
@@ -104,13 +104,10 @@ public class Monitor {
   private static final int REFRESH_TIME = 5;
   private static long lastRecalc = 0L;
   private static double totalIngestRate = 0.0;
-  private static double totalIngestByteRate = 0.0;
   private static double totalQueryRate = 0.0;
   private static double totalScanRate = 0.0;
-  private static double totalQueryByteRate = 0.0;
   private static long totalEntries = 0L;
   private static int totalTabletCount = 0;
-  private static int onlineTabletCount = 0;
   private static long totalHoldTime = 0;
   private static long totalLookups = 0;
   private static int totalTables = 0;
@@ -140,7 +137,6 @@ public class Monitor {
   private static final List<Pair<Long,Double>> loadOverTime = Collections.synchronizedList(new MaxList<Double>(MAX_TIME_PERIOD));
   private static final List<Pair<Long,Double>> ingestRateOverTime = Collections.synchronizedList(new MaxList<Double>(MAX_TIME_PERIOD));
   private static final List<Pair<Long,Double>> ingestByteRateOverTime = Collections.synchronizedList(new MaxList<Double>(MAX_TIME_PERIOD));
-  private static final List<Pair<Long,Integer>> recoveriesOverTime = Collections.synchronizedList(new MaxList<Integer>(MAX_TIME_PERIOD));
   private static final List<Pair<Long,Integer>> minorCompactionsOverTime = Collections.synchronizedList(new MaxList<Integer>(MAX_TIME_PERIOD));
   private static final List<Pair<Long,Integer>> majorCompactionsOverTime = Collections.synchronizedList(new MaxList<Integer>(MAX_TIME_PERIOD));
   private static final List<Pair<Long,Double>> lookupsOverTime = Collections.synchronizedList(new MaxList<Double>(MAX_TIME_PERIOD));
@@ -234,7 +230,6 @@ public class Monitor {
     double totalScanRate = 0.;
     long totalEntries = 0;
     int totalTabletCount = 0;
-    int onlineTabletCount = 0;
     long totalHoldTime = 0;
     long totalLookups = 0;
     boolean retry = true;
@@ -311,20 +306,16 @@ public class Monitor {
         int totalTables = 0;
         for (TableInfo tInfo : mmi.tableMap.values()) {
           totalTabletCount += tInfo.tablets;
-          onlineTabletCount += tInfo.onlineTablets;
           totalTables++;
         }
         Monitor.totalIngestRate = totalIngestRate;
         Monitor.totalTables = totalTables;
         totalIngestByteRate = totalIngestByteRate / 1000000.0;
-        Monitor.totalIngestByteRate = totalIngestByteRate;
         Monitor.totalQueryRate = totalQueryRate;
         Monitor.totalScanRate = totalScanRate;
         totalQueryByteRate = totalQueryByteRate / 1000000.0;
-        Monitor.totalQueryByteRate = totalQueryByteRate;
         Monitor.totalEntries = totalEntries;
         Monitor.totalTabletCount = totalTabletCount;
-        Monitor.onlineTabletCount = onlineTabletCount;
         Monitor.totalHoldTime = totalHoldTime;
         Monitor.totalLookups = totalLookups;
 
@@ -696,10 +687,6 @@ public class Monitor {
     return totalTabletCount;
   }
 
-  public static int getOnlineTabletCount() {
-    return onlineTabletCount;
-  }
-
   public static long getTotalEntries() {
     return totalEntries;
   }
@@ -708,10 +695,6 @@ public class Monitor {
     return totalIngestRate;
   }
 
-  public static double getTotalIngestByteRate() {
-    return totalIngestByteRate;
-  }
-
   public static double getTotalQueryRate() {
     return totalQueryRate;
   }
@@ -720,10 +703,6 @@ public class Monitor {
     return totalScanRate;
   }
 
-  public static double getTotalQueryByteRate() {
-    return totalQueryByteRate;
-  }
-
   public static long getTotalHoldTime() {
     return totalHoldTime;
   }
@@ -766,12 +745,6 @@ public class Monitor {
     }
   }
 
-  public static List<Pair<Long,Integer>> getRecoveriesOverTime() {
-    synchronized (recoveriesOverTime) {
-      return new ArrayList<Pair<Long,Integer>>(recoveriesOverTime);
-    }
-  }
-
   public static List<Pair<Long,Integer>> getMinorCompactionsOverTime() {
     synchronized (minorCompactionsOverTime) {
       return new ArrayList<Pair<Long,Integer>>(minorCompactionsOverTime);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/monitor/src/main/java/org/apache/accumulo/monitor/ZooKeeperStatus.java
----------------------------------------------------------------------
diff --git a/server/monitor/src/main/java/org/apache/accumulo/monitor/ZooKeeperStatus.java b/server/monitor/src/main/java/org/apache/accumulo/monitor/ZooKeeperStatus.java
index 1daf8f6..2e89344 100644
--- a/server/monitor/src/main/java/org/apache/accumulo/monitor/ZooKeeperStatus.java
+++ b/server/monitor/src/main/java/org/apache/accumulo/monitor/ZooKeeperStatus.java
@@ -87,10 +87,6 @@ public class ZooKeeperStatus implements Runnable {
     return status;
   }
 
-  public void stop() {
-    this.stop = true;
-  }
-
   @Override
   public void run() {
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tracer/src/main/java/org/apache/accumulo/tracer/ZooTraceClient.java
----------------------------------------------------------------------
diff --git a/server/tracer/src/main/java/org/apache/accumulo/tracer/ZooTraceClient.java b/server/tracer/src/main/java/org/apache/accumulo/tracer/ZooTraceClient.java
index 4ba6309..8011a59 100644
--- a/server/tracer/src/main/java/org/apache/accumulo/tracer/ZooTraceClient.java
+++ b/server/tracer/src/main/java/org/apache/accumulo/tracer/ZooTraceClient.java
@@ -37,6 +37,7 @@ import org.apache.zookeeper.Watcher;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+import com.google.common.annotations.VisibleForTesting;
 import com.google.common.util.concurrent.ThreadFactoryBuilder;
 
 /**
@@ -69,7 +70,7 @@ public class ZooTraceClient extends SendSpansViaThrift implements Watcher {
     setInitialTraceHosts();
   }
 
-  // Visible for testing
+  @VisibleForTesting
   protected void setRetryPause(long pause) {
     retryPause = pause;
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/ActiveAssignmentRunnable.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/ActiveAssignmentRunnable.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/ActiveAssignmentRunnable.java
index c02f7f2..bfc34a6 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/ActiveAssignmentRunnable.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/ActiveAssignmentRunnable.java
@@ -18,12 +18,12 @@ package org.apache.accumulo.tserver;
 
 import java.util.concurrent.ConcurrentHashMap;
 
-import com.google.common.base.Preconditions;
-
 import org.apache.accumulo.core.data.KeyExtent;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+import com.google.common.base.Preconditions;
+
 /**
  *
  */

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/CompactionQueue.java
----------------------------------------------------------------------
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 3ba7a5c..bbb6536 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
@@ -16,8 +16,6 @@
  */
 package org.apache.accumulo.tserver;
 
-import org.apache.htrace.wrappers.TraceRunnable;
-
 import java.util.AbstractQueue;
 import java.util.Collection;
 import java.util.Collections;
@@ -28,59 +26,64 @@ import java.util.List;
 import java.util.concurrent.BlockingQueue;
 import java.util.concurrent.TimeUnit;
 
-@SuppressWarnings({"rawtypes", "unchecked"})
-public class CompactionQueue extends AbstractQueue<Runnable> implements BlockingQueue<Runnable> {
+import org.apache.htrace.wrappers.TraceRunnable;
+
+/**
+ * {@link TraceRunnable} objects placed in this queue <b>must</a> wrap a {@link Runnable} which is also {@link Comparable}
+ */
+class CompactionQueue extends AbstractQueue<TraceRunnable> implements BlockingQueue<TraceRunnable> {
 
   private List<TraceRunnable> task = new LinkedList<TraceRunnable>();
 
   private static final Comparator<TraceRunnable> comparator = new Comparator<TraceRunnable>() {
+    @SuppressWarnings("unchecked")
     @Override
     public int compare(TraceRunnable o1, TraceRunnable o2) {
-      return ((Comparable) o1.getRunnable()).compareTo(o2.getRunnable());
+      return ((Comparable<Runnable>) o1.getRunnable()).compareTo(o2.getRunnable());
     }
   };
 
   @Override
-  public synchronized Runnable poll() {
+  public synchronized TraceRunnable poll() {
     if (task.size() == 0)
       return null;
 
     TraceRunnable min = Collections.min(task, comparator);
     task.remove(min);
-    return (Runnable) min;
+    return min;
   }
 
   @Override
-  public synchronized Runnable peek() {
+  public synchronized TraceRunnable peek() {
     if (task.size() == 0)
       return null;
 
     TraceRunnable min = Collections.min(task, comparator);
-    return (Runnable) min;
+    return min;
   }
 
   @Override
-  public synchronized boolean offer(Runnable e) {
-    task.add((TraceRunnable) e);
+  public synchronized boolean offer(TraceRunnable e) {
+    task.add(e);
     notify();
     return true;
   }
 
   @Override
-  public synchronized void put(Runnable e) throws InterruptedException {
-    task.add((TraceRunnable) e);
+  public synchronized void put(TraceRunnable e) throws InterruptedException {
+    task.add(e);
     notify();
   }
 
   @Override
-  public synchronized boolean offer(Runnable e, long timeout, TimeUnit unit) throws InterruptedException {
-    task.add((TraceRunnable) e);
+  public synchronized boolean offer(TraceRunnable e, long timeout, TimeUnit unit) throws InterruptedException {
+    task.add(e);
     notify();
     return true;
   }
 
   @Override
-  public synchronized Runnable take() throws InterruptedException {
+  public synchronized TraceRunnable take() throws InterruptedException {
     while (task.size() == 0) {
       wait();
     }
@@ -89,7 +92,7 @@ public class CompactionQueue extends AbstractQueue<Runnable> implements Blocking
   }
 
   @Override
-  public synchronized Runnable poll(long timeout, TimeUnit unit) throws InterruptedException {
+  public synchronized TraceRunnable poll(long timeout, TimeUnit unit) throws InterruptedException {
     if (task.size() == 0) {
       wait(unit.toMillis(timeout));
     }
@@ -106,19 +109,19 @@ public class CompactionQueue extends AbstractQueue<Runnable> implements Blocking
   }
 
   @Override
-  public synchronized int drainTo(Collection<? super Runnable> c) {
+  public synchronized int drainTo(Collection<? super TraceRunnable> c) {
     return drainTo(c, task.size());
   }
 
   @Override
-  public synchronized int drainTo(Collection<? super Runnable> c, int maxElements) {
+  public synchronized int drainTo(Collection<? super TraceRunnable> c, int maxElements) {
     Collections.sort(task, comparator);
 
     int num = Math.min(task.size(), maxElements);
 
     Iterator<TraceRunnable> iter = task.iterator();
     for (int i = 0; i < num; i++) {
-      c.add((Runnable) iter.next());
+      c.add(iter.next());
       iter.remove();
     }
 
@@ -126,28 +129,10 @@ public class CompactionQueue extends AbstractQueue<Runnable> implements Blocking
   }
 
   @Override
-  public synchronized Iterator<Runnable> iterator() {
+  public synchronized Iterator<TraceRunnable> iterator() {
     Collections.sort(task, comparator);
 
-    final Iterator<TraceRunnable> iter = task.iterator();
-
-    return new Iterator<Runnable>() {
-
-      @Override
-      public boolean hasNext() {
-        return iter.hasNext();
-      }
-
-      @Override
-      public Runnable next() {
-        return (Runnable) iter.next();
-      }
-
-      @Override
-      public void remove() {
-        iter.remove();
-      }
-    };
+    return task.iterator();
   }
 
   @Override
@@ -155,4 +140,9 @@ public class CompactionQueue extends AbstractQueue<Runnable> implements Blocking
     return task.size();
   }
 
+  @SuppressWarnings({"rawtypes", "unchecked"})
+  BlockingQueue<Runnable> asBlockingQueueOfRunnable() {
+    return (BlockingQueue) this;
+  }
+
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/FileManager.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/FileManager.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/FileManager.java
index 02dacd7..b5f5e16 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/FileManager.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/FileManager.java
@@ -60,7 +60,7 @@ public class FileManager {
 
   private static final Logger log = LoggerFactory.getLogger(FileManager.class);
 
-  int maxOpen;
+  private int maxOpen;
 
   private static class OpenReader implements Comparable<OpenReader> {
     long releaseTime;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/InMemoryMap.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/InMemoryMap.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/InMemoryMap.java
index cd96717..80feb47 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/InMemoryMap.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/InMemoryMap.java
@@ -96,7 +96,7 @@ class MemKeyComparator implements Comparator<Key>, Serializable {
 
 class PartialMutationSkippingIterator extends SkippingIterator implements InterruptibleIterator {
 
-  int kvCount;
+  private int kvCount;
 
   public PartialMutationSkippingIterator(SortedKeyValueIterator<Key,Value> source, int maxKVCount) {
     setSource(source);
@@ -122,8 +122,8 @@ class PartialMutationSkippingIterator extends SkippingIterator implements Interr
 }
 
 class MemKeyConversionIterator extends WrappingIterator implements InterruptibleIterator {
-  MemKey currKey = null;
-  Value currVal = null;
+  private MemKey currKey = null;
+  private Value currVal = null;
 
   public MemKeyConversionIterator(SortedKeyValueIterator<Key,Value> source) {
     super();
@@ -521,7 +521,7 @@ public class InMemoryMap {
 
   class MemoryDataSource implements DataSource {
 
-    boolean switched = false;
+    private boolean switched = false;
     private InterruptibleIterator iter;
     private FileSKVIterator reader;
     private MemoryDataSource parent;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/MemValue.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/MemValue.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/MemValue.java
index 0ce3b9e..bc44459 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/MemValue.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/MemValue.java
@@ -28,17 +28,6 @@ public class MemValue extends Value {
   int kvCount;
   boolean merged = false;
 
-  /**
-   * @param value
-   *          Value
-   * @param kv
-   *          kv count
-   */
-  public MemValue(byte[] value, int kv) {
-    super(value);
-    this.kvCount = kv;
-  }
-
   public MemValue() {
     super();
     this.kvCount = Integer.MAX_VALUE;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/NativeMap.java
----------------------------------------------------------------------
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 2c47f07..6eb8e4e 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
@@ -48,6 +48,8 @@ import org.apache.accumulo.core.util.PreAllocatedArray;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+import com.google.common.annotations.VisibleForTesting;
+
 /**
  * This class stores data in a C++ map. Doing this allows us to store more in memory and avoid pauses caused by Java GC.
  *
@@ -122,7 +124,7 @@ public class NativeMap implements Iterable<Map.Entry<Key,Value>> {
    *
    * @return true if they are loaded; false otherwise
    */
-  public static boolean isLoaded() {
+  static boolean isLoaded() {
     return loadedNativeLibraries.get();
   }
 
@@ -506,6 +508,7 @@ public class NativeMap implements Iterable<Map.Entry<Key,Value>> {
     }
   }
 
+  @VisibleForTesting
   public void mutate(Mutation mutation, int mutationCount) {
     wlock.lock();
     try {
@@ -521,7 +524,7 @@ public class NativeMap implements Iterable<Map.Entry<Key,Value>> {
     }
   }
 
-  public void mutate(List<Mutation> mutations, int mutationCount) {
+  void mutate(List<Mutation> mutations, int mutationCount) {
     Iterator<Mutation> iter = mutations.iterator();
 
     while (iter.hasNext()) {
@@ -547,6 +550,7 @@ public class NativeMap implements Iterable<Map.Entry<Key,Value>> {
     }
   }
 
+  @VisibleForTesting
   public void put(Key key, Value value) {
     wlock.lock();
     try {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/RunnableStartedAt.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/RunnableStartedAt.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/RunnableStartedAt.java
index 6513091..50433d2 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/RunnableStartedAt.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/RunnableStartedAt.java
@@ -17,7 +17,6 @@
 package org.apache.accumulo.tserver;
 
 import java.util.AbstractMap;
-import java.util.Map.Entry;
 
 /**
  * Encapsulation of a task and the time it began execution.
@@ -30,10 +29,6 @@ public class RunnableStartedAt extends AbstractMap.SimpleEntry<ActiveAssignmentR
     super(task, startedAtMillis);
   }
 
-  public RunnableStartedAt(Entry<? extends ActiveAssignmentRunnable,? extends Long> entry) {
-    super(entry);
-  }
-
   /**
    * @return The task being executed
    */

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/TLevel.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/TLevel.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/TLevel.java
index 5705c9e..b57e2da 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/TLevel.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/TLevel.java
@@ -27,10 +27,4 @@ public class TLevel extends Level {
     super(Level.DEBUG_INT + 100, "TABLET_HIST", Level.DEBUG_INT + 100);
   }
 
-  static public Level toLevel(int val) {
-    if (val == Level.DEBUG_INT + 100)
-      return Level.DEBUG;
-    return Level.toLevel(val);
-  }
-
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
----------------------------------------------------------------------
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 46b26b5..d9c3775 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
@@ -3039,11 +3039,6 @@ public class TabletServer extends AccumuloServerContext implements Runnable {
       }
 
       @Override
-      public Set<TServerInstance> getCurrentTServers() {
-        return null;
-      }
-
-      @Override
       public AccumuloConfiguration getConfiguration() {
         return TabletServer.this.getConfiguration();
       }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServerResourceManager.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServerResourceManager.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServerResourceManager.java
index cd01e60..077fbb8 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServerResourceManager.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServerResourceManager.java
@@ -63,6 +63,8 @@ import org.apache.htrace.wrappers.TraceExecutorService;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+import com.google.common.annotations.VisibleForTesting;
+
 /**
  * ResourceManager is responsible for managing the resources of all tablets within a tablet server.
  */
@@ -182,7 +184,7 @@ public class TabletServerResourceManager {
 
     // make this thread pool have a priority queue... and execute tablets with the most
     // files first!
-    majorCompactionThreadPool = createEs(Property.TSERV_MAJC_MAXCONCURRENT, "major compactor", new CompactionQueue());
+    majorCompactionThreadPool = createEs(Property.TSERV_MAJC_MAXCONCURRENT, "major compactor", new CompactionQueue().asBlockingQueueOfRunnable());
     rootMajorCompactionThreadPool = createEs(0, 1, 300, "md root major compactor");
     defaultMajorCompactionThreadPool = createEs(0, 1, 300, "md major compactor");
 
@@ -546,10 +548,12 @@ public class TabletServerResourceManager {
       this.tableConf = tableConf;
     }
 
+    @VisibleForTesting
     KeyExtent getExtent() {
       return extent;
     }
 
+    @VisibleForTesting
     AccumuloConfiguration getTableConfiguration() {
       return tableConf;
     }
@@ -732,52 +736,6 @@ public class TabletServerResourceManager {
     }
   }
 
-  public void stopSplits() {
-    splitThreadPool.shutdown();
-    defaultSplitThreadPool.shutdown();
-    while (true) {
-      try {
-        while (!splitThreadPool.awaitTermination(1, TimeUnit.MINUTES)) {
-          log.info("Waiting for metadata split thread pool to stop");
-        }
-        while (!defaultSplitThreadPool.awaitTermination(1, TimeUnit.MINUTES)) {
-          log.info("Waiting for split thread pool to stop");
-        }
-        break;
-      } catch (InterruptedException ex) {
-        log.info("Interrupted waiting for splits executor to terminate", ex);
-      }
-    }
-  }
-
-  public void stopNormalAssignments() {
-    assignmentPool.shutdown();
-    while (true) {
-      try {
-        while (!assignmentPool.awaitTermination(1, TimeUnit.MINUTES)) {
-          log.info("Waiting for assignment thread pool to stop");
-        }
-        break;
-      } catch (InterruptedException ex) {
-        log.info("Interrupted waiting for assignment executor to terminate", ex);
-      }
-    }
-  }
-
-  public void stopMetadataAssignments() {
-    assignMetaDataPool.shutdown();
-    while (true) {
-      try {
-        while (!assignMetaDataPool.awaitTermination(1, TimeUnit.MINUTES)) {
-          log.info("Waiting for metadata assignment thread pool to stop");
-        }
-        break;
-      } catch (InterruptedException ex) {
-        log.info("Interrupted waiting for metadata assignment executor to terminate", ex);
-      }
-    }
-  }
-
   public LruBlockCache getIndexCache() {
     return _iCache;
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletStatsKeeper.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletStatsKeeper.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletStatsKeeper.java
index 1e2cdf4..e8d8aec 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletStatsKeeper.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletStatsKeeper.java
@@ -87,15 +87,7 @@ public class TabletStatsKeeper {
     ActionStatsUpdator.update(major, t.majors);
   }
 
-  public void saveMinorTimes(TabletStatsKeeper t) {
-    ActionStatsUpdator.update(minor, t.minor);
-  }
-
-  public void saveMajorTimes(TabletStatsKeeper t) {
-    ActionStatsUpdator.update(major, t.major);
-  }
-
-  public void resetTimes() {
+  private void resetTimes() {
     major = new ActionStats();
     split = new ActionStats();
     minor = new ActionStats();
@@ -109,7 +101,7 @@ public class TabletStatsKeeper {
     major.status++;
   }
 
-  public void incrementStatusSplit() {
+  void incrementStatusSplit() {
     split.status++;
   }
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/compaction/MajorCompactionRequest.java
----------------------------------------------------------------------
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 444a97f..03817c1 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
@@ -28,9 +28,7 @@ import org.apache.accumulo.core.file.FileSKVIterator;
 import org.apache.accumulo.core.metadata.schema.DataFileValue;
 import org.apache.accumulo.server.fs.FileRef;
 import org.apache.accumulo.server.fs.VolumeManager;
-import org.apache.hadoop.fs.FileStatus;
 import org.apache.hadoop.fs.FileSystem;
-import org.apache.hadoop.fs.Path;
 
 /**
  * Information that can be used to determine how a tablet is to be major compacted, if needed.
@@ -72,11 +70,6 @@ public class MajorCompactionRequest implements Cloneable {
     this.files = Collections.unmodifiableMap(update);
   }
 
-  public FileStatus[] listStatus(Path path) throws IOException {
-    // @TODO verify the file isn't some random file in HDFS
-    return volumeManager.listStatus(path);
-  }
-
   public FileSKVIterator openReader(FileRef ref) throws IOException {
     // @TODO verify the file isn't some random file in HDFS
     // @TODO ensure these files are always closed?

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/log/DfsLogger.java
----------------------------------------------------------------------
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 e065617..ed2ce06 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
@@ -36,7 +36,6 @@ import java.util.Collections;
 import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
-import java.util.Set;
 import java.util.UUID;
 import java.util.concurrent.CountDownLatch;
 import java.util.concurrent.LinkedBlockingQueue;
@@ -57,7 +56,6 @@ import org.apache.accumulo.core.util.Pair;
 import org.apache.accumulo.fate.util.LoggingRunnable;
 import org.apache.accumulo.server.ServerConstants;
 import org.apache.accumulo.server.fs.VolumeManager;
-import org.apache.accumulo.server.master.state.TServerInstance;
 import org.apache.accumulo.tserver.TabletMutations;
 import org.apache.accumulo.tserver.logger.LogFileKey;
 import org.apache.accumulo.tserver.logger.LogFileValue;
@@ -95,14 +93,6 @@ public class DfsLogger {
   public static class LogHeaderIncompleteException extends IOException {
     private static final long serialVersionUID = 1l;
 
-    public LogHeaderIncompleteException(String msg) {
-      super(msg);
-    }
-
-    public LogHeaderIncompleteException(String msg, Throwable cause) {
-      super(msg, cause);
-    }
-
     public LogHeaderIncompleteException(Throwable cause) {
       super(cause);
     }
@@ -139,8 +129,6 @@ public class DfsLogger {
     AccumuloConfiguration getConfiguration();
 
     VolumeManager getFileSystem();
-
-    Set<TServerInstance> getCurrentTServers();
   }
 
   private final LinkedBlockingQueue<DfsLogger.LogWork> workQueue = new LinkedBlockingQueue<DfsLogger.LogWork>();
@@ -213,7 +201,7 @@ public class DfsLogger {
     }
   }
 
-  static class LogWork {
+  private static class LogWork {
     final CountDownLatch latch;
     final Durability durability;
     volatile Exception exception;
@@ -224,7 +212,7 @@ public class DfsLogger {
     }
   }
 
-  public static class LoggerOperation {
+  static class LoggerOperation {
     private final LogWork work;
 
     public LoggerOperation(LogWork work) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/log/TabletServerLogger.java
----------------------------------------------------------------------
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 711c497..ec5fa38 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
@@ -211,15 +211,6 @@ public class TabletServerLogger {
     }
   }
 
-  public void resetLoggers() throws IOException {
-    logSetLock.writeLock().lock();
-    try {
-      close();
-    } finally {
-      logSetLock.writeLock().unlock();
-    }
-  }
-
   synchronized private void close() throws IOException {
     if (!logSetLock.isWriteLockedByCurrentThread()) {
       throw new IllegalStateException("close should be called with write lock held!");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/logger/LogFileKey.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/logger/LogFileKey.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/logger/LogFileKey.java
index 829cf2f..1959ffb 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/logger/LogFileKey.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/logger/LogFileKey.java
@@ -168,10 +168,6 @@ public class LogFileKey implements WritableComparable<LogFileKey> {
     return (int) seq;
   }
 
-  public static void printEntry(LogFileKey entry) {
-    System.out.println(entry.toString());
-  }
-
   @Override
   public String toString() {
     switch (event) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/logger/LogFileValue.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/logger/LogFileValue.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/logger/LogFileValue.java
index 9ca0f38..87e17b3 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/logger/LogFileValue.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/logger/LogFileValue.java
@@ -55,10 +55,6 @@ public class LogFileValue implements Writable {
     }
   }
 
-  public static void print(LogFileValue value) {
-    System.out.println(value.toString());
-  }
-
   private static String displayLabels(byte[] labels) {
     String s = new String(labels, UTF_8);
     s = s.replace("&", " & ");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/mastermessage/SplitReportMessage.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/mastermessage/SplitReportMessage.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/mastermessage/SplitReportMessage.java
index fa35cd3..cd68e36 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/mastermessage/SplitReportMessage.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/mastermessage/SplitReportMessage.java
@@ -31,17 +31,12 @@ import org.apache.hadoop.io.Text;
 import org.apache.thrift.TException;
 
 public class SplitReportMessage implements MasterMessage {
-  Map<KeyExtent,Text> extents;
-  KeyExtent old_extent;
-
-  public SplitReportMessage(KeyExtent old_extent, Map<KeyExtent,Text> newExtents) {
-    this.old_extent = old_extent;
-    extents = new TreeMap<KeyExtent,Text>(newExtents);
-  }
+  private Map<KeyExtent,Text> extents;
+  private KeyExtent old_extent;
 
   public SplitReportMessage(KeyExtent old_extent, KeyExtent ne1, Text np1, KeyExtent ne2, Text np2) {
     this.old_extent = old_extent;
-    extents = new TreeMap<KeyExtent,Text>();
+    extents = new TreeMap<>();
     extents.put(ne1, np1);
     extents.put(ne2, np2);
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/session/Session.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/session/Session.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/session/Session.java
index 9aaa17a..a561166 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/session/Session.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/session/Session.java
@@ -21,12 +21,12 @@ import org.apache.accumulo.server.rpc.TServerUtils;
 
 public class Session {
   public final String client;
-  public long lastAccessTime;
+  long lastAccessTime;
   public long startTime;
-  public boolean reserved;
+  boolean reserved;
   private final TCredentials credentials;
 
-  public Session(TCredentials credentials) {
+  Session(TCredentials credentials) {
     this.credentials = credentials;
     this.client = TServerUtils.clientAddress.get();
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Rate.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Rate.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Rate.java
index a0ea2d6..fa85f0e 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Rate.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Rate.java
@@ -34,10 +34,6 @@ public class Rate {
     this.ratio = ratio;
   }
 
-  public double update(long counter) {
-    return update(System.currentTimeMillis(), counter);
-  }
-
   synchronized public double update(long when, long counter) {
     if (lastCounter < 0) {
       lastTime = when;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java
----------------------------------------------------------------------
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 7c152b0..fd7537d 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
@@ -1203,10 +1203,6 @@ public class Tablet implements TabletCommitter {
     }
   }
 
-  public synchronized void waitForMinC() {
-    getTabletMemory().waitForMinC();
-  }
-
   private synchronized CommitSession finishPreparingMutations(long time) {
     if (writesInProgress < 0) {
       throw new IllegalStateException("waitingForLogs < 0 " + writesInProgress);
@@ -2317,10 +2313,6 @@ public class Tablet implements TabletCommitter {
     return this.queryCount;
   }
 
-  public long totalIngest() {
-    return this.ingestCount;
-  }
-
   // synchronized?
   public void updateRates(long now) {
     queryRate.update(now, queryCount);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/shell/src/main/java/org/apache/accumulo/shell/Shell.java
----------------------------------------------------------------------
diff --git a/shell/src/main/java/org/apache/accumulo/shell/Shell.java b/shell/src/main/java/org/apache/accumulo/shell/Shell.java
index 8abafdb..2db2e63 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/Shell.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/Shell.java
@@ -893,22 +893,6 @@ public class Shell extends ShellOptions implements KeywordExecutable {
       TABLENAMES, USERNAMES, COMMANDS, NAMESPACES
     }
 
-    static Set<String> getCommandNames(Map<CompletionSet,Set<String>> objects) {
-      return objects.get(CompletionSet.COMMANDS);
-    }
-
-    static Set<String> getTableNames(Map<CompletionSet,Set<String>> objects) {
-      return objects.get(CompletionSet.TABLENAMES);
-    }
-
-    static Set<String> getUserNames(Map<CompletionSet,Set<String>> objects) {
-      return objects.get(CompletionSet.USERNAMES);
-    }
-
-    static Set<String> getNamespaces(Map<CompletionSet,Set<String>> objects) {
-      return objects.get(CompletionSet.NAMESPACES);
-    }
-
     public void registerCompletionGeneral(Token root, Set<String> args, boolean caseSens) {
       Token t = new Token(args);
       t.setCaseSensitive(caseSens);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/shell/src/main/java/org/apache/accumulo/shell/ShellCommandException.java
----------------------------------------------------------------------
diff --git a/shell/src/main/java/org/apache/accumulo/shell/ShellCommandException.java b/shell/src/main/java/org/apache/accumulo/shell/ShellCommandException.java
index d24c4e0..f88a061 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/ShellCommandException.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/ShellCommandException.java
@@ -45,10 +45,6 @@ public class ShellCommandException extends Exception {
   private ErrorCode code;
   private String command;
 
-  public ShellCommandException(ErrorCode code) {
-    this(code, null);
-  }
-
   public ShellCommandException(ErrorCode code, String command) {
     this.code = code;
     this.command = command;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/shell/src/main/java/org/apache/accumulo/shell/ShellCompletor.java
----------------------------------------------------------------------
diff --git a/shell/src/main/java/org/apache/accumulo/shell/ShellCompletor.java b/shell/src/main/java/org/apache/accumulo/shell/ShellCompletor.java
index 3ed6a04..8edbc5b 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/ShellCompletor.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/ShellCompletor.java
@@ -36,10 +36,6 @@ public class ShellCompletor implements Completer {
 
   public ShellCompletor() {}
 
-  public ShellCompletor(Token root) {
-    this.root = root;
-  }
-
   public ShellCompletor(Token rootToken, Map<CompletionSet,Set<String>> options) {
     this.root = rootToken;
     this.options = options;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/shell/src/main/java/org/apache/accumulo/shell/ShellOptions.java
----------------------------------------------------------------------
diff --git a/shell/src/main/java/org/apache/accumulo/shell/ShellOptions.java b/shell/src/main/java/org/apache/accumulo/shell/ShellOptions.java
index 302a8a9..f7f3017 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/ShellOptions.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/ShellOptions.java
@@ -16,7 +16,6 @@
  */
 package org.apache.accumulo.shell;
 
-import org.apache.commons.cli.Option;
 
 /**
  * Abstract class to encompass the Options available on the Accumulo Shell
@@ -28,6 +27,4 @@ public abstract class ShellOptions {
   public static final String namespaceOption = "ns";
   public static final String helpOption = "?";
   public static final String helpLongOption = "help";
-
-  final Option helpOpt = new Option(helpOption, helpLongOption, false, "display this help");
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/shell/src/main/java/org/apache/accumulo/shell/Token.java
----------------------------------------------------------------------
diff --git a/shell/src/main/java/org/apache/accumulo/shell/Token.java b/shell/src/main/java/org/apache/accumulo/shell/Token.java
index a533aa1..fe29537 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/Token.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/Token.java
@@ -46,12 +46,6 @@ public class Token {
     command.addAll(commandNames);
   }
 
-  public Token(Set<String> commandNames, Set<Token> subCommandNames) {
-    this();
-    command.addAll(commandNames);
-    subcommands.addAll(subCommandNames);
-  }
-
   public void setCaseSensitive(boolean cs) {
     caseSensitive = cs;
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/shell/src/main/java/org/apache/accumulo/shell/commands/CompactCommand.java
----------------------------------------------------------------------
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/CompactCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/CompactCommand.java
index e39d862..33a8d45 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/CompactCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/CompactCommand.java
@@ -42,8 +42,6 @@ public class CompactCommand extends TableOperation {
 
   private CompactionConfig compactionConfig = null;
 
-  boolean override = false;
-
   private boolean cancel = false;
 
   @Override

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/shell/src/main/java/org/apache/accumulo/shell/commands/ScanCommand.java
----------------------------------------------------------------------
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/ScanCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/ScanCommand.java
index 5917b1e..334ca56 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/ScanCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/ScanCommand.java
@@ -146,11 +146,6 @@ public class ScanCommand extends Command {
     }
   }
 
-  protected void printRecords(final CommandLine cl, final Shell shellState, final Iterable<Entry<Key,Value>> scanner, final Class<? extends Formatter> formatter)
-      throws IOException {
-    printRecords(cl, shellState, scanner, formatter, null);
-  }
-
   protected void printRecords(final CommandLine cl, final Shell shellState, final Iterable<Entry<Key,Value>> scanner,
       final Class<? extends Formatter> formatter, PrintFile outFile) throws IOException {
     if (outFile == null) {
@@ -160,10 +155,6 @@ public class ScanCommand extends Command {
     }
   }
 
-  protected void printBinaryRecords(final CommandLine cl, final Shell shellState, final Iterable<Entry<Key,Value>> scanner) throws IOException {
-    printBinaryRecords(cl, shellState, scanner, null);
-  }
-
   protected void printBinaryRecords(final CommandLine cl, final Shell shellState, final Iterable<Entry<Key,Value>> scanner, PrintFile outFile)
       throws IOException {
     if (outFile == null) {


[2/2] accumulo git commit: ACCUMULO-3204 Remove unused code

Posted by ct...@apache.org.
ACCUMULO-3204 Remove unused code


Project: http://git-wip-us.apache.org/repos/asf/accumulo/repo
Commit: http://git-wip-us.apache.org/repos/asf/accumulo/commit/a194c0b0
Tree: http://git-wip-us.apache.org/repos/asf/accumulo/tree/a194c0b0
Diff: http://git-wip-us.apache.org/repos/asf/accumulo/diff/a194c0b0

Branch: refs/heads/master
Commit: a194c0b00b7a927e938da72350916f30b0a0707d
Parents: 956a50e
Author: Christopher Tubbs <ct...@apache.org>
Authored: Fri Apr 17 18:02:03 2015 -0400
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Fri Apr 17 18:02:03 2015 -0400

----------------------------------------------------------------------
 .../accumulo/core/bloomfilter/Filter.java       | 48 ----------
 .../core/client/impl/ReplicationClient.java     | 41 --------
 .../core/client/impl/ScannerIterator.java       |  5 -
 .../core/client/impl/ScannerOptions.java        |  5 -
 .../accumulo/core/client/impl/Tables.java       |  5 -
 .../accumulo/core/client/mock/MockAccumulo.java |  4 -
 .../accumulo/core/client/mock/MockTable.java    |  6 +-
 .../org/apache/accumulo/core/conf/Property.java | 11 ---
 .../accumulo/core/conf/SiteConfiguration.java   | 17 ----
 .../apache/accumulo/core/data/PartialKey.java   |  2 +
 .../core/file/blockfile/ABlockReader.java       |  2 -
 .../core/file/blockfile/ABlockWriter.java       |  3 -
 .../core/file/blockfile/BlockFileWriter.java    |  2 -
 .../core/file/blockfile/cache/BlockCache.java   |  5 -
 .../core/file/blockfile/cache/CachedBlock.java  |  4 -
 .../core/file/blockfile/cache/ClassSize.java    | 98 --------------------
 .../file/blockfile/cache/LruBlockCache.java     |  1 -
 .../file/blockfile/impl/CachableBlockFile.java  | 28 ------
 .../file/keyfunctor/ColumnFamilyFunctor.java    |  2 +-
 .../accumulo/core/file/rfile/bcfile/BCFile.java | 19 ----
 .../core/file/rfile/bcfile/CompareUtils.java    | 36 -------
 .../accumulo/core/file/rfile/bcfile/Utils.java  | 82 ----------------
 .../core/metadata/schema/MetadataSchema.java    | 14 ---
 .../apache/accumulo/core/rpc/ThriftUtil.java    | 70 --------------
 .../apache/accumulo/core/util/AddressUtil.java  |  4 -
 .../apache/accumulo/core/util/ByteArraySet.java |  4 -
 .../org/apache/accumulo/core/util/Daemon.java   | 20 ----
 .../apache/accumulo/core/util/MapCounter.java   |  4 -
 .../apache/accumulo/core/util/StopWatch.java    | 15 ---
 .../core/volume/VolumeConfiguration.java        |  5 -
 .../simple/mapreduce/TeraSortIngest.java        |  2 -
 .../accumulo/fate/zookeeper/ZooCache.java       |  9 --
 .../apache/accumulo/fate/zookeeper/ZooLock.java | 18 ----
 .../accumulo/fate/zookeeper/ZooQueueLock.java   |  7 --
 .../accumulo/fate/zookeeper/ZooSession.java     |  4 -
 .../impl/MiniAccumuloClusterImpl.java           | 15 +--
 .../impl/ZooKeeperBindException.java            |  8 --
 .../apache/accumulo/server/ServerConstants.java |  4 -
 .../accumulo/server/client/BulkImporter.java    |  9 --
 .../server/conf/NamespaceConfWatcher.java       |  4 -
 .../accumulo/server/conf/TableConfWatcher.java  |  4 -
 .../server/conf/TableParentConfiguration.java   | 10 --
 .../server/conf/ZooConfigurationFactory.java    | 11 ---
 .../accumulo/server/log/SortedLogState.java     |  8 --
 .../accumulo/server/master/LiveTServerSet.java  |  9 --
 .../master/state/DistributedStoreException.java |  3 -
 .../server/master/state/TServerInstance.java    |  4 -
 .../server/master/state/TabletServerState.java  |  5 -
 .../server/metrics/AbstractMetricsImpl.java     |  4 -
 .../server/metrics/MetricsConfiguration.java    | 18 ----
 .../server/replication/StatusFormatter.java     |  5 -
 .../server/rpc/TBufferedServerSocket.java       | 71 --------------
 .../server/rpc/TNonblockingServerSocket.java    |  7 --
 .../server/security/SecurityOperation.java      |  4 -
 .../security/handler/KerberosAuthorizor.java    |  8 --
 .../handler/KerberosPermissionHandler.java      |  8 --
 .../accumulo/server/tables/TableManager.java    |  4 -
 .../accumulo/server/util/AccumuloStatus.java    | 14 ---
 .../accumulo/server/util/CleanZookeeper.java    |  3 -
 .../accumulo/server/util/FileSystemMonitor.java | 12 ---
 .../accumulo/server/util/MetadataTableUtil.java |  5 -
 .../accumulo/server/util/RestoreZookeeper.java  |  2 -
 .../accumulo/server/util/time/RelativeTime.java |  4 -
 .../accumulo/server/util/time/SimpleTimer.java  | 10 --
 .../accumulo/server/zookeeper/ZooCache.java     |  5 -
 .../accumulo/gc/SimpleGarbageCollector.java     |  2 -
 .../org/apache/accumulo/monitor/Monitor.java    | 27 ------
 .../accumulo/monitor/ZooKeeperStatus.java       |  4 -
 .../apache/accumulo/tracer/ZooTraceClient.java  |  3 +-
 .../tserver/ActiveAssignmentRunnable.java       |  4 +-
 .../accumulo/tserver/CompactionQueue.java       | 70 ++++++--------
 .../apache/accumulo/tserver/FileManager.java    |  2 +-
 .../apache/accumulo/tserver/InMemoryMap.java    |  8 +-
 .../org/apache/accumulo/tserver/MemValue.java   | 11 ---
 .../org/apache/accumulo/tserver/NativeMap.java  |  8 +-
 .../accumulo/tserver/RunnableStartedAt.java     |  5 -
 .../org/apache/accumulo/tserver/TLevel.java     |  6 --
 .../apache/accumulo/tserver/TabletServer.java   |  5 -
 .../tserver/TabletServerResourceManager.java    | 52 +----------
 .../accumulo/tserver/TabletStatsKeeper.java     | 12 +--
 .../compaction/MajorCompactionRequest.java      |  7 --
 .../apache/accumulo/tserver/log/DfsLogger.java  | 16 +---
 .../tserver/log/TabletServerLogger.java         |  9 --
 .../accumulo/tserver/logger/LogFileKey.java     |  4 -
 .../accumulo/tserver/logger/LogFileValue.java   |  4 -
 .../mastermessage/SplitReportMessage.java       | 11 +--
 .../accumulo/tserver/session/Session.java       |  6 +-
 .../apache/accumulo/tserver/tablet/Rate.java    |  4 -
 .../apache/accumulo/tserver/tablet/Tablet.java  |  8 --
 .../java/org/apache/accumulo/shell/Shell.java   | 16 ----
 .../accumulo/shell/ShellCommandException.java   |  4 -
 .../apache/accumulo/shell/ShellCompletor.java   |  4 -
 .../org/apache/accumulo/shell/ShellOptions.java |  3 -
 .../java/org/apache/accumulo/shell/Token.java   |  6 --
 .../accumulo/shell/commands/CompactCommand.java |  2 -
 .../accumulo/shell/commands/ScanCommand.java    |  9 --
 96 files changed, 67 insertions(+), 1145 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/bloomfilter/Filter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/bloomfilter/Filter.java b/core/src/main/java/org/apache/accumulo/core/bloomfilter/Filter.java
index 27eab69..f6fb632 100644
--- a/core/src/main/java/org/apache/accumulo/core/bloomfilter/Filter.java
+++ b/core/src/main/java/org/apache/accumulo/core/bloomfilter/Filter.java
@@ -53,8 +53,6 @@ package org.apache.accumulo.core.bloomfilter;
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
-import java.util.Collection;
-import java.util.List;
 
 import org.apache.hadoop.io.Writable;
 import org.apache.hadoop.util.bloom.HashFunction;
@@ -163,52 +161,6 @@ public abstract class Filter implements Writable {
    */
   public abstract void not();
 
-  /**
-   * Adds a list of keys to <i>this</i> filter.
-   *
-   * @param keys
-   *          The list of keys.
-   */
-  public void add(final List<Key> keys) {
-    if (keys == null) {
-      throw new IllegalArgumentException("ArrayList<Key> may not be null");
-    }
-
-    for (Key key : keys) {
-      add(key);
-    }
-  }// end add()
-
-  /**
-   * Adds a collection of keys to <i>this</i> filter.
-   *
-   * @param keys
-   *          The collection of keys.
-   */
-  public void add(final Collection<Key> keys) {
-    if (keys == null) {
-      throw new IllegalArgumentException("Collection<Key> may not be null");
-    }
-    for (Key key : keys) {
-      add(key);
-    }
-  }// end add()
-
-  /**
-   * Adds an array of keys to <i>this</i> filter.
-   *
-   * @param keys
-   *          The array of keys.
-   */
-  public void add(Key[] keys) {
-    if (keys == null) {
-      throw new IllegalArgumentException("Key[] may not be null");
-    }
-    for (int i = 0; i < keys.length; i++) {
-      add(keys[i]);
-    }
-  }// end add()
-
   // Writable interface
 
   @Override

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/client/impl/ReplicationClient.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ReplicationClient.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ReplicationClient.java
index a449389..673775a 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ReplicationClient.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ReplicationClient.java
@@ -29,7 +29,6 @@ import org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.replication.thrift.ReplicationCoordinator;
 import org.apache.accumulo.core.replication.thrift.ReplicationServicer;
 import org.apache.accumulo.core.rpc.ThriftUtil;
-import org.apache.accumulo.core.util.UtilWaitThread;
 import org.apache.accumulo.core.zookeeper.ZooUtil;
 import org.apache.accumulo.fate.zookeeper.ZooReader;
 import org.apache.thrift.TServiceClient;
@@ -181,27 +180,6 @@ public class ReplicationClient {
     throw new AccumuloException("Could not connect to ReplicationCoordinator at " + context.getInstance().getInstanceName());
   }
 
-  public static void executeCoordinator(ClientContext context, ClientExec<ReplicationCoordinator.Client> exec) throws AccumuloException,
-      AccumuloSecurityException {
-    ReplicationCoordinator.Client client = null;
-    try {
-      client = getCoordinatorConnectionWithRetry(context);
-      exec.execute(client);
-    } catch (TTransportException tte) {
-      log.debug("ReplicationClient coordinator request failed, retrying ... ", tte);
-      UtilWaitThread.sleep(100);
-    } catch (ThriftSecurityException e) {
-      throw new AccumuloSecurityException(e.user, e.code, e);
-    } catch (AccumuloException e) {
-      throw e;
-    } catch (Exception e) {
-      throw new AccumuloException(e);
-    } finally {
-      if (client != null)
-        close(client);
-    }
-  }
-
   public static <T> T executeServicerWithReturn(ClientContext context, HostAndPort tserver, ClientExecReturn<T,ReplicationServicer.Client> exec)
       throws AccumuloException, AccumuloSecurityException, TTransportException {
     ReplicationServicer.Client client = null;
@@ -222,23 +200,4 @@ public class ReplicationClient {
     }
   }
 
-  public static void executeServicer(ClientContext context, HostAndPort tserver, ClientExec<ReplicationServicer.Client> exec) throws AccumuloException,
-      AccumuloSecurityException, TTransportException {
-    ReplicationServicer.Client client = null;
-    try {
-      client = getServicerConnection(context, tserver);
-      exec.execute(client);
-      return;
-    } catch (ThriftSecurityException e) {
-      throw new AccumuloSecurityException(e.user, e.code, e);
-    } catch (AccumuloException e) {
-      throw e;
-    } catch (Exception e) {
-      throw new AccumuloException(e);
-    } finally {
-      if (client != null)
-        close(client);
-    }
-  }
-
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerIterator.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerIterator.java
index 123f532..fd91b5a 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerIterator.java
@@ -26,7 +26,6 @@ import java.util.concurrent.SynchronousQueue;
 import java.util.concurrent.ThreadPoolExecutor;
 import java.util.concurrent.TimeUnit;
 
-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.TableDeletedException;
@@ -105,10 +104,6 @@ public class ScannerIterator implements Iterator<Entry<Key,Value>> {
 
   }
 
-  ScannerIterator(ClientContext context, Text table, Authorizations authorizations, Range range, int size, int timeOut, ScannerOptions options, boolean isolated) {
-    this(context, table, authorizations, range, size, timeOut, options, isolated, Constants.SCANNER_DEFAULT_READAHEAD_THRESHOLD);
-  }
-
   ScannerIterator(ClientContext context, Text table, Authorizations authorizations, Range range, int size, int timeOut, ScannerOptions options,
       boolean isolated, long readaheadThreshold) {
     this.tableId = new Text(table);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerOptions.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerOptions.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerOptions.java
index 3d486d2..e455d5a 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerOptions.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ScannerOptions.java
@@ -133,11 +133,6 @@ public class ScannerOptions implements ScannerBase {
     fetchedColumns.add(c);
   }
 
-  public synchronized void fetchColumn(Column column) {
-    checkArgument(column != null, "column is null");
-    fetchedColumns.add(column);
-  }
-
   @Override
   public void fetchColumn(IteratorSetting.Column column) {
     checkArgument(column != null, "Column is null");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/client/impl/Tables.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/Tables.java b/core/src/main/java/org/apache/accumulo/core/client/impl/Tables.java
index 44f48c3..beacea9 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/Tables.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/Tables.java
@@ -154,11 +154,6 @@ public class Tables {
     return tableName == null ? "(ID:" + tableId + ")" : tableName;
   }
 
-  public static String getPrintableTableIdFromName(Map<String,String> nameToIdMap, String tableName) {
-    String tableId = nameToIdMap.get(tableName);
-    return tableId == null ? "(NAME:" + tableName + ")" : tableId;
-  }
-
   public static String getPrintableTableInfoFromId(Instance instance, String tableId) {
     String tableName = null;
     try {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/client/mock/MockAccumulo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mock/MockAccumulo.java b/core/src/main/java/org/apache/accumulo/core/client/mock/MockAccumulo.java
index f171889..e1ca768 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mock/MockAccumulo.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mock/MockAccumulo.java
@@ -75,10 +75,6 @@ public class MockAccumulo {
     return systemProperties.remove(key);
   }
 
-  void createTable(String user, String table) {
-    createTable(user, table, true, TimeType.MILLIS);
-  }
-
   public void addMutation(String table, Mutation m) {
     MockTable t = tables.get(table);
     t.addMutation(m);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/client/mock/MockTable.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mock/MockTable.java b/core/src/main/java/org/apache/accumulo/core/client/mock/MockTable.java
index 2244d20..6f66c60 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mock/MockTable.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mock/MockTable.java
@@ -57,7 +57,7 @@ public class MockTable {
 
     @Override
     public boolean equals(Object other) {
-      return (other instanceof MockMemKey) && super.equals((MockMemKey) other) && count == ((MockMemKey) other).count;
+      return (other instanceof MockMemKey) && super.equals(other) && count == ((MockMemKey) other).count;
     }
 
     @Override
@@ -105,10 +105,6 @@ public class MockTable {
     }
   }
 
-  MockTable(MockNamespace namespace, boolean limitVersion, TimeType timeType, String tableId) {
-    this(namespace, limitVersion, timeType, tableId, new HashMap<String,String>());
-  }
-
   MockTable(MockNamespace namespace, boolean limitVersion, TimeType timeType, String tableId, Map<String,String> properties) {
     this(limitVersion, timeType, tableId);
     Set<Entry<String,String>> set = namespace.settings.entrySet();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/conf/Property.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/Property.java b/core/src/main/java/org/apache/accumulo/core/conf/Property.java
index 08ba3a2..429abad 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/Property.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/Property.java
@@ -25,7 +25,6 @@ import java.util.HashSet;
 import java.util.Map;
 import java.util.Map.Entry;
 import java.util.Properties;
-import java.util.Set;
 
 import org.apache.accumulo.core.Constants;
 import org.apache.accumulo.core.client.security.tokens.PasswordToken;
@@ -792,16 +791,6 @@ public enum Property {
   }
 
   /**
-   * Gets the set of "fixed" valid Zookeeper properties.
-   *
-   * @return fixed Zookeeper properties
-   * @see #isFixedZooPropertyKey(Property)
-   */
-  public static Set<Property> getFixedProperties() {
-    return fixedProperties;
-  }
-
-  /**
    * Checks if the given property key is valid for a property that may be changed via Zookeeper.
    *
    * @param key

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/conf/SiteConfiguration.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/conf/SiteConfiguration.java b/core/src/main/java/org/apache/accumulo/core/conf/SiteConfiguration.java
index e8c49b4..b2f5a18 100644
--- a/core/src/main/java/org/apache/accumulo/core/conf/SiteConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/conf/SiteConfiguration.java
@@ -169,23 +169,6 @@ public class SiteConfiguration extends AccumuloConfiguration {
   }
 
   /**
-   * method here to support testing, do not call
-   */
-  public void clear() {
-    getXmlConfig().clear();
-  }
-
-  /**
-   * Clears the configuration properties in this configuration (but not the parent) and nulls it. This method supports testing and should not be called.
-   */
-  public synchronized void clearAndNull() {
-    if (xmlConfig != null) {
-      xmlConfig.clear();
-      xmlConfig = null;
-    }
-  }
-
-  /**
    * Sets a property. This method supports testing and should not be called.
    *
    * @param property

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/data/PartialKey.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/PartialKey.java b/core/src/main/java/org/apache/accumulo/core/data/PartialKey.java
index f4289d2..bf0df1e 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/PartialKey.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/PartialKey.java
@@ -38,7 +38,9 @@ public enum PartialKey {
    * @return partial key
    * @throws IllegalArgumentException
    *           if no partial key has the given depth
+   * @deprecated since 1.7.0
    */
+  @Deprecated
   public static PartialKey getByDepth(int depth) {
     for (PartialKey d : PartialKey.values())
       if (depth == d.depth)

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockReader.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockReader.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockReader.java
index 8df2469..9ae895e 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockReader.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockReader.java
@@ -28,8 +28,6 @@ import java.io.IOException;
 
 public interface ABlockReader extends DataInput {
 
-  long getRawSize();
-
   DataInputStream getStream() throws IOException;
 
   void close() throws IOException;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockWriter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockWriter.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockWriter.java
index ece0a5e..f7a734b 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockWriter.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/ABlockWriter.java
@@ -17,7 +17,6 @@
 package org.apache.accumulo.core.file.blockfile;
 
 import java.io.DataOutput;
-import java.io.DataOutputStream;
 import java.io.IOException;
 
 /*
@@ -36,6 +35,4 @@ public interface ABlockWriter extends DataOutput {
 
   long getStartPos() throws IOException;
 
-  DataOutputStream getStream() throws IOException;
-
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/file/blockfile/BlockFileWriter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/BlockFileWriter.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/BlockFileWriter.java
index 3bdbea3..570a8a5 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/BlockFileWriter.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/BlockFileWriter.java
@@ -28,8 +28,6 @@ import java.io.IOException;
 
 public interface BlockFileWriter {
 
-  ABlockWriter prepareMetaBlock(String name, String compressionName) throws IOException;
-
   ABlockWriter prepareMetaBlock(String name) throws IOException;
 
   ABlockWriter prepareDataBlock() throws IOException;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/BlockCache.java
----------------------------------------------------------------------
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 a6c08ff..73ef0a6 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
@@ -55,11 +55,6 @@ public interface BlockCache {
   CacheEntry getBlock(String blockName);
 
   /**
-   * Shutdown the cache.
-   */
-  void shutdown();
-
-  /**
    * Get the maximum size of this cache.
    *
    * @return max size in bytes

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CachedBlock.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CachedBlock.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CachedBlock.java
index eef900c..b1d5c71 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CachedBlock.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/CachedBlock.java
@@ -55,10 +55,6 @@ public class CachedBlock implements HeapSize, Comparable<CachedBlock>, CacheEntr
   private BlockPriority priority;
   private Object index;
 
-  public CachedBlock(String blockName, byte buf[], long accessTime) {
-    this(blockName, buf, accessTime, false);
-  }
-
   public CachedBlock(String blockName, byte buf[], long accessTime, boolean inMemory) {
     this.blockName = blockName;
     this.buf = buf;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/ClassSize.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/ClassSize.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/ClassSize.java
index b46da23..bd1e2e8 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/ClassSize.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/ClassSize.java
@@ -20,8 +20,6 @@
 
 package org.apache.accumulo.core.file.blockfile.cache;
 
-import java.lang.reflect.Field;
-import java.lang.reflect.Modifier;
 import java.util.Properties;
 
 import org.apache.commons.logging.Log;
@@ -35,8 +33,6 @@ import org.apache.commons.logging.LogFactory;
 public class ClassSize {
   static final Log LOG = LogFactory.getLog(ClassSize.class);
 
-  private static final int nrOfRefsPerObj = 2;
-
   /** Array overhead */
   public static final int ARRAY;
 
@@ -152,100 +148,6 @@ public class ClassSize {
   }
 
   /**
-   * The estimate of the size of a class instance depends on whether the JVM uses 32 or 64 bit addresses, that is it depends on the size of an object reference.
-   * It is a linear function of the size of a reference, e.g. 24 + 5*r where r is the size of a reference (usually 4 or 8 bytes).
-   *
-   * This method returns the coefficients of the linear function, e.g. {24, 5} in the above example.
-   *
-   * @param cl
-   *          A class whose instance size is to be estimated
-   * @return an array of 3 integers. The first integer is the size of the primitives, the second the number of arrays and the third the number of references.
-   */
-  private static int[] getSizeCoefficients(Class<?> cl, boolean debug) {
-    int primitives = 0;
-    int arrays = 0;
-    // The number of references that a new object takes
-    int references = nrOfRefsPerObj;
-
-    for (; null != cl; cl = cl.getSuperclass()) {
-      Field[] field = cl.getDeclaredFields();
-      if (null != field) {
-        for (int i = 0; i < field.length; i++) {
-          if (!Modifier.isStatic(field[i].getModifiers())) {
-            Class<?> fieldClass = field[i].getType();
-            if (fieldClass.isArray()) {
-              arrays++;
-              references++;
-            } else if (!fieldClass.isPrimitive()) {
-              references++;
-            } else {// Is simple primitive
-              String name = fieldClass.getName();
-
-              if (name.equals("int") || name.equals("I"))
-                primitives += SizeConstants.SIZEOF_INT;
-              else if (name.equals("long") || name.equals("J"))
-                primitives += SizeConstants.SIZEOF_LONG;
-              else if (name.equals("boolean") || name.equals("Z"))
-                primitives += SizeConstants.SIZEOF_BOOLEAN;
-              else if (name.equals("short") || name.equals("S"))
-                primitives += SizeConstants.SIZEOF_SHORT;
-              else if (name.equals("byte") || name.equals("B"))
-                primitives += SizeConstants.SIZEOF_BYTE;
-              else if (name.equals("char") || name.equals("C"))
-                primitives += SizeConstants.SIZEOF_CHAR;
-              else if (name.equals("float") || name.equals("F"))
-                primitives += SizeConstants.SIZEOF_FLOAT;
-              else if (name.equals("double") || name.equals("D"))
-                primitives += SizeConstants.SIZEOF_DOUBLE;
-            }
-            if (debug) {
-              if (LOG.isDebugEnabled()) {
-                // Write out region name as string and its encoded name.
-                LOG.debug(field[i].getName() + "\n\t" + field[i].getType());
-              }
-            }
-          }
-        }
-      }
-    }
-    return new int[] {primitives, arrays, references};
-  }
-
-  /**
-   * Estimate the static space taken up by a class instance given the coefficients returned by getSizeCoefficients.
-   *
-   * @param coeff
-   *          the coefficients
-   *
-   * @return the size estimate, in bytes
-   */
-  private static long estimateBaseFromCoefficients(int[] coeff, boolean debug) {
-    long size = coeff[0] + align(coeff[1] * ARRAY) + coeff[2] * REFERENCE;
-
-    // Round up to a multiple of 8
-    size = align(size);
-    if (debug) {
-      if (LOG.isDebugEnabled()) {
-        // Write out region name as string and its encoded name.
-        LOG.debug("Primitives " + coeff[0] + ", arrays " + coeff[1] + ", references(includes " + nrOfRefsPerObj + " for object overhead) " + coeff[2]
-            + ", refSize " + REFERENCE + ", size " + size);
-      }
-    }
-    return size;
-  }
-
-  /**
-   * Estimate the static space taken up by the fields of a class. This includes the space taken up by by references (the pointer) but not by the referenced
-   * object. So the estimated size of an array field does not depend on the size of the array. Similarly the size of an object (reference) field does not depend
-   * on the object.
-   *
-   * @return the size estimate in bytes.
-   */
-  public static long estimateBase(Class<?> cl, boolean debug) {
-    return estimateBaseFromCoefficients(getSizeCoefficients(cl, debug), debug);
-  }
-
-  /**
    * Aligns a number to 8.
    *
    * @param num

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/LruBlockCache.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/LruBlockCache.java b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/LruBlockCache.java
index 2bd1a38..af2f6df 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/LruBlockCache.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/blockfile/cache/LruBlockCache.java
@@ -698,7 +698,6 @@ public class LruBlockCache implements BlockCache, HeapSize {
     return (long) Math.floor(this.maxSize * this.memoryFactor * this.minFactor);
   }
 
-  @Override
   public void shutdown() {
     this.scheduleThreadPool.shutdown();
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/file/blockfile/impl/CachableBlockFile.java
----------------------------------------------------------------------
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 54da7d9..d00a797 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
@@ -78,12 +78,6 @@ public class CachableBlockFile {
     }
 
     @Override
-    public ABlockWriter prepareMetaBlock(String name, String compressionName) throws IOException {
-      _bw = new BlockWrite(_bc.prepareMetaBlock(name, compressionName));
-      return _bw;
-    }
-
-    @Override
     public ABlockWriter prepareDataBlock() throws IOException {
       _bw = new BlockWrite(_bc.prepareDataBlock());
       return _bw;
@@ -128,12 +122,6 @@ public class CachableBlockFile {
     }
 
     @Override
-    public DataOutputStream getStream() throws IOException {
-
-      return this;
-    }
-
-    @Override
     public long getStartPos() throws IOException {
       return _ba.getStartPos();
     }
@@ -430,12 +418,6 @@ public class CachableBlockFile {
       super(buf);
     }
 
-    public SeekableByteArrayInputStream(byte buf[], int offset, int length) {
-      super(buf, offset, length);
-      throw new UnsupportedOperationException("Seek code assumes offset is zero"); // do not need this constructor, documenting that seek will not work
-                                                                                   // unless offset it kept track of
-    }
-
     public void seek(int position) {
       if (pos < 0 || pos >= buf.length)
         throw new IllegalArgumentException("pos = " + pos + " buf.lenght = " + buf.length);
@@ -508,19 +490,9 @@ public class CachableBlockFile {
    *
    */
   public static class BlockRead extends DataInputStream implements ABlockReader {
-    private long size;
 
     public BlockRead(InputStream in, long size) {
       super(in);
-      this.size = size;
-    }
-
-    /**
-     * Size is the size of the bytearray that was read form the cache
-     */
-    @Override
-    public long getRawSize() {
-      return size;
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnFamilyFunctor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnFamilyFunctor.java b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnFamilyFunctor.java
index 3660291..c38aaee 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnFamilyFunctor.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/keyfunctor/ColumnFamilyFunctor.java
@@ -41,7 +41,7 @@ public class ColumnFamilyFunctor implements KeyFunctor {
 
   @Override
   public Key transform(Range range) {
-    if (RowFunctor.isRangeInBloomFilter(range, PartialKey.ROW_COLFAM)) {
+    if (RowFunctor.isRangeInBloomFilter(range, kDepth)) {
       return transform(range.getStartKey());
     }
     return null;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/BCFile.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/BCFile.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/BCFile.java
index ecc0b90..91d61e1 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/BCFile.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/BCFile.java
@@ -37,8 +37,6 @@ import org.apache.accumulo.core.conf.Property;
 import org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile;
 import org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead;
 import org.apache.accumulo.core.file.rfile.bcfile.CompareUtils.Scalar;
-import org.apache.accumulo.core.file.rfile.bcfile.CompareUtils.ScalarComparator;
-import org.apache.accumulo.core.file.rfile.bcfile.CompareUtils.ScalarLong;
 import org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm;
 import org.apache.accumulo.core.file.rfile.bcfile.Utils.Version;
 import org.apache.accumulo.core.security.crypto.CryptoModule;
@@ -1032,23 +1030,6 @@ public final class BCFile {
       return new BlockReader(rbs);
     }
 
-    /**
-     * Find the smallest Block index whose starting offset is greater than or equal to the specified offset.
-     *
-     * @param offset
-     *          User-specific offset.
-     * @return the index to the data Block if such block exists; or -1 otherwise.
-     */
-    public int getBlockIndexNear(long offset) {
-      ArrayList<BlockRegion> list = dataIndex.getBlockRegionList();
-      int idx = Utils.lowerBound(list, new ScalarLong(offset), new ScalarComparator());
-
-      if (idx == list.size()) {
-        return -1;
-      }
-
-      return idx;
-    }
   }
 
   /**

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/CompareUtils.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/CompareUtils.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/CompareUtils.java
index ac0bdb1..0d16cd9 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/CompareUtils.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/CompareUtils.java
@@ -19,9 +19,6 @@ package org.apache.accumulo.core.file.rfile.bcfile;
 import java.io.Serializable;
 import java.util.Comparator;
 
-import org.apache.hadoop.io.RawComparator;
-import org.apache.hadoop.io.WritableComparator;
-
 class CompareUtils {
   /**
    * Prevent the instantiation of class.
@@ -31,26 +28,6 @@ class CompareUtils {
   }
 
   /**
-   * A comparator to compare anything that implements {@link RawComparable} using a customized comparator.
-   */
-  public static final class BytesComparator implements Comparator<RawComparable> {
-    private RawComparator<Object> cmp;
-
-    public BytesComparator(RawComparator<Object> cmp) {
-      this.cmp = cmp;
-    }
-
-    @Override
-    public int compare(RawComparable o1, RawComparable o2) {
-      return compare(o1.buffer(), o1.offset(), o1.size(), o2.buffer(), o2.offset(), o2.size());
-    }
-
-    public int compare(byte[] a, int off1, int len1, byte[] b, int off2, int len2) {
-      return cmp.compare(a, off1, len1, b, off2, len2);
-    }
-  }
-
-  /**
    * Interface for all objects that has a single integer magnitude.
    */
   interface Scalar {
@@ -84,17 +61,4 @@ class CompareUtils {
     }
   }
 
-  public static final class MemcmpRawComparator implements RawComparator<Object>, Serializable {
-    private static final long serialVersionUID = 1L;
-
-    @Override
-    public int compare(byte[] b1, int s1, int l1, byte[] b2, int s2, int l2) {
-      return WritableComparator.compareBytes(b1, s1, l1, b2, s2, l2);
-    }
-
-    @Override
-    public int compare(Object o1, Object o2) {
-      throw new RuntimeException("Object comparison not supported");
-    }
-  }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Utils.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Utils.java b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Utils.java
index fca120e..6cb04a1 100644
--- a/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Utils.java
+++ b/core/src/main/java/org/apache/accumulo/core/file/rfile/bcfile/Utils.java
@@ -384,86 +384,4 @@ public final class Utils {
     return low;
   }
 
-  /**
-   * Upper bound binary search. Find the index to the first element in the list that compares greater than the input key.
-   *
-   * @param <T>
-   *          Type of the input key.
-   * @param list
-   *          The list
-   * @param key
-   *          The input key.
-   * @param cmp
-   *          Comparator for the key.
-   * @return The index to the desired element if it exists; or list.size() otherwise.
-   */
-  public static <T> int upperBound(List<? extends T> list, T key, Comparator<? super T> cmp) {
-    int low = 0;
-    int high = list.size();
-
-    while (low < high) {
-      int mid = (low + high) >>> 1;
-      T midVal = list.get(mid);
-      int ret = cmp.compare(midVal, key);
-      if (ret <= 0)
-        low = mid + 1;
-      else
-        high = mid;
-    }
-    return low;
-  }
-
-  /**
-   * Lower bound binary search. Find the index to the first element in the list that compares greater than or equal to key.
-   *
-   * @param <T>
-   *          Type of the input key.
-   * @param list
-   *          The list
-   * @param key
-   *          The input key.
-   * @return The index to the desired element if it exists; or list.size() otherwise.
-   */
-  public static <T> int lowerBound(List<? extends Comparable<? super T>> list, T key) {
-    int low = 0;
-    int high = list.size();
-
-    while (low < high) {
-      int mid = (low + high) >>> 1;
-      Comparable<? super T> midVal = list.get(mid);
-      int ret = midVal.compareTo(key);
-      if (ret < 0)
-        low = mid + 1;
-      else
-        high = mid;
-    }
-    return low;
-  }
-
-  /**
-   * Upper bound binary search. Find the index to the first element in the list that compares greater than the input key.
-   *
-   * @param <T>
-   *          Type of the input key.
-   * @param list
-   *          The list
-   * @param key
-   *          The input key.
-   * @return The index to the desired element if it exists; or list.size() otherwise.
-   */
-  public static <T> int upperBound(List<? extends Comparable<? super T>> list, T key) {
-    int low = 0;
-    int high = list.size();
-
-    while (low < high) {
-      int mid = (low + high) >>> 1;
-      Comparable<? super T> midVal = list.get(mid);
-      int ret = midVal.compareTo(key);
-      if (ret <= 0)
-        low = mid + 1;
-      else
-        high = mid;
-    }
-    return low;
-  }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataSchema.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataSchema.java b/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataSchema.java
index 534dd7f..6baae17 100644
--- a/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataSchema.java
+++ b/core/src/main/java/org/apache/accumulo/core/metadata/schema/MetadataSchema.java
@@ -246,20 +246,6 @@ public class MetadataSchema {
     }
 
     /**
-     * Extract the table ID from the colfam (inefficiently if called repeatedly)
-     *
-     * @param k
-     *          Key to extract from
-     * @return The table ID
-     * @see #getTableId(Key,Text)
-     */
-    public static String getTableId(Key k) {
-      Text buff = new Text();
-      getTableId(k, buff);
-      return buff.toString();
-    }
-
-    /**
      * Extract the table ID from the colfam into the given {@link Text}
      *
      * @param k

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/rpc/ThriftUtil.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/rpc/ThriftUtil.java b/core/src/main/java/org/apache/accumulo/core/rpc/ThriftUtil.java
index 0f952c2..1b5c256 100644
--- a/core/src/main/java/org/apache/accumulo/core/rpc/ThriftUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/rpc/ThriftUtil.java
@@ -29,16 +29,10 @@ import javax.net.ssl.SSLSocket;
 import javax.net.ssl.SSLSocketFactory;
 import javax.net.ssl.TrustManagerFactory;
 
-import org.apache.accumulo.core.client.AccumuloException;
-import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.impl.ClientContext;
-import org.apache.accumulo.core.client.impl.ClientExec;
-import org.apache.accumulo.core.client.impl.ClientExecReturn;
 import org.apache.accumulo.core.client.impl.ThriftTransportPool;
-import org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.rpc.SaslConnectionParams.SaslMechanism;
 import org.apache.accumulo.core.tabletserver.thrift.TabletClientService;
-import org.apache.accumulo.core.util.UtilWaitThread;
 import org.apache.hadoop.security.UserGroupInformation;
 import org.apache.thrift.TException;
 import org.apache.thrift.TServiceClient;
@@ -181,70 +175,6 @@ public class ThriftUtil {
   }
 
   /**
-   * Execute the provided closure against a TabletServer at the given address. If a Thrift transport exception occurs, the operation will be automatically
-   * retried.
-   *
-   * @param address
-   *          TabletServer address
-   * @param context
-   *          RPC options
-   * @param exec
-   *          The closure to execute
-   */
-  public static void execute(HostAndPort address, ClientContext context, ClientExec<TabletClientService.Client> exec) throws AccumuloException,
-      AccumuloSecurityException {
-    while (true) {
-      TabletClientService.Client client = null;
-      try {
-        exec.execute(client = getTServerClient(address, context));
-        break;
-      } catch (TTransportException tte) {
-        log.debug("getTServerClient request failed, retrying ... ", tte);
-        UtilWaitThread.sleep(100);
-      } catch (ThriftSecurityException e) {
-        throw new AccumuloSecurityException(e.user, e.code, e);
-      } catch (Exception e) {
-        throw new AccumuloException(e);
-      } finally {
-        if (client != null)
-          returnClient(client);
-      }
-    }
-  }
-
-  /**
-   * Execute the provided closure against the TabletServer at the given address, and return the result of the closure to the client. If a Thrift transport
-   * exception occurs, the operation will be automatically retried.
-   *
-   * @param address
-   *          TabletServer address
-   * @param context
-   *          RPC options
-   * @param exec
-   *          Closure with a return value to execute
-   * @return The result from the closure
-   */
-  public static <T> T execute(HostAndPort address, ClientContext context, ClientExecReturn<T,TabletClientService.Client> exec) throws AccumuloException,
-      AccumuloSecurityException {
-    while (true) {
-      TabletClientService.Client client = null;
-      try {
-        return exec.execute(client = getTServerClient(address, context));
-      } catch (TTransportException tte) {
-        log.debug("getTServerClient request failed, retrying ... ", tte);
-        UtilWaitThread.sleep(100);
-      } catch (ThriftSecurityException e) {
-        throw new AccumuloSecurityException(e.user, e.code, e);
-      } catch (Exception e) {
-        throw new AccumuloException(e);
-      } finally {
-        if (client != null)
-          returnClient(client);
-      }
-    }
-  }
-
-  /**
    * Create a transport that is not pooled
    *
    * @param address

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/util/AddressUtil.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/AddressUtil.java b/core/src/main/java/org/apache/accumulo/core/util/AddressUtil.java
index 1426239..4a0d32b 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/AddressUtil.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/AddressUtil.java
@@ -20,10 +20,6 @@ import com.google.common.net.HostAndPort;
 
 public class AddressUtil extends org.apache.accumulo.fate.util.AddressUtil {
 
-  static public HostAndPort parseAddress(String address) throws NumberFormatException {
-    return parseAddress(address, false);
-  }
-
   static public HostAndPort parseAddress(String address, boolean ignoreMissingPort) throws NumberFormatException {
     address = address.replace('+', ':');
     HostAndPort hap = HostAndPort.fromString(address);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/util/ByteArraySet.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/ByteArraySet.java b/core/src/main/java/org/apache/accumulo/core/util/ByteArraySet.java
index ca43469..bf177fd 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/ByteArraySet.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/ByteArraySet.java
@@ -48,8 +48,4 @@ public class ByteArraySet extends TreeSet<byte[]> {
     return ByteArraySet.fromStrings(Arrays.asList(c));
   }
 
-  public List<byte[]> toList() {
-    return new ArrayList<byte[]>(this);
-  }
-
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/util/Daemon.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/Daemon.java b/core/src/main/java/org/apache/accumulo/core/util/Daemon.java
index a2c9e79..34d95ab 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/Daemon.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/Daemon.java
@@ -32,29 +32,9 @@ public class Daemon extends Thread {
     setDaemon(true);
   }
 
-  public Daemon(ThreadGroup group, Runnable target) {
-    super(group, target);
-    setDaemon(true);
-  }
-
-  public Daemon(ThreadGroup group, String name) {
-    super(group, name);
-    setDaemon(true);
-  }
-
   public Daemon(Runnable target, String name) {
     super(target, name);
     setDaemon(true);
   }
 
-  public Daemon(ThreadGroup group, Runnable target, String name) {
-    super(group, target, name);
-    setDaemon(true);
-  }
-
-  public Daemon(ThreadGroup group, Runnable target, String name, long stackSize) {
-    super(group, target, name, stackSize);
-    setDaemon(true);
-  }
-
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/util/MapCounter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/MapCounter.java b/core/src/main/java/org/apache/accumulo/core/util/MapCounter.java
index f6f3ff7..4372cfc 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/MapCounter.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/MapCounter.java
@@ -53,10 +53,6 @@ public class MapCounter<KT> {
     return increment(key, -1 * l);
   }
 
-  public boolean contains(KT key) {
-    return map.containsKey(key);
-  }
-
   public long get(KT key) {
     MutableLong ml = map.get(key);
     if (ml == null) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/util/StopWatch.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/StopWatch.java b/core/src/main/java/org/apache/accumulo/core/util/StopWatch.java
index ddb612f..8abe19e 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/StopWatch.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/StopWatch.java
@@ -34,11 +34,6 @@ public class StopWatch<K extends Enum<K>> {
     startTime.put(timer, System.currentTimeMillis());
   }
 
-  public synchronized void stopIfActive(K timer) {
-    if (startTime.containsKey(timer))
-      stop(timer);
-  }
-
   public synchronized void stop(K timer) {
 
     Long st = startTime.get(timer);
@@ -55,10 +50,6 @@ public class StopWatch<K extends Enum<K>> {
     startTime.remove(timer);
   }
 
-  public synchronized void reset(K timer) {
-    totalTime.remove(timer);
-  }
-
   public synchronized long get(K timer) {
     Long existingTime = totalTime.get(timer);
     if (existingTime == null)
@@ -73,10 +64,4 @@ public class StopWatch<K extends Enum<K>> {
     return existingTime / 1000.0;
   }
 
-  public synchronized void print() {
-    for (K timer : totalTime.keySet()) {
-      System.out.printf("%20s : %,6.4f secs%n", timer.toString(), get(timer) / 1000.0);
-    }
-  }
-
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/core/src/main/java/org/apache/accumulo/core/volume/VolumeConfiguration.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/volume/VolumeConfiguration.java b/core/src/main/java/org/apache/accumulo/core/volume/VolumeConfiguration.java
index 99032ad..01fa0f9 100644
--- a/core/src/main/java/org/apache/accumulo/core/volume/VolumeConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/volume/VolumeConfiguration.java
@@ -150,11 +150,6 @@ public class VolumeConfiguration {
     return new VolumeImpl(fs, basePath);
   }
 
-  public static Volume create(String path, Configuration conf) throws IOException {
-    Preconditions.checkNotNull(path);
-    return create(new Path(path), conf);
-  }
-
   public static Volume create(Path path, Configuration conf) throws IOException {
     return new VolumeImpl(path, conf);
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/examples/simple/src/main/java/org/apache/accumulo/examples/simple/mapreduce/TeraSortIngest.java
----------------------------------------------------------------------
diff --git a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/mapreduce/TeraSortIngest.java b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/mapreduce/TeraSortIngest.java
index 9aac75e..b535513 100644
--- a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/mapreduce/TeraSortIngest.java
+++ b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/mapreduce/TeraSortIngest.java
@@ -115,8 +115,6 @@ public class TeraSortIngest extends Configured implements Tool {
       long finishedRows;
       long totalRows;
 
-      LongWritable currentKey;
-
       public RangeRecordReader(RangeInputSplit split) {
         startRow = split.firstRow;
         finishedRows = 0;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooCache.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooCache.java b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooCache.java
index 1fade84..5a4fb11 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooCache.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooCache.java
@@ -387,13 +387,4 @@ public class ZooCache {
     }
   }
 
-  private static ZooCacheFactory zcf = new ZooCacheFactory();
-
-  /**
-   * @deprecated Use {@link ZooCacheFactory} instead.
-   */
-  @Deprecated
-  public static synchronized ZooCache getInstance(String zooKeepers, int sessionTimeout) {
-    return zcf.getZooCache(zooKeepers, sessionTimeout);
-  }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooLock.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooLock.java b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooLock.java
index 11da1ec..992a444 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooLock.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooLock.java
@@ -396,24 +396,6 @@ public class ZooLock implements Watcher {
 
   }
 
-  public static boolean isLockHeld(ZooKeeper zk, LockID lid) throws KeeperException, InterruptedException {
-
-    List<String> children = zk.getChildren(lid.path, false);
-
-    if (children == null || children.size() == 0) {
-      return false;
-    }
-
-    Collections.sort(children);
-
-    String lockNode = children.get(0);
-    if (!lid.node.equals(lockNode))
-      return false;
-
-    Stat stat = zk.exists(lid.path + "/" + lid.node, false);
-    return stat != null && stat.getEphemeralOwner() == lid.eid;
-  }
-
   public static boolean isLockHeld(ZooCache zc, LockID lid) {
 
     List<String> children = zc.getChildren(lid.path);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooQueueLock.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooQueueLock.java b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooQueueLock.java
index f9195f3..1b22dc9 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooQueueLock.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooQueueLock.java
@@ -32,17 +32,10 @@ public class ZooQueueLock implements QueueLock {
 
   private static final String PREFIX = "lock-";
 
-  // private static final Logger log = Logger.getLogger(ZooQueueLock.class);
-
   private IZooReaderWriter zoo;
   private String path;
   private boolean ephemeral;
 
-  public ZooQueueLock(String zookeepers, int timeInMillis, String scheme, byte[] auth, String path, boolean ephemeral) throws KeeperException,
-      InterruptedException {
-    this(ZooReaderWriter.getInstance(zookeepers, timeInMillis, scheme, auth), path, ephemeral);
-  }
-
   protected ZooQueueLock(IZooReaderWriter zrw, String path, boolean ephemeral) {
     this.zoo = zrw;
     this.path = path;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooSession.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooSession.java b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooSession.java
index 811f035..837785f 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooSession.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooSession.java
@@ -140,10 +140,6 @@ public class ZooSession {
     return zooKeeper;
   }
 
-  public static synchronized ZooKeeper getSession(String zooKeepers, int timeout) {
-    return getSession(zooKeepers, timeout, null, null);
-  }
-
   public static synchronized ZooKeeper getSession(String zooKeepers, int timeout, String scheme, byte[] auth) {
 
     if (sessions == null)

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
----------------------------------------------------------------------
diff --git a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
index 2df1c5d..b1b59f2 100644
--- a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
+++ b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
@@ -106,6 +106,7 @@ import org.apache.zookeeper.data.Stat;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+import com.google.common.annotations.VisibleForTesting;
 import com.google.common.base.Joiner;
 import com.google.common.base.Predicate;
 import com.google.common.collect.Maps;
@@ -714,16 +715,6 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
     return config;
   }
 
-  /**
-   * Utility method to get a connector to the MAC.
-   *
-   * @since 1.6.0
-   */
-  @Deprecated
-  public Connector getConnector(String user, String passwd) throws AccumuloException, AccumuloSecurityException {
-    return getConnector(user, new PasswordToken(passwd));
-  }
-
   @Override
   public Connector getConnector(String user, AuthenticationToken token) throws AccumuloException, AccumuloSecurityException {
     Instance instance = new ZooKeeperInstance(getClientConfig());
@@ -745,12 +736,12 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
     }
   }
 
-  // Visible for testing
+  @VisibleForTesting
   protected void setShutdownExecutor(ExecutorService svc) {
     this.executor = svc;
   }
 
-  // Visible for testing
+  @VisibleForTesting
   protected ExecutorService getShutdownExecutor() {
     return executor;
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/ZooKeeperBindException.java
----------------------------------------------------------------------
diff --git a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/ZooKeeperBindException.java b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/ZooKeeperBindException.java
index 50217ce..4e69861 100644
--- a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/ZooKeeperBindException.java
+++ b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/ZooKeeperBindException.java
@@ -29,12 +29,4 @@ public class ZooKeeperBindException extends RuntimeException {
     super(message);
   }
 
-  public ZooKeeperBindException(Throwable cause) {
-    super(cause);
-  }
-
-  public ZooKeeperBindException(String message, Throwable cause) {
-    super(message, cause);
-  }
-
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/ServerConstants.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/ServerConstants.java b/server/base/src/main/java/org/apache/accumulo/server/ServerConstants.java
index 9d969d1..0ce2b47 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/ServerConstants.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/ServerConstants.java
@@ -156,10 +156,6 @@ public class ServerConstants {
     return VolumeConfiguration.prefix(getBaseUris(), WALOG_ARCHIVE_DIR);
   }
 
-  public static String[] getFileArchives() {
-    return VolumeConfiguration.prefix(getBaseUris(), FILE_ARCHIVE_DIR);
-  }
-
   public static Path getInstanceIdLocation(Volume v) {
     // all base dirs should have the same instance id, so can choose any one
     return v.prefixChild(INSTANCE_ID_DIR);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/client/BulkImporter.java
----------------------------------------------------------------------
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 33fbe82..747e224 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
@@ -700,15 +700,6 @@ public class BulkImporter {
       this.completeFailures = completeFailures;
     }
 
-    void tabletSplit(KeyExtent parent, Collection<KeyExtent> children) {
-      Integer count = getCount(parent);
-
-      counts.remove(parent);
-
-      for (KeyExtent keyExtent : children)
-        counts.put(keyExtent, count);
-    }
-
     private Integer getCount(KeyExtent parent) {
       Integer count = counts.get(parent);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/conf/NamespaceConfWatcher.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/conf/NamespaceConfWatcher.java b/server/base/src/main/java/org/apache/accumulo/server/conf/NamespaceConfWatcher.java
index 945e904..71cc0a2 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/conf/NamespaceConfWatcher.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/conf/NamespaceConfWatcher.java
@@ -43,10 +43,6 @@ class NamespaceConfWatcher implements Watcher {
     scf = new ServerConfigurationFactory(instance);
   }
 
-  void setServerConfigurationFactory(ServerConfigurationFactory scf) {
-    this.scf = scf;
-  }
-
   static String toString(WatchedEvent event) {
     return new StringBuilder("{path=").append(event.getPath()).append(",state=").append(event.getState()).append(",type=").append(event.getType()).append("}")
         .toString();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/conf/TableConfWatcher.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/conf/TableConfWatcher.java b/server/base/src/main/java/org/apache/accumulo/server/conf/TableConfWatcher.java
index 3c8d45d..2c1c9a5 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/conf/TableConfWatcher.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/conf/TableConfWatcher.java
@@ -41,10 +41,6 @@ class TableConfWatcher implements Watcher {
     scf = new ServerConfigurationFactory(instance);
   }
 
-  void setServerConfigurationFactory(ServerConfigurationFactory scf) {
-    this.scf = scf;
-  }
-
   static String toString(WatchedEvent event) {
     return new StringBuilder("{path=").append(event.getPath()).append(",state=").append(event.getState()).append(",type=").append(event.getType()).append("}")
         .toString();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/conf/TableParentConfiguration.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/conf/TableParentConfiguration.java b/server/base/src/main/java/org/apache/accumulo/server/conf/TableParentConfiguration.java
index bd2e5ab..26fee7c 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/conf/TableParentConfiguration.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/conf/TableParentConfiguration.java
@@ -27,22 +27,12 @@ public class TableParentConfiguration extends NamespaceConfiguration {
 
   private String tableId;
 
-  public TableParentConfiguration(String tableId, AccumuloConfiguration parent) {
-    super(null, parent);
-    this.tableId = tableId;
-    this.namespaceId = getNamespaceId();
-  }
-
   public TableParentConfiguration(String tableId, Instance inst, AccumuloConfiguration parent) {
     super(null, inst, parent);
     this.tableId = tableId;
     this.namespaceId = getNamespaceId();
   }
 
-  String getTableId() {
-    return tableId;
-  }
-
   @Override
   protected String getNamespaceId() {
     return Tables.getNamespaceId(inst, tableId);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/conf/ZooConfigurationFactory.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/conf/ZooConfigurationFactory.java b/server/base/src/main/java/org/apache/accumulo/server/conf/ZooConfigurationFactory.java
index 4fbb645..6c8ceca 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/conf/ZooConfigurationFactory.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/conf/ZooConfigurationFactory.java
@@ -82,17 +82,6 @@ class ZooConfigurationFactory {
   }
 
   /**
-   * Gets a configuration object with the given parent. A default instance is used. Repeated calls will return the same object.
-   *
-   * @param parent
-   *          parent configuration (required)
-   * @return configuration
-   */
-  public ZooConfiguration getInstance(AccumuloConfiguration parent) {
-    return getInstance(null, parent);
-  }
-
-  /**
    * Gets a configuration object for the given instance with the given parent. Repeated calls will return the same object.
    *
    * @param inst

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/log/SortedLogState.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/log/SortedLogState.java b/server/base/src/main/java/org/apache/accumulo/server/log/SortedLogState.java
index c0580ac..1ce4840 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/log/SortedLogState.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/log/SortedLogState.java
@@ -39,10 +39,6 @@ public enum SortedLogState {
     return FINISHED.getMarker().equals(fileName);
   }
 
-  public static boolean isFailed(String fileName) {
-    return FAILED.getMarker().equals(fileName);
-  }
-
   public static Path getFinishedMarkerPath(String rootPath) {
     return new Path(rootPath, FINISHED.getMarker());
   }
@@ -55,10 +51,6 @@ public enum SortedLogState {
     return new Path(rootPath, FAILED.getMarker());
   }
 
-  public static Path getFailedMarkerPath(Path rootPath) {
-    return new Path(rootPath, FAILED.getMarker());
-  }
-
   @Override
   public String toString() {
     return marker;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/master/LiveTServerSet.java
----------------------------------------------------------------------
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 13cd0a1..cad9bb7 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
@@ -176,15 +176,6 @@ public class LiveTServerSet implements Watcher {
       }
     }
 
-    public void flushTablet(ZooLock lock, KeyExtent extent) throws TException {
-      TabletClientService.Client client = ThriftUtil.getClient(new TabletClientService.Client.Factory(), address, context);
-      try {
-        client.flushTablet(Tracer.traceInfo(), context.rpcCreds(), lockString(lock), extent.toThrift());
-      } finally {
-        ThriftUtil.returnClient(client);
-      }
-    }
-
     public void compact(ZooLock lock, String tableId, byte[] startRow, byte[] endRow) throws TException {
       TabletClientService.Client client = ThriftUtil.getClient(new TabletClientService.Client.Factory(), address, context);
       try {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/master/state/DistributedStoreException.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/master/state/DistributedStoreException.java b/server/base/src/main/java/org/apache/accumulo/server/master/state/DistributedStoreException.java
index 3290075..85cddc1 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/master/state/DistributedStoreException.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/master/state/DistributedStoreException.java
@@ -28,7 +28,4 @@ public class DistributedStoreException extends Exception {
     super(cause);
   }
 
-  public DistributedStoreException(String why, Exception cause) {
-    super(why, cause);
-  }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/master/state/TServerInstance.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/master/state/TServerInstance.java b/server/base/src/main/java/org/apache/accumulo/server/master/state/TServerInstance.java
index c0c71e6..d2d4f44 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/master/state/TServerInstance.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/master/state/TServerInstance.java
@@ -112,10 +112,6 @@ public class TServerInstance implements Comparable<TServerInstance>, Serializabl
     return cachedStringRepresentation;
   }
 
-  public int port() {
-    return getLocation().getPort();
-  }
-
   public String host() {
     return getLocation().getHostText();
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/master/state/TabletServerState.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/master/state/TabletServerState.java b/server/base/src/main/java/org/apache/accumulo/server/master/state/TabletServerState.java
index dde9807..942eabf 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/master/state/TabletServerState.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/master/state/TabletServerState.java
@@ -16,10 +16,8 @@
  */
 package org.apache.accumulo.server.master.state;
 
-import java.util.Collections;
 import java.util.HashMap;
 import java.util.HashSet;
-import java.util.Set;
 
 public enum TabletServerState {
   // not a valid state, reserved for internal use only
@@ -70,7 +68,4 @@ public enum TabletServerState {
     throw new IndexOutOfBoundsException("No such state");
   }
 
-  public static Set<TabletServerState> getBadStates() {
-    return Collections.unmodifiableSet(badStates);
-  }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/metrics/AbstractMetricsImpl.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/metrics/AbstractMetricsImpl.java b/server/base/src/main/java/org/apache/accumulo/server/metrics/AbstractMetricsImpl.java
index 39d5602..42d2d00 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/metrics/AbstractMetricsImpl.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/metrics/AbstractMetricsImpl.java
@@ -148,10 +148,6 @@ public abstract class AbstractMetricsImpl implements Metrics {
     registry.put(name, new Metric());
   }
 
-  public Metric getMetric(String name) {
-    return registry.get(name);
-  }
-
   public long getMetricCount(String name) {
     return registry.get(name).getCount();
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/metrics/MetricsConfiguration.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/metrics/MetricsConfiguration.java b/server/base/src/main/java/org/apache/accumulo/server/metrics/MetricsConfiguration.java
index 8d11243..d772048 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/metrics/MetricsConfiguration.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/metrics/MetricsConfiguration.java
@@ -17,7 +17,6 @@
 package org.apache.accumulo.server.metrics;
 
 import java.io.File;
-import java.util.Iterator;
 
 import org.apache.accumulo.core.util.Daemon;
 import org.apache.commons.configuration.AbstractFileConfiguration;
@@ -29,7 +28,6 @@ import org.apache.commons.configuration.XMLConfiguration;
 import org.apache.commons.configuration.event.ConfigurationEvent;
 import org.apache.commons.configuration.event.ConfigurationListener;
 import org.apache.commons.configuration.reloading.FileChangedReloadingStrategy;
-import org.apache.commons.lang.builder.ToStringBuilder;
 
 public class MetricsConfiguration {
 
@@ -210,26 +208,10 @@ public class MetricsConfiguration {
     return enabled;
   }
 
-  public static String toStringValue(Configuration config) {
-    ToStringBuilder tsb = new ToStringBuilder(MetricsConfiguration.class);
-    Iterator<?> keys = config.getKeys();
-    while (keys.hasNext()) {
-      tsb.append("\n");
-      String k = (String) keys.next();
-      Object v = config.getString(k);
-      if (null == v)
-        v = config.getList(k);
-      tsb.append(k, v.toString());
-    }
-    return tsb.toString();
-  }
-
   public static void main(String[] args) throws Exception {
     MetricsConfiguration mc = new MetricsConfiguration("master");
     while (true) {
-      // System.out.println(MetricsConfiguration.toStringValue(getSystemConfiguration()));
       System.out.println("------------------------------------------------------------------------------------------------");
-      // System.out.println(MetricsConfiguration.toStringValue());
       long t1 = System.currentTimeMillis();
       System.out.println(mc.isEnabled() + " took: " + (System.currentTimeMillis() - t1));
       Thread.sleep(1000);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/replication/StatusFormatter.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/replication/StatusFormatter.java b/server/base/src/main/java/org/apache/accumulo/server/replication/StatusFormatter.java
index cee30bc..a674802 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/replication/StatusFormatter.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/replication/StatusFormatter.java
@@ -138,11 +138,6 @@ public class StatusFormatter implements Formatter {
     return appendBytes(sb, t.getBytes(), 0, t.getLength());
   }
 
-  protected String getValue(Value v) {
-    StringBuilder sb = new StringBuilder();
-    return appendBytes(sb, v.get(), 0, v.get().length).toString();
-  }
-
   protected StringBuilder appendBytes(StringBuilder sb, byte ba[], int offset, int len) {
     for (int i = 0; i < len; i++) {
       int c = 0xff & ba[offset + i];

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/rpc/TBufferedServerSocket.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/rpc/TBufferedServerSocket.java b/server/base/src/main/java/org/apache/accumulo/server/rpc/TBufferedServerSocket.java
deleted file mode 100644
index 2887f48..0000000
--- a/server/base/src/main/java/org/apache/accumulo/server/rpc/TBufferedServerSocket.java
+++ /dev/null
@@ -1,71 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.accumulo.server.rpc;
-
-import java.io.IOException;
-import java.net.ServerSocket;
-
-import org.apache.accumulo.core.rpc.TBufferedSocket;
-import org.apache.thrift.transport.TServerTransport;
-import org.apache.thrift.transport.TSocket;
-import org.apache.thrift.transport.TTransport;
-import org.apache.thrift.transport.TTransportException;
-
-// Thrift-959 removed the small buffer from TSocket; this adds it back for servers
-public class TBufferedServerSocket extends TServerTransport {
-
-  // expose acceptImpl
-  static class TServerSocket extends org.apache.thrift.transport.TServerSocket {
-    public TServerSocket(ServerSocket serverSocket) {
-      super(serverSocket);
-    }
-
-    public TSocket acceptImplPublic() throws TTransportException {
-      return acceptImpl();
-    }
-  }
-
-  final TServerSocket impl;
-  final int bufferSize;
-
-  public TBufferedServerSocket(ServerSocket serverSocket, int bufferSize) {
-    this.impl = new TServerSocket(serverSocket);
-    this.bufferSize = bufferSize;
-  }
-
-  @Override
-  public void listen() throws TTransportException {
-    impl.listen();
-  }
-
-  @Override
-  public void close() {
-    impl.close();
-  }
-
-  // Wrap accepted sockets using buffered IO
-  @Override
-  protected TTransport acceptImpl() throws TTransportException {
-    TSocket sock = impl.acceptImplPublic();
-    try {
-      return new TBufferedSocket(sock, this.bufferSize);
-    } catch (IOException e) {
-      throw new TTransportException(e);
-    }
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/rpc/TNonblockingServerSocket.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/rpc/TNonblockingServerSocket.java b/server/base/src/main/java/org/apache/accumulo/server/rpc/TNonblockingServerSocket.java
index c0bcdb7..a6dc6ab 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/rpc/TNonblockingServerSocket.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/rpc/TNonblockingServerSocket.java
@@ -62,13 +62,6 @@ public class TNonblockingServerSocket extends TNonblockingServerTransport {
   /**
    * Creates just a port listening server socket
    */
-  public TNonblockingServerSocket(int port) throws TTransportException {
-    this(port, 0);
-  }
-
-  /**
-   * Creates just a port listening server socket
-   */
   public TNonblockingServerSocket(int port, int clientTimeout) throws TTransportException {
     this(new InetSocketAddress(port), clientTimeout);
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/security/SecurityOperation.java
----------------------------------------------------------------------
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 f08742d..d7bee31 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
@@ -79,10 +79,6 @@ public class SecurityOperation {
 
   static SecurityOperation instance;
 
-  public static synchronized SecurityOperation getInstance(AccumuloServerContext context) {
-    return getInstance(context, false);
-  }
-
   public static synchronized SecurityOperation getInstance(AccumuloServerContext context, boolean initialize) {
     if (instance == null) {
       String instanceId = context.getInstance().getInstanceID();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthorizor.java
----------------------------------------------------------------------
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 b047f1a..bd48440 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
@@ -32,14 +32,6 @@ import org.apache.accumulo.core.util.Base64;
  */
 public class KerberosAuthorizor implements Authorizor {
 
-  private static KerberosAuthorizor INST;
-
-  public static synchronized KerberosAuthorizor getInstance() {
-    if (INST == null)
-      INST = new KerberosAuthorizor();
-    return INST;
-  }
-
   private final ZKAuthorizor zkAuthorizor;
 
   public KerberosAuthorizor() {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosPermissionHandler.java
----------------------------------------------------------------------
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 691c555..7de48a6 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
@@ -33,14 +33,6 @@ import org.apache.accumulo.core.util.Base64;
  */
 public class KerberosPermissionHandler implements PermissionHandler {
 
-  private static KerberosPermissionHandler INST;
-
-  public static synchronized KerberosPermissionHandler getInstance() {
-    if (INST == null)
-      INST = new KerberosPermissionHandler();
-    return INST;
-  }
-
   private final ZKPermHandler zkPermissionHandler;
 
   public KerberosPermissionHandler() {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/tables/TableManager.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/tables/TableManager.java b/server/base/src/main/java/org/apache/accumulo/server/tables/TableManager.java
index 293aaf8..0b23061 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/tables/TableManager.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/tables/TableManager.java
@@ -239,10 +239,6 @@ public class TableManager {
     }
   }
 
-  public boolean removeObserver(TableObserver to) {
-    return observers.remove(to);
-  }
-
   private class TableStateWatcher implements Watcher {
     @Override
     public void process(WatchedEvent event) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/util/AccumuloStatus.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/AccumuloStatus.java b/server/base/src/main/java/org/apache/accumulo/server/util/AccumuloStatus.java
index 1e75124..5d95d68 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/AccumuloStatus.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/AccumuloStatus.java
@@ -19,9 +19,7 @@ package org.apache.accumulo.server.util;
 import java.io.IOException;
 
 import org.apache.accumulo.core.Constants;
-import org.apache.accumulo.core.zookeeper.ZooUtil;
 import org.apache.accumulo.fate.zookeeper.IZooReader;
-import org.apache.accumulo.server.client.HdfsZooInstance;
 import org.apache.zookeeper.KeeperException;
 
 public class AccumuloStatus {
@@ -32,18 +30,6 @@ public class AccumuloStatus {
    * @throws IOException
    *           if there are issues connecting to ZooKeeper to determine service status
    */
-  public static boolean isAccumuloOffline(IZooReader reader) throws IOException {
-    String rootPath = ZooUtil.getRoot(HdfsZooInstance.getInstance());
-    return isAccumuloOffline(reader, rootPath);
-  }
-
-  /**
-   * Determines if there could be an accumulo instance running via zookeeper lock checking
-   *
-   * @return true iff all servers show no indication of being registered in zookeeper, otherwise false
-   * @throws IOException
-   *           if there are issues connecting to ZooKeeper to determine service status
-   */
   public static boolean isAccumuloOffline(IZooReader reader, String rootPath) throws IOException {
     try {
       for (String child : reader.getChildren(rootPath + Constants.ZTSERVERS)) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/a194c0b0/server/base/src/main/java/org/apache/accumulo/server/util/CleanZookeeper.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/util/CleanZookeeper.java b/server/base/src/main/java/org/apache/accumulo/server/util/CleanZookeeper.java
index afe7f6f..b3ca6dd 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/util/CleanZookeeper.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/util/CleanZookeeper.java
@@ -37,9 +37,6 @@ public class CleanZookeeper {
   private static final Logger log = LoggerFactory.getLogger(CleanZookeeper.class);
 
   static class Opts extends Help {
-    @Parameter(names = {"-z", "--keepers"},
-        description = "Comma-separated list of zookeeper hosts, if different than instance.zookeeper.host in accumulo-site.xml")
-    String keepers = "localhost:2181";
     @Parameter(names = {"--password"}, description = "The system secret, if different than instance.secret in accumulo-site.xml", password = true)
     String auth;
   }