You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by ec...@apache.org on 2013/07/22 20:25:04 UTC

[1/5] git commit: ACCUMULO-1595 remove code to lock jvm to ram

Updated Branches:
  refs/heads/master a943f323b -> 1a48f7c34


ACCUMULO-1595 remove code to lock jvm to ram


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

Branch: refs/heads/master
Commit: b3f1155962ead8af40b63c83103120ca0b82b3f2
Parents: a943f32
Author: Eric Newton <ec...@apache.org>
Authored: Mon Jul 22 13:07:54 2013 -0400
Committer: Eric Newton <ec...@apache.org>
Committed: Mon Jul 22 13:07:54 2013 -0400

----------------------------------------------------------------------
 .../accumulo/server/tabletserver/TabletServer.java   | 15 ---------------
 1 file changed, 15 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/b3f11559/server/src/main/java/org/apache/accumulo/server/tabletserver/TabletServer.java
----------------------------------------------------------------------
diff --git a/server/src/main/java/org/apache/accumulo/server/tabletserver/TabletServer.java b/server/src/main/java/org/apache/accumulo/server/tabletserver/TabletServer.java
index ceed0ee..d83102d 100644
--- a/server/src/main/java/org/apache/accumulo/server/tabletserver/TabletServer.java
+++ b/server/src/main/java/org/apache/accumulo/server/tabletserver/TabletServer.java
@@ -3036,21 +3036,6 @@ public class TabletServer extends AbstractMetricsImpl implements org.apache.accu
     clientAddress = new InetSocketAddress(hostname, 0);
     logger = new TabletServerLogger(this, getSystemConfiguration().getMemoryInBytes(Property.TSERV_WALOG_MAX_SIZE));
     
