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/05/25 00:41:35 UTC

incubator-geode git commit: Annotate disabled tests with @Ignore and @Test.

Repository: incubator-geode
Updated Branches:
  refs/heads/feature/GEODE-837 5fb3826e5 -> 4ad502363


Annotate disabled tests with @Ignore and @Test.

Include TRAC# summary if available.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/4ad50236
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/4ad50236
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/4ad50236

Branch: refs/heads/feature/GEODE-837
Commit: 4ad50236339b20e64e5a4d505440941f024b7ea1
Parents: 5fb3826
Author: Kirk Lund <kl...@apache.org>
Authored: Tue May 24 17:41:00 2016 -0700
Committer: Kirk Lund <kl...@apache.org>
Committed: Tue May 24 17:41:00 2016 -0700

----------------------------------------------------------------------
 .../gemfire/cache30/TXOrderDUnitTest.java       |   8 +-
 .../internal/DistributionManagerDUnitTest.java  |   9 +-
 .../cache/ConcurrentMapOpsDUnitTest.java        |  19 +-
 .../cache/InterruptClientServerDUnitTest.java   |  12 +-
 .../internal/cache/InterruptsDUnitTest.java     |  11 --
 ...gionBucketCreationDistributionDUnitTest.java |   6 +-
 .../internal/cache/ha/HADuplicateDUnitTest.java |   6 +-
 .../cache/ha/HAEventIdPropagationDUnitTest.java |  10 +-
 .../internal/cache/ha/HAGIIBugDUnitTest.java    |  12 +-
 .../cache/ha/HARQueueNewImplDUnitTest.java      |  17 +-
 .../cache/ha/HARegionQueueDUnitTest.java        |  14 +-
 .../partitioned/PartitionResolverDUnitTest.java |   5 +-
 .../DurableClientQueueSizeDUnitTest.java        |   5 +-
 .../EventIDVerificationInP2PDUnitTest.java      |   6 +-
 .../InstantiatorPropagationDUnitTest.java       |  14 +-
 .../sockets/InterestListRecoveryDUnitTest.java  |   7 +-
 .../sockets/RedundancyLevelPart1DUnitTest.java  | 176 ++++++++-----------
 .../sockets/UnregisterInterestDUnitTest.java    |   6 +-
 .../VerifyEventIDGenerationInP2PDUnitTest.java  |  12 +-
 .../internal/cache/ha/CQListGIIDUnitTest.java   |  10 +-
 .../sockets/DurableClientSimpleDUnitTest.java   |  78 ++++----
 ...llelGatewaySenderQueueOverflowDUnitTest.java |  21 ++-
 22 files changed, 229 insertions(+), 235 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/cache30/TXOrderDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/TXOrderDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/TXOrderDUnitTest.java
index c76f813..c97c04c 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/TXOrderDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/TXOrderDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.cache30;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -177,10 +178,11 @@ public class TXOrderDUnitTest extends JUnit4CacheTestCase {
   }
 
   /**
-   * test bug#40870
-   * @throws Exception
+   * Tests fix for #40870 Remote CacheListeners invoke afterCreate with Operation.LOCAL_LOAD_CREATE when create executed transactionally"
    */
