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 2013/05/23 18:58:25 UTC

svn commit: r1485778 - in /accumulo/trunk: core/src/main/java/org/apache/accumulo/core/client/admin/ core/src/main/java/org/apache/accumulo/core/util/ core/src/test/java/org/apache/accumulo/core/client/lexicoder/ server/src/main/java/org/apache/accumul...

Author: ctubbsii
Date: Thu May 23 16:58:24 2013
New Revision: 1485778

URL: http://svn.apache.org/r1485778
Log:
ACCUMULO-1393 cleaned up unused import warnings from prior changes on this ticket; formatter also seemed to want to get in on the action

Modified:
    accumulo/trunk/core/src/main/java/org/apache/accumulo/core/client/admin/InstanceOperationsImpl.java
    accumulo/trunk/core/src/main/java/org/apache/accumulo/core/util/ServerServices.java
    accumulo/trunk/core/src/test/java/org/apache/accumulo/core/client/lexicoder/BigIntegerLexicoderTest.java
    accumulo/trunk/server/src/main/java/org/apache/accumulo/server/gc/GarbageCollectWriteAheadLogs.java
    accumulo/trunk/server/src/main/java/org/apache/accumulo/server/master/LiveTServerSet.java
    accumulo/trunk/server/src/main/java/org/apache/accumulo/server/master/state/TabletStateChangeIterator.java
    accumulo/trunk/server/src/main/java/org/apache/accumulo/server/util/Admin.java
    accumulo/trunk/test/src/main/java/org/apache/accumulo/test/randomwalk/concurrent/StopTabletServer.java

Modified: accumulo/trunk/core/src/main/java/org/apache/accumulo/core/client/admin/InstanceOperationsImpl.java
URL: http://svn.apache.org/viewvc/accumulo/trunk/core/src/main/java/org/apache/accumulo/core/client/admin/InstanceOperationsImpl.java?rev=1485778&r1=1485777&r2=1485778&view=diff
==============================================================================
--- accumulo/trunk/core/src/main/java/org/apache/accumulo/core/client/admin/InstanceOperationsImpl.java (original)
+++ accumulo/trunk/core/src/main/java/org/apache/accumulo/core/client/admin/InstanceOperationsImpl.java Thu May 23 16:58:24 2013
@@ -33,7 +33,6 @@ import org.apache.accumulo.core.client.i
 import org.apache.accumulo.core.client.impl.thrift.ClientService;
 import org.apache.accumulo.core.client.impl.thrift.ConfigurationType;
 import org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException;
-import org.apache.accumulo.core.conf.Property;
 import org.apache.accumulo.core.master.thrift.MasterClientService;
 import org.apache.accumulo.core.security.thrift.TCredentials;
 import org.apache.accumulo.core.tabletserver.thrift.TabletClientService;
@@ -67,7 +66,9 @@ public class InstanceOperationsImpl impl
     this.credentials = credentials;
   }
   
-  /* (non-Javadoc)
+  /*
+   * (non-Javadoc)
+   * 
    * @see org.apache.accumulo.core.client.admin.InstanceOperations#setProperty(java.lang.String, java.lang.String)
    */
   @Override
@@ -81,7 +82,9 @@ public class InstanceOperationsImpl impl
     });
   }
   
-  /* (non-Javadoc)
+  /*
+   * (non-Javadoc)
+   * 
    * @see org.apache.accumulo.core.client.admin.InstanceOperations#removeProperty(java.lang.String)
    */
   @Override
@@ -95,7 +98,9 @@ public class InstanceOperationsImpl impl
     });
   }
   
-  /* (non-Javadoc)
+  /*
+   * (non-Javadoc)
+   * 
    * @see org.apache.accumulo.core.client.admin.InstanceOperations#getSystemConfiguration()
    */
   @Override
@@ -108,7 +113,9 @@ public class InstanceOperationsImpl impl
     });
   }
   
