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/01 21:55:59 UTC

[42/50] [abbrv] incubator-geode git commit: Refactor dunit

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllDAckDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllDAckDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllDAckDUnitTest.java
index b192a43..d995f35 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllDAckDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllDAckDUnitTest.java
@@ -38,6 +38,7 @@ import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 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.VM;
@@ -144,7 +145,7 @@ public class PutAllDAckDUnitTest extends DistributedTestCase {
                 obj = region.put(ob, str);
             }
         }catch(Exception ex){
-            fail("Failed while region.put", ex);
+            Assert.fail("Failed while region.put", ex);
         }
         return obj;
     }//end of putMethod
@@ -162,7 +163,7 @@ public class PutAllDAckDUnitTest extends DistributedTestCase {
             region.putAll(m);
             
         }catch(Exception ex){
-            fail("Failed while region.putAll", ex);
+            Assert.fail("Failed while region.putAll", ex);
         }
     }//end of putAllMethod
     

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllGlobalDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllGlobalDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllGlobalDUnitTest.java
index 0aa77f0..a7274d5 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllGlobalDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllGlobalDUnitTest.java
@@ -44,6 +44,7 @@ import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.locks.DLockGrantor;
+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.Host;
@@ -196,7 +197,7 @@ public class PutAllGlobalDUnitTest extends DistributedTestCase {
                     }
                 }
                 catch(Exception ex){
-                  fail("async2 threw unexpected exception", ex);
+                  Assert.fail("async2 threw unexpected exception", ex);
                     //ex.printStackTrace();
                 } 
             }
@@ -205,12 +206,12 @@ public class PutAllGlobalDUnitTest extends DistributedTestCase {
         DistributedTestCase.join(async2, 30 * 1000, getLogWriter());
         if (async2.exceptionOccurred()) {
           DistributedTestCase.join(async1, 30 * 1000, getLogWriter());
-          fail("async2 failed", async2.getException());
+          Assert.fail("async2 failed", async2.getException());
         }
         
         DistributedTestCase.join(async1, 30 * 1000, getLogWriter());
         if (async1.exceptionOccurred()) {
-          fail("async1 failed", async1.getException());
+          Assert.fail("async1 failed", async1.getException());
         }
         
     }//end of test case1
@@ -231,7 +232,7 @@ public class PutAllGlobalDUnitTest extends DistributedTestCase {
             
         }catch(Exception ex){
 //            ex.printStackTrace();
-            fail("Failed while region.putAll", ex);
+            Assert.fail("Failed while region.putAll", ex);
         }
     }//end of putAllMethod
     

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoteTransactionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoteTransactionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoteTransactionDUnitTest.java
index 8a58653..8467650 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoteTransactionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoteTransactionDUnitTest.java
@@ -98,6 +98,7 @@ import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.IgnoredException;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
@@ -3919,7 +3920,7 @@ protected static class ClientListener extends CacheListenerAdapter {
       
       //Putting a string key causes this, the partition resolver
       //doesn't handle it.
-      addExpectedException("IllegalStateException");
+      IgnoredException.addExpectedException("IllegalStateException");
       assertEquals(Status.STATUS_ACTIVE, tx.getStatus());
       final CountDownLatch latch = new CountDownLatch(1);
       Thread t = new Thread(new Runnable() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/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 7ccdd6a..02ed1cd 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
@@ -36,6 +36,7 @@ import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 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.VM;
@@ -139,7 +140,7 @@ public class RemoveAllDAckDUnitTest extends DistributedTestCase {
                 obj = region.put(ob, str);
             }
         }catch(Exception ex){
-            fail("Failed while region.put", ex);
+            Assert.fail("Failed while region.put", ex);
         }
         return obj;
     }//end of putMethod

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/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 a6023c7..502654b 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
@@ -41,6 +41,7 @@ import com.gemstone.gemfire.internal.cache.execute.data.CustId;
 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.Host;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
@@ -239,7 +240,7 @@ public class SingleHopStatsDUnitTest extends CacheTestCase{
       server.start();
     }
     catch (IOException e) {
-      fail("Failed to start server ", e);
+      Assert.fail("Failed to start server ", e);
     }
 
     if (colocation.equals("No_Colocation")) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SizingFlagDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SizingFlagDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SizingFlagDUnitTest.java
