You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by kl...@apache.org on 2016/02/02 21:21:34 UTC

[27/44] incubator-geode git commit: Refactor dunit

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveAllDAckDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveAllDAckDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveAllDAckDUnitTest.java
index 02ed1cd..1dc55f4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveAllDAckDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveAllDAckDUnitTest.java
@@ -39,6 +39,7 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.LogWriterSupport;
 import com.gemstone.gemfire.test.dunit.VM;
 
 /**
@@ -69,7 +70,7 @@ public class RemoveAllDAckDUnitTest extends DistributedTestCase {
       VM vm1 = host.getVM(1);
       vm0.invoke(RemoveAllDAckDUnitTest.class, "createCacheForVM0");
       vm1.invoke(RemoveAllDAckDUnitTest.class, "createCacheForVM1");
-      getLogWriter().fine("Cache created successfully");
+      LogWriterSupport.getLogWriter().fine("Cache created successfully");
     }
     
     public void tearDown2(){
@@ -160,7 +161,7 @@ public class RemoveAllDAckDUnitTest extends DistributedTestCase {
             beforeDestroyRemoveAllcounter++;
             assertEquals(true, event.getOperation().isRemoveAll());
             assertEquals("removeAllCallback", event.getCallbackArgument());
-            getLogWriter().fine("*******BeforeDestroy*****");
+            LogWriterSupport.getLogWriter().fine("*******BeforeDestroy*****");
             beforeDestroy = true;
         }
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveDAckDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveDAckDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveDAckDUnitTest.java
index b32f4f5..984d7f8 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveDAckDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveDAckDUnitTest.java
@@ -35,6 +35,7 @@ import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.LogWriterSupport;
 import com.gemstone.gemfire.test.dunit.VM;
 
 /**
@@ -65,7 +66,7 @@ public class RemoveDAckDUnitTest extends DistributedTestCase {
       VM vm1 = host.getVM(1);
       vm0.invoke(RemoveDAckDUnitTest.class, "createCacheVM0");
       vm1.invoke(RemoveDAckDUnitTest.class, "createCacheVM1");
-      getLogWriter().fine("Cache created in successfully");
+      LogWriterSupport.getLogWriter().fine("Cache created in successfully");
     }
     
     public void tearDown2(){

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveGlobalDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveGlobalDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveGlobalDUnitTest.java
index 008d09b..0d1b60a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveGlobalDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveGlobalDUnitTest.java
@@ -39,7 +39,9 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.LogWriterSupport;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.Threads;
 import com.gemstone.gemfire.test.dunit.VM;
 
 /**
@@ -150,7 +152,7 @@ public class RemoveGlobalDUnitTest extends DistributedTestCase {
             }
         });
         
-        DistributedTestCase.join(async, 30 * 1000, getLogWriter());
+        Threads.join(async, 30 * 1000, LogWriterSupport.getLogWriter());
         if(async.exceptionOccurred())
           throw async.getException();
         
@@ -223,7 +225,7 @@ public class RemoveGlobalDUnitTest extends DistributedTestCase {
             }
         });
         
-        DistributedTestCase.join(async, 30 * 1000, getLogWriter());
+        Threads.join(async, 30 * 1000, LogWriterSupport.getLogWriter());
         if(async.exceptionOccurred())
           throw async.getException();
         
@@ -241,7 +243,7 @@ public class RemoveGlobalDUnitTest extends DistributedTestCase {
             }catch(InterruptedException ex){
                 fail("interrupted");
             }
-            getLogWriter().fine("quitingfromcachewriter");
+            LogWriterSupport.getLogWriter().fine("quitingfromcachewriter");
         }
     }///////////    
     

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SimpleDiskRegionJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SimpleDiskRegionJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SimpleDiskRegionJUnitTest.java
index 10bdab3..bc2e3bf 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SimpleDiskRegionJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SimpleDiskRegionJUnitTest.java
@@ -34,7 +34,7 @@ import org.junit.experimental.categories.Category;
 import static org.junit.Assert.*;
 
 import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Threads;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
 /**
@@ -363,11 +363,11 @@ public class SimpleDiskRegionJUnitTest extends DiskRegionTestingBase
     thread4.start();
     thread5.start();
 
-    DistributedTestCase.join(thread1, 30 * 1000, null);
-    DistributedTestCase.join(thread2, 30 * 1000, null);
-    DistributedTestCase.join(thread3, 30 * 1000, null);
-    DistributedTestCase.join(thread4, 30 * 1000, null);
-    DistributedTestCase.join(thread5, 30 * 1000, null);
+    Threads.join(thread1, 30 * 1000, null);
+    Threads.join(thread2, 30 * 1000, null);
+    Threads.join(thread3, 30 * 1000, null);
+    Threads.join(thread4, 30 * 1000, null);
+    Threads.join(thread5, 30 * 1000, null);
 
     if (keyIds.size() != 50000) {
       fail("Size not equal to 5000 as expected but is " + keyIds.size());

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SingleHopStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SingleHopStatsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SingleHopStatsDUnitTest.java
index 502654b..a2c9592 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SingleHopStatsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SingleHopStatsDUnitTest.java
@@ -42,9 +42,14 @@ import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
 import com.gemstone.gemfire.internal.cache.execute.data.ShipmentId;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
 import com.gemstone.gemfire.test.dunit.Assert;
+import com.gemstone.gemfire.test.dunit.DistributedTestSupport;
 import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.Invoke;
+import com.gemstone.gemfire.test.dunit.LogWriterSupport;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.Wait;
+import com.gemstone.gemfire.test.dunit.WaitCriterion;
 
 public class SingleHopStatsDUnitTest extends CacheTestCase{
 
@@ -123,11 +128,11 @@ public class SingleHopStatsDUnitTest extends CacheTestCase{
       member2 = null;
       member3 = null;
       cache = null;
-      invokeInEveryVM(new SerializableRunnable() { public void run() { cache = null; } });
+      Invoke.invokeInEveryVM(new SerializableRunnable() { public void run() { cache = null; } });
 
     }
     finally {
-      unregisterAllDataSerializersFromAllVms();
+      DistributedTestSupport.unregisterAllDataSerializersFromAllVms();
     }
   }
 
@@ -250,7 +255,7 @@ public class SingleHopStatsDUnitTest extends CacheTestCase{
         attr.setDataPolicy(DataPolicy.REPLICATE);
         region = cache.createRegion(Region_Name, attr.create());
         assertNotNull(region);
-        getLogWriter().info(
+        LogWriterSupport.getLogWriter().info(
             "Distributed Region " + Region_Name + " created Successfully :"
                 + region.toString());
       }else{
@@ -261,7 +266,7 @@ public class SingleHopStatsDUnitTest extends CacheTestCase{
       attr.setPartitionAttributes(paf.create());
       region = cache.createRegion(Region_Name, attr.create());
       assertNotNull(region);
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "Partitioned Region " + Region_Name + " created Successfully :"
               + region.toString());
       }
@@ -275,7 +280,7 @@ public class SingleHopStatsDUnitTest extends CacheTestCase{
       attr.setPartitionAttributes(paf.create());
       customerRegion = cache.createRegion("CUSTOMER", attr.create());
       assertNotNull(customerRegion);
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "Partitioned Region CUSTOMER created Successfully :"
               + customerRegion.toString());
 
@@ -287,7 +292,7 @@ public class SingleHopStatsDUnitTest extends CacheTestCase{
       attr.setPartitionAttributes(paf.create());
       orderRegion = cache.createRegion("ORDER", attr.create());
       assertNotNull(orderRegion);
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "Partitioned Region ORDER created Successfully :"
               + orderRegion.toString());
 
@@ -299,7 +304,7 @@ public class SingleHopStatsDUnitTest extends CacheTestCase{
       attr.setPartitionAttributes(paf.create());
       shipmentRegion = cache.createRegion("SHIPMENT", attr.create());
       assertNotNull(shipmentRegion);
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "Partitioned Region SHIPMENT created Successfully :"
               + shipmentRegion.toString());
     }
@@ -314,7 +319,7 @@ public class SingleHopStatsDUnitTest extends CacheTestCase{
       RegionAttributes attrs = factory.create();
       region = cache.createRegion(Region_Name, attrs);
       assertNotNull(region);
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "Region " + Region_Name + " created Successfully :" + region.toString());
     }
     else {
@@ -323,7 +328,7 @@ public class SingleHopStatsDUnitTest extends CacheTestCase{
       RegionAttributes attrs = factory.create();
       customerRegion = cache.createRegion("CUSTOMER", attrs);
       assertNotNull(customerRegion);
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "Partitioned Region CUSTOMER created Successfully :"
               + customerRegion.toString());
 
@@ -332,7 +337,7 @@ public class SingleHopStatsDUnitTest extends CacheTestCase{
       attrs = factory.create();
       orderRegion = cache.createRegion("ORDER", attrs);
       assertNotNull(orderRegion);
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "Partitioned Region ORDER created Successfully :"
               + orderRegion.toString());
 
@@ -341,7 +346,7 @@ public class SingleHopStatsDUnitTest extends CacheTestCase{
       attrs = factory.create();
       shipmentRegion = cache.createRegion("SHIPMENT", attrs);
       assertNotNull(shipmentRegion);
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "Partitioned Region SHIPMENT created Successfully :"
               + shipmentRegion.toString());
     }
@@ -369,7 +374,7 @@ public class SingleHopStatsDUnitTest extends CacheTestCase{
         cms = ((GemFireCacheImpl)cache).getClientMetadataService();
         // since PR metadata is fetched in a background executor thread
         // we need to wait for it to arrive for a bit
-        waitForCriterion(new WaitCriterion(){
+        Wait.waitForCriterion(new WaitCriterion(){
           public boolean done() {
             return regionMetaData.size() == 1;
           }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SystemFailureDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SystemFailureDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SystemFailureDUnitTest.java
index ac132ae..a1dc855 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SystemFailureDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SystemFailureDUnitTest.java
@@ -56,7 +56,7 @@ public class SystemFailureDUnitTest extends DistributedCacheTestCase {
   /////////  Public test methods
 
   public void testNullFailure() {
-    getLogWriter().info("TODO: this test needs to use VM#bounce.");
+    com.gemstone.gemfire.test.dunit.LogWriterSupport.getLogWriter().info("TODO: this test needs to use VM#bounce.");
     try {
       SystemFailure.initiateFailure(null);
       fail("Null failure set allowed");
@@ -308,7 +308,7 @@ public class SystemFailureDUnitTest extends DistributedCacheTestCase {
   
   static private final Runnable listener1 = new Runnable() {
     public void run() {
-      getLogWriter().info("Inside of preListener1");
+      com.gemstone.gemfire.test.dunit.LogWriterSupport.getLogWriter().info("Inside of preListener1");
       listenerCount.addAndGet(1);
     }
   };
@@ -495,7 +495,7 @@ public class SystemFailureDUnitTest extends DistributedCacheTestCase {
   protected static void message(String s) {
     System.out.println(s);
     System.err.println(s);
-    getLogWriter().info(s);
+    com.gemstone.gemfire.test.dunit.LogWriterSupport.getLogWriter().info(s);
     cache.getLogger().info(s);
   }
   
@@ -545,7 +545,7 @@ public class SystemFailureDUnitTest extends DistributedCacheTestCase {
       }
     }
     public void afterCreate(EntryEvent event) {
-      getLogWriter().info("Invoking afterCreate on listener; name=" +
+      com.gemstone.gemfire.test.dunit.LogWriterSupport.getLogWriter().info("Invoking afterCreate on listener; name=" +
                           event.getKey());
       forceOutOfMemory();
     }
@@ -590,7 +590,7 @@ public class SystemFailureDUnitTest extends DistributedCacheTestCase {
         }
       }
       public void afterCreate(EntryEvent event) {
-        getLogWriter().info("Invoking afterCreate on listener; name=" +
+        com.gemstone.gemfire.test.dunit.LogWriterSupport.getLogWriter().info("Invoking afterCreate on listener; name=" +
                             event.getKey());
         forceOutOfMemory();
       }
@@ -660,7 +660,7 @@ public class SystemFailureDUnitTest extends DistributedCacheTestCase {
     }
 
     public void afterCreate(EntryEvent event) {
-      getLogWriter().info("Invoking afterCreate on listener; name=" +
+      com.gemstone.gemfire.test.dunit.LogWriterSupport.getLogWriter().info("Invoking afterCreate on listener; name=" +
                           event.getKey());
       forceLowMemory();
     }
@@ -676,7 +676,7 @@ public class SystemFailureDUnitTest extends DistributedCacheTestCase {
     }
     
     public void afterCreate(EntryEvent event) {
-      getLogWriter().info("Invoking afterCreate on listener; name=" +
+      com.gemstone.gemfire.test.dunit.LogWriterSupport.getLogWriter().info("Invoking afterCreate on listener; name=" +
                           event.getKey());
       forceInternalError();
     }
@@ -692,7 +692,7 @@ public class SystemFailureDUnitTest extends DistributedCacheTestCase {
     }
     
     public void afterCreate(EntryEvent event) {
-      getLogWriter().info("Invoking afterCreate on listener; name=" +
+      com.gemstone.gemfire.test.dunit.LogWriterSupport.getLogWriter().info("Invoking afterCreate on listener; name=" +
                           event.getKey());
       forceInternalError();
     }
@@ -704,7 +704,7 @@ public class SystemFailureDUnitTest extends DistributedCacheTestCase {
     }
     
     public void afterCreate(EntryEvent event) {
-      getLogWriter().info("Invoking afterCreate on listener; name=" +
+      com.gemstone.gemfire.test.dunit.LogWriterSupport.getLogWriter().info("Invoking afterCreate on listener; name=" +
                           event.getKey());
       forceError();
     }
@@ -756,7 +756,7 @@ public class SystemFailureDUnitTest extends DistributedCacheTestCase {
   }
   
   protected void doCreateEntry(String name) {
-    LogWriter log = getLogWriter();
+    LogWriter log = com.gemstone.gemfire.test.dunit.LogWriterSupport.getLogWriter();
     log.info(
         "<ExpectedException action=add>" +
         "dunit.RMIException"

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TXReservationMgrJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TXReservationMgrJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TXReservationMgrJUnitTest.java
index 663ef61..ef5b9ef 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TXReservationMgrJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TXReservationMgrJUnitTest.java
@@ -30,7 +30,7 @@ import com.gemstone.gemfire.cache.CacheFactory;
 import com.gemstone.gemfire.cache.CommitConflictException;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Threads;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
 @Category(IntegrationTest.class)
@@ -124,7 +124,7 @@ public class TXReservationMgrJUnitTest {
       threads[i].start();
     }
     for (int i=0; i < THREAD_COUNT; i++) {
-      DistributedTestCase.join(threads[i], 60 * 1000, null); // increased from 30 to 60 for parallel junit runs
+      Threads.join(threads[i], 60 * 1000, null); // increased from 30 to 60 for parallel junit runs
     }
     int invalidCount = 0;
     for (int i=0; i < KEY_COUNT; i++) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TransactionsWithDeltaDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TransactionsWithDeltaDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TransactionsWithDeltaDUnitTest.java
index 06a8f09..a0549a4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TransactionsWithDeltaDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TransactionsWithDeltaDUnitTest.java
@@ -44,6 +44,7 @@ import com.gemstone.gemfire.internal.cache.execute.data.CustId;
 import com.gemstone.gemfire.internal.cache.execute.data.Order;
 import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
 import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.LogWriterSupport;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.VM;
 
@@ -114,7 +115,7 @@ public class TransactionsWithDeltaDUnitTest extends CacheTestCase {
         ClientCacheFactory ccf = new ClientCacheFactory();
         ccf.addPoolServer("localhost"/*getServerHostName(Host.getHost(0))*/, port);
         ccf.setPoolSubscriptionEnabled(false);