-  /* (non-Javadoc)
+  /*
+   * (non-Javadoc)
+   * 
    * @see org.apache.accumulo.core.client.admin.InstanceOperations#getSiteConfiguration()
    */
   @Override
@@ -121,7 +128,9 @@ public class InstanceOperationsImpl impl
     });
   }
   
-  /* (non-Javadoc)
+  /*
+   * (non-Javadoc)
+   * 
    * @see org.apache.accumulo.core.client.admin.InstanceOperations#getTabletServers()
    */
   
@@ -144,7 +153,9 @@ public class InstanceOperationsImpl impl
     return results;
   }
   
-  /* (non-Javadoc)
+  /*
+   * (non-Javadoc)
+   * 
    * @see org.apache.accumulo.core.client.admin.InstanceOperations#getActiveScans(java.lang.String)
    */
   
@@ -175,7 +186,9 @@ public class InstanceOperationsImpl impl
     }
   }
   
-  /* (non-Javadoc)
+  /*
+   * (non-Javadoc)
+   * 
    * @see org.apache.accumulo.core.client.admin.InstanceOperations#testClassLoad(java.lang.String, java.lang.String)
    */
   @Override

Modified: accumulo/trunk/core/src/main/java/org/apache/accumulo/core/util/ServerServices.java
URL: http://svn.apache.org/viewvc/accumulo/trunk/core/src/main/java/org/apache/accumulo/core/util/ServerServices.java?rev=1485778&r1=1485777&r2=1485778&view=diff
==============================================================================
--- accumulo/trunk/core/src/main/java/org/apache/accumulo/core/util/ServerServices.java (original)
+++ accumulo/trunk/core/src/main/java/org/apache/accumulo/core/util/ServerServices.java Thu May 23 16:58:24 2013
@@ -19,38 +19,35 @@ package org.apache.accumulo.core.util;
 import java.net.InetSocketAddress;
 import java.util.EnumMap;
 