index 19170f2..90360ef 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SizingFlagDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SizingFlagDUnitTest.java
@@ -46,6 +46,7 @@ import com.gemstone.gemfire.distributed.DistributedMember;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 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.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
@@ -358,7 +359,7 @@ public class SizingFlagDUnitTest extends CacheTestCase {
         try {
           region.getAttributesMutator().addCacheListener(new TestCacheListener());
         } catch (Exception e) {
-          fail("couldn't create index", e);
+          Assert.fail("couldn't create index", e);
         }
       }
     });

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/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 e3858fb..ac132ae 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
@@ -398,7 +398,7 @@ public class SystemFailureDUnitTest extends DistributedCacheTestCase {
   
   protected static Boolean verifyConnected() {
     if (SystemFailure.getFailure() != null) {
-      fail("System failure present!", SystemFailure.getFailure());
+      com.gemstone.gemfire.test.dunit.Assert.fail("System failure present!", SystemFailure.getFailure());
       return Boolean.FALSE;
     }
     GemFireCacheImpl gfc = (GemFireCacheImpl)cache;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/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 1c25dcc..003e867 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
@@ -73,6 +73,7 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceObserverAdapter;
 import com.gemstone.gemfire.internal.cache.partitioned.BucketCountLoadProbe;
 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.SerializableCallable;
@@ -610,7 +611,7 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
         try {
           barrier.await(MAX_WAIT, TimeUnit.SECONDS);
         } catch (Exception e) {
-          fail("failed waiting for barrier", e);
+          Assert.fail("failed waiting for barrier", e);
         }
         observerCalled = true;
       } else {
@@ -819,9 +820,9 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
           .simulate()
           .getResults(MAX_WAIT, TimeUnit.SECONDS);
       } catch (InterruptedException e) {
-        fail("Interrupted waiting on rebalance", e);
+        Assert.fail("Interrupted waiting on rebalance", e);
       } catch (TimeoutException e) {
-        fail("Timeout waiting on rebalance", e);
+        Assert.fail("Timeout waiting on rebalance", e);
       }
     } else {
       try {
@@ -831,9 +832,9 @@ public class RebalanceOperationDUnitTest extends CacheTestCase {
         .start()
         .getResults(MAX_WAIT, TimeUnit.SECONDS);
       } catch (InterruptedException e) {
-        fail("Interrupted waiting on rebalance", e);
+        Assert.fail("Interrupted waiting on rebalance", e);
       } catch (TimeoutException e) {
-        fail("Timeout waiting on rebalance", e);
+        Assert.fail("Timeout waiting on rebalance", e);
       }
     }
     assertEquals(Collections.emptySet(), manager.getRebalanceOperations());

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/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 1e78da2..61fd881 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
@@ -33,8 +33,10 @@ import com.gemstone.gemfire.cache.execute.ResultCollector;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 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 java.io.Serializable;
 import java.util.ArrayList;
@@ -59,7 +61,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
 
   public void setUp() throws Exception {
     super.setUp();
-    addExpectedException("java.net.ConnectException");
+    IgnoredException.addExpectedException("java.net.ConnectException");
   }
 
   
@@ -300,7 +302,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;
-    addExpectedException("did not send last result");
+    IgnoredException.addExpectedException("did not send last result");
     createScenario();
     
     server1.invoke(
@@ -337,8 +339,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;
-    addExpectedException("Socket Closed");
-    addExpectedException("did not send last result");
+    IgnoredException.addExpectedException("Socket Closed");
+    IgnoredException.addExpectedException("did not send last result");
     createScenario();
     
     server1.invoke(
@@ -379,7 +381,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;
-    addExpectedException("did not send last result");
+    IgnoredException.addExpectedException("did not send last result");
     createScenario();
     server1.invoke(
         ClientServerFunctionExecutionDUnitTest.class,
@@ -678,7 +680,7 @@ public class ClientServerFunctionExecutionDUnitTest extends PRClientServerTestBa
       assertTrue(((Integer)list.get(1)) == 5);
     } catch (Exception ex) {
       ex.printStackTrace();
-      fail("This is not expected Exception", ex);
+      Assert.fail("This is not expected Exception", ex);
     }
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/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 81b9984..365470c 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
@@ -39,6 +39,7 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.partitioned.RegionAdvisor;
 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.SerializableRunnable;
@@ -374,7 +375,7 @@ public class ColocationFailoverDUnitTest extends DistributedTestCase {
       assertNotNull(cache);
     }
     catch (Exception e) {
-      fail("Failed while creating the cache", e);
+      Assert.fail("Failed while creating the cache", e);
     }
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/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 286a5bd..20a8306 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
@@ -52,8 +52,10 @@ import com.gemstone.gemfire.internal.cache.functions.DistribuedRegionFunctionFun
 import com.gemstone.gemfire.internal.cache.functions.DistributedRegionFunction;
 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.Host;
 import com.gemstone.gemfire.test.dunit.VM;
 
@@ -314,7 +316,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
         "registerFunction", new Object[] { new Boolean(true), new Integer(5) });
 
     // add expected exception to avoid suspect strings
-    final ExpectedException ex = addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
     replicate1.invoke(DistributedRegionFunctionExecutionDUnitTest.class,
         "executeFunctionFunctionInvocationTargetException");
     ex.remove();
@@ -361,7 +363,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
                 new Integer(0) });
 
     // add expected exception to avoid suspect strings
-    final ExpectedException ex = addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
     replicate1.invoke(DistributedRegionFunctionExecutionDUnitTest.class,
         "executeFunctionFunctionInvocationTargetExceptionWithoutHA");
     ex.remove();
@@ -401,7 +403,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
         "registerFunction", new Object[] { new Boolean(true), new Integer(5) });
 
     // add expected exception to avoid suspect strings
-    final ExpectedException ex = addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
     executeFunctionFunctionInvocationTargetException();
     ex.remove();
   }
@@ -443,7 +445,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
             new Integer(0) });
 
     // add expected exception to avoid suspect strings
-    final ExpectedException ex = addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
     executeFunctionFunctionInvocationTargetExceptionWithoutHA();
     ex.remove();
   }
@@ -533,7 +535,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
 
     DistributedTestCase.join(async[0], 50 * 1000, getLogWriter());
     if (async[0].getException() != null) {
-      fail("UnExpected Exception Occured : ", async[0].getException());
+      Assert.fail("UnExpected Exception Occured : ", async[0].getException());
     }
     List l = (List)async[0].getReturnValue();
     assertEquals(5001, l.size());
@@ -634,9 +636,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 ExpectedException expectedEx = addExpectedException(
+    final IgnoredException expectedEx = IgnoredException.addExpectedException(
         "did not send last result", empty1);
-    final ExpectedException expectedEx2 = addExpectedException(
+    final IgnoredException expectedEx2 = IgnoredException.addExpectedException(
         "did not send last result", empty2);
     try {
       executeFunction_NoLastResult();
@@ -689,7 +691,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
         "closeCacheHA");
     DistributedTestCase.join(async[0], 4 * 60 * 1000, getLogWriter());
     if (async[0].getException() != null) {
-      fail("UnExpected Exception Occured : ", async[0].getException());
+      Assert.fail("UnExpected Exception Occured : ", async[0].getException());
     }
     List l = (List)async[0].getReturnValue();
     assertEquals(5001, l.size());
@@ -730,7 +732,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
 
     createClientAndPopulateClientRegion(DataPolicy.EMPTY, port1, port2);
     // add expected exception
-    final ExpectedException ex = addExpectedException(
+    final IgnoredException ex = IgnoredException.addExpectedException(
         "DataPolicy.NORMAL is not supported");
     try {
       executeFunction();
@@ -846,7 +848,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
     createClientAndPopulateClientRegion(DataPolicy.EMPTY, port1, port2);
 
     // add expected exception to avoid suspect strings
-    final ExpectedException ex = addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
     executeFunctionFunctionInvocationTargetException_ClientServer();
     ex.remove();
   }
@@ -897,7 +899,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
     createClientAndPopulateClientRegion(DataPolicy.EMPTY, port1, port2);
 
     // add expected exception to avoid suspect strings
-    final ExpectedException ex = addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
     executeFunctionFunctionInvocationTargetException_ClientServer_WithoutHA();
     ex.remove();
   }
@@ -939,7 +941,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
         "registerFunction", new Object[] { new Boolean(true), new Integer(5) });
 
     // add expected exception to avoid suspect strings
-    final ExpectedException ex = addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
     executeFunctionFunctionInvocationTargetException_ClientServer();
     ex.remove();
   }
@@ -989,7 +991,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
                 new Integer(0) });
 
     // add expected exception to avoid suspect strings
-    final ExpectedException ex = addExpectedException("I have been thrown");
+    final IgnoredException ex = IgnoredException.addExpectedException("I have been thrown");
     executeFunctionFunctionInvocationTargetException_ClientServer_WithoutHA();
     ex.remove();
   }
@@ -1079,7 +1081,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
   }
   
   public void testFunctionWithNoResultThrowsException(){
-    addExpectedException("RuntimeException");
+    IgnoredException.addExpectedException("RuntimeException");
     replicate1.invoke(DistributedRegionFunctionExecutionDUnitTest.class,
         "createCacheInVm");
     replicate2.invoke(DistributedRegionFunctionExecutionDUnitTest.class,
@@ -1134,7 +1136,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
     catch (Exception e) {
       getLogWriter().info("Exception Occured : " + e.getMessage());
       e.printStackTrace();
-      fail("Test failed", e);
+      Assert.fail("Test failed", e);
     }
   }
   
@@ -1314,7 +1316,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
     }
     catch (Exception e) {
       e.printStackTrace();
-      fail("This is not expected Exception", e);
+      Assert.fail("This is not expected Exception", e);
     }
   }
 