-  public void _testFarSideOpForLoad() throws Exception {
+  @Ignore("TODO")
+  @Test
+  public void testFarSideOpForLoad() throws Exception {
     Host host = Host.getHost(0);
     VM vm1 = host.getVM(0);
     VM vm2 = host.getVM(1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/distributed/internal/DistributionManagerDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/distributed/internal/DistributionManagerDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/distributed/internal/DistributionManagerDUnitTest.java
index 7b6c839..17caee4 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/distributed/internal/DistributionManagerDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/distributed/internal/DistributionManagerDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.distributed.internal;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -117,6 +118,7 @@ public class DistributionManagerDUnitTest extends JUnit4DistributedTestCase {
   /**
    * Send the distribution manager a message it can't deserialize
    */
+  @Ignore("TODO: use Awaitility and reenable assertions")
   @Test
   public void testExceptionInThreads() throws InterruptedException {
     DM dm = getSystem().getDistributionManager();
@@ -131,7 +133,9 @@ public class DistributionManagerDUnitTest extends JUnit4DistributedTestCase {
 //    assertTrue(!dm.exceptionInThreads());
   }
 
-  public void _testGetDistributionManagerIds() {
+  @Ignore("TODO: this passes when enabled")
+  @Test
+  public void testGetDistributionManagerIds() {
     int systemCount = 0;
     for (int h = 0; h < Host.getHostCount(); h++) {
       Host host = Host.getHost(h);
@@ -143,9 +147,6 @@ public class DistributionManagerDUnitTest extends JUnit4DistributedTestCase {
 
     assertEquals(systemCount, dm.getNormalDistributionManagerIds().size());
   }
-  
-  
-
 
   /**
    * Demonstrate that a new UDP port is used when an attempt is made to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapOpsDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapOpsDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapOpsDUnitTest.java
index 6a6b650..4fb244a 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapOpsDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapOpsDUnitTest.java
@@ -19,6 +19,7 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -839,13 +840,25 @@ public class ConcurrentMapOpsDUnitTest extends JUnit4CacheTestCase {
       }
     });
   }
-  
-  public void _testBug42195() {
+
+  /**
+   * Replicate Region test for bug #42195: putIfAbsent from client does not put old value in local cache
+   */
+  @Ignore("TODO")
+  @Test
+  public void testBug42195() {
     doPutIfAbsentPutsKeyInLocalClientCacheWork(REP_REG_NAME);
   }
-  public void _testBug42195PR() {
+
+  /**
+   * Partitioned Region test for bug #42195: putIfAbsent from client does not put old value in local cache
+   */
+  @Ignore("TODO")
+  @Test
+  public void testBug42195PR() {
     doPutIfAbsentPutsKeyInLocalClientCacheWork(PR_REG_NAME);
   }
+
   private void doPutIfAbsentPutsKeyInLocalClientCacheWork(final String regionName) {
     Host host = Host.getHost(0);
     VM server = host.getVM(0);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptClientServerDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptClientServerDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptClientServerDUnitTest.java
index 191ad72..79b58d6 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptClientServerDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptClientServerDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -76,17 +77,6 @@ public class InterruptClientServerDUnitTest extends JUnit4CacheTestCase {
       }
     });
   }
-  
-  public void _testLoop() throws Throwable {
-    for(int i=0; i < 100; i++) {
-      System.err.println("i=" +i);
-      System.out.println("i=" +i);
-      testClientPutWithInterrupt();
-      tearDown();
-      setUp();
-    }
-  }
-
 
   /**
    * A simple test case that we are actually

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptsDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptsDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptsDUnitTest.java
index f9277f6..7596b82 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptsDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptsDUnitTest.java
@@ -72,17 +72,6 @@ public class InterruptsDUnitTest extends JUnit4CacheTestCase {
     });
   }
   
-  public void _testLoop() throws Throwable {
-    for(int i=0; i < 10; i++) {
-      System.err.println("i=" +i);
-      System.out.println("i=" +i);
-      testDRPutWithInterrupt();
-      tearDown();
-      setUp();
-    }
-  }
-
-
   /**
    * A simple test case that we are actually
    * persisting with a PR.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionBucketCreationDistributionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionBucketCreationDistributionDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionBucketCreationDistributionDUnitTest.java
index b6e70d9..78e5481 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionBucketCreationDistributionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionBucketCreationDistributionDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -399,8 +400,9 @@ public class PartitionedRegionBucketCreationDistributionDUnitTest extends
    * 2. do put() operations so that size of the objects that were put >
    * localMaxMemory of partition region
    */
-  public void _testLocalMaxMemoryInPartitionedRegion() throws Throwable
-  {
+  @Ignore("TODO")
+  @Test
+  public void testLocalMaxMemoryInPartitionedRegion() throws Throwable {
     Host host = Host.getHost(0);
     /** creating 4 VMs */
     createVMs(host);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HADuplicateDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HADuplicateDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HADuplicateDUnitTest.java
index 9cc953e..815c34c 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HADuplicateDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HADuplicateDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.ha;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -120,8 +121,9 @@ public class HADuplicateDUnitTest extends JUnit4DistributedTestCase
     server2.invoke(() -> HADuplicateDUnitTest.closeCache());
   }
 
-  public void _testDuplicate() throws Exception
-  {
+  @Ignore("TODO")
+  @Test
+  public void testDuplicate() throws Exception {
     createClientServerConfiguration();
     server1.invoke(putForKnownKeys());
     server1.invoke(stopServer());

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAEventIdPropagationDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAEventIdPropagationDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAEventIdPropagationDUnitTest.java
index ebd9545..6718ed3 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAEventIdPropagationDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAEventIdPropagationDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.ha;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -430,9 +431,9 @@ public class HAEventIdPropagationDUnitTest extends JUnit4DistributedTestCase
 
   }
 
-
-  public void _testEventIDPropagationForDestroyRegion() throws Exception
-  {
+  @Ignore("TODO: test passes")
+  @Test
+  public void testEventIDPropagationForDestroyRegion() throws Exception {
     createClientServerConfiguration();
     client1.invoke(() -> HAEventIdPropagationDUnitTest.setReceivedOperationToFalse());
     Object eventId1 = server1.invoke(() -> HAEventIdPropagationDUnitTest.destroyRegion());
@@ -445,8 +446,7 @@ public class HAEventIdPropagationDUnitTest extends JUnit4DistributedTestCase
     if (!eventId1.equals(eventId2)) {
       fail("Test failed as the eventIds are not equal");
     }
- }
-
+  }
 
   public static void setReceivedOperationToFalse()
   {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAGIIBugDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAGIIBugDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAGIIBugDUnitTest.java
index 1445e07..079da2b 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAGIIBugDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAGIIBugDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.ha;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -143,16 +144,9 @@ public class HAGIIBugDUnitTest extends JUnit4DistributedTestCase
     assertNotNull(cache);
   }
 
-  
+  @Ignore("TODO")
   @Test
-  public void testDummy() throws Exception
-  {
-    LogWriterUtils.getLogWriter().info("This is Dummy test for the GII");  
-  }
-  
-  
-  public void _testGIIBug() throws Exception
-  {
+  public void testGIIBug() throws Exception {
 
     vm0.invoke(putFromVmBeforeGII("vm0_1"));
     populateKeySet("vm0_1");

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQueueNewImplDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQueueNewImplDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQueueNewImplDUnitTest.java
index 4987e48..97c8ad1 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQueueNewImplDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQueueNewImplDUnitTest.java
@@ -26,6 +26,9 @@ import java.util.Map;
 import java.util.Properties;
 import java.util.Set;
 
+import org.junit.Ignore;
+import org.junit.Test;
+
 import com.gemstone.gemfire.LogWriter;
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.Cache;
@@ -553,11 +556,6 @@ public class HARQueueNewImplDUnitTest extends DistributedTestCase {
     serverVM1.invoke(() -> ConflationDUnitTest.unsetIsSlowStart());
   }
 
-  /*
-   * public void PtestRefCountForConcurrentPutAndRemove() throws Exception { }
-   * public void PtestRefCountForConcurrentGIIPut() throws Exception { }
-   */
-
   /**
    * This test verifies that when two BridgeServerImpl instances are created in
    * a single VM, they do share the client-messages-region.
@@ -751,14 +749,13 @@ public class HARQueueNewImplDUnitTest extends DistributedTestCase {
   }
 
   /**
-   * This test verifies that the memory foorprint of the ha region queues is
+   * This test verifies that the memory footprint of the ha region queues is
    * less when ha-overflow is enabled (with an appropriate value of haCapacity)
    * compared to when it is disabled, for the same amount of data feed.
-   * 
-   * @throws Exception
    */
-  public void _testMemoryFootprintOfHARegionQueuesWithAndWithoutOverflow()
-      throws Exception {
+  @Ignore("TODO")
+  @Test
+  public void testMemoryFootprintOfHARegionQueuesWithAndWithoutOverflow() throws Exception {
     serverVM0.invoke(() -> HARQueueNewImplDUnitTest.closeCache());
     serverVM1.invoke(() -> HARQueueNewImplDUnitTest.closeCache());
     Thread.sleep(2000);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionQueueDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionQueueDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionQueueDUnitTest.java
index 267d76e..6c572b1 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionQueueDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionQueueDUnitTest.java
@@ -22,6 +22,8 @@ import java.util.Map;
 import java.util.Properties;
 import java.util.Set;
 
+import org.junit.Ignore;
+import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
 import junit.framework.Assert;
@@ -224,12 +226,14 @@ public class HARegionQueueDUnitTest extends DistributedTestCase {
    */
   
   /**
-   * Behaviour of take() has been changed for relaible messaging feature. Region queue take()
+   * Behaviour of take() has been changed for reliable messaging feature. Region queue take()
    * operation will no longer add to the Dispatch Message Map. Hence disabling the test - SUYOG
-  */
-    
-  public void _testBugNo35988() throws Exception
-  {
+   *
+   * Test for #35988 HARegionQueue.take() is not functioning as expected
+   */
+  @Ignore("TODO")
+  @Test
+  public void testBugNo35988() throws Exception {
     
     CacheSerializableRunnable createQueue = new CacheSerializableRunnable(
         "CreateCache, HARegionQueue and start thread") {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionResolverDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionResolverDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionResolverDUnitTest.java
index 4c1c022..2330cb9 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionResolverDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionResolverDUnitTest.java
@@ -19,6 +19,7 @@
  */
 package com.gemstone.gemfire.internal.cache.partitioned;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -365,7 +366,9 @@ public class PartitionResolverDUnitTest extends JUnit4CacheTestCase {
     verifyResolverCountInVM(datastore2, getResolverCountForVM(datastore2));
   }
 
-  public void _testTxOps() {
+  @Ignore("TODO")
+  @Test
+  public void testTxOps() {
     initAccessorAndDataStore(0);
     doOps(true);
     verifyResolverCountInVM(accessor, 7);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientQueueSizeDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientQueueSizeDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientQueueSizeDUnitTest.java
index ddd9dea..8e804ef 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientQueueSizeDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientQueueSizeDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -237,7 +238,9 @@ public class DurableClientQueueSizeDUnitTest extends JUnit4DistributedTestCase {
     vm2.invoke(() -> DurableClientQueueSizeDUnitTest.verifyQueueSize( PoolImpl.PRIMARY_QUEUE_TIMED_OUT, PoolImpl.PRIMARY_QUEUE_TIMED_OUT));
   }
 
-  public void _testMultiPoolClientFailsOver() throws Exception {
+  @Ignore("TODO")
+  @Test
+  public void testMultiPoolClientFailsOver() throws Exception {
   }
 
   public static void closeCache() throws Exception {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/EventIDVerificationInP2PDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/EventIDVerificationInP2PDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/EventIDVerificationInP2PDUnitTest.java
index 7feb77c..a54515e 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/EventIDVerificationInP2PDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/EventIDVerificationInP2PDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -103,8 +104,9 @@ public class EventIDVerificationInP2PDUnitTest extends JUnit4DistributedTestCase
     verifyOperations();
   }
 
-  public void _testEventIDsNOACK() throws Exception
-  {
+  @Ignore("TODO")
+  @Test
+  public void testEventIDsNOACK() throws Exception {
     createServerCache(new Integer(0));
     vm0.invoke(() -> EventIDVerificationInP2PDUnitTest.createServerCache( new Integer(0) ));
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InstantiatorPropagationDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InstantiatorPropagationDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InstantiatorPropagationDUnitTest.java
index f431613..7c0d146 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InstantiatorPropagationDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InstantiatorPropagationDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -669,7 +670,9 @@ public class InstantiatorPropagationDUnitTest extends JUnit4DistributedTestCase
    * Test's Number of Instantiators at all clients & servers with one Server
    * being stopped and then restarted
    */
-  public void _testInstantiatorsWithServerKillAndReInvoked() throws Exception {
+  @Ignore("TODO")
+  @Test
+  public void testInstantiatorsWithServerKillAndReInvoked() throws Exception {
     PORT1 = initServerCache(server1);
     PORT2 = initServerCache(server2);
     client1
@@ -773,14 +776,14 @@ public class InstantiatorPropagationDUnitTest extends JUnit4DistributedTestCase
     factory.setPoolName(p.getName());
     cache.createRegion(REGION_NAME, factory.create());
   }
+
   /**
    * Test's same eventId being same for the Instantiators at all clients &
    * servers
-   * 
    */
-  // disabled - the eventID received does not match the sender's eventID.  Why is this a requirement anyway?
-  public void _testInstantiatorsEventIdVerificationClientsAndServers()
-      throws Exception {
+  @Ignore("TODO: disabled - the eventID received does not match the sender's eventID.  Why is this a requirement anyway?")
+  @Test
+  public void _testInstantiatorsEventIdVerificationClientsAndServers() throws Exception {
     PORT1 = initServerCache(server1, 1);
     PORT2 = initServerCache(server2, 2);
 
@@ -801,7 +804,6 @@ public class InstantiatorPropagationDUnitTest extends JUnit4DistributedTestCase
     assertTrue("EventId found Different", pass.booleanValue());
 
     PoolImpl.IS_INSTANTIATOR_CALLBACK = false;
-
   }
   
   @Test

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListRecoveryDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListRecoveryDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListRecoveryDUnitTest.java
index 402a36a..5d0b8d0 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListRecoveryDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListRecoveryDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -113,9 +114,9 @@ public class InterestListRecoveryDUnitTest extends JUnit4DistributedTestCase
     createClientCache(NetworkUtils.getServerHostName(host), new Integer(PORT1), new Integer(PORT2));
   }
 
-  // this test fails because of bug# 35352 , hence commented the bug is Deferred to: Danube
-  public void XtestKeyInterestRecoveryWhileServerFailover() throws Exception
-  {
+  @Ignore("TODO: this test fails because of #35352: proxy.markServerUnavailable() is not causing interestListEndpoint to change")
+  @Test
+  public void testKeyInterestRecoveryWhileServerFailover() throws Exception {
     createEntries();
     server1.invoke(() -> InterestListRecoveryDUnitTest.createEntries());
     registerK1toK5();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart1DUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart1DUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart1DUnitTest.java
index 178e314..5b408c0 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart1DUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart1DUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -188,122 +189,101 @@ public class RedundancyLevelPart1DUnitTest extends RedundancyLevelTestBase
     }
   }
   
-  /*
+  /**
    * Redundancy level specified & less than total Eps. If an EP dies & was not
    * part of the fail over list , then it should be removed from Live Server Map &
    * added to dead server map. It should not change the current failover set.
    * Failover detection by CCU
    */
-  
-  public void _testRedundancySpecifiedNonFailoverEPFailsDetectionByCCU()
-  {
-    try {
-      
-      FailOverDetectionByCCU = true;
-      createClientCache(NetworkUtils.getServerHostName(Host.getHost(0)), PORT1, PORT2, PORT3, PORT4, 1, 250, 500);
-      waitConnectedServers(4);
-      assertEquals(1, pool.getRedundantNames().size());
-      // assertTrue(pool.getRedundantNames()
-      // .contains(SERVER1));
-      assertTrue(pool.getRedundantNames().contains(SERVER4));
-      //assertIndexDetailsEquals(0, proxy.getDeadServers().size());
-      verifyOrderOfEndpoints();
-      server2.invoke(() -> RedundancyLevelTestBase.stopServer());
-      // pause(5000);
-      verifyDeadServers(1);
-      verifyRedundantServersContain(SERVER4);
-      verifyLiveAndRedundantServers(3, 1);
-      verifyOrderOfEndpoints();
-      // assertTrue(proxy.getDeadServers().contains(SERVER3));
-      // assertIndexDetailsEquals(2, pool.getRedundantNames().size());
-      // assertTrue(pool.getRedundantNames()
-      // .contains(SERVER1));
-      // assertIndexDetailsEquals(3, pool.getConnectedServerCount());
-      //assertIndexDetailsEquals(1, proxy.getDeadServers().size());
-    }
-    catch (Exception ex) {
-      Assert.fail(
-          "test failed due to exception in test testRedundancySpecifiedNonFailoverEPFailsDetectionByCCU ",
-          ex);
-    }
+  @Ignore("TODO")
+  @Test
+  public void testRedundancySpecifiedNonFailoverEPFailsDetectionByCCU() throws Exception {
+    FailOverDetectionByCCU = true;
+    createClientCache(NetworkUtils.getServerHostName(Host.getHost(0)), PORT1, PORT2, PORT3, PORT4, 1, 250, 500);
+    waitConnectedServers(4);
+    assertEquals(1, pool.getRedundantNames().size());
+    // assertTrue(pool.getRedundantNames()
+    // .contains(SERVER1));
+    assertTrue(pool.getRedundantNames().contains(SERVER4));
+    //assertIndexDetailsEquals(0, proxy.getDeadServers().size());
+    verifyOrderOfEndpoints();
+    server2.invoke(() -> RedundancyLevelTestBase.stopServer());
+    // pause(5000);
+    verifyDeadServers(1);
+    verifyRedundantServersContain(SERVER4);
+    verifyLiveAndRedundantServers(3, 1);
+    verifyOrderOfEndpoints();
+    // assertTrue(proxy.getDeadServers().contains(SERVER3));
+    // assertIndexDetailsEquals(2, pool.getRedundantNames().size());
+    // assertTrue(pool.getRedundantNames()
+    // .contains(SERVER1));
+    // assertIndexDetailsEquals(3, pool.getConnectedServerCount());
+    //assertIndexDetailsEquals(1, proxy.getDeadServers().size());
   }
-  /*
+
+  /**
    * Redundancy level specified & less than total Eps. If an EP dies & was not
    * part of the fail over list , then it should be removed from Live Server Map &
    * added to dead server map. It should not change the current failover set.
    * Failover detection by Register Interest
    */
-  
-  public void _testRedundancySpecifiedNonFailoverEPFailsDetectionByRegisterInterest()
-  {
-    try {
-      createClientCache(NetworkUtils.getServerHostName(Host.getHost(0)), PORT1, PORT2, PORT3, PORT4, 1,250, 500);
-      waitConnectedServers(4);
-      assertEquals(1, pool.getRedundantNames().size());
-      // assertTrue(pool.getRedundantNames()
-      // .contains(SERVER1));
-      assertTrue(pool.getRedundantNames().contains(SERVER4));
-      //assertIndexDetailsEquals(0, proxy.getDeadServers().size());
-      verifyOrderOfEndpoints();
-      server2.invoke(() -> RedundancyLevelTestBase.stopServer());
-      // pause(5000);
-      createEntriesK1andK2();
-      registerK1AndK2();
-      verifyDeadServers(1);
-      verifyRedundantServersContain(SERVER4);
-      verifyLiveAndRedundantServers(3, 1);
-      verifyOrderOfEndpoints();
-      // assertTrue(proxy.getDeadServers().contains(SERVER3));
-      // assertIndexDetailsEquals(2, pool.getRedundantNames().size());
-      // assertTrue(pool.getRedundantNames()
-      // .contains(SERVER1));
-      // assertIndexDetailsEquals(3, pool.getConnectedServerCount());
-      //assertIndexDetailsEquals(1, proxy.getDeadServers().size());
-    }
-    catch (Exception ex) {
-      Assert.fail(
-          "test failed due to exception in test testRedundancySpecifiedNonFailoverEPFailsDetectionByRegisterInterest ",
-          ex);
-    }
+  @Ignore("TODO")
+  @Test
+  public void testRedundancySpecifiedNonFailoverEPFailsDetectionByRegisterInterest() throws Exception {
+    createClientCache(NetworkUtils.getServerHostName(Host.getHost(0)), PORT1, PORT2, PORT3, PORT4, 1,250, 500);
+    waitConnectedServers(4);
+    assertEquals(1, pool.getRedundantNames().size());
+    // assertTrue(pool.getRedundantNames()
+    // .contains(SERVER1));
+    assertTrue(pool.getRedundantNames().contains(SERVER4));
+    //assertIndexDetailsEquals(0, proxy.getDeadServers().size());
+    verifyOrderOfEndpoints();
+    server2.invoke(() -> RedundancyLevelTestBase.stopServer());
+    // pause(5000);
+    createEntriesK1andK2();
+    registerK1AndK2();
+    verifyDeadServers(1);
+    verifyRedundantServersContain(SERVER4);
+    verifyLiveAndRedundantServers(3, 1);
+    verifyOrderOfEndpoints();
+    // assertTrue(proxy.getDeadServers().contains(SERVER3));
+    // assertIndexDetailsEquals(2, pool.getRedundantNames().size());
+    // assertTrue(pool.getRedundantNames()
+    // .contains(SERVER1));
+    // assertIndexDetailsEquals(3, pool.getConnectedServerCount());
+    //assertIndexDetailsEquals(1, proxy.getDeadServers().size());
   }
   
-  /*
+  /**
    * Redundancy level specified & less than total Eps. If an EP dies & was not
    * part of the fail over list , then it should be removed from Live Server Map &
    * added to dead server map. It should not change the current failover set.
    * Failover detection by Unregister Interest
    */
-  
-  public void _testRedundancySpecifiedNonFailoverEPFailsDetectionByUnregisterInterest()
-  {
-    try {
-      createClientCache(NetworkUtils.getServerHostName(Host.getHost(0)), PORT1, PORT2, PORT3, PORT4, 1,250,500);
-      waitConnectedServers(4);
-      assertEquals(1, pool.getRedundantNames().size());
-      // assertTrue(pool.getRedundantNames()
-      // .contains(SERVER1));
-      assertTrue(pool.getRedundantNames().contains(SERVER4));
-      //assertIndexDetailsEquals(0, proxy.getDeadServers().size());
-      verifyOrderOfEndpoints();
-      server2.invoke(() -> RedundancyLevelTestBase.stopServer());
-      // pause(5000);
-      unregisterInterest();
-      verifyDeadServers(1);
-      verifyRedundantServersContain(SERVER4);
-      verifyLiveAndRedundantServers(3, 1);
-      verifyOrderOfEndpoints();
-      // assertTrue(proxy.getDeadServers().contains(SERVER3));
-      // assertIndexDetailsEquals(2, pool.getRedundantNames().size());
-      // assertTrue(pool.getRedundantNames()
-      // .contains(SERVER1));
-      // assertIndexDetailsEquals(3, pool.getConnectedServerCount());
-      //assertIndexDetailsEquals(1, proxy.getDeadServers().size());
-    }
-    catch (Exception ex) {
-      Assert.fail(
-          "test failed due to exception in test testRedundancySpecifiedNonFailoverEPFailsDetectionByUnregisterInterest ",
-          ex);
-    }    
+  @Ignore("TODO")
+  @Test
+  public void testRedundancySpecifiedNonFailoverEPFailsDetectionByUnregisterInterest() throws Exception {
+    createClientCache(NetworkUtils.getServerHostName(Host.getHost(0)), PORT1, PORT2, PORT3, PORT4, 1,250,500);
+    waitConnectedServers(4);
+    assertEquals(1, pool.getRedundantNames().size());
+    // assertTrue(pool.getRedundantNames()
+    // .contains(SERVER1));
+    assertTrue(pool.getRedundantNames().contains(SERVER4));
+    //assertIndexDetailsEquals(0, proxy.getDeadServers().size());
+    verifyOrderOfEndpoints();
+    server2.invoke(() -> RedundancyLevelTestBase.stopServer());
+    // pause(5000);
+    unregisterInterest();
+    verifyDeadServers(1);
+    verifyRedundantServersContain(SERVER4);
+    verifyLiveAndRedundantServers(3, 1);
+    verifyOrderOfEndpoints();
+    // assertTrue(proxy.getDeadServers().contains(SERVER3));
+    // assertIndexDetailsEquals(2, pool.getRedundantNames().size());
+    // assertTrue(pool.getRedundantNames()
+    // .contains(SERVER1));
+    // assertIndexDetailsEquals(3, pool.getConnectedServerCount());
+    //assertIndexDetailsEquals(1, proxy.getDeadServers().size());
   }
   
   /*

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/UnregisterInterestDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/UnregisterInterestDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/UnregisterInterestDUnitTest.java
index 2b970ed..dc4acf8 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/UnregisterInterestDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/UnregisterInterestDUnitTest.java
@@ -19,6 +19,7 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -214,8 +215,9 @@ public class UnregisterInterestDUnitTest extends JUnit4DistributedTestCase {
     client2.invoke(() -> UnregisterInterestDUnitTest.timedWaitForInvalidates(5));
   }
 
-  public void _testUnregisterInterestFilters() throws Exception {
-    
+  @Ignore("TODO")
+  @Test
+  public void testUnregisterInterestFilters() throws Exception {
   }
 
   public static void checkRIArtifacts(Integer interestType, Integer value, Integer valueInv) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/VerifyEventIDGenerationInP2PDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/VerifyEventIDGenerationInP2PDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/VerifyEventIDGenerationInP2PDUnitTest.java
index 90c3412..c7c67da 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/VerifyEventIDGenerationInP2PDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/VerifyEventIDGenerationInP2PDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -86,20 +87,15 @@ public class VerifyEventIDGenerationInP2PDUnitTest extends JUnit4DistributedTest
     receiver = false;
   }
 
-  public void _testEventIDGeneration() throws Exception
-  {
+  @Ignore("TODO")
+  @Test
+  public void testEventIDGeneration() throws Exception {
     createEntry();
     vm0.invoke(() -> VerifyEventIDGenerationInP2PDUnitTest.get());
     Boolean pass = (Boolean)vm0.invoke(() -> VerifyEventIDGenerationInP2PDUnitTest.verifyResult());
     assertFalse(pass.booleanValue());
   }
 
-  @Test
-  public void testDummy() throws Exception
-  {
-    
-  }
-  
   private void createCache(Properties props) throws Exception
   {
     DistributedSystem ds = getSystem(props);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/CQListGIIDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/CQListGIIDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/CQListGIIDUnitTest.java
index 98ad134..f0752b6 100755
--- a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/CQListGIIDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/CQListGIIDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.ha;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -606,12 +607,9 @@ public class CQListGIIDUnitTest extends JUnit4DistributedTestCase {
     }
   }
 
-  /**
-   *
-   *
-   * @throws Exception
-   */
-  public void _testSpecificClientCQIsGIIedPart1() throws Exception {
+  @Ignore("TODO")
+  @Test
+  public void testSpecificClientCQIsGIIedPart1() throws Exception {
     Integer size = Integer.valueOf(10);
     // slow start for dispatcher
     serverVM0.invoke(() -> ConflationDUnitTest.setIsSlowStart( "30000" ));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientSimpleDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientSimpleDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientSimpleDUnitTest.java
index 3841f27..e77b3ab 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientSimpleDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientSimpleDUnitTest.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
-
-import org.junit.experimental.categories.Category;
-import org.junit.Test;
-
-import static org.junit.Assert.*;
-
-import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
-import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
-import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
+import org.junit.experimental.categories.Category;
+import org.junit.Test;
+
+import static org.junit.Assert.*;
+
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
 import java.util.Iterator;
 
@@ -63,7 +63,7 @@ import com.gemstone.gemfire.test.dunit.Wait;
 import com.gemstone.gemfire.test.dunit.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.FlakyTest;
 
-@Category(DistributedTest.class)
+@Category(DistributedTest.class)
 public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
 
   public DurableClientSimpleDUnitTest() {
@@ -72,7 +72,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
   /**
    * Test that a durable client correctly receives updates.
    */
-  @Test
+  @Test
   public void testSimpleDurableClientUpdate() {
     // Start a server
     int serverPort = ((Integer) this.server1VM.invoke(() -> CacheServerTestUtil.createCacheServer(regionName, new Boolean(true))))
@@ -150,7 +150,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Test that a durable client VM with multiple BridgeClients correctly
    * registers on the server.
    */
-  @Test
+  @Test
   public void testMultipleBridgeClientsInSingleDurableVM() {
     // Start a server
     int serverPort = ((Integer) this.server1VM.invoke(() -> CacheServerTestUtil.createCacheServer(regionName, new Boolean(true))))
@@ -217,7 +217,9 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * while the first VM is connected. Also, verify that the first client is not
    * affected by the second one attempting to connect.
    */
-  public void XtestMultipleVMsWithSameDurableId() {
+  @Ignore("TODO")
+  @Test
+  public void testMultipleVMsWithSameDurableId() {
     // Start a server
     final int serverPort = ((Integer) this.server1VM.invoke(() -> CacheServerTestUtil.createCacheServer(regionName, new Boolean(true))))
         .intValue();
@@ -326,7 +328,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
   /**
    * Test that the server correctly processes starting two durable clients.
    */
-  @Test
+  @Test
   public void testSimpleTwoDurableClients() {
     // Start a server
     int serverPort = ((Integer) this.server1VM.invoke(() -> CacheServerTestUtil.createCacheServer(regionName, new Boolean(true))))
@@ -569,7 +571,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
   /**
    * Test that updates to two durable clients are processed correctly.
    */
-  @Test
+  @Test
   public void testTwoDurableClientsStartStopUpdate() {
     // Start a server
     int serverPort = ((Integer) this.server1VM.invoke(() -> CacheServerTestUtil.createCacheServer(regionName, new Boolean(true))))
@@ -843,7 +845,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
   /**
    * Tests whether a durable client reconnects properly to two servers.
    */
-  @Test
+  @Test
   public void testDurableClientReconnectTwoServers() {
     // Start server 1
     Integer[] ports = ((Integer[]) this.server1VM.invoke(() -> CacheServerTestUtil.createCacheServerReturnPorts(regionName, new Boolean(true))));
@@ -1037,7 +1039,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
     this.server2VM.invoke(() -> CacheServerTestUtil.closeCache());
   }
   
-  @Test
+  @Test
   public void testReadyForEventsNotCalledImplicitly() {
     // Start a server
     int serverPort = ((Integer) this.server1VM.invoke(() -> CacheServerTestUtil.createCacheServer(regionName, new Boolean(true))))
@@ -1097,7 +1099,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
   //This test method is disabled because it is failing
   //periodically and causing cruise control failures
   //See bug #47060
-  @Test
+  @Test
   public void testReadyForEventsNotCalledImplicitlyWithCacheXML() {
     try {
       setPeriodicACKObserver(durableClientVM);
@@ -1364,7 +1366,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
     vm.invoke(cacheSerializableRunnable);
   }
   
-  @Test
+  @Test
   public void testReadyForEventsNotCalledImplicitlyForRegisterInterestWithCacheXML() {
     final String cqName = "cqTest";
     regionName = "testReadyForEventsNotCalledImplicitlyWithCacheXML_region";
@@ -1553,7 +1555,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Events are queued up and the stats are checked
    * Durable client is then reconnected, events are dispatched and stats are rechecked
    */
-  @Test
+  @Test
   public void testHAQueueSizeStat() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -1630,7 +1632,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Stats should now be 0
    * Durable client is then reconnected, no events should exist and stats are rechecked
    */
-  @Test
+  @Test
   public void testHAQueueSizeStatExpired() throws Exception {
     int timeoutInSeconds = 20;
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
@@ -1717,7 +1719,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Stats are checked
    * Durable client then reregisters cqs and sends ready for events
    */
-  @Test
+  @Test
   public void testHAQueueSizeStatForGII() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -1808,7 +1810,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
   /**
    * Tests the ha queued cq stat
    */
-  @Test
+  @Test
   public void testHAQueuedCqStat() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -1884,7 +1886,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
   /**
    * @throws Exception
    */
-  @Test
+  @Test
   public void testHAQueuedCqStatOnSecondary() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -1984,7 +1986,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * 
    * @throws Exception
    */
-  @Test
+  @Test
   public void testHAQueuedCqStatForGII() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2085,7 +2087,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Durable Client sends ready or events and receives events
    * Recheck stats
    */
-  @Test
+  @Test
   public void testHAQueuedCqStatForGII2() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2183,7 +2185,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * 
    * @throws Exception
    */
-  @Test
+  @Test
   public void testHAQueuedCqStatForGIINoFailover() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2281,7 +2283,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * server 2 behaves accordingly
    * @throws Exception
    */
-  @Test
+  @Test
   public void testHAQueuedCqStatForFailover() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2370,7 +2372,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
   /**
    * Tests the ha queued cq stat
    */
-  @Test
+  @Test
   public void testHAQueuedCqStatWithTimeOut() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2455,7 +2457,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Test functionality to close the cq and drain all events from the ha queue from the server
    * @throws Exception
    */
-  @Test
+  @Test
   public void testCloseCqAndDrainEvents() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2539,7 +2541,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * This draining should not affect events that still have register interest
    * @throws Exception
    */
-  @Test
+  @Test
   public void testCloseAllCqsAndDrainEvents() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2626,7 +2628,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Continues to publish afterwards to verify that stats are correct
    * @throws Exception
    */
-  @Test
+  @Test
   public void testCloseAllCqsAndDrainEventsNoInterestRegistered() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2737,7 +2739,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Two durable clients, one will have a cq be closed, the other should be unaffected
    * @throws Exception
    */
-  @Test
+  @Test
   public void testCloseCqAndDrainEvents2Client() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -2856,7 +2858,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * The client should be rejected until no cqs are currently being drained
    * @throws Exception
    */
-  @Test
+  @Test
   public void testRejectClientWhenDrainingCq() throws Exception {
     try {
       IgnoredException.addIgnoredException(LocalizedStrings.CacheClientNotifier_COULD_NOT_CONNECT_DUE_TO_CQ_BEING_DRAINED.toLocalizedString());
@@ -2981,7 +2983,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * @throws Exception
    */
   @Category(FlakyTest.class) // GEODE-1060: random ports, async actions, time sensitive, eats exceptions (fixed 1)
-  @Test
+  @Test
   public void testCqCloseExceptionDueToActivatingClient() throws Exception {
     try {
       String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
@@ -3082,7 +3084,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Tests situation where a client is trying to reconnect while a cq is being drained
    * @throws Exception
    */
-  @Test
+  @Test
   public void testCqCloseExceptionDueToActiveConnection() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -3158,7 +3160,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * and drain all events from the ha queue from the server
    * @throws Exception
    */
-  @Test
+  @Test
   public void testCloseCacheProxy() throws Exception {
     String greaterThan5Query = "select * from /" + regionName + " p where p.ID > 5";
     String allQuery = "select * from /" + regionName + " p where p.ID > -1";
@@ -3251,7 +3253,7 @@ public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
    * Test that starting a durable client on multiple servers is processed
    * correctly.
    */
-  @Test
+  @Test
   public void testSimpleDurableClientMultipleServers() {
     // Start server 1
     Integer[] ports = ((Integer[]) this.server1VM.invoke(() -> CacheServerTestUtil.createCacheServerReturnPorts(regionName, new Boolean(true))));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4ad50236/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderQueueOverflowDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderQueueOverflowDUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderQueueOverflowDUnitTest.java
index a77c879..deb60d1 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderQueueOverflowDUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderQueueOverflowDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.wan.parallel;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -143,7 +144,9 @@ public class ParallelGatewaySenderQueueOverflowDUnitTest extends WANTestBase {
    *   
    * @throws Exception
    */
-  public void _testParallelSenderQueueEventsOverflow() throws Exception {
+  @Ignore("TODO")
+  @Test
+  public void testParallelSenderQueueEventsOverflow() throws Exception {
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
 
@@ -224,7 +227,9 @@ public class ParallelGatewaySenderQueueOverflowDUnitTest extends WANTestBase {
    * 
    * @throws Exception
    */
-  public void _testParallelSenderQueueEventsOverflow_2() throws Exception {
+  @Ignore("TODO")
+  @Test
+  public void testParallelSenderQueueEventsOverflow_2() throws Exception {
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
 
@@ -305,7 +310,9 @@ public class ParallelGatewaySenderQueueOverflowDUnitTest extends WANTestBase {
     vm3.invoke(() -> WANTestBase.validateRegionSize( getTestMethodName(), 50 ));
   }
 
-  public void _testParallelSenderQueueNoEventsOverflow() throws Exception {
+  @Ignore("TODO")
+  @Test
+  public void testParallelSenderQueueNoEventsOverflow() throws Exception {
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
 
@@ -384,7 +391,9 @@ public class ParallelGatewaySenderQueueOverflowDUnitTest extends WANTestBase {
    * Test to validate that ParallelGatewaySenderQueue diskSynchronous attribute
    * when persistence of sender is enabled. 
    */
-  public void _test_ValidateParallelGatewaySenderQueueAttributes_1() {
+  @Ignore("TODO")
+  @Test
+  public void test_ValidateParallelGatewaySenderQueueAttributes_1() {
     Integer localLocPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     
     Integer remoteLocPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, localLocPort ));
@@ -447,7 +456,9 @@ public class ParallelGatewaySenderQueueOverflowDUnitTest extends WANTestBase {
    * Test to validate that ParallelGatewaySenderQueue diskSynchronous attribute
    * when persistence of sender is not enabled. 
    */
-  public void _test_ValidateParallelGatewaySenderQueueAttributes_2() {
+  @Ignore("TODO")
+  @Test
+  public void test_ValidateParallelGatewaySenderQueueAttributes_2() {
     Integer localLocPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     
     Integer remoteLocPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, localLocPort ));