-    if (getSystemConfiguration().getBoolean(Property.TSERV_LOCK_MEMORY)) {
-      String path = "lib/native/mlock/" + System.mapLibraryName("MLock-" + Platform.getPlatform());
-      path = new File(path).getAbsolutePath();
-      try {
-        System.load(path);
-        log.info("Trying to lock memory pages to RAM");
-        if (MLock.lockMemoryPages() < 0)
-          log.error("Failed to lock memory pages to RAM");
-        else
-          log.info("Memory pages are now locked into RAM");
-      } catch (Throwable t) {
-        log.error("Failed to load native library for locking pages to RAM " + path + " (" + t + ")", t);
-      }
-    }
-    
     try {
       AccumuloVFSClassLoader.getContextManager().setContextConfig(new ContextManager.DefaultContextsConfig(new Iterable<Entry<String,String>>() {
         @Override


[5/5] git commit: ACCUMULO-1586 committing Michael Berman's patch

Posted by ec...@apache.org.
ACCUMULO-1586 committing Michael Berman's patch


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

Branch: refs/heads/master
Commit: 1a48f7c34da98f4ba1fe3fac133081ee5f35caca
Parents: 8545123
Author: Eric Newton <ec...@apache.org>
Authored: Mon Jul 22 14:20:49 2013 -0400
Committer: Eric Newton <ec...@apache.org>
Committed: Mon Jul 22 14:20:49 2013 -0400

----------------------------------------------------------------------
 .../accumulo/server/metrics/AbstractMetricsImpl.java     |  1 -
 .../org/apache/accumulo/server/util/TServerUtils.java    | 11 ++++++++---
 2 files changed, 8 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/1a48f7c3/server/src/main/java/org/apache/accumulo/server/metrics/AbstractMetricsImpl.java
----------------------------------------------------------------------
diff --git a/server/src/main/java/org/apache/accumulo/server/metrics/AbstractMetricsImpl.java b/server/src/main/java/org/apache/accumulo/server/metrics/AbstractMetricsImpl.java
index a047507..9735371 100644
--- a/server/src/main/java/org/apache/accumulo/server/metrics/AbstractMetricsImpl.java
+++ b/server/src/main/java/org/apache/accumulo/server/metrics/AbstractMetricsImpl.java
@@ -138,7 +138,6 @@ public abstract class AbstractMetricsImpl {
     if (null == getObjectName())
       throw new IllegalArgumentException("MBean object name must be set.");
     mbs.registerMBean(this, getObjectName());
-    
     setupLogging();
   }
   

http://git-wip-us.apache.org/repos/asf/accumulo/blob/1a48f7c3/server/src/main/java/org/apache/accumulo/server/util/TServerUtils.java
----------------------------------------------------------------------
diff --git a/server/src/main/java/org/apache/accumulo/server/util/TServerUtils.java b/server/src/main/java/org/apache/accumulo/server/util/TServerUtils.java
index be14023..0c751f5 100644
--- a/server/src/main/java/org/apache/accumulo/server/util/TServerUtils.java
+++ b/server/src/main/java/org/apache/accumulo/server/util/TServerUtils.java
@@ -101,6 +101,8 @@ public class TServerUtils {
     boolean portSearch = false;
     if (portSearchProperty != null)
       portSearch = conf.getBoolean(portSearchProperty);
+    // create the TimedProcessor outside the port search loop so we don't try to register the same metrics mbean more than once
+    TServerUtils.TimedProcessor timedProcessor = new TServerUtils.TimedProcessor(processor, serverName, threadName);
     Random random = new Random();
     for (int j = 0; j < 100; j++) {
       
@@ -116,7 +118,7 @@ public class TServerUtils {
         if (port > 65535)
           port = 1024 + port % (65535 - 1024);
         try {
-          return TServerUtils.startTServer(port, processor, serverName, threadName, minThreads, timeBetweenThreadChecks, maxMessageSize);
+          return TServerUtils.startTServer(port, timedProcessor, serverName, threadName, minThreads, timeBetweenThreadChecks, maxMessageSize);
         } catch (Exception ex) {
           log.info("Unable to use port " + port + ", retrying. (Thread Name = " + threadName + ")");
           UtilWaitThread.sleep(250);
@@ -246,7 +248,6 @@ public class TServerUtils {
       }
     }, timeBetweenThreadChecks, timeBetweenThreadChecks);
     options.executorService(pool);
-    processor = new TServerUtils.TimedProcessor(processor, serverName, threadName);
     options.processorFactory(new TProcessorFactory(processor));
     return new ServerPort(new THsHaServer(options), port);
   }
@@ -268,13 +269,17 @@ public class TServerUtils {
     TThreadPoolServer.Args options = new TThreadPoolServer.Args(transport);
     options.protocolFactory(ThriftUtil.protocolFactory());
     options.transportFactory(ThriftUtil.transportFactory());
-    processor = new TServerUtils.TimedProcessor(processor, serverName, threadName);
     options.processorFactory(new ClientInfoProcessorFactory(processor));
     return new ServerPort(new TThreadPoolServer(options), port);
   }
   
   public static ServerPort startTServer(int port, TProcessor processor, String serverName, String threadName, int numThreads, long timeBetweenThreadChecks, long maxMessageSize)
       throws TTransportException {
+    return startTServer(port, new TimedProcessor(processor, serverName, threadName), serverName, threadName, numThreads, timeBetweenThreadChecks, maxMessageSize);
+  }
+  
+  public static ServerPort startTServer(int port, TimedProcessor processor, String serverName, String threadName, int numThreads, long timeBetweenThreadChecks, long maxMessageSize)
+      throws TTransportException {
     ServerPort result = startHsHaServer(port, processor, serverName, threadName, numThreads, timeBetweenThreadChecks, maxMessageSize);
     // ServerPort result = startThreadPoolServer(port, processor, serverName, threadName, -1);
     final TServer finalServer = result.server;


[2/5] git commit: ACCUMULO-1595 remove mlock config entry

Posted by ec...@apache.org.
ACCUMULO-1595 remove mlock config entry


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

Branch: refs/heads/master
Commit: 93f741e7efe761c980eda74b7fb679bd015838f3
Parents: b3f1155
Author: Eric Newton <ec...@apache.org>
Authored: Mon Jul 22 13:10:34 2013 -0400
Committer: Eric Newton <ec...@apache.org>
Committed: Mon Jul 22 13:10:34 2013 -0400

----------------------------------------------------------------------
 core/src/main/java/org/apache/accumulo/core/conf/Property.java | 6 ------
 1 file changed, 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/93f741e7/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 ca86c9a..a28c52b 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
@@ -187,12 +187,6 @@ public enum Property {
       "A long running scan could possibly hold memory that has been minor compacted.  To prevent this, the in memory map is dumped to a local file and the "
           + "scan is switched to that local file.  We can not switch to the minor compacted file because it may have been modified by iterators.  The file "
           + "dumped to the local dir is an exact copy of what was in memory."),
-  TSERV_LOCK_MEMORY("tserver.memory.lock", "false", PropertyType.BOOLEAN,
-      "The tablet server must communicate with zookeeper frequently to maintain its locks.  If the tablet server's memory is swapped out"
-          + " the java garbage collector can stop all processing for long periods.  Change this property to true and the tablet server will "
-          + " attempt to lock all of its memory to RAM, which may reduce delays during java garbage collection.  You will have to modify the "
-          + " system limit for \"max locked memory\". This feature is only available when running on Linux.  Alternatively you may also "
-          + " want to set /proc/sys/vm/swappiness to zero (again, this is Linux-specific)."),
   TSERV_BULK_PROCESS_THREADS("tserver.bulk.process.threads", "1", PropertyType.COUNT,
       "The master will task a tablet server with pre-processing a bulk file prior to assigning it to the appropriate tablet servers.  This configuration"
           + " value controls the number of threads used to process the files."),


[4/5] git commit: ACCUMULO-1596 moved Mutator interface up to IZooReaderWriter

Posted by ec...@apache.org.
ACCUMULO-1596 moved Mutator interface up to IZooReaderWriter


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

Branch: refs/heads/master
Commit: 85451233c6a00352daaf460fb668d02d76bdd953
Parents: 734cd50
Author: Eric Newton <ec...@apache.org>
Authored: Mon Jul 22 13:52:57 2013 -0400
Committer: Eric Newton <ec...@apache.org>
Committed: Mon Jul 22 13:52:57 2013 -0400

----------------------------------------------------------------------
 server/src/main/java/org/apache/accumulo/server/master/Master.java | 2 +-
 .../apache/accumulo/server/master/state/tables/TableManager.java   | 2 +-
 .../apache/accumulo/server/master/tableOps/CancelCompactions.java  | 2 +-
 .../org/apache/accumulo/server/master/tableOps/CompactRange.java   | 2 +-
 .../org/apache/accumulo/server/master/tableOps/RenameTable.java    | 2 +-
 .../java/org/apache/accumulo/server/master/tableOps/Utils.java     | 2 +-
 .../java/org/apache/accumulo/server/tabletserver/TabletServer.java | 2 --
 7 files changed, 6 insertions(+), 8 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/85451233/server/src/main/java/org/apache/accumulo/server/master/Master.java
----------------------------------------------------------------------
diff --git a/server/src/main/java/org/apache/accumulo/server/master/Master.java b/server/src/main/java/org/apache/accumulo/server/master/Master.java
index 0cb0378..3d14d12 100644
--- a/server/src/main/java/org/apache/accumulo/server/master/Master.java
+++ b/server/src/main/java/org/apache/accumulo/server/master/Master.java
@@ -84,8 +84,8 @@ import org.apache.accumulo.fate.AgeOffStore;
 import org.apache.accumulo.fate.Fate;
 import org.apache.accumulo.fate.TStore.TStatus;
 import org.apache.accumulo.fate.zookeeper.IZooReaderWriter;
+import org.apache.accumulo.fate.zookeeper.IZooReaderWriter.Mutator;
 import org.apache.accumulo.fate.zookeeper.ZooLock.LockLossReason;
-import org.apache.accumulo.fate.zookeeper.ZooReaderWriter.Mutator;
 import org.apache.accumulo.fate.zookeeper.ZooUtil.NodeExistsPolicy;
 import org.apache.accumulo.fate.zookeeper.ZooUtil.NodeMissingPolicy;
 import org.apache.accumulo.server.Accumulo;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/85451233/server/src/main/java/org/apache/accumulo/server/master/state/tables/TableManager.java
----------------------------------------------------------------------
diff --git a/server/src/main/java/org/apache/accumulo/server/master/state/tables/TableManager.java b/server/src/main/java/org/apache/accumulo/server/master/state/tables/TableManager.java
index fedbc96..bc81786 100644
--- a/server/src/main/java/org/apache/accumulo/server/master/state/tables/TableManager.java
+++ b/server/src/main/java/org/apache/accumulo/server/master/state/tables/TableManager.java
@@ -29,7 +29,7 @@ import org.apache.accumulo.core.client.Instance;
 import org.apache.accumulo.core.master.state.tables.TableState;
 import org.apache.accumulo.core.zookeeper.ZooUtil;
 import org.apache.accumulo.fate.zookeeper.IZooReaderWriter;
-import org.apache.accumulo.fate.zookeeper.ZooReaderWriter.Mutator;
+import org.apache.accumulo.fate.zookeeper.IZooReaderWriter.Mutator;
 import org.apache.accumulo.fate.zookeeper.ZooUtil.NodeExistsPolicy;
 import org.apache.accumulo.fate.zookeeper.ZooUtil.NodeMissingPolicy;
 import org.apache.accumulo.server.client.HdfsZooInstance;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/85451233/server/src/main/java/org/apache/accumulo/server/master/tableOps/CancelCompactions.java
----------------------------------------------------------------------
diff --git a/server/src/main/java/org/apache/accumulo/server/master/tableOps/CancelCompactions.java b/server/src/main/java/org/apache/accumulo/server/master/tableOps/CancelCompactions.java
index efddc79..7d06639 100644
--- a/server/src/main/java/org/apache/accumulo/server/master/tableOps/CancelCompactions.java
+++ b/server/src/main/java/org/apache/accumulo/server/master/tableOps/CancelCompactions.java
@@ -20,7 +20,7 @@ import org.apache.accumulo.core.Constants;
 import org.apache.accumulo.core.client.impl.thrift.TableOperation;
 import org.apache.accumulo.fate.Repo;
 import org.apache.accumulo.fate.zookeeper.IZooReaderWriter;
-import org.apache.accumulo.fate.zookeeper.ZooReaderWriter.Mutator;
+import org.apache.accumulo.fate.zookeeper.IZooReaderWriter.Mutator;
 import org.apache.accumulo.server.client.HdfsZooInstance;
 import org.apache.accumulo.server.master.Master;
 import org.apache.accumulo.server.zookeeper.ZooReaderWriter;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/85451233/server/src/main/java/org/apache/accumulo/server/master/tableOps/CompactRange.java
----------------------------------------------------------------------
diff --git a/server/src/main/java/org/apache/accumulo/server/master/tableOps/CompactRange.java b/server/src/main/java/org/apache/accumulo/server/master/tableOps/CompactRange.java
index 09046f7..41b052b 100644
--- a/server/src/main/java/org/apache/accumulo/server/master/tableOps/CompactRange.java
+++ b/server/src/main/java/org/apache/accumulo/server/master/tableOps/CompactRange.java
@@ -47,7 +47,7 @@ import org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection;
 import org.apache.accumulo.core.security.Authorizations;
 import org.apache.accumulo.fate.Repo;
 import org.apache.accumulo.fate.zookeeper.IZooReaderWriter;
-import org.apache.accumulo.fate.zookeeper.ZooReaderWriter.Mutator;
+import org.apache.accumulo.fate.zookeeper.IZooReaderWriter.Mutator;
 import org.apache.accumulo.server.client.HdfsZooInstance;
 import org.apache.accumulo.server.master.LiveTServerSet.TServerConnection;
 import org.apache.accumulo.server.master.Master;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/85451233/server/src/main/java/org/apache/accumulo/server/master/tableOps/RenameTable.java
----------------------------------------------------------------------
diff --git a/server/src/main/java/org/apache/accumulo/server/master/tableOps/RenameTable.java b/server/src/main/java/org/apache/accumulo/server/master/tableOps/RenameTable.java
index 0ca29cd..16201b1 100644
--- a/server/src/main/java/org/apache/accumulo/server/master/tableOps/RenameTable.java
+++ b/server/src/main/java/org/apache/accumulo/server/master/tableOps/RenameTable.java
@@ -25,7 +25,7 @@ import org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 import org.apache.accumulo.core.zookeeper.ZooUtil;
 import org.apache.accumulo.fate.Repo;
 import org.apache.accumulo.fate.zookeeper.IZooReaderWriter;
-import org.apache.accumulo.fate.zookeeper.ZooReaderWriter.Mutator;
+import org.apache.accumulo.fate.zookeeper.IZooReaderWriter.Mutator;
 import org.apache.accumulo.server.master.Master;
 import org.apache.accumulo.server.zookeeper.ZooReaderWriter;
 import org.apache.log4j.Logger;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/85451233/server/src/main/java/org/apache/accumulo/server/master/tableOps/Utils.java
----------------------------------------------------------------------
diff --git a/server/src/main/java/org/apache/accumulo/server/master/tableOps/Utils.java b/server/src/main/java/org/apache/accumulo/server/master/tableOps/Utils.java
index d467119..e57801c 100644
--- a/server/src/main/java/org/apache/accumulo/server/master/tableOps/Utils.java
+++ b/server/src/main/java/org/apache/accumulo/server/master/tableOps/Utils.java
@@ -29,7 +29,7 @@ import org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 import org.apache.accumulo.core.zookeeper.ZooUtil;
 import org.apache.accumulo.fate.zookeeper.DistributedReadWriteLock;
 import org.apache.accumulo.fate.zookeeper.IZooReaderWriter;
-import org.apache.accumulo.fate.zookeeper.ZooReaderWriter.Mutator;
+import org.apache.accumulo.fate.zookeeper.IZooReaderWriter.Mutator;
 import org.apache.accumulo.fate.zookeeper.ZooReservation;
 import org.apache.accumulo.server.client.HdfsZooInstance;
 import org.apache.accumulo.server.zookeeper.ZooQueueLock;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/85451233/server/src/main/java/org/apache/accumulo/server/tabletserver/TabletServer.java
----------------------------------------------------------------------
diff --git a/server/src/main/java/org/apache/accumulo/server/tabletserver/TabletServer.java b/server/src/main/java/org/apache/accumulo/server/tabletserver/TabletServer.java
index d83102d..9824c64 100644
--- a/server/src/main/java/org/apache/accumulo/server/tabletserver/TabletServer.java
+++ b/server/src/main/java/org/apache/accumulo/server/tabletserver/TabletServer.java
@@ -18,7 +18,6 @@ package org.apache.accumulo.server.tabletserver;
 
 import static org.apache.accumulo.server.problems.ProblemType.TABLET_LOAD;
 
-import java.io.File;
 import java.io.FileNotFoundException;
 import java.io.IOException;
 import java.lang.management.GarbageCollectorMXBean;
@@ -196,7 +195,6 @@ import org.apache.accumulo.server.zookeeper.TransactionWatcher;
 import org.apache.accumulo.server.zookeeper.ZooCache;
 import org.apache.accumulo.server.zookeeper.ZooLock;
 import org.apache.accumulo.server.zookeeper.ZooReaderWriter;
-import org.apache.accumulo.start.Platform;
 import org.apache.accumulo.start.classloader.vfs.AccumuloVFSClassLoader;
 import org.apache.accumulo.start.classloader.vfs.ContextManager;
 import org.apache.accumulo.trace.instrument.Span;


[3/5] git commit: ACCUMULO-1596 moved Mutator interface up to IZooReaderWriter

Posted by ec...@apache.org.
ACCUMULO-1596 moved Mutator interface up to IZooReaderWriter


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

Branch: refs/heads/master
Commit: 734cd505d37f229d9c7204276059f33d3a7707ce
Parents: 93f741e
Author: Eric Newton <ec...@apache.org>
Authored: Mon Jul 22 13:44:48 2013 -0400
Committer: Eric Newton <ec...@apache.org>
Committed: Mon Jul 22 13:44:48 2013 -0400

----------------------------------------------------------------------
 .../org/apache/accumulo/fate/zookeeper/IZooReaderWriter.java    | 5 ++++-
 .../org/apache/accumulo/fate/zookeeper/ZooReaderWriter.java     | 4 ----
 2 files changed, 4 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/734cd505/fate/src/main/java/org/apache/accumulo/fate/zookeeper/IZooReaderWriter.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/IZooReaderWriter.java b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/IZooReaderWriter.java
index 5dcad23..a43ae7c 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/IZooReaderWriter.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/IZooReaderWriter.java
@@ -18,7 +18,6 @@ package org.apache.accumulo.fate.zookeeper;
 
 import java.util.List;
 
-import org.apache.accumulo.fate.zookeeper.ZooReaderWriter.Mutator;
 import org.apache.accumulo.fate.zookeeper.ZooUtil.NodeExistsPolicy;
 import org.apache.accumulo.fate.zookeeper.ZooUtil.NodeMissingPolicy;
 import org.apache.zookeeper.KeeperException;
@@ -54,6 +53,10 @@ public interface IZooReaderWriter extends IZooReader {
   
   public abstract void delete(String path, int version) throws InterruptedException, KeeperException;
   
+  public interface Mutator {
+    byte[] mutate(byte[] currentValue) throws Exception;
+  }
+  
   public abstract byte[] mutate(String zPath, byte[] createValue, List<ACL> acl, Mutator mutator) throws Exception;
   
   public abstract boolean isLockHeld(ZooUtil.LockID lockID) throws KeeperException, InterruptedException;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/734cd505/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooReaderWriter.java
----------------------------------------------------------------------
diff --git a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooReaderWriter.java b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooReaderWriter.java
index 7800ec0..13c3c1a 100644
--- a/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooReaderWriter.java
+++ b/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooReaderWriter.java
@@ -114,10 +114,6 @@ public class ZooReaderWriter extends ZooReader implements IZooReaderWriter {
     getZooKeeper().delete(path, version);
   }
   
-  public interface Mutator {
-    byte[] mutate(byte[] currentValue) throws Exception;
-  }
-  
   @Override
   public byte[] mutate(String zPath, byte[] createValue, List<ACL> acl, Mutator mutator) throws Exception {
     if (createValue != null) {