@@ -1344,7 +1346,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
     }
     catch (Exception e) {
       e.printStackTrace();
-      fail("This is not expected Exception", e);
+      Assert.fail("This is not expected Exception", e);
     }
   }
 
@@ -1459,7 +1461,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
       server.start();
     }
     catch (IOException e) {
-      fail("Failed to start the Server", e);
+      Assert.fail("Failed to start the Server", e);
     }
     assertTrue(server.isRunning());
     return new Integer(server.getPort());
@@ -1496,7 +1498,7 @@ public class DistributedRegionFunctionExecutionDUnitTest extends
       FunctionService.registerFunction(function);
     }
     catch (Exception e) {
-      fail(
+      Assert.fail(
           "DistributedRegionFunctionExecutionDUnitTest#createCache() Failed while creating the cache",
           e);
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/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 3c36a60..f695d0b 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
@@ -52,6 +52,7 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 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.SerializableCallable;
@@ -398,13 +399,13 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
             server.start();
           }
           catch (IOException e) {
-            fail("Failed to start the Server", e);
+            Assert.fail("Failed to start the Server", e);
           }
           assertTrue(server.isRunning());
           return new Integer(server.getPort());
         }
         catch (Exception e) {
-          fail(
+          Assert.fail(
               "FunctionServiceStatsDUnitTest#createCache() Failed while creating the cache",
               e);
           throw e;
@@ -460,7 +461,7 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
           return Boolean.TRUE;
         }
         catch (Exception e) {
-          fail(
+          Assert.fail(
               "FunctionServiceStatsDUnitTest#createCache() Failed while creating the cache",
               e);
           throw e;
@@ -517,12 +518,12 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
         }
         catch (FunctionException e) {
           e.printStackTrace();
-          fail("test failed due to", e);
+          Assert.fail("test failed due to", e);
           throw e;
         }
         catch (Exception e) {
           e.printStackTrace();
-          fail("test failed due to", e);
+          Assert.fail("test failed due to", e);
           throw e;
         }
       
@@ -1028,12 +1029,12 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
         }
         catch (FunctionException e) {
           e.printStackTrace();
-          fail("test failed due to", e);
+          Assert.fail("test failed due to", e);
           return Boolean.FALSE;
         }
         catch (Exception e) {
           e.printStackTrace();
-          fail("test failed due to", e);
+          Assert.fail("test failed due to", e);
           return Boolean.FALSE;
         }
         
@@ -1090,7 +1091,7 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
           assertNotNull(ds);
         }
         catch (Exception e) {
-          fail("Failed while creating the Distribued System", e);
+          Assert.fail("Failed while creating the Distribued System", e);
         }
         return Boolean.TRUE;
       }
@@ -1149,7 +1150,7 @@ public class FunctionServiceStatsDUnitTest extends PRClientServerTestBase{
         catch (Exception e) {
           getLogWriter().info("Exception Occured : " + e.getMessage());
           e.printStackTrace();
-          fail("Test failed", e);
+          Assert.fail("Test failed", e);
         }
         return Boolean.TRUE;
       }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/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 5dfb429..cb63a35 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
@@ -44,6 +44,7 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 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.SerializableCallable;
@@ -204,7 +205,7 @@ public class LocalDataSetDUnitTest extends CacheTestCase {
     }
     catch (Exception e) {
       e.printStackTrace();
-      fail("Test failed due to ", e);
+      Assert.fail("Test failed due to ", e);
     }
   }
   private void registerFunctions() {
@@ -249,7 +250,7 @@ public class LocalDataSetDUnitTest extends CacheTestCase {
       assertNotNull(cache);
     }
     catch (Exception e) {
-      fail("Failed while creating the cache", e);
+      Assert.fail("Failed while creating the cache", e);
     }
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetIndexingDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetIndexingDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetIndexingDUnitTest.java
index 8b0d4ba..1d933e3 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetIndexingDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetIndexingDUnitTest.java
@@ -124,7 +124,7 @@ public class LocalDataSetIndexingDUnitTest extends CacheTestCase {
               "/pr2 e2");
         }
         catch (Exception e) {
-          fail("Test failed due to Exception in index creation ", e);
+          com.gemstone.gemfire.test.dunit.Assert.fail("Test failed due to Exception in index creation ", e);
         }
       }
     };

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/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 f58d349..7dd8c1c 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
@@ -34,6 +34,7 @@ import com.gemstone.gemfire.cache.execute.ResultCollector;
 import com.gemstone.gemfire.distributed.DistributedMember;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 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.SerializableRunnable;
@@ -96,7 +97,7 @@ public class LocalFunctionExecutionDUnitTest extends DistributedTestCase{
       assertNotNull(cache);
     }
     catch (Exception e) {
-      fail("Failed while creating the cache", e);
+      Assert.fail("Failed while creating the cache", e);
     }
   }
   