-        ccf.set("log-level", getDUnitLogLevel());
+        ccf.set("log-level", LogWriterSupport.getDUnitLogLevel());
         ClientCache cCache = getClientCache(ccf);
         ClientRegionFactory<Integer, String> crf = cCache
             .createClientRegionFactory(isEmpty ? ClientRegionShortcut.PROXY
@@ -330,7 +331,7 @@ public class TransactionsWithDeltaDUnitTest extends CacheTestCase {
         pr.put(cust1, new Customer(1, "name1"));
         Iterator<CustId> it = pr.keySet().iterator();
         while (it.hasNext()) {
-          getLogWriter().info("SWAP:iterator1:"+pr.get(it.next()));
+          LogWriterSupport.getLogWriter().info("SWAP:iterator1:"+pr.get(it.next()));
         }
         Customer c = pr.get(cust1);
         assertNotNull(c);
@@ -348,10 +349,10 @@ public class TransactionsWithDeltaDUnitTest extends CacheTestCase {
         mgr.begin();
         Customer c = pr.get(cust1);
         c.setName("updatedName");
-        getLogWriter().info("SWAP:doingPut");
+        LogWriterSupport.getLogWriter().info("SWAP:doingPut");
         pr.put(cust1, c);
-        getLogWriter().info("SWAP:getfromtx:"+pr.get(cust1));
-        getLogWriter().info("SWAP:doingCommit");
+        LogWriterSupport.getLogWriter().info("SWAP:getfromtx:"+pr.get(cust1));
+        LogWriterSupport.getLogWriter().info("SWAP:doingCommit");
         assertEquals("updatedName", pr.get(cust1).getName());
         TXStateProxy tx = mgr.internalSuspend();
         assertEquals("name1", pr.get(cust1).getName());

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/control/RebalanceOperationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/control/RebalanceOperationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/control/RebalanceOperationDUnitTest.java
index c67180b..5f4652c 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/control/RebalanceOperationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/control/RebalanceOperationDUnitTest.java
@@ -76,9 +76,13 @@ import com.gemstone.gemfire.internal.cache.partitioned.LoadProbe;
 import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.Invoke;
+import com.gemstone.gemfire.test.dunit.LogWriterSupport;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.Wait;
+import com.gemstone.gemfire.test.dunit.WaitCriterion;
 
 /**
  * @author dsmith
@@ -94,7 +98,7 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
   @Override
   public void tearDown2() throws Exception {
     super.tearDown2();
-    invokeInEveryVM(new SerializableRunnable() {
+    Invoke.invokeInEveryVM(new SerializableRunnable() {
       public void run() {
         InternalResourceManager.setResourceObserver(null);
         System.clearProperty("gemfire.resource.manager.threads");
@@ -329,7 +333,7 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
   }
   
   public void enforceIp(final boolean simulate) {
-    invokeInEveryVM(new SerializableRunnable() {
+    Invoke.invokeInEveryVM(new SerializableRunnable() {
       public void run() {
         Properties props = new Properties();
         props.setProperty(DistributionConfig.ENFORCE_UNIQUE_HOST_NAME, "true");
@@ -427,7 +431,7 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
 
     } finally {
       disconnectFromDS();
-      invokeInEveryVM(new SerializableRunnable() {
+      Invoke.invokeInEveryVM(new SerializableRunnable() {
         public void run() {
           disconnectFromDS(); 
         }
@@ -560,7 +564,7 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
     
     } finally {
       disconnectFromDS();
-      invokeInEveryVM(new SerializableRunnable() {
+      Invoke.invokeInEveryVM(new SerializableRunnable() {
         public void run() {
           //clear the redundancy zone setting
           disconnectFromDS(); 
@@ -765,7 +769,7 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
     checkBucketCount(vm2, "region2", 6);
     } finally {
       disconnectFromDS();
-      invokeInEveryVM(new SerializableRunnable() {
+      Invoke.invokeInEveryVM(new SerializableRunnable() {
         public void run() {
           //clear the redundancy zone setting
           disconnectFromDS(); 
@@ -1099,7 +1103,7 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
   }
   
   public void testRecoverRedundancyParallelAsyncEventQueueSimulation() throws NoSuchFieldException, SecurityException {
-    invokeInEveryVM(new SerializableRunnable() {
+    Invoke.invokeInEveryVM(new SerializableRunnable() {
 
       @Override
       public void run () {
@@ -1868,7 +1872,7 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
           assertEquals(12, details.getCreatedBucketCount());
           assertEquals(1,details.getActualRedundantCopies());
           assertEquals(0,details.getLowRedundancyBucketCount());
-          getLogWriter().info("details=" + details.getPartitionMemberInfo());
+          LogWriterSupport.getLogWriter().info("details=" + details.getPartitionMemberInfo());
           long afterSize = 0;
           for(PartitionMemberInfo memberDetails: details.getPartitionMemberInfo()) {
             assertEquals(8, memberDetails.getBucketCount());
@@ -2010,7 +2014,7 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
         assertEquals(12, details.getCreatedBucketCount());
         assertEquals(1,details.getActualRedundantCopies());
         assertEquals(0,details.getLowRedundancyBucketCount());
-        getLogWriter().info("details=" + details.getPartitionMemberInfo());
+        LogWriterSupport.getLogWriter().info("details=" + details.getPartitionMemberInfo());
         long afterSize = 0;
         for(PartitionMemberInfo memberDetails: details.getPartitionMemberInfo()) {
           assertEquals(8, memberDetails.getBucketCount());
@@ -2079,7 +2083,7 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
           assertEquals(12, details.getCreatedBucketCount());
           assertEquals(1,details.getActualRedundantCopies());
           assertEquals(0,details.getLowRedundancyBucketCount());
-          getLogWriter().info("details=" + details.getPartitionMemberInfo());
+          LogWriterSupport.getLogWriter().info("details=" + details.getPartitionMemberInfo());
           long afterSize = 0;
           for(PartitionMemberInfo memberDetails: details.getPartitionMemberInfo()) {
             assertEquals(6, memberDetails.getBucketCount());
@@ -2194,7 +2198,7 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
         assertEquals(12, details.getCreatedBucketCount());
         assertEquals(1,details.getActualRedundantCopies());
         assertEquals(0,details.getLowRedundancyBucketCount());
-        getLogWriter().info("details=" + details.getPartitionMemberInfo());
+        LogWriterSupport.getLogWriter().info("details=" + details.getPartitionMemberInfo());
         long afterSize = 0;
         for(PartitionMemberInfo memberDetails: details.getPartitionMemberInfo()) {
           assertEquals(8, memberDetails.getBucketCount());
@@ -2504,7 +2508,7 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
     }
     cacheWriter.release();
    
-    getLogWriter().info("starting wait for rebalance.  Will wait for " + MAX_WAIT + " seconds");
+    LogWriterSupport.getLogWriter().info("starting wait for rebalance.  Will wait for " + MAX_WAIT + " seconds");
     RebalanceResults results = rebalance.getResults(MAX_WAIT, TimeUnit.SECONDS);
     assertEquals(2, results.getTotalBucketCreatesCompleted());
     assertEquals(1, results.getTotalPrimaryTransfersCompleted());
@@ -2745,7 +2749,7 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
     // the rebalance op may think that the other member doesn't have buckets, then
     // ask it to create them and get a negative reply because it actually does
     // have the buckets, causing the test to fail
-    pause(10000);  
+    Wait.pause(10000);  
     
     //Try to rebalance again. This shouldn't do anything, because
     //we already recovered redundancy earlier.
@@ -3165,7 +3169,7 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
         Cache cache = getCache();
         final PartitionedRegion region = (PartitionedRegion) cache.getRegion(regionName);
         
-        waitForCriterion(new WaitCriterion() {
+        Wait.waitForCriterion(new WaitCriterion() {
           
           @Override
           public boolean done() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowAsyncRollingOpLogJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowAsyncRollingOpLogJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowAsyncRollingOpLogJUnitTest.java
index 10a7df7..5f0a249 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowAsyncRollingOpLogJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowAsyncRollingOpLogJUnitTest.java
@@ -29,8 +29,8 @@ import com.gemstone.gemfire.*;
 import com.gemstone.gemfire.cache.*;
 import com.gemstone.gemfire.internal.cache.lru.LRUStatistics;
 import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.test.dunit.DistributedTestCase;
-import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.Wait;
+import com.gemstone.gemfire.test.dunit.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
 /**
@@ -168,7 +168,7 @@ public class DiskRegionOverflowAsyncRollingOpLogJUnitTest extends
             return null;
           }
         };
-      DistributedTestCase.waitForCriterion(ev, 30 * 1000, 200, true);
+      Wait.waitForCriterion(ev, 30 * 1000, 200, true);
     }
 
     //Now get 0-9999 entries

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowSyncRollingOpLogJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowSyncRollingOpLogJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowSyncRollingOpLogJUnitTest.java
index df09e2c..d94cf73 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowSyncRollingOpLogJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowSyncRollingOpLogJUnitTest.java
@@ -30,8 +30,8 @@ import static org.junit.Assert.*;
 import com.gemstone.gemfire.*;
 import com.gemstone.gemfire.cache.*;
 import com.gemstone.gemfire.internal.cache.lru.LRUStatistics;
-import com.gemstone.gemfire.test.dunit.DistributedTestCase;
-import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.Wait;
+import com.gemstone.gemfire.test.dunit.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
 /**
@@ -163,7 +163,7 @@ public class DiskRegionOverflowSyncRollingOpLogJUnitTest extends
             return null;
           }
         };
-      DistributedTestCase.waitForCriterion(ev, 30 * 1000, 200, true);
+      Wait.waitForCriterion(ev, 30 * 1000, 200, true);
     }
     
     //Now get 0-9999 entries

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/MultiThreadedOplogPerJUnitPerformanceTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/MultiThreadedOplogPerJUnitPerformanceTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/MultiThreadedOplogPerJUnitPerformanceTest.java
index 719a9b2..4d18cde 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/MultiThreadedOplogPerJUnitPerformanceTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/MultiThreadedOplogPerJUnitPerformanceTest.java
@@ -34,7 +34,7 @@ import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.DiskStoreFactoryImpl;
-import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Threads;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
 @Category(IntegrationTest.class)
@@ -142,7 +142,7 @@ public class MultiThreadedOplogPerJUnitPerformanceTest
     }
 
     for (int i = 0; i < numberOfThreads; i++) {
-      DistributedTestCase.join(threads[i], 30 * 1000, null);
+      Threads.join(threads[i], 30 * 1000, null);
     }
 
     long totalPuts = ((long)numberOfIterations * numberOfKeysPerThread * numberOfThreads);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/Bug51193DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/Bug51193DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/Bug51193DUnitTest.java
index 63fdf64..a5803f2 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/Bug51193DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/Bug51193DUnitTest.java
@@ -42,6 +42,7 @@ import com.gemstone.gemfire.internal.cache.tier.ClientHandShake;
 import com.gemstone.gemfire.internal.cache.tier.sockets.AcceptorImpl;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ServerConnection;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestSupport;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.VM;
 
@@ -117,7 +118,7 @@ public class Bug51193DUnitTest extends DistributedTestCase {
   public static Integer createServerCache(Boolean createPR)
       throws Exception {
     Properties props = new Properties();
-    props.setProperty("locators", "localhost["+getDUnitLocatorPort()+"]");
+    props.setProperty("locators", "localhost["+DistributedTestSupport.getDUnitLocatorPort()+"]");
 
     Bug51193DUnitTest test = new Bug51193DUnitTest("Bug51193DUnitTest");
     DistributedSystem ds = test.getSystem(props);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ClientServerFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ClientServerFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ClientServerFunctionExecutionDUnitTest.java
index 61fd881..982cb79 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ClientServerFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ClientServerFunctionExecutionDUnitTest.java
@@ -35,8 +35,11 @@ import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
 import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.AsyncInvocation;
-import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.IgnoredException;
+import com.gemstone.gemfire.test.dunit.LogWriterSupport;
+import com.gemstone.gemfire.test.dunit.NetworkSupport;
+import com.gemstone.gemfire.test.dunit.Wait;
+import com.gemstone.gemfire.test.dunit.WaitCriterion;
 
 import java.io.Serializable;
 import java.util.ArrayList;
@@ -61,7 +64,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
 
   public void setUp() throws Exception {
     super.setUp();
-    IgnoredException.addExpectedException("java.net.ConnectException");
+    IgnoredException.addIgnoredException("java.net.ConnectException");
   }
 
   
@@ -99,7 +102,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
     registerFunctionAtServer(function);
     isByName = new Boolean(true);   
     toRegister = new Boolean(true);
-    getLogWriter().info("ClientServerFFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
+    LogWriterSupport.getLogWriter().info("ClientServerFFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
         "serverExecution", new Object[] { isByName, function, toRegister});
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
@@ -116,7 +119,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
     registerFunctionAtServer(function);
     isByName = new Boolean(true);   
     toRegister = new Boolean(true);
-    getLogWriter().info("ClientServerFFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
+    LogWriterSupport.getLogWriter().info("ClientServerFFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
         "serverExecution_SendException", new Object[] { isByName, function, toRegister});
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
@@ -135,7 +138,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
     registerFunctionAtServer(function);
     isByName = new Boolean(true);   
     toRegister = new Boolean(true);
-    getLogWriter().info("ClientServerFFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
+    LogWriterSupport.getLogWriter().info("ClientServerFFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
         "serverExecution_NoLastResult", new Object[] { isByName, function, toRegister});
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
@@ -151,7 +154,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
     registerFunctionAtServer(function);
     isByName = new Boolean(true);  
     toRegister = new Boolean(false);
-    getLogWriter().info("ClientServerFFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
+    LogWriterSupport.getLogWriter().info("ClientServerFFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
         "serverExecution", new Object[] { isByName, function, toRegister});
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
@@ -162,7 +165,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
    */   
   public void testServerExecution_byInlineFunction() {
     createScenario();
-    getLogWriter().info("ClientServerFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
+    LogWriterSupport.getLogWriter().info("ClientServerFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
         "serverExecution_Inline");
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
@@ -175,7 +178,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
    */   
   public void testServerExecution_byInlineFunction_InvalidAttrbiutes() {
     createScenario();
-    getLogWriter().info("ClientServerFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
+    LogWriterSupport.getLogWriter().info("ClientServerFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
         "serverExecution_Inline_InvalidAttributes");
   }
@@ -185,7 +188,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
    */
   public void testBug40714() {
     createScenario();
-    getLogWriter()
+    LogWriterSupport.getLogWriter()
         .info(
             "ClientServerFunctionExecutionDUnitTest#testBug40714 : Starting test");
 
@@ -255,7 +258,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
     }
     catch (Exception ex) {
       ex.printStackTrace();
-      getLogWriter().info("Exception : ", ex);
+      LogWriterSupport.getLogWriter().info("Exception : ", ex);
       fail("Test failed after the execute operation.");
     }
   }
@@ -270,7 +273,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
     registerFunctionAtServer(function);
     isByName = new Boolean(true);
     toRegister = new Boolean(true);    
-    getLogWriter().info("ClientServerFFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
+    LogWriterSupport.getLogWriter().info("ClientServerFFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
         "serverExecution", new Object[] { isByName, function, toRegister});
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
@@ -284,7 +287,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
     registerFunctionAtServer(function);
     isByName = new Boolean(true);
     toRegister = new Boolean(false);
-    getLogWriter().info("ClientServerFFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
+    LogWriterSupport.getLogWriter().info("ClientServerFFunctionExecutionDUnitTest#testServerSingleKeyExecution_byName : Starting test");
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
         "serverExecution", new Object[] { isByName, function, toRegister});
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
@@ -302,7 +305,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
     //The test code appears to trigger this because the first
     //call to the function disconnects from the DS but does not call
     //last result;
-    IgnoredException.addExpectedException("did not send last result");
+    IgnoredException.addIgnoredException("did not send last result");
     createScenario();
     
     server1.invoke(
@@ -319,7 +322,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
     
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
         "createProxyRegion",
-        new Object[] { getServerHostName(server1.getHost()) });
+        new Object[] { NetworkSupport.getServerHostName(server1.getHost()) });
     
     function = new TestFunction(true, TestFunction.TEST_FUNCTION_HA_SERVER);
     registerFunctionAtServer(function);
@@ -339,8 +342,8 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
     //The test code appears to trigger this because the first
     //call to the function disconnects from the DS but does not call
     //last result;
-    IgnoredException.addExpectedException("Socket Closed");
-    IgnoredException.addExpectedException("did not send last result");
+    IgnoredException.addIgnoredException("Socket Closed");
+    IgnoredException.addIgnoredException("did not send last result");
     createScenario();
     
     server1.invoke(
@@ -357,7 +360,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
     
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
         "createProxyRegion",
-        new Object[] { getServerHostName(server1.getHost()) });
+        new Object[] { NetworkSupport.getServerHostName(server1.getHost()) });
     
     function = new TestFunction(true, TestFunction.TEST_FUNCTION_HA_SERVER);
     registerFunctionAtServer(function);
@@ -381,7 +384,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
     //The test code appears to trigger this because the first
     //call to the function disconnects from the DS but does not call
     //last result;
-    IgnoredException.addExpectedException("did not send last result");
+    IgnoredException.addIgnoredException("did not send last result");
     createScenario();
     server1.invoke(
         ClientServerFunctionExecutionDUnitTest.class,
@@ -397,7 +400,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
     
     client.invoke(ClientServerFunctionExecutionDUnitTest.class,
         "createProxyRegion",
-        new Object[] { getServerHostName(server1.getHost()) });
+        new Object[] { NetworkSupport.getServerHostName(server1.getHost()) });
     
     function = new TestFunction(true, TestFunction.TEST_FUNCTION_NONHA_SERVER);
     registerFunctionAtServer(function);
@@ -428,7 +431,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
   
   
   private void createScenario() {
-    getLogWriter().info("ClientServerFFunctionExecutionDUnitTest#createScenario : creating scenario");
+    LogWriterSupport.getLogWriter().info("ClientServerFFunctionExecutionDUnitTest#createScenario : creating scenario");
     createClientServerScenarionWithoutRegion();    
   }
    
@@ -447,7 +450,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
       
     }catch (Exception ex) {
       ex.printStackTrace();
-      getLogWriter().info("Exception : " , ex);
+      LogWriterSupport.getLogWriter().info("Exception : " , ex);
       fail("Test failed after the execute operation");
     }
     
@@ -467,7 +470,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
       
     }catch (Exception ex) {
       ex.printStackTrace();
-      getLogWriter().info("Exception : " , ex);
+      LogWriterSupport.getLogWriter().info("Exception : " , ex);
       fail("Test failed after the execute operations");
     }
   }
@@ -504,7 +507,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
       
     }catch (Exception ex) {
       ex.printStackTrace();
-      getLogWriter().info("Exception : " , ex);
+      LogWriterSupport.getLogWriter().info("Exception : " , ex);
       fail("Test failed after the execute operation");
     }
     