-import org.apache.accumulo.core.conf.AccumuloConfiguration;
-import org.apache.accumulo.core.conf.Property;
-
 public class ServerServices implements Comparable<ServerServices> {
   public static enum Service {
     TSERV_CLIENT, GC_CLIENT;
   }
-
+  
   public static final String SERVICE_SEPARATOR = ";";
   public static final String SEPARATOR_CHAR = "=";
-
+  
   private EnumMap<Service,String> services;
   private String stringForm = null;
-
+  
   public ServerServices(String services) {
     this.services = new EnumMap<Service,String>(Service.class);
-
+    
     String[] addresses = services.split(SERVICE_SEPARATOR);
     for (String address : addresses) {
       String[] sa = address.split(SEPARATOR_CHAR, 2);
       this.services.put(Service.valueOf(sa[0]), sa[1]);
     }
   }
-
+  
   public ServerServices(String address, Service service) {
     this(service.name() + SEPARATOR_CHAR + address);
   }
-
+  
   public String getAddressString(Service service) {
     return services.get(service);
   }
-
+  
   public InetSocketAddress getAddress(Service service) {
     String address = getAddressString(service);
     String[] parts = address.split(":", 2);
@@ -63,11 +60,12 @@ public class ServerServices implements C
   }
   
   // DON'T CHANGE THIS; WE'RE USING IT FOR SERIALIZATION!!!
+  @Override
   public String toString() {
     if (stringForm == null) {
       StringBuilder sb = new StringBuilder();
       String prefix = "";
-      for (Service service : new Service[] { Service.TSERV_CLIENT, Service.GC_CLIENT}) {
+      for (Service service : new Service[] {Service.TSERV_CLIENT, Service.GC_CLIENT}) {
         if (services.containsKey(service)) {
           sb.append(prefix).append(service.name()).append(SEPARATOR_CHAR).append(services.get(service));
           prefix = SERVICE_SEPARATOR;

Modified: accumulo/trunk/core/src/test/java/org/apache/accumulo/core/client/lexicoder/BigIntegerLexicoderTest.java
URL: http://svn.apache.org/viewvc/accumulo/trunk/core/src/test/java/org/apache/accumulo/core/client/lexicoder/BigIntegerLexicoderTest.java?rev=1485778&r1=1485777&r2=1485778&view=diff
==============================================================================
--- accumulo/trunk/core/src/test/java/org/apache/accumulo/core/client/lexicoder/BigIntegerLexicoderTest.java (original)
+++ accumulo/trunk/core/src/test/java/org/apache/accumulo/core/client/lexicoder/BigIntegerLexicoderTest.java Thu May 23 16:58:24 2013
@@ -16,10 +16,7 @@
  */
 package org.apache.accumulo.core.client.lexicoder;
 
-import org.apache.accumulo.core.util.ComparablePair;
-
 import java.math.BigInteger;
-import java.util.Date;
 
 /**
  * 
@@ -33,7 +30,6 @@ public class BigIntegerLexicoderTest ext
         new BigInteger("-2147483647"), new BigInteger("-2147483649"), new BigInteger("32768"), new BigInteger("32769"), new BigInteger("32767"),
         new BigInteger("-32768"), new BigInteger("-32769"), new BigInteger("-32767"), new BigInteger("126"), new BigInteger("127"), new BigInteger("128"),
         new BigInteger("129"), new BigInteger("-126"), new BigInteger("-127"), new BigInteger("-128"), new BigInteger("-129"));
-
-
+    
   }
 }

Modified: accumulo/trunk/server/src/main/java/org/apache/accumulo/server/gc/GarbageCollectWriteAheadLogs.java
URL: http://svn.apache.org/viewvc/accumulo/trunk/server/src/main/java/org/apache/accumulo/server/gc/GarbageCollectWriteAheadLogs.java?rev=1485778&r1=1485777&r2=1485778&view=diff
==============================================================================
--- accumulo/trunk/server/src/main/java/org/apache/accumulo/server/gc/GarbageCollectWriteAheadLogs.java (original)
+++ accumulo/trunk/server/src/main/java/org/apache/accumulo/server/gc/GarbageCollectWriteAheadLogs.java Thu May 23 16:58:24 2013
@@ -32,7 +32,6 @@ import java.util.UUID;
 import org.apache.accumulo.core.Constants;
 import org.apache.accumulo.core.client.Instance;
 import org.apache.accumulo.core.conf.AccumuloConfiguration;
-import org.apache.accumulo.core.conf.Property;
 import org.apache.accumulo.core.gc.thrift.GCStatus;
 import org.apache.accumulo.core.gc.thrift.GcCycleStats;
 import org.apache.accumulo.core.tabletserver.thrift.TabletClientService;
@@ -55,13 +54,12 @@ import org.apache.log4j.Logger;
 import org.apache.thrift.TException;
 import org.apache.zookeeper.KeeperException;
 
-
 public class GarbageCollectWriteAheadLogs {
   private static final Logger log = Logger.getLogger(GarbageCollectWriteAheadLogs.class);
   
   private final Instance instance;
   private final FileSystem fs;
-
+  
   private Trash trash;
   
   GarbageCollectWriteAheadLogs(Instance instance, FileSystem fs, boolean noTrash) throws IOException {
@@ -70,14 +68,14 @@ public class GarbageCollectWriteAheadLog
     if (!noTrash)
       this.trash = new Trash(fs, fs.getConf());
   }
-
+  
   public void collect(GCStatus status) {
     
     Span span = Trace.start("scanServers");
     try {
       
       Set<String> sortedWALogs = getSortedWALogs();
-
+      
       status.currentLog.started = System.currentTimeMillis();
       
       Map<String,String> fileToServerMap = new HashMap<String,String>();
@@ -131,7 +129,7 @@ public class GarbageCollectWriteAheadLog
       return true;
     }
   }
-
+  
   private int removeFiles(Map<String,ArrayList<String>> serverToFileMap, Set<String> sortedWALogs, final GCStatus status) {
     AccumuloConfiguration conf = instance.getConfiguration();
     for (Entry<String,ArrayList<String>> entry : serverToFileMap.entrySet()) {
@@ -206,7 +204,7 @@ public class GarbageCollectWriteAheadLog
         }
       }
     }
-
+    
     return 0;
   }
   
@@ -234,7 +232,7 @@ public class GarbageCollectWriteAheadLog
           status.currentLog.inUse++;
         
         sortedWALogs.remove(filename);
-
+        
         count++;
       }
     }
@@ -261,7 +259,7 @@ public class GarbageCollectWriteAheadLog
         log.info("Ignoring file " + name + " because it doesn't look like a uuid");
       }
     }
-
+    
     int count = 0;
     return count;
   }
@@ -271,7 +269,7 @@ public class GarbageCollectWriteAheadLog
     Path recoveryDir = new Path(Constants.getRecoveryDir(conf));
     
     Set<String> sortedWALogs = new HashSet<String>();
-
+    
     if (fs.exists(recoveryDir)) {
       for (FileStatus status : fs.listStatus(recoveryDir)) {
         if (isUUID(status.getPath().getName())) {
@@ -284,7 +282,7 @@ public class GarbageCollectWriteAheadLog
     
     return sortedWALogs;
   }
-
+  
   /**
    * @param name
    * @return

Modified: accumulo/trunk/server/src/main/java/org/apache/accumulo/server/master/LiveTServerSet.java
URL: http://svn.apache.org/viewvc/accumulo/trunk/server/src/main/java/org/apache/accumulo/server/master/LiveTServerSet.java?rev=1485778&r1=1485777&r2=1485778&view=diff
==============================================================================
--- accumulo/trunk/server/src/main/java/org/apache/accumulo/server/master/LiveTServerSet.java (original)
+++ accumulo/trunk/server/src/main/java/org/apache/accumulo/server/master/LiveTServerSet.java Thu May 23 16:58:24 2013
@@ -29,7 +29,6 @@ import org.apache.accumulo.core.Constant
 import org.apache.accumulo.core.client.Instance;
 import org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.conf.AccumuloConfiguration;
-import org.apache.accumulo.core.conf.Property;
 import org.apache.accumulo.core.data.KeyExtent;
 import org.apache.accumulo.core.master.thrift.TabletServerStatus;
 import org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException;
@@ -136,8 +135,8 @@ public class LiveTServerSet implements W
     public void flush(ZooLock lock, String tableId, byte[] startRow, byte[] endRow) throws TException {
       TabletClientService.Client client = ThriftUtil.getClient(new TabletClientService.Client.Factory(), address, conf);
       try {
-        client.flush(Tracer.traceInfo(), SecurityConstants.getSystemCredentials(), lockString(lock), tableId, startRow == null ? null : ByteBuffer.wrap(startRow),
-            endRow == null ? null : ByteBuffer.wrap(endRow));
+        client.flush(Tracer.traceInfo(), SecurityConstants.getSystemCredentials(), lockString(lock), tableId,
+            startRow == null ? null : ByteBuffer.wrap(startRow), endRow == null ? null : ByteBuffer.wrap(endRow));
       } finally {
         ThriftUtil.returnClient(client);
       }
@@ -155,8 +154,8 @@ public class LiveTServerSet implements W
     public void splitTablet(ZooLock lock, KeyExtent extent, Text splitPoint) throws TException, ThriftSecurityException, NotServingTabletException {
       TabletClientService.Client client = ThriftUtil.getClient(new TabletClientService.Client.Factory(), address, conf);
       try {
-        client
-            .splitTablet(Tracer.traceInfo(), SecurityConstants.getSystemCredentials(), extent.toThrift(), ByteBuffer.wrap(splitPoint.getBytes(), 0, splitPoint.getLength()));
+        client.splitTablet(Tracer.traceInfo(), SecurityConstants.getSystemCredentials(), extent.toThrift(),
+            ByteBuffer.wrap(splitPoint.getBytes(), 0, splitPoint.getLength()));
       } finally {
         ThriftUtil.returnClient(client);
       }
@@ -174,8 +173,8 @@ public class LiveTServerSet implements W
     public void compact(ZooLock lock, String tableId, byte[] startRow, byte[] endRow) throws TException {
       TabletClientService.Client client = ThriftUtil.getClient(new TabletClientService.Client.Factory(), address, conf);
       try {
-        client.compact(Tracer.traceInfo(), SecurityConstants.getSystemCredentials(), lockString(lock), tableId, startRow == null ? null : ByteBuffer.wrap(startRow),
-            endRow == null ? null : ByteBuffer.wrap(endRow));
+        client.compact(Tracer.traceInfo(), SecurityConstants.getSystemCredentials(), lockString(lock), tableId,
+            startRow == null ? null : ByteBuffer.wrap(startRow), endRow == null ? null : ByteBuffer.wrap(endRow));
       } finally {
         ThriftUtil.returnClient(client);
       }
@@ -205,7 +204,7 @@ public class LiveTServerSet implements W
   // Map from tserver master service to server information
   private Map<String,TServerInfo> current = new HashMap<String,TServerInfo>();
   private Map<String,Long> locklessServers = new HashMap<String,Long>();
-
+  
   public LiveTServerSet(Instance instance, AccumuloConfiguration conf, Listener cback) {
     this.cback = cback;
     this.instance = instance;
@@ -240,11 +239,11 @@ public class LiveTServerSet implements W
       all.addAll(getZooCache().getChildren(path));
       
       locklessServers.keySet().retainAll(all);
-
+      
       for (String server : all) {
         checkServer(updates, doomed, path, server);
       }
-
+      
       // log.debug("Current: " + current.keySet());
       if (!doomed.isEmpty() || !updates.isEmpty())
         this.cback.update(this, doomed, updates);
@@ -252,7 +251,7 @@ public class LiveTServerSet implements W
       log.error(ex, ex);
     }
   }
-
+  
   private void deleteServerNode(String serverNode) throws InterruptedException, KeeperException {
     try {
       ZooReaderWriter.getInstance().delete(serverNode, -1);
@@ -265,13 +264,13 @@ public class LiveTServerSet implements W
   
   private synchronized void checkServer(final Set<TServerInstance> updates, final Set<TServerInstance> doomed, final String path, final String server)
       throws TException, InterruptedException, KeeperException {
-
+    
     TServerInfo info = current.get(server);
     
     final String lockPath = path + "/" + server;
     Stat stat = new Stat();
     byte[] lockData = ZooLock.getLockData(getZooCache(), lockPath, stat);
-
+    
     if (lockData == null) {
       if (info != null) {
         doomed.add(info.instance);
@@ -302,19 +301,19 @@ public class LiveTServerSet implements W
       }
     }
   }
-
+  
   @Override
   public void process(WatchedEvent event) {
-
+    
     // its important that these event are propagated by ZooCache, because this ensures when reading zoocache that is has already processed the event and cleared
     // relevant nodes before code below reads from zoocache
-
+    
     if (event.getPath() != null) {
       if (event.getPath().endsWith(Constants.ZTSERVERS)) {
         scanServers();
       } else if (event.getPath().contains(Constants.ZTSERVERS)) {
         int pos = event.getPath().lastIndexOf('/');
-
+        
         // do only if ZTSERVER is parent
         if (pos >= 0 && event.getPath().substring(0, pos).endsWith(Constants.ZTSERVERS)) {
           
@@ -324,7 +323,7 @@ public class LiveTServerSet implements W
           final Set<TServerInstance> doomed = new HashSet<TServerInstance>();
           
           final String path = ZooUtil.getRoot(instance) + Constants.ZTSERVERS;
-
+          
           try {
             checkServer(updates, doomed, path, server);
             if (!doomed.isEmpty() || !updates.isEmpty())
@@ -377,7 +376,7 @@ public class LiveTServerSet implements W
   
   public synchronized void remove(TServerInstance server) {
     current.remove(server.hostPort());
-
+    
     log.info("Removing zookeeper lock for " + server);
     String zpath = ZooUtil.getRoot(instance) + Constants.ZTSERVERS + "/" + server.hostPort();
     try {

Modified: accumulo/trunk/server/src/main/java/org/apache/accumulo/server/master/state/TabletStateChangeIterator.java
URL: http://svn.apache.org/viewvc/accumulo/trunk/server/src/main/java/org/apache/accumulo/server/master/state/TabletStateChangeIterator.java?rev=1485778&r1=1485777&r2=1485778&view=diff
==============================================================================
--- accumulo/trunk/server/src/main/java/org/apache/accumulo/server/master/state/TabletStateChangeIterator.java (original)
+++ accumulo/trunk/server/src/main/java/org/apache/accumulo/server/master/state/TabletStateChangeIterator.java Thu May 23 16:58:24 2013
@@ -27,7 +27,6 @@ import java.util.Map;
 import java.util.Set;
 
 import org.apache.accumulo.core.client.IteratorSetting;
-import org.apache.accumulo.core.conf.Property;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.KeyExtent;
 import org.apache.accumulo.core.data.Value;
@@ -115,7 +114,7 @@ public class TabletStateChangeIterator e
       
       if (onlineTables == null || current == null)
         return;
-
+      
       TabletLocationState tls;
       try {
         tls = MetaDataTableScanner.createTabletLocationState(k, v);

Modified: accumulo/trunk/server/src/main/java/org/apache/accumulo/server/util/Admin.java
URL: http://svn.apache.org/viewvc/accumulo/trunk/server/src/main/java/org/apache/accumulo/server/util/Admin.java?rev=1485778&r1=1485777&r2=1485778&view=diff
==============================================================================
--- accumulo/trunk/server/src/main/java/org/apache/accumulo/server/util/Admin.java (original)
+++ accumulo/trunk/server/src/main/java/org/apache/accumulo/server/util/Admin.java Thu May 23 16:58:24 2013
@@ -31,7 +31,6 @@ import org.apache.accumulo.core.client.T
 import org.apache.accumulo.core.client.impl.ClientExec;
 import org.apache.accumulo.core.client.impl.MasterClient;
 import org.apache.accumulo.core.client.security.tokens.AuthenticationToken;
-import org.apache.accumulo.core.conf.Property;
 import org.apache.accumulo.core.master.thrift.MasterClientService;
 import org.apache.accumulo.core.security.CredentialHelper;
 import org.apache.accumulo.core.security.thrift.TCredentials;
@@ -49,27 +48,25 @@ public class Admin {
   private static final Logger log = Logger.getLogger(Admin.class);
   
   static class AdminOpts extends ClientOpts {
-    @Parameter(names={"-f", "--force"}, description="force the given server to stop by removing its lock")
+    @Parameter(names = {"-f", "--force"}, description = "force the given server to stop by removing its lock")
     boolean force = false;
   }
-
-  @Parameters(commandDescription="stop the tablet server on the given hosts")
+  
+  @Parameters(commandDescription = "stop the tablet server on the given hosts")
   static class StopCommand {
-    @Parameter(description="<host> {<host> ... }")
+    @Parameter(description = "<host> {<host> ... }")
     List<String> args = new ArrayList<String>();
   }
   
-  @Parameters(commandDescription="stop the master")
-  static class StopMasterCommand {
-  }
-
-  @Parameters(commandDescription="stop all the servers")
-  static class StopAllCommand {
-  }
-
+  @Parameters(commandDescription = "stop the master")
+  static class StopMasterCommand {}
+  
+  @Parameters(commandDescription = "stop all the servers")
+  static class StopAllCommand {}
+  
   public static void main(String[] args) {
     boolean everything;
-
+    
     AdminOpts opts = new AdminOpts();
     JCommander cl = new JCommander(opts);
     cl.setProgramName(Admin.class.getName());
@@ -86,7 +83,7 @@ public class Admin {
       return;
     }
     Instance instance = opts.getInstance();
-      
+    
     try {
       String principal;
       AuthenticationToken token;
@@ -97,26 +94,26 @@ public class Admin {
         principal = opts.principal;
         token = opts.getToken();
       }
-
+      
       if (cl.getParsedCommand().equals("stop")) {
         stopTabletServer(instance, CredentialHelper.create(principal, token, instance.getInstanceID()), stopOpts.args, opts.force);
       } else {
         everything = cl.getParsedCommand().equals("stopAll");
-
+        
         if (everything)
           flushAll(instance, principal, token);
-
+        
         stopServer(instance, CredentialHelper.create(principal, token, instance.getInstanceID()), everything);
       }
     } catch (AccumuloException e) {
-      log.error(e,e);
+      log.error(e, e);
       System.exit(1);
     } catch (AccumuloSecurityException e) {
-      log.error(e,e);
+      log.error(e, e);
       System.exit(2);
     }
   }
-
+  
   /**
    * flushing during shutdown is a perfomance optimization, its not required. The method will make an attempt to initiate flushes of all tables and give up if
    * it takes too long.
@@ -126,7 +123,7 @@ public class Admin {
       AccumuloSecurityException {
     
     final AtomicInteger flushesStarted = new AtomicInteger(0);
-
+    
     Runnable flushTask = new Runnable() {
       
       @Override
@@ -169,8 +166,9 @@ public class Admin {
       }
     }
   }
-
-  private static void stopServer(Instance instance, final TCredentials credentials, final boolean tabletServersToo) throws AccumuloException, AccumuloSecurityException {
+  
+  private static void stopServer(Instance instance, final TCredentials credentials, final boolean tabletServersToo) throws AccumuloException,
+      AccumuloSecurityException {
     MasterClient.execute(HdfsZooInstance.getInstance(), new ClientExec<MasterClientService.Client>() {
       @Override
       public void execute(MasterClientService.Client client) throws Exception {
@@ -179,7 +177,8 @@ public class Admin {
     });
   }
   
-  private static void stopTabletServer(Instance instance, final TCredentials creds, List<String> servers, final boolean force) throws AccumuloException, AccumuloSecurityException {
+  private static void stopTabletServer(Instance instance, final TCredentials creds, List<String> servers, final boolean force) throws AccumuloException,
+      AccumuloSecurityException {
     for (String server : servers) {
       InetSocketAddress address = AddressUtil.parseAddress(server);
       final String finalServer = org.apache.accumulo.core.util.AddressUtil.toString(address);

Modified: accumulo/trunk/test/src/main/java/org/apache/accumulo/test/randomwalk/concurrent/StopTabletServer.java
URL: http://svn.apache.org/viewvc/accumulo/trunk/test/src/main/java/org/apache/accumulo/test/randomwalk/concurrent/StopTabletServer.java?rev=1485778&r1=1485777&r2=1485778&view=diff
==============================================================================
--- accumulo/trunk/test/src/main/java/org/apache/accumulo/test/randomwalk/concurrent/StopTabletServer.java (original)
+++ accumulo/trunk/test/src/main/java/org/apache/accumulo/test/randomwalk/concurrent/StopTabletServer.java Thu May 23 16:58:24 2013
@@ -25,13 +25,12 @@ import java.util.Set;
 
 import org.apache.accumulo.core.Constants;
 import org.apache.accumulo.core.client.Instance;
-import org.apache.accumulo.core.conf.Property;
 import org.apache.accumulo.core.zookeeper.ZooUtil;
 import org.apache.accumulo.fate.zookeeper.ZooReader;
 import org.apache.accumulo.server.master.state.TServerInstance;
+import org.apache.accumulo.server.util.AddressUtil;
 import org.apache.accumulo.test.randomwalk.State;
 import org.apache.accumulo.test.randomwalk.Test;
-import org.apache.accumulo.server.util.AddressUtil;
 import org.apache.zookeeper.KeeperException;
 import org.apache.zookeeper.data.Stat;