@@ -144,7 +145,7 @@ public class LocalFunctionExecutionDUnitTest extends DistributedTestCase{
       FunctionService.registerFunction(function1);
       ResultCollector rc = FunctionService.onRegion(region).withArgs(Boolean.TRUE).execute(function1.getId());
       rc.getResult();
-      fail("Exception should occur",new Exception("Test Failed"));
+      Assert.fail("Exception should occur",new Exception("Test Failed"));
     }
     catch (Exception e) {
       assertTrue(e.getMessage().contains("I have been thrown from TestFunction"));
@@ -158,7 +159,7 @@ public class LocalFunctionExecutionDUnitTest extends DistributedTestCase{
       DistributedMember localmember = system.getDistributedMember();
       ResultCollector rc = FunctionService.onMember(system, localmember).withArgs(Boolean.TRUE).execute(function1.getId());
       rc.getResult();
-      fail("Exception should occur",new Exception("Test Failed"));
+      Assert.fail("Exception should occur",new Exception("Test Failed"));
     }
     catch (Exception e) {
       assertTrue(e.getMessage().contains("I have been thrown from TestFunction"));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/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 9508726..275dda9 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
@@ -48,6 +48,7 @@ import com.gemstone.gemfire.i18n.LogWriterI18n;
 import com.gemstone.gemfire.internal.ClassBuilder;
 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.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
@@ -340,7 +341,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
           fail("Should have seen an exception");
         } catch (Exception e) {
           if(!(e.getCause() instanceof FunctionInvocationTargetException)) {
-            fail("failed", e);
+            Assert.fail("failed", e);
           }
         }
         
@@ -396,7 +397,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
     catch (Exception e) {
       getLogWriter().info("Exception Occured : "+ e.getMessage());
       e.printStackTrace();
-      fail("Test failed",e);
+      Assert.fail("Test failed",e);
     }
   }
   /*
@@ -452,7 +453,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
     catch (Exception e) {
       getLogWriter().info("Exception Occured : "+ e.getMessage());
       e.printStackTrace();
-      fail("Test failed",e);
+      Assert.fail("Test failed",e);
     }
   }
   
@@ -492,7 +493,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
     catch (Exception e) {
       getLogWriter().info("Exception Occured : "+ e.getMessage());
       e.printStackTrace();
-      fail("Test failed",e);
+      Assert.fail("Test failed",e);
     }
   }
   
@@ -594,7 +595,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
     catch (Exception e) {
       getLogWriter().info("Exception Occured : "+ e.getMessage());
       e.printStackTrace();
-      fail("Test failed",e);
+      Assert.fail("Test failed",e);
     }
   }
   
@@ -658,7 +659,7 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
       FunctionService.registerFunction(new TestFunction(true,TestFunction.TEST_FUNCTION_NO_LASTRESULT));
     }
     catch (Exception e) {
-      fail("Failed while creating the Distribued System", e);
+      Assert.fail("Failed while creating the Distribued System", e);
     }
     return ds;
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MultiRegionFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MultiRegionFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MultiRegionFunctionExecutionDUnitTest.java
index b9f0dc2..d4a8826 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MultiRegionFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MultiRegionFunctionExecutionDUnitTest.java
@@ -153,7 +153,7 @@ public class MultiRegionFunctionExecutionDUnitTest extends CacheTestCase {
       assertNotNull(cache);
     }
     catch (Exception e) {
-      fail("Failed while creating the cache", e);
+      com.gemstone.gemfire.test.dunit.Assert.fail("Failed while creating the cache", e);
     }
   }
   @SuppressWarnings("unchecked")

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/OnGroupsFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/OnGroupsFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/OnGroupsFunctionExecutionDUnitTest.java
index fd5b1a4..ec6126c 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/OnGroupsFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/OnGroupsFunctionExecutionDUnitTest.java
@@ -44,6 +44,7 @@ import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.IgnoredException;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.VM;
@@ -492,7 +493,7 @@ public class OnGroupsFunctionExecutionDUnitTest extends DistributedTestCase {
     
     //The test function deliberately throws a null pointer exception.
     //which is logged.
-    addExpectedException(NullPointerException.class.getSimpleName());
+    IgnoredException.addExpectedException(NullPointerException.class.getSimpleName());
     
     initVM(vm0, "g0,mg", regionName, false);
     initVM(vm1, "g1", regionName, false);
@@ -862,7 +863,7 @@ public class OnGroupsFunctionExecutionDUnitTest extends DistributedTestCase {
         ccf.set("log-level", getDUnitLogLevel());
         ClientCache c = ccf.create();
 
-        ExpectedException ex = addExpectedException("No member found");
+        IgnoredException ex = IgnoredException.addExpectedException("No member found");
         try {
           InternalFunctionService.onServer(c, "no such group").execute(new OnGroupsFunction()).getResult();
          fail("expected exception not thrown");
@@ -942,7 +943,7 @@ public class OnGroupsFunctionExecutionDUnitTest extends DistributedTestCase {
         ccf.set("log-level", getDUnitLogLevel());
         ClientCache c = ccf.create();
 
-        ExpectedException expected = addExpectedException("No member found");
+        IgnoredException expected = IgnoredException.addExpectedException("No member found");
         try {
           InternalFunctionService.onServers(c, "no such group").execute(new OnGroupsFunction()).getResult();
           fail("expected exception not thrown");
@@ -951,7 +952,7 @@ public class OnGroupsFunctionExecutionDUnitTest extends DistributedTestCase {
           expected.remove();
         }
 
-        addExpectedException("NullPointerException");
+        IgnoredException.addExpectedException("NullPointerException");
         Execution e = InternalFunctionService.onServers(c, "mg");
         ArrayList<String> args = new ArrayList<String>();
         args.add("runtime");
@@ -1024,7 +1025,7 @@ public class OnGroupsFunctionExecutionDUnitTest extends DistributedTestCase {
         args.add("disconnect");
         e = e.withArgs(args);
         
-        addExpectedException("FunctionInvocationTargetException");
+        IgnoredException.addExpectedException("FunctionInvocationTargetException");
         try {
           e.execute(new OnGroupsExceptionFunction()).getResult();
           fail("expected exception not thrown");
@@ -1073,7 +1074,7 @@ public class OnGroupsFunctionExecutionDUnitTest extends DistributedTestCase {
         args.add("disconnect");
         args.add("g2");
         e = e.withArgs(args);
-        addExpectedException("FunctionInvocationTargetException");
+        IgnoredException.addExpectedException("FunctionInvocationTargetException");
         try {
           e.execute(new OnGroupsExceptionFunction()).getResult();
           fail("expected exception not thrown");
@@ -1152,7 +1153,7 @@ public class OnGroupsFunctionExecutionDUnitTest extends DistributedTestCase {
   public void testNoAckGroupsFunction() {
     //Workaround for #52005. This is a product bug
     //that should be fixed
-    addExpectedException("Cannot return any result");
+    IgnoredException.addExpectedException("Cannot return any result");
     Host host = Host.getHost(0);
     final VM server0 = host.getVM(0);
     final VM server1 = host.getVM(1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionDUnitTest.java
index 72780f1..b2594f6 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionDUnitTest.java
@@ -56,8 +56,10 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+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.SerializableRunnable;
 
 public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServerTestBase {
@@ -211,7 +213,7 @@ public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServ
     isByName = new Boolean(true);
     toRegister = new Boolean(true);
 
-    final ExpectedException ex = addExpectedException("did not send last result");
+    final IgnoredException ex = IgnoredException.addExpectedException("did not send last result");
     client.invoke(PRClientServerRegionFunctionExecutionDUnitTest.class,
         "serverSingleKeyExecution_NoLastResult", new Object[] { isByName,
             toRegister });
@@ -522,7 +524,7 @@ public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServ
     } catch (Exception ex) {
         ex.printStackTrace();
         getLogWriter().info("Exception : ", ex);
-        fail("Test failed after the execute operation", ex);
+        Assert.fail("Test failed after the execute operation", ex);
     }
   }
   
@@ -872,7 +874,7 @@ public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServ
       assertEquals(origVals, foundVals);
       
     }catch(Exception e){
-      fail("Test failed after the put operation", e);
+      Assert.fail("Test failed after the put operation", e);
       
     }
   }
@@ -994,7 +996,7 @@ public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServ
       }
 
     }catch(Exception e){
-      fail("Test failed after the put operation", e);
+      Assert.fail("Test failed after the put operation", e);
       
     }
   }
@@ -1024,7 +1026,7 @@ public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServ
     }catch (Exception ex) {
       ex.printStackTrace();
       getLogWriter().info("Exception : " , ex);
-      fail("Test failed after the put operation",ex);
+      Assert.fail("Test failed after the put operation",ex);
     }
   }
   
@@ -1127,7 +1129,7 @@ public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServ
     }
     catch (Throwable e) {
       e.printStackTrace();
-      fail("This is not expected Exception", e);
+      Assert.fail("This is not expected Exception", e);
     }
 
   }
@@ -1163,7 +1165,7 @@ public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServ
           .toLocalizedString("return any"))));
     }
     catch (Exception notexpected) {
-      fail("Test failed during execute or sleeping", notexpected);
+      Assert.fail("Test failed during execute or sleeping", notexpected);
     } finally {
       cache.getLogger().info("<ExpectedException action=remove>" +
           "FunctionException" +
@@ -1246,7 +1248,7 @@ public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServ
     }catch (Exception ex) {
       ex.printStackTrace();
       getLogWriter().info("Exception : " , ex);
-      fail("Test failed after the put operation",ex);
+      Assert.fail("Test failed after the put operation",ex);
     }
   }
   
@@ -1301,7 +1303,7 @@ public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServ
     catch (Exception ex) {
       ex.printStackTrace();
       getLogWriter().info("Exception : ", ex);
-      fail("Test failed after the put operation", ex);
+      Assert.fail("Test failed after the put operation", ex);
     }
     
     try {
@@ -1321,7 +1323,7 @@ public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServ
     catch (Exception ex) {
       ex.printStackTrace();
       getLogWriter().info("Exception : ", ex);
-      fail("Test failed after the put operation", ex);
+      Assert.fail("Test failed after the put operation", ex);
     }
   }
   
@@ -1383,7 +1385,7 @@ public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServ
     }catch (Exception ex) {
       ex.printStackTrace();
       getLogWriter().info("Exception : " , ex);
-      fail("Test failed after the put operation",ex);
+      Assert.fail("Test failed after the put operation",ex);
     }
     
     Region region2 = cache.getRegion(PartitionedRegionName+"2");
@@ -1454,7 +1456,7 @@ public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServ
     }
     catch (Exception ex) {
       ex.printStackTrace();
-      fail("This is not expected Exception", ex);
+      Assert.fail("This is not expected Exception", ex);
     }
   }
   
@@ -1557,7 +1559,7 @@ public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServ
     }catch (Exception ex) {
       ex.printStackTrace();
       getLogWriter().info("Exception : " , ex);
-      fail("Test failed after the put operation",ex);
+      Assert.fail("Test failed after the put operation",ex);
     }
   }
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionFailoverDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionFailoverDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionFailoverDUnitTest.java
index 5ee1472..50a6b6a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionFailoverDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionFailoverDUnitTest.java
@@ -44,9 +44,11 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 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.Host;
+import com.gemstone.gemfire.test.dunit.IgnoredException;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
 
@@ -64,10 +66,10 @@ public class PRClientServerRegionFunctionExecutionFailoverDUnitTest extends
   @Override
   public void setUp() throws Exception {
     super.setUp();
-    addExpectedException("Connection reset");
-    addExpectedException("SocketTimeoutException");
-    addExpectedException("ServerConnectivityException");
-    addExpectedException("Socket Closed");
+    IgnoredException.addExpectedException("Connection reset");
+    IgnoredException.addExpectedException("SocketTimeoutException");
+    IgnoredException.addExpectedException("ServerConnectivityException");
+    IgnoredException.addExpectedException("Socket Closed");
   }
   
   @Override
@@ -90,7 +92,7 @@ public class PRClientServerRegionFunctionExecutionFailoverDUnitTest extends
    */
   public void testServerFailoverWithTwoServerAliveHA()
       throws InterruptedException {
-    addExpectedException("FunctionInvocationTargetException");
+    IgnoredException.addExpectedException("FunctionInvocationTargetException");
     ArrayList commonAttributes = createCommonServerAttributes(
         "TestPartitionedRegion", null, 1, 13, null);
     createClientServerScenarion(commonAttributes, 20, 20, 20);
@@ -118,7 +120,7 @@ public class PRClientServerRegionFunctionExecutionFailoverDUnitTest extends
             new Integer(2) });
     DistributedTestCase.join(async[0], 6 * 60 * 1000, getLogWriter());
     if (async[0].getException() != null) {
-      fail("UnExpected Exception Occured : ", async[0].getException());
+      Assert.fail("UnExpected Exception Occured : ", async[0].getException());
     }
     List l = (List)async[0].getReturnValue();
     assertEquals(2, l.size());