@@ -531,7 +534,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
       
     }catch (Exception ex) {
       ex.printStackTrace();
-      getLogWriter().info("Exception : " , ex);
+      LogWriterSupport.getLogWriter().info("Exception : " , ex);
       fail("Test failed after the execute operations");
     }
   }
@@ -576,7 +579,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
       String excuse;
       public boolean done() {
         int sz = pool.getConnectedServerCount();
-        getLogWriter().info(
+        LogWriterSupport.getLogWriter().info(
             "Checking for the Live Servers : Expected  : " + expectedLiveServers
                 + " Available :" + sz);
         if (sz == expectedLiveServers.intValue()) {
@@ -589,7 +592,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
         return excuse;
       }
     };
-    DistributedTestCase.waitForCriterion(wc, 3 * 60 * 1000, 1000, true);
+    Wait.waitForCriterion(wc, 3 * 60 * 1000, 1000, true);
   }
   
   public static Object serverExecutionHAOneServerDown(Boolean isByName, Function function,
@@ -610,7 +613,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
       assertEquals(retryRegionName, ((List)rs.getResult()).get(0));
     } catch (Exception ex) {
       ex.printStackTrace();
-      getLogWriter().info("Exception : ", ex);
+      LogWriterSupport.getLogWriter().info("Exception : ", ex);
       fail("Test failed after the execute operation");
     }
     return rs.getResult();
@@ -633,7 +636,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
     } catch (Exception ex) {
       if (!(ex instanceof ServerConnectivityException)) {
         ex.printStackTrace();
-        getLogWriter().info("Exception : ", ex);
+        LogWriterSupport.getLogWriter().info("Exception : ", ex);
         fail("Test failed after the execute operation");
       }
     }
@@ -657,7 +660,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
     } catch (Exception ex) {
       if (!(ex instanceof ServerConnectivityException)) {
         ex.printStackTrace();
-        getLogWriter().info("Exception : ", ex);
+        LogWriterSupport.getLogWriter().info("Exception : ", ex);
         fail("Test failed after the execute operation");
       }
     }
@@ -731,7 +734,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
       
     }catch (Exception ex) {
       ex.printStackTrace();
-      getLogWriter().info("Exception : " , ex);
+      LogWriterSupport.getLogWriter().info("Exception : " , ex);
       fail("Test failed after the execute operation nn TRUE");
     }
   }
@@ -766,7 +769,7 @@ public static void serverExecution_Inline_InvalidAttributes() {
       fail("Should have failed with Invalid attributes.");
       
     }catch (Exception ex) {
-      getLogWriter().info("Exception : " , ex);
+      LogWriterSupport.getLogWriter().info("Exception : " , ex);
       assertTrue(ex.getMessage().contains(
           "For Functions with isHA true, hasResult must also be true."));
     }