@@ -130,7 +132,7 @@ public class PRClientServerRegionFunctionExecutionFailoverDUnitTest extends
    */
   public void testServerCacheClosedFailoverWithTwoServerAliveHA()
       throws InterruptedException {
-    addExpectedException("FunctionInvocationTargetException");
+    IgnoredException.addExpectedException("FunctionInvocationTargetException");
     ArrayList commonAttributes = createCommonServerAttributes(
         "TestPartitionedRegion", null, 1, 13, null);
     createClientServerScenarion(commonAttributes, 20, 20, 20);
@@ -158,7 +160,7 @@ public class PRClientServerRegionFunctionExecutionFailoverDUnitTest extends
             new Integer(2) });
     DistributedTestCase.join(async[0], 5 * 60 * 1000, getLogWriter());
     if (async[0].getException() != null) {
-      fail("UnExpected Exception Occured : ", async[0].getException());
+      Assert.fail("UnExpected Exception Occured : ", async[0].getException());
     }
     List l = (List)async[0].getReturnValue();
     assertEquals(2, l.size());
@@ -180,7 +182,7 @@ public class PRClientServerRegionFunctionExecutionFailoverDUnitTest extends
 
   public void testOnRegionFailoverWithTwoServerDownHA()
       throws InterruptedException {
-    addExpectedException("FunctionInvocationTargetException");
+    IgnoredException.addExpectedException("FunctionInvocationTargetException");
     createScenario();
 
     server1.invoke(PRClientServerRegionFunctionExecutionDUnitTest.class,
@@ -211,7 +213,7 @@ public class PRClientServerRegionFunctionExecutionFailoverDUnitTest extends
   // retry attempts is 2
   public void testOnRegionFailoverWithOneServerDownHA()
       throws InterruptedException {
-    addExpectedException("FunctionInvocationTargetException");
+    IgnoredException.addExpectedException("FunctionInvocationTargetException");
     createScenario();
 
     server1.invokeAsync(PRClientServerRegionFunctionExecutionDUnitTest.class,
@@ -245,7 +247,7 @@ public class PRClientServerRegionFunctionExecutionFailoverDUnitTest extends
    */
   public void testOnRegionFailoverNonHA() throws InterruptedException { // See #47489 before enabling it
     createScenario();
-    addExpectedException("FunctionInvocationTargetException");
+    IgnoredException.addExpectedException("FunctionInvocationTargetException");
     server1.invoke(PRClientServerRegionFunctionExecutionDUnitTest.class,
         "createReplicatedRegion");
 
@@ -341,7 +343,7 @@ public class PRClientServerRegionFunctionExecutionFailoverDUnitTest extends
 
   public void testServerBucketMovedException() throws InterruptedException {
 
-    addExpectedException("BucketMovedException");
+    IgnoredException.addExpectedException("BucketMovedException");
     final Host host = Host.getHost(0);
     VM server1 = host.getVM(0);
     VM server2 = host.getVM(1);
@@ -400,7 +402,7 @@ public class PRClientServerRegionFunctionExecutionFailoverDUnitTest extends
 
   public void testServerBucketMovedException_LocalServer()
       throws InterruptedException {
-    addExpectedException("BucketMovedException");
+    IgnoredException.addExpectedException("BucketMovedException");
 
     final Host host = Host.getHost(0);
     VM server1 = host.getVM(0);
@@ -467,7 +469,7 @@ public class PRClientServerRegionFunctionExecutionFailoverDUnitTest extends
       locator = Locator.startLocatorAndDS(locatorPort, logFile, null, props);
     }
     catch (IOException e) {
-      fail("Unable to start locator ", e);
+      Assert.fail("Unable to start locator ", e);
     }
   }
   
@@ -492,7 +494,7 @@ public class PRClientServerRegionFunctionExecutionFailoverDUnitTest extends
       server.start();
     }
     catch (IOException e) {
-      fail("Failed to start server ", e);
+      Assert.fail("Failed to start server ", e);
     }
     PartitionAttributesFactory paf = new PartitionAttributesFactory();
     if (isAccessor) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest.java
index 0344a55..9091155 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest.java
@@ -47,8 +47,10 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 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.AsyncInvocation;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.IgnoredException;
 
 public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
     PRClientServerTestBase {
@@ -329,7 +331,7 @@ public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
    */
   public void testServerFailoverWithTwoServerAliveHA()
       throws InterruptedException {
-    addExpectedException("FunctionInvocationTargetException");
+    IgnoredException.addExpectedException("FunctionInvocationTargetException");
     ArrayList commonAttributes = createCommonServerAttributes(
         "TestPartitionedRegion", null, 1, 13, null);
     createClientServerScenarion(commonAttributes, 20, 20, 20);
@@ -364,7 +366,7 @@ public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
             new Integer(2) });
     DistributedTestCase.join(async[0], 6 * 60 * 1000, getLogWriter());
     if (async[0].getException() != null) {
-      fail("UnExpected Exception Occured : ", async[0].getException());
+      Assert.fail("UnExpected Exception Occured : ", async[0].getException());
     }
     List l = (List)async[0].getReturnValue();
 
@@ -377,7 +379,7 @@ public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
    */
   public void testServerCacheClosedFailoverWithTwoServerAliveHA()
       throws InterruptedException {
-    addExpectedException("FunctionInvocationTargetException");
+    IgnoredException.addExpectedException("FunctionInvocationTargetException");
     ArrayList commonAttributes = createCommonServerAttributes(
         "TestPartitionedRegion", null, 1, 13, null);
     createClientServerScenarion(commonAttributes, 20, 20, 20);
@@ -412,7 +414,7 @@ public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
             new Integer(2) });
     DistributedTestCase.join(async[0], 5 * 60 * 1000, getLogWriter());
     if (async[0].getException() != null) {
-      fail("UnExpected Exception Occured : ", async[0].getException());
+      Assert.fail("UnExpected Exception Occured : ", async[0].getException());
     }
     List l = (List)async[0].getReturnValue();
     assertEquals(2, l.size());
@@ -692,7 +694,7 @@ public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
 
     }
     catch (Exception e) {
-      fail("Test failed after the put operation", e);
+      Assert.fail("Test failed after the put operation", e);
 
     }
   }
@@ -722,7 +724,7 @@ public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
 
     }
     catch (Exception e) {
-      fail("Test failed after the put operation", e);
+      Assert.fail("Test failed after the put operation", e);
 
     }
   }