@@ -795,7 +798,7 @@ public static void serverExecution_Inline_InvalidAttributes() {
       
     }catch (Exception ex) {
       ex.printStackTrace();
-      getLogWriter().info("Exception : " , ex);
+      LogWriterSupport.getLogWriter().info("Exception : " , ex);
       fail("Test failed after the execute operation");
     }
     
@@ -820,7 +823,7 @@ public static void serverExecution_Inline_InvalidAttributes() {
           
     }catch (Exception ex) {
       ex.printStackTrace();
-      getLogWriter().info("Exception : " , ex);
+      LogWriterSupport.getLogWriter().info("Exception : " , ex);
       fail("Test failed after the execute operation");
     }
     
@@ -848,7 +851,7 @@ public static void allServerExecution_SendException(Boolean isByName, Function f
       
     }catch (Exception ex) {
       ex.printStackTrace();
-      getLogWriter().info("Exception : " , ex);
+      LogWriterSupport.getLogWriter().info("Exception : " , ex);
       fail("Test failed after the execute operation");
     }
     
@@ -874,7 +877,7 @@ public static void allServerExecution_SendException(Boolean isByName, Function f
       
     }catch (Exception ex) {
       ex.printStackTrace();
-      getLogWriter().info("Exception : " , ex);
+      LogWriterSupport.getLogWriter().info("Exception : " , ex);
       fail("Test failed after the execute operation");
     }
     
@@ -929,7 +932,7 @@ public static void allServerExecution_SendException(Boolean isByName, Function f
            
     }catch (Exception ex) {
       ex.printStackTrace();
-      getLogWriter().info("Exception : " , ex);
+      LogWriterSupport.getLogWriter().info("Exception : " , ex);
       fail("Test failed after the execute operation asdfasdfa   ");
     }
   }
@@ -937,9 +940,9 @@ public static void allServerExecution_SendException(Boolean isByName, Function f
   private static ResultCollector execute(Execution member,
       Serializable args, Function function, Boolean isByName) throws Exception {
     if (isByName.booleanValue()) {// by name
-      getLogWriter().info("The function name to execute : " + function.getId());
+      LogWriterSupport.getLogWriter().info("The function name to execute : " + function.getId());
       Execution me = member.withArgs(args);   
-      getLogWriter().info("The args passed  : " + args);
+      LogWriterSupport.getLogWriter().info("The args passed  : " + args);
       return me.execute(function.getId()); 
     }
     else { // By Instance

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ColocationFailoverDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ColocationFailoverDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ColocationFailoverDUnitTest.java
index 365470c..1cc2038 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ColocationFailoverDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ColocationFailoverDUnitTest.java
@@ -42,8 +42,12 @@ import com.gemstone.gemfire.internal.logging.InternalLogWriter;
 import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.Invoke;
+import com.gemstone.gemfire.test.dunit.LogWriterSupport;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.Wait;
+import com.gemstone.gemfire.test.dunit.WaitCriterion;
 
 public class ColocationFailoverDUnitTest extends DistributedTestCase {
 
@@ -101,7 +105,7 @@ public class ColocationFailoverDUnitTest extends DistributedTestCase {
     putInPRs();
     verifyColocationInAllVms();
     dataStore1.invoke(ColocationFailoverDUnitTest.class, "closeCache");
-    pause(5000); //wait for volunteering primary
+    Wait.pause(5000); //wait for volunteering primary
     verifyColocationAfterFailover();
   }
   
@@ -207,12 +211,12 @@ public class ColocationFailoverDUnitTest extends DistributedTestCase {
         return excuse;
       }
     };
-    DistributedTestCase.waitForCriterion(wc, 60 * 1000, 1000, true);
+    Wait.waitForCriterion(wc, 60 * 1000, 1000, true);
   }
 
   
   protected static void dump() {
-    final InternalLogWriter logger = getLogWriter();
+    final InternalLogWriter logger = LogWriterSupport.getLogWriter();
     ((PartitionedRegion)customerPR).dumpAllBuckets(false);
     ((PartitionedRegion)orderPR).dumpAllBuckets(false);
     ((PartitionedRegion)shipmentPR).dumpAllBuckets(false);
@@ -349,7 +353,7 @@ public class ColocationFailoverDUnitTest extends DistributedTestCase {
         return excuse;
       }
     };
-    DistributedTestCase.waitForCriterion(wc, 2 * 60 * 1000, 1000, true);
+    Wait.waitForCriterion(wc, 2 * 60 * 1000, 1000, true);
   }
 
   public static void createCacheInAllVms() {
@@ -427,7 +431,7 @@ public class ColocationFailoverDUnitTest extends DistributedTestCase {
     if (partitionedRegionName.equals(customerPR_Name)) {
       customerPR = cache.createRegion(partitionedRegionName, attr.create());
       assertNotNull(customerPR);
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "Partitioned Region " + partitionedRegionName
               + " created Successfully :" + customerPR);
 
@@ -435,7 +439,7 @@ public class ColocationFailoverDUnitTest extends DistributedTestCase {
     if (partitionedRegionName.equals(orderPR_Name)) {
       orderPR = cache.createRegion(partitionedRegionName, attr.create());
       assertNotNull(orderPR);
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "Partitioned Region " + partitionedRegionName
               + " created Successfully :" + orderPR);
 
@@ -444,7 +448,7 @@ public class ColocationFailoverDUnitTest extends DistributedTestCase {
     if (partitionedRegionName.equals(shipmentPR_Name)) {
       shipmentPR = cache.createRegion(partitionedRegionName, attr.create());
       assertNotNull(shipmentPR);
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "Partitioned Region " + partitionedRegionName
               + " created Successfully :" + shipmentPR);
 
@@ -469,7 +473,7 @@ public class ColocationFailoverDUnitTest extends DistributedTestCase {
 
   public void tearDown2() throws Exception {
     closeCache();
-    invokeInEveryVM(new SerializableRunnable() {
+    Invoke.invokeInEveryVM(new SerializableRunnable() {
       public void run() {
         closeCache();
       }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/DistributedRegionFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/DistributedRegionFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/DistributedRegionFunctionExecutionDUnitTest.java
index 20a8306..ad90094 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/DistributedRegionFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/DistributedRegionFunctionExecutionDUnitTest.java
@@ -56,8 +56,12 @@ import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.IgnoredException;
+import com.gemstone.gemfire.test.dunit.LogWriterSupport;
+import com.gemstone.gemfire.test.dunit.Threads;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.Wait;
+import com.gemstone.gemfire.test.dunit.WaitCriterion;
 
 public class DistributedRegionFunctionExecutionDUnitTest extends
     DistributedTestCase {
@@ -316,7 +320,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
         "registerFunction", new Object[] { new Boolean(true), new Integer(5) });
 
     // add expected exception to avoid suspect strings
-    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addIgnoredException("I have been thrown");
     replicate1.invoke(DistributedRegionFunctionExecutionDUnitTest.class,
         "executeFunctionFunctionInvocationTargetException");
     ex.remove();
@@ -363,7 +367,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
                 new Integer(0) });
 
     // add expected exception to avoid suspect strings
-    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addIgnoredException("I have been thrown");
     replicate1.invoke(DistributedRegionFunctionExecutionDUnitTest.class,
         "executeFunctionFunctionInvocationTargetExceptionWithoutHA");
     ex.remove();
@@ -403,7 +407,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
         "registerFunction", new Object[] { new Boolean(true), new Integer(5) });
 
     // add expected exception to avoid suspect strings
-    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addIgnoredException("I have been thrown");
     executeFunctionFunctionInvocationTargetException();
     ex.remove();
   }
@@ -445,7 +449,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
             new Integer(0) });
 
     // add expected exception to avoid suspect strings
-    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addIgnoredException("I have been thrown");
     executeFunctionFunctionInvocationTargetExceptionWithoutHA();
     ex.remove();
   }
@@ -533,7 +537,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
     replicate1.invoke(DistributedRegionFunctionExecutionDUnitTest.class,
         "disconnect");
 
-    DistributedTestCase.join(async[0], 50 * 1000, getLogWriter());
+    Threads.join(async[0], 50 * 1000, LogWriterSupport.getLogWriter());
     if (async[0].getException() != null) {
       Assert.fail("UnExpected Exception Occured : ", async[0].getException());
     }
@@ -636,9 +640,9 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
     createClientAndPopulateClientRegion(DataPolicy.EMPTY, port1, port2);
     // add ExpectedException's to servers since client can connect to any
     // one of those
-    final IgnoredException expectedEx = IgnoredException.addExpectedException(
+    final IgnoredException expectedEx = IgnoredException.addIgnoredException(
         "did not send last result", empty1);
-    final IgnoredException expectedEx2 = IgnoredException.addExpectedException(
+    final IgnoredException expectedEx2 = IgnoredException.addIgnoredException(
         "did not send last result", empty2);
     try {
       executeFunction_NoLastResult();
@@ -689,7 +693,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
         "startServerHA");
     emptyServer1.invoke(DistributedRegionFunctionExecutionDUnitTest.class,
         "closeCacheHA");
-    DistributedTestCase.join(async[0], 4 * 60 * 1000, getLogWriter());
+    Threads.join(async[0], 4 * 60 * 1000, LogWriterSupport.getLogWriter());
     if (async[0].getException() != null) {
       Assert.fail("UnExpected Exception Occured : ", async[0].getException());
     }
@@ -732,7 +736,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
 
     createClientAndPopulateClientRegion(DataPolicy.EMPTY, port1, port2);
     // add expected exception
-    final IgnoredException ex = IgnoredException.addExpectedException(
+    final IgnoredException ex = IgnoredException.addIgnoredException(
         "DataPolicy.NORMAL is not supported");
     try {
       executeFunction();
@@ -848,7 +852,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
     createClientAndPopulateClientRegion(DataPolicy.EMPTY, port1, port2);
 
     // add expected exception to avoid suspect strings
-    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addIgnoredException("I have been thrown");
     executeFunctionFunctionInvocationTargetException_ClientServer();
     ex.remove();
   }
@@ -899,7 +903,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
     createClientAndPopulateClientRegion(DataPolicy.EMPTY, port1, port2);
 
     // add expected exception to avoid suspect strings
-    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addIgnoredException("I have been thrown");
     executeFunctionFunctionInvocationTargetException_ClientServer_WithoutHA();
     ex.remove();
   }
@@ -941,7 +945,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
         "registerFunction", new Object[] { new Boolean(true), new Integer(5) });
 
     // add expected exception to avoid suspect strings
-    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addIgnoredException("I have been thrown");
     executeFunctionFunctionInvocationTargetException_ClientServer();
     ex.remove();
   }
@@ -991,7 +995,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
                 new Integer(0) });
 
     // add expected exception to avoid suspect strings
-    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addIgnoredException("I have been thrown");
     executeFunctionFunctionInvocationTargetException_ClientServer_WithoutHA();
     ex.remove();
   }
@@ -1081,7 +1085,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
   }
   
   public void testFunctionWithNoResultThrowsException(){
-    IgnoredException.addExpectedException("RuntimeException");
+    IgnoredException.addIgnoredException("RuntimeException");
     replicate1.invoke(DistributedRegionFunctionExecutionDUnitTest.class,
         "createCacheInVm");
     replicate2.invoke(DistributedRegionFunctionExecutionDUnitTest.class,
@@ -1099,7 +1103,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
     createClientAndPopulateClientRegion(DataPolicy.EMPTY, port1, port2);
 
     executeFunctionWithNoResultThrowException();
-    pause(10000);
+    Wait.pause(10000);
   }
   
   public static void executeFunction_NoResult() {
@@ -1134,7 +1138,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
       ds.disconnect();
     }
     catch (Exception e) {
-      getLogWriter().info("Exception Occured : " + e.getMessage());
+      LogWriterSupport.getLogWriter().info("Exception Occured : " + e.getMessage());
       e.printStackTrace();
       Assert.fail("Test failed", e);
     }
@@ -1414,7 +1418,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
     factory.setDataPolicy(policy);
     assertNotNull(cache);
     region = cache.createRegion(REGION_NAME, factory.create());
-    getLogWriter().info("Client Region Created :" + region);
+    LogWriterSupport.getLogWriter().info("Client Region Created :" + region);
     assertNotNull(region);
     for (int i = 1; i <= 200; i++) {
       region.put("execKey-" + i, new Integer(i));
@@ -1440,7 +1444,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
     factory.setPoolName(p.getName());
     assertNotNull(cache);
     region = cache.createRegion(REGION_NAME, factory.create());
-    getLogWriter().info("Client Region Created :" + region);
+    LogWriterSupport.getLogWriter().info("Client Region Created :" + region);
     assertNotNull(region);
   }
 
@@ -1450,7 +1454,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
     factory.setDataPolicy(policy);
     assertNotNull(cache);
     region = cache.createRegion(REGION_NAME, factory.create());
-    getLogWriter().info("Region Created :" + region);
+    LogWriterSupport.getLogWriter().info("Region Created :" + region);
     assertNotNull(region);
 
     CacheServer server = cache.addCacheServer();
@@ -1473,7 +1477,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
     factory.setDataPolicy(policy);
     assertNotNull(cache);
     region = cache.createRegion(REGION_NAME, factory.create());
-    getLogWriter().info("Region Created :" + region);
+    LogWriterSupport.getLogWriter().info("Region Created :" + region);
     assertNotNull(region);
   }
   