@@ -752,7 +754,7 @@ public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
 
     }
     catch (Exception e) {
-      fail("Test failed after the put operation", e);
+      Assert.fail("Test failed after the put operation", e);
 
     }
   }
@@ -847,7 +849,7 @@ public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
 
     }
     catch (Exception e) {
-      fail("Test failed after the put operation", e);
+      Assert.fail("Test failed after the put operation", e);
 
     }
   }
@@ -885,7 +887,7 @@ public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
 
     }
     catch (Exception e) {
-      fail("Test failed after the function execution", e);
+      Assert.fail("Test failed after the function execution", e);
 
     }
   }
@@ -917,7 +919,7 @@ public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
     catch (Exception ex) {
       ex.printStackTrace();
       getLogWriter().info("Exception : ", ex);
-      fail("Test failed after the put operation", ex);
+      Assert.fail("Test failed after the put operation", ex);
     }
   }
 
@@ -1018,7 +1020,7 @@ public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
     }
     catch (Throwable e) {
       e.printStackTrace();
-      fail("This is not expected Exception", e);
+      Assert.fail("This is not expected Exception", e);
     }
 
   }
@@ -1059,7 +1061,7 @@ public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
               .toLocalizedString("return any"))));
     }
     catch (Exception notexpected) {
-      fail("Test failed during execute or sleeping", notexpected);
+      Assert.fail("Test failed during execute or sleeping", notexpected);
     }
     finally {
       cache.getLogger().info(
@@ -1115,7 +1117,7 @@ public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
     catch (Exception ex) {
       ex.printStackTrace();
       getLogWriter().info("Exception : ", ex);
-      fail("Test failed after the put operation", ex);
+      Assert.fail("Test failed after the put operation", ex);
     }
   }
 
@@ -1141,7 +1143,7 @@ public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
     }
     catch (Exception ex) {
       ex.printStackTrace();
-      fail("This is not expected Exception", ex);
+      Assert.fail("This is not expected Exception", ex);
     }
   }
 