@@ -1493,7 +1497,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
       ds.disconnect();
       ds = getSystem(props);
       cache = CacheFactory.create(ds);
-      getLogWriter().info("Created Cache on peer");
+      LogWriterSupport.getLogWriter().info("Created Cache on peer");
       assertNotNull(cache);
       FunctionService.registerFunction(function);
     }
@@ -1517,7 +1521,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
         return excuse;
       }
     };
-    DistributedTestCase.waitForCriterion(wc, 3000, 200, false);
+    Wait.waitForCriterion(wc, 3000, 200, false);
     long endTime = System.currentTimeMillis();
     region.getCache().getLogger().fine(
         "Time wait for Cache Close = " + (endTime - startTime));
@@ -1536,13 +1540,13 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
         return excuse;
       }
     };
-    DistributedTestCase.waitForCriterion(wc, 2000, 500, false);
+    Wait.waitForCriterion(wc, 2000, 500, false);
     Collection bridgeServers = cache.getCacheServers();
-    getLogWriter().info(
+    LogWriterSupport.getLogWriter().info(
         "Start Server Bridge Servers list : " + bridgeServers.size());
     Iterator bridgeIterator = bridgeServers.iterator();
     CacheServer bridgeServer = (CacheServer)bridgeIterator.next();
-    getLogWriter().info("start Server Bridge Server" + bridgeServer);
+    LogWriterSupport.getLogWriter().info("start Server Bridge Server" + bridgeServer);
     try {
       bridgeServer.start();
     }
@@ -1563,7 +1567,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
         return excuse;
       }
     };
-    DistributedTestCase.waitForCriterion(wc, 1000, 200, false);
+    Wait.waitForCriterion(wc, 1000, 200, false);
     try {
       Iterator iter = cache.getCacheServers().iterator();
       if (iter.hasNext()) {
@@ -1588,7 +1592,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
         return excuse;
       }
     };
-    DistributedTestCase.waitForCriterion(wc, 1000, 200, false);
+    Wait.waitForCriterion(wc, 1000, 200, false);
     if (cache != null && !cache.isClosed()) {
       try {
         Iterator iter = cache.getCacheServers().iterator();
@@ -1618,7 +1622,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
         return excuse;
       }
     };
-    DistributedTestCase.waitForCriterion(wc, 2000, 200, false);
+    Wait.waitForCriterion(wc, 2000, 200, false);
     long endTime = System.currentTimeMillis();
     region.getCache().getLogger().fine(
         "Time wait for Disconnecting = " + (endTime - startTime));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/FunctionServiceStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/FunctionServiceStatsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/FunctionServiceStatsDUnitTest.java
index 0ff435a..5235a4f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/FunctionServiceStatsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/FunctionServiceStatsDUnitTest.java
@@ -53,11 +53,12 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegionTestHelper;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
 import com.gemstone.gemfire.test.dunit.Assert;