@@ -1241,7 +1243,7 @@ public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
     catch (Exception ex) {
       ex.printStackTrace();
       getLogWriter().info("Exception : ", ex);
-      fail("Test failed after the put operation", ex);
+      Assert.fail("Test failed after the put operation", ex);
     }
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest.java
index cf97932..0765533 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest.java
@@ -47,8 +47,10 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 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.AsyncInvocation;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.IgnoredException;
 
 public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest extends
     PRClientServerTestBase {
@@ -286,11 +288,11 @@ public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest e
    */
   public void testServerFailoverWithTwoServerAliveHA()
       throws InterruptedException {
-    addExpectedException("FunctionInvocationTargetException");
-    addExpectedException("Connection reset");
-    addExpectedException("SocketTimeoutException");
-    addExpectedException("ServerConnectivityException");
-    addExpectedException("Socket Closed");
+    IgnoredException.addExpectedException("FunctionInvocationTargetException");
+    IgnoredException.addExpectedException("Connection reset");
+    IgnoredException.addExpectedException("SocketTimeoutException");
+    IgnoredException.addExpectedException("ServerConnectivityException");
+    IgnoredException.addExpectedException("Socket Closed");
     ArrayList commonAttributes = createCommonServerAttributes(
         "TestPartitionedRegion", null, 1, 13, null);
     createClientServerScenarion(commonAttributes, 20, 20, 20);
@@ -325,7 +327,7 @@ public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest e
             new Integer(2) });
     DistributedTestCase.join(async[0], 6 * 60 * 1000, getLogWriter());
     if (async[0].getException() != null) {
-      fail("UnExpected Exception Occured : ", async[0].getException());
+      Assert.fail("UnExpected Exception Occured : ", async[0].getException());
     }
     List l = (List)async[0].getReturnValue();
 
@@ -338,11 +340,11 @@ public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest e
    */
   public void testServerCacheClosedFailoverWithTwoServerAliveHA()
       throws InterruptedException {
-    addExpectedException("FunctionInvocationTargetException");
-    addExpectedException("Connection reset");
-    addExpectedException("SocketTimeoutException");
-    addExpectedException("ServerConnectivityException");
-    addExpectedException("Socket Closed");
+    IgnoredException.addExpectedException("FunctionInvocationTargetException");
+    IgnoredException.addExpectedException("Connection reset");
+    IgnoredException.addExpectedException("SocketTimeoutException");
+    IgnoredException.addExpectedException("ServerConnectivityException");
+    IgnoredException.addExpectedException("Socket Closed");
     ArrayList commonAttributes = createCommonServerAttributes(
         "TestPartitionedRegion", null, 1, 13, null);
     createClientServerScenarion(commonAttributes, 20, 20, 20);
@@ -377,7 +379,7 @@ public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest e
             new Integer(2) });
     DistributedTestCase.join(async[0], 5 * 60 * 1000, getLogWriter());
     if (async[0].getException() != null) {
-      fail("UnExpected Exception Occured : ", async[0].getException());
+      Assert.fail("UnExpected Exception Occured : ", async[0].getException());
     }
     List l = (List)async[0].getReturnValue();
     assertEquals(2, l.size());
@@ -651,7 +653,7 @@ public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest e
 
     }
     catch (Exception e) {
-      fail("Test failed after the put operation", e);
+      Assert.fail("Test failed after the put operation", e);
 
     }
   }
@@ -681,7 +683,7 @@ public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest e
 
     }
     catch (Exception e) {
-      fail("Test failed after the put operation", e);
+      Assert.fail("Test failed after the put operation", e);
 
     }
   }
@@ -711,7 +713,7 @@ public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest e
 
     }
     catch (Exception e) {
-      fail("Test failed after the put operation", e);
+      Assert.fail("Test failed after the put operation", e);
 
     }
   }
@@ -806,7 +808,7 @@ public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest e
 
     }
     catch (Exception e) {
-      fail("Test failed after the put operation", e);
+      Assert.fail("Test failed after the put operation", e);
 
     }
   }
@@ -843,7 +845,7 @@ public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest e
 
     }
     catch (Exception e) {
-      fail("Test failed after the function execution", e);
+      Assert.fail("Test failed after the function execution", e);
 
     }
   }
@@ -875,7 +877,7 @@ public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest e
     catch (Exception ex) {
       ex.printStackTrace();
       getLogWriter().info("Exception : ", ex);
-      fail("Test failed after the put operation", ex);
+      Assert.fail("Test failed after the put operation", ex);
     }
   }
 
@@ -976,7 +978,7 @@ public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest e
     }
     catch (Throwable e) {
       e.printStackTrace();
-      fail("This is not expected Exception", e);
+      Assert.fail("This is not expected Exception", e);
     }
 
   }
@@ -1017,7 +1019,7 @@ public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest e
               .toLocalizedString("return any"))));
     }
     catch (Exception notexpected) {
-      fail("Test failed during execute or sleeping", notexpected);
+      Assert.fail("Test failed during execute or sleeping", notexpected);
     }
     finally {
       cache.getLogger().info(
@@ -1073,7 +1075,7 @@ public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest e
     catch (Exception ex) {
       ex.printStackTrace();
       getLogWriter().info("Exception : ", ex);
-      fail("Test failed after the put operation", ex);
+      Assert.fail("Test failed after the put operation", ex);
     }
   }
 
@@ -1099,7 +1101,7 @@ public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest e
     }
     catch (Exception ex) {
       ex.printStackTrace();
-      fail("This is not expected Exception", ex);
+      Assert.fail("This is not expected Exception", ex);
     }
   }
 
@@ -1199,7 +1201,7 @@ public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest e
     catch (Exception ex) {
       ex.printStackTrace();
       getLogWriter().info("Exception : ", ex);
-      fail("Test failed after the put operation", ex);
+      Assert.fail("Test failed after the put operation", ex);
     }
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSingleHopDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSingleHopDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSingleHopDUnitTest.java
index d6f2fd8..bb0b184 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSingleHopDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSingleHopDUnitTest.java
@@ -47,8 +47,10 @@ import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 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.AsyncInvocation;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.IgnoredException;
   public class PRClientServerRegionFunctionExecutionSingleHopDUnitTest extends PRClientServerTestBase {
     private static final String TEST_FUNCTION7 = TestFunction.TEST_FUNCTION7;
 
@@ -64,8 +66,8 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
     @Override
     public void setUp() throws Exception {
       //Workaround for bug #52004
-      addExpectedException("InternalFunctionInvocationTargetException");
-      addExpectedException("Connection refused");
+      IgnoredException.addExpectedException("InternalFunctionInvocationTargetException");
+      IgnoredException.addExpectedException("Connection refused");
       super.setUp();
     }
 
@@ -132,7 +134,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
       registerFunctionAtServer(function);
       isByName = Boolean.TRUE;
       // add expected exception for server going down after wait
-      final ExpectedException expectedEx = addExpectedException(
+      final IgnoredException expectedEx = IgnoredException.addExpectedException(
           DistributedSystemDisconnectedException.class.getName(), server1);
       try {
         client.invoke(
@@ -252,8 +254,8 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
      * After 5th attempt function will send Boolean as last result.
      */
     public void testserverMultiKeyExecution_FunctionInvocationTargetException() {
-      addExpectedException("FunctionException: IOException while sending");
-      addExpectedException("java.net.SocketException: Software caused connection abort");
+      IgnoredException.addExpectedException("FunctionException: IOException while sending");
+      IgnoredException.addExpectedException("java.net.SocketException: Software caused connection abort");
       createScenario();
       client.invoke(PRClientServerRegionFunctionExecutionSingleHopDUnitTest.class,
           "serverMultiKeyExecution_FunctionInvocationTargetException");
@@ -264,7 +266,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
      * object and using the name of the function
      */
     public void testserverMultiKeyExecutionNoResult_byName(){
-      addExpectedException("Cannot send result");
+      IgnoredException.addExpectedException("Cannot send result");
       createScenario();
       Function function = new TestFunction(false,TEST_FUNCTION7);
       registerFunctionAtServer(function);
@@ -350,7 +352,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
               new Integer(2) });
       DistributedTestCase.join(async[0], 6 * 60 * 1000, getLogWriter());
       if (async[0].getException() != null) {
-        fail("UnExpected Exception Occured : ", async[0].getException());
+        Assert.fail("UnExpected Exception Occured : ", async[0].getException());
       }
       List l = (List)async[0].getReturnValue();
       
@@ -379,7 +381,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
       client.invoke(PRClientServerRegionFunctionExecutionSingleHopDUnitTest.class, "verifyDeadAndLiveServers",new Object[]{new Integer(1),new Integer(2)});
       DistributedTestCase.join(async[0],  5 * 60 * 1000, getLogWriter());
       if(async[0].getException() != null){
-        fail("UnExpected Exception Occured : ", async[0].getException());
+        Assert.fail("UnExpected Exception Occured : ", async[0].getException());
       }
       List l = (List)async[0].getReturnValue();
       assertEquals(2, l.size());
@@ -644,7 +646,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
         assertEquals(origVals, foundVals);
         
       }catch(Exception e){
-        fail("Test failed after the put operation", e);
+        Assert.fail("Test failed after the put operation", e);
         
       }
     }
@@ -674,7 +676,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
         assertTrue(secondResultMap.equals(origVals));
         
       }catch(Exception e){
-        fail("Test failed after the put operation", e);
+        Assert.fail("Test failed after the put operation", e);
         
       }
     }
@@ -703,7 +705,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
         assertTrue(secondResultMap.equals(origVals));
         
       }catch(Exception e){
-        fail("Test failed after the put operation", e);
+        Assert.fail("Test failed after the put operation", e);
         
       }
     }
@@ -797,7 +799,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
         assertEquals(origVals, foundVals);
         
       }catch(Exception e){
-        fail("Test failed after the put operation", e);
+        Assert.fail("Test failed after the put operation", e);
         
       }
     }
@@ -832,7 +834,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
         }
 
       }catch(Exception e){
-        fail("Test failed after the function execution", e);
+        Assert.fail("Test failed after the function execution", e);
         
       }
     }
@@ -862,7 +864,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
       }catch (Exception ex) {
         ex.printStackTrace();
         getLogWriter().info("Exception : " , ex);
-        fail("Test failed after the put operation",ex);
+        Assert.fail("Test failed after the put operation",ex);
       }
     }
     
@@ -965,7 +967,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
       }
       catch (Throwable e) {
         e.printStackTrace();
-        fail("This is not expected Exception", e);
+        Assert.fail("This is not expected Exception", e);
       }
 
     }
@@ -1003,7 +1005,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
             .toLocalizedString("return any"))));
       }
       catch (Exception notexpected) {
-        fail("Test failed during execute or sleeping", notexpected);
+        Assert.fail("Test failed during execute or sleeping", notexpected);
       } finally {
         cache.getLogger().info("<ExpectedException action=remove>" +
             "FunctionException" +
@@ -1057,7 +1059,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
       }catch (Exception ex) {
         ex.printStackTrace();
         getLogWriter().info("Exception : " , ex);
-        fail("Test failed after the put operation",ex);
+        Assert.fail("Test failed after the put operation",ex);
       }
     }
     
@@ -1083,7 +1085,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
       }
       catch (Exception ex) {
         ex.printStackTrace();
-        fail("This is not expected Exception", ex);
+        Assert.fail("This is not expected Exception", ex);
       }
     }
     
@@ -1186,7 +1188,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
       }catch (Exception ex) {
         ex.printStackTrace();
         getLogWriter().info("Exception : " , ex);
-        fail("Test failed after the put operation",ex);
+        Assert.fail("Test failed after the put operation",ex);
       }
     }
     

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0d759cb3/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerTestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerTestBase.java
index 7026ead..739deb5 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerTestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerTestBase.java
@@ -51,6 +51,7 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
 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.SerializableRunnable;
@@ -151,7 +152,7 @@ public class PRClientServerTestBase extends CacheTestCase {
       server1.start();
     }
     catch (IOException e) {
-      fail("Failed to start the Server", e);
+      Assert.fail("Failed to start the Server", e);
     }
     assertTrue(server1.isRunning());
 
@@ -183,7 +184,7 @@ public class PRClientServerTestBase extends CacheTestCase {
       server1.start();
     }
     catch (IOException e) {
-      fail("Failed to start the Server", e);
+      Assert.fail("Failed to start the Server", e);
     }
     assertTrue(server1.isRunning());
 
@@ -216,7 +217,7 @@ public class PRClientServerTestBase extends CacheTestCase {
       server1.start();
     }
     catch (IOException e) {
-      fail("Failed to start the Server", e);
+      Assert.fail("Failed to start the Server", e);
     }
     assertTrue(server1.isRunning());
 
@@ -231,7 +232,7 @@ public class PRClientServerTestBase extends CacheTestCase {
       server1.start();
     }
     catch (IOException e) {
-      fail("Failed to start the Server", e);
+      Assert.fail("Failed to start the Server", e);
     }
     assertTrue(server1.isRunning());
 
@@ -254,7 +255,7 @@ public class PRClientServerTestBase extends CacheTestCase {
       server1.start();
     }       
     catch (IOException e) {
-      fail("Failed to start the Server", e);
+      Assert.fail("Failed to start the Server", e);
     }
     assertTrue(server1.isRunning());
 
@@ -675,7 +676,7 @@ public class PRClientServerTestBase extends CacheTestCase {
       assertNotNull(cache);
     }
     catch (Exception e) {
-      fail("Failed while creating the cache", e);
+      Assert.fail("Failed while creating the cache", e);
     }
   }
 
@@ -798,7 +799,7 @@ public class PRClientServerTestBase extends CacheTestCase {
      
       
     }catch(Exception e){
-      fail("Test failed ", e);
+      Assert.fail("Test failed ", e);
       
     }
   }
@@ -839,7 +840,7 @@ public class PRClientServerTestBase extends CacheTestCase {
       }
       assertTrue(expectedBucketSet.isEmpty());
     }catch(Exception e){
-      fail("Test failed ", e);
+      Assert.fail("Test failed ", e);
       
     }