-import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.LogWriterSupport;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.VM;
-import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.Wait;
+import com.gemstone.gemfire.test.dunit.WaitCriterion;
 
 /*
  * This is DUnite Test to test the Function Execution stats under various
@@ -262,7 +263,7 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
 
         }
         catch (Exception e) {
-          getLogWriter().info("Exception : " + e.getMessage());
+          LogWriterSupport.getLogWriter().info("Exception : " + e.getMessage());
           e.printStackTrace();
           fail("Test failed after the put operation");
         }
@@ -286,9 +287,9 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
             .getFunctionExecutionsCompleted());
         assertTrue(functionServiceStats.getResultsReceived() >= resultReceived_Aggregate);
 
-        getLogWriter().info("Calling FunctionStats for  TEST_FUNCTION2 :");
+        LogWriterSupport.getLogWriter().info("Calling FunctionStats for  TEST_FUNCTION2 :");
         FunctionStats functionStats = FunctionStats.getFunctionStats(TestFunction.TEST_FUNCTION2, iDS);
-        getLogWriter().info("Called FunctionStats for  TEST_FUNCTION2 :");
+        LogWriterSupport.getLogWriter().info("Called FunctionStats for  TEST_FUNCTION2 :");
         assertEquals(noOfExecutionCalls_TESTFUNCTION2, functionStats
             .getFunctionExecutionCalls());
         assertEquals(noOfExecutionsCompleted_TESTFUNCTION2, functionStats
@@ -379,14 +380,14 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
           ds.disconnect();
           ds = getSystem(props);
           cache = CacheFactory.create(ds);
-          getLogWriter().info("Created Cache on Server");
+          LogWriterSupport.getLogWriter().info("Created Cache on Server");
           assertNotNull(cache);
           AttributesFactory factory = new AttributesFactory();
           factory.setScope(Scope.DISTRIBUTED_ACK);
           factory.setDataPolicy(DataPolicy.REPLICATE);
           assertNotNull(cache);
           Region region = cache.createRegion(regionName, factory.create());
-          getLogWriter().info("Region Created :" + region);
+          LogWriterSupport.getLogWriter().info("Region Created :" + region);
           assertNotNull(region);
           for (int i = 1; i <= 200; i++) {
             region.put("execKey-" + i, new Integer(i));
@@ -428,7 +429,7 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
           ds.disconnect();
           ds = getSystem(props);
           cache = CacheFactory.create(ds);
-          getLogWriter().info("Created Cache on Client");
+          LogWriterSupport.getLogWriter().info("Created Cache on Client");
           assertNotNull(cache);
 
 
@@ -453,7 +454,7 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
           factory.setPoolName(p.getName());
           assertNotNull(cache);
           Region region = cache.createRegion(regionName, factory.create());
-          getLogWriter().info("Client Region Created :" + region);
+          LogWriterSupport.getLogWriter().info("Client Region Created :" + region);
           assertNotNull(region);
           for (int i = 1; i <= 200; i++) {
             region.put("execKey-" + i, new Integer(i));
@@ -604,7 +605,7 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
         }
         catch (Exception ex) {
           ex.printStackTrace();
-          getLogWriter().info("Exception : ", ex);
+          LogWriterSupport.getLogWriter().info("Exception : ", ex);
           fail("Test failed after the execute operation nn TRUE");
         }
         function = new TestFunction(true, TestFunction.TEST_FUNCTION5);
@@ -626,7 +627,7 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
         }
         catch (Exception ex) {
           ex.printStackTrace();
-          getLogWriter().info("Exception : ", ex);
+          LogWriterSupport.getLogWriter().info("Exception : ", ex);
           fail("Test failed after the execute operationssssss");
         }
         return Boolean.TRUE;
@@ -974,7 +975,7 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
         factory.setScope(Scope.DISTRIBUTED_ACK);
         factory.setDataPolicy(DataPolicy.EMPTY);
         Region region = getCache().createRegion(rName, factory.create());
-        getLogWriter().info("Region Created :" + region);
+        LogWriterSupport.getLogWriter().info("Region Created :" + region);
         assertNotNull(region);
         FunctionService.registerFunction(new TestFunction(true, TestFunction.TEST_FUNCTION2));
         for (int i = 1; i <= 200; i++) {
@@ -992,7 +993,7 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
         factory.setScope(Scope.DISTRIBUTED_ACK);
         factory.setDataPolicy(DataPolicy.REPLICATE);
         Region region = getCache().createRegion(rName, factory.create());
-        getLogWriter().info("Region Created :" + region);
+        LogWriterSupport.getLogWriter().info("Region Created :" + region);
         assertNotNull(region);
         FunctionService.registerFunction(new TestFunction(true, TestFunction.TEST_FUNCTION2));
         for (int i = 1; i <= 200; i++) {
@@ -1146,7 +1147,7 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
           
         }
         catch (Exception e) {
-          getLogWriter().info("Exception Occured : " + e.getMessage());
+          LogWriterSupport.getLogWriter().info("Exception Occured : " + e.getMessage());
           e.printStackTrace();
           Assert.fail("Test failed", e);
         }
@@ -1295,7 +1296,7 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
               return excuse;
             }
           };
-          DistributedTestCase.waitForCriterion(wc, 20000, 1000, false);
+          Wait.waitForCriterion(wc, 20000, 1000, false);
           rc.getResult();
         }
         catch (Exception expected) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetDUnitTest.java
index cb63a35..be26687 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetDUnitTest.java
@@ -47,6 +47,7 @@ import com.gemstone.gemfire.internal.cache.functions.LocalDataSetFunction;
 import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.LogWriterSupport;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
@@ -142,7 +143,7 @@ public class LocalDataSetDUnitTest extends CacheTestCase {
       Region localRegion = PartitionRegionHelper.getLocalDataForContext((RegionFunctionContext)context);
       Iterator it = localRegion.keySet().iterator();
       while (it.hasNext()) {
-        getLogWriter().info("LocalKeys:"+it.next());
+        LogWriterSupport.getLogWriter().info("LocalKeys:"+it.next());
       }
       context.getResultSender().lastResult(Boolean.TRUE);
     }
@@ -303,7 +304,7 @@ public class LocalDataSetDUnitTest extends CacheTestCase {
     if (partitionedRegionName.equals("CustomerPR")) {
       customerPR = cache.createRegion(partitionedRegionName, attr.create());
       assertNotNull(customerPR);
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "Partitioned Region " + partitionedRegionName
               + " created Successfully :" + customerPR);
 
@@ -311,7 +312,7 @@ public class LocalDataSetDUnitTest extends CacheTestCase {
     if (partitionedRegionName.equals("OrderPR")) {
       orderPR = cache.createRegion(partitionedRegionName, attr.create());
       assertNotNull(orderPR);
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "Partitioned Region " + partitionedRegionName
               + " created Successfully :" + orderPR);
 
@@ -320,7 +321,7 @@ public class LocalDataSetDUnitTest extends CacheTestCase {
     if (partitionedRegionName.equals("ShipmentPR")) {
       shipmentPR = cache.createRegion(partitionedRegionName, attr.create());
       assertNotNull(shipmentPR);
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "Partitioned Region " + partitionedRegionName
               + " created Successfully :" + shipmentPR);
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalFunctionExecutionDUnitTest.java
index 7dd8c1c..238ddba 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalFunctionExecutionDUnitTest.java
@@ -37,6 +37,8 @@ import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.Invoke;
+import com.gemstone.gemfire.test.dunit.LogWriterSupport;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
 
@@ -114,7 +116,7 @@ public class LocalFunctionExecutionDUnitTest extends DistributedTestCase{
     
     region = cache.createRegion(partitionedRegionName, attr.create());
     assertNotNull(region);
-    getLogWriter().info(
+    LogWriterSupport.getLogWriter().info(
         "Partitioned Region " + partitionedRegionName
             + " created Successfully :" + region);
   }
@@ -127,7 +129,7 @@ public class LocalFunctionExecutionDUnitTest extends DistributedTestCase{
     assertNotNull(cache);
     region = cache.createRegion(distributedRegionName, attr.create());
     assertNotNull(region);
-    getLogWriter().info(
+    LogWriterSupport.getLogWriter().info(
         "Distributed Region " + distributedRegionName
             + " created Successfully :" + region);
   }
@@ -173,7 +175,7 @@ public class LocalFunctionExecutionDUnitTest extends DistributedTestCase{
       cache.close();
     }
     cache = null;
-    invokeInEveryVM(new SerializableRunnable() { public void run() {
+    Invoke.invokeInEveryVM(new SerializableRunnable() { public void run() {
       if(cache != null) {
         cache.close();
       }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/76e324b5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutionDUnitTest.java
index 275dda9..fcf264f 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutionDUnitTest.java
@@ -50,6 +50,7 @@ import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 import com.gemstone.gemfire.test.dunit.Assert;
 import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.LogWriterSupport;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
@@ -167,7 +168,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
       resultCollector.getResult();
       fail("Should have received FunctionException due to class not found");
     } catch (FunctionException expected) {
-      getLogWriter().warning("received wrong exception cause", expected.getCause());
+      LogWriterSupport.getLogWriter().warning("received wrong exception cause", expected.getCause());
       assertTrue((expected.getCause() instanceof ClassNotFoundException));
     }
   }
@@ -386,7 +387,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
         }
       });
       List li = (ArrayList)rc.getResult();
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "MemberFunctionExecutionDUnitTest#excuteOnMembers: Result : " + li);
       assertEquals(li.size(), 1);
       for (Object obj : li) {
@@ -395,7 +396,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
       ds.disconnect();
     }
     catch (Exception e) {
-      getLogWriter().info("Exception Occured : "+ e.getMessage());
+      LogWriterSupport.getLogWriter().info("Exception Occured : "+ e.getMessage());
       e.printStackTrace();
       Assert.fail("Test failed",e);
     }
@@ -443,7 +444,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
     try {
       ResultCollector rc = executor.execute(function.getId());
       List li = (ArrayList)rc.getResult();
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "MemberFunctionExecutionDUnitTest#excuteOnMembers: Result : " + li);
       assertEquals(li.size(), noOfMembers.intValue());
       for (Object obj : li) {
@@ -451,7 +452,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
       }
     }
     catch (Exception e) {
-      getLogWriter().info("Exception Occured : "+ e.getMessage());
+      LogWriterSupport.getLogWriter().info("Exception Occured : "+ e.getMessage());
       e.printStackTrace();
       Assert.fail("Test failed",e);
     }
@@ -483,7 +484,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
     try {
       ResultCollector rc = memberExcution.withArgs(Boolean.TRUE).execute(function);
       List li = (ArrayList)rc.getResult();
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "MemberFunctionExecutionDUnitTest#excuteOnMembers: Result : " + li);
       assertEquals(noOfMembers.intValue(), li.size());
       for (Object obj : li) {
@@ -491,7 +492,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
       }
     }
     catch (Exception e) {
-      getLogWriter().info("Exception Occured : "+ e.getMessage());
+      LogWriterSupport.getLogWriter().info("Exception Occured : "+ e.getMessage());
       e.printStackTrace();
       Assert.fail("Test failed",e);
     }
@@ -585,7 +586,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
         }
       });
       List li = (ArrayList)rc.getResult();
-      getLogWriter().info(
+      LogWriterSupport.getLogWriter().info(
           "MemberFunctionExecutionDUnitTest#excuteOnMembers: Result : " + li);
       assertEquals(li.size(), noOfMembers.intValue());
       for (Object obj : li) {
@@ -593,7 +594,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
       }
     }
     catch (Exception e) {
-      getLogWriter().info("Exception Occured : "+ e.getMessage());
+      LogWriterSupport.getLogWriter().info("Exception Occured : "+ e.getMessage());
       e.printStackTrace();
       Assert.fail("Test failed",e);
     }
@@ -613,7 +614,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
       fail("Test Failed");
     }
     catch (Exception expected) {
-      getLogWriter().info("Exception Occured : "+ expected.getMessage());
+      LogWriterSupport.getLogWriter().info("Exception Occured : "+ expected.getMessage());
 //      boolean check = expected.getMessage().equals("Cannot return any result, as Function.hasResult() is false");
       assertTrue(expected.getMessage().equals(LocalizedStrings.ExecuteFunction_CANNOT_0_RESULTS_HASRESULT_FALSE
           .toLocalizedString("return any")));