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/07/11 17:41:19 UTC

[1/2] incubator-geode git commit: GEODE-1452: annotate disabled tests with @Ignore and rename

Repository: incubator-geode
Updated Branches:
  refs/heads/develop cf3fb80ac -> 48f6e6ec5


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPropogationDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPropogationDUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPropogationDUnitTest.java
index 5b0802c..afa03d5 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPropogationDUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPropogationDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.wan.misc;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -118,7 +119,9 @@ public class ReplicatedRegion_ParallelWANPropogationDUnitTest extends WANTestBas
     4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0
    */
-  public void DISABLED_test_PGS_Started_DR_CREATED_NO_RECEIVER() throws Exception {
+  @Ignore
+  @Test
+  public void test_PGS_Started_DR_CREATED_NO_RECEIVER() throws Exception {
     try {
       Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
       Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
@@ -161,7 +164,9 @@ public class ReplicatedRegion_ParallelWANPropogationDUnitTest extends WANTestBas
     4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0
    */
-  public void DISABLED_test_DR_CREATED_PGS_STARTED_NO_RECEIVER() throws Exception {
+  @Ignore
+  @Test
+  public void test_DR_CREATED_PGS_STARTED_NO_RECEIVER() throws Exception {
     try {
       Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
       Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
@@ -198,7 +203,9 @@ public class ReplicatedRegion_ParallelWANPropogationDUnitTest extends WANTestBas
   3> We have to enabled it in next release
   4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0*/
-  public void DISABLED_test_DR_PGS_1Node_Put_ValidateQueue_No_Receiver() throws Exception {
+  @Ignore
+  @Test
+  public void test_DR_PGS_1Node_Put_ValidateQueue_No_Receiver() throws Exception {
     try {
       Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
       Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
@@ -243,7 +250,9 @@ public class ReplicatedRegion_ParallelWANPropogationDUnitTest extends WANTestBas
   3> We have to enabled it in next release
   4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0*/
-  public void DISABLED_test_DR_PGS_2Nodes_Put_ValidateQueue_No_Receiver() throws Exception {
+  @Ignore
+  @Test
+  public void test_DR_PGS_2Nodes_Put_ValidateQueue_No_Receiver() throws Exception {
     try {
       Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
       Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
@@ -329,7 +338,9 @@ public class ReplicatedRegion_ParallelWANPropogationDUnitTest extends WANTestBas
   3> We have to enabled it in next release
   4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0*/
-  public void DISABLED_test_DR_PGS_1Nodes_Put_Receiver() throws Exception {
+  @Ignore
+  @Test
+  public void test_DR_PGS_1Nodes_Put_Receiver_2() throws Exception {
     try {
       Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
       Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
@@ -373,7 +384,9 @@ public class ReplicatedRegion_ParallelWANPropogationDUnitTest extends WANTestBas
   3> We have to enabled it in next release
   4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0*/
-  public void DISABLED_test_DR_PGS_2Nodes_Put_Receiver() throws Exception {
+  @Ignore
+  @Test
+  public void test_DR_PGS_2Nodes_Put_Receiver() throws Exception {
     try {
       Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
       Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
@@ -425,7 +438,9 @@ public class ReplicatedRegion_ParallelWANPropogationDUnitTest extends WANTestBas
   3> We have to enabled it in next release
   4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0*/
-  public void DISABLED_test_DR_PGS_2Nodes_EMPTY_Put_Receiver() throws Exception {
+  @Ignore
+  @Test
+  public void test_DR_PGS_2Nodes_EMPTY_Put_Receiver() throws Exception {
     try {
       Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
       Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
@@ -478,7 +493,9 @@ public class ReplicatedRegion_ParallelWANPropogationDUnitTest extends WANTestBas
   3> We have to enabled it in next release
   4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0*/
-  public void DISABLED_test_DR_PR_PGS_4Nodes_Put_Receiver_2Nodes() throws Exception {
+  @Ignore
+  @Test
+  public void test_DR_PR_PGS_4Nodes_Put_Receiver_2Nodes() throws Exception {
     try {
       Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
       Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
@@ -576,7 +593,9 @@ public class ReplicatedRegion_ParallelWANPropogationDUnitTest extends WANTestBas
   3> We have to enabled it in next release
   4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0*/
-  public void DISABLED_test_DR_PGS_NOMANUALSTART_4Nodes_Put_ValidateReceiver() throws Exception {
+  @Ignore
+  @Test
+  public void test_DR_PGS_NOMANUALSTART_4Nodes_Put_ValidateReceiver() throws Exception {
     try {
       Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
       Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
@@ -650,7 +669,9 @@ public class ReplicatedRegion_ParallelWANPropogationDUnitTest extends WANTestBas
   3> We have to enabled it in next release
   4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0*/
-  public void DISABLED_test_DR_PGS_4Nodes_Put_CLOSE4NODESCACHE_RECREATE_PUT_ValidateReceiver()
+  @Ignore
+  @Test
+  public void test_DR_PGS_4Nodes_Put_CLOSE4NODESCACHE_RECREATE_PUT_ValidateReceiver()
       throws Exception {
     try {
       Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
@@ -772,7 +793,9 @@ public class ReplicatedRegion_ParallelWANPropogationDUnitTest extends WANTestBas
   3> We have to enabled it in next release
   4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0*/
-  public void DISABLED_test_DR_NO_ACK_PGS_2Nodes_Put_ValidateQueue_Receiver() throws Exception {
+  @Ignore
+  @Test
+  public void test_DR_NO_ACK_PGS_2Nodes_Put_ValidateQueue_Receiver() throws Exception {
     try {
       Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
       Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
@@ -824,7 +847,9 @@ public class ReplicatedRegion_ParallelWANPropogationDUnitTest extends WANTestBas
   3> We have to enabled it in next release
   4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0*/
-  public void DISABLED_test_DR_PGS_2NODES_1NODESDOWN_Validate_Receiver() throws Exception {
+  @Ignore
+  @Test
+  public void test_DR_PGS_2NODES_1NODESDOWN_Validate_Receiver() throws Exception {
 
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
@@ -895,7 +920,9 @@ public class ReplicatedRegion_ParallelWANPropogationDUnitTest extends WANTestBas
   3> We have to enabled it in next release
   4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0*/
-  public void DISABLED_test_DR_PGS_4NODES_2NODESDOWN_Validate_Receiver() throws Exception {
+  @Ignore
+  @Test
+  public void test_DR_PGS_4NODES_2NODESDOWN_Validate_Receiver() throws Exception {
 
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WANConfigurationJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WANConfigurationJUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WANConfigurationJUnitTest.java
index 9df768e..d6b339c 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WANConfigurationJUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WANConfigurationJUnitTest.java
@@ -31,6 +31,7 @@ import com.gemstone.gemfire.internal.cache.wan.MyGatewaySenderEventListener;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 import org.junit.After;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -151,7 +152,9 @@ public class WANConfigurationJUnitTest {
    * with parallel distribution policy
    * 
    */
-  public void DIABLEB_DUE_TO_BUG51491_test_GatewaySender_Parallel_DistributedRegion() {
+  @Ignore("Bug51491")
+  @Test
+  public void test_GatewaySender_Parallel_DistributedRegion() {
     cache = new CacheFactory().set(MCAST_PORT, "0").create();
     GatewaySenderFactory fact = cache.createGatewaySenderFactory();
     fact.setParallel(true);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WanAutoDiscoveryDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WanAutoDiscoveryDUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WanAutoDiscoveryDUnitTest.java
index 851dc49..48cc379 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WanAutoDiscoveryDUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WanAutoDiscoveryDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.wan.misc;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -83,7 +84,9 @@ public class WanAutoDiscoveryDUnitTest extends WANTestBase {
    * 
    * @throws Exception
    */
-  public void __test_AllLocatorsinDSShouldHaveDistributedSystemId() throws Exception {
+  @Ignore
+  @Test
+  public void test_AllLocatorsinDSShouldHaveDistributedSystemId() throws Exception {
     try {
       Integer lnLocPort1 = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId(1));
 
@@ -341,8 +344,10 @@ public class WanAutoDiscoveryDUnitTest extends WANTestBase {
     vm2.invoke(() -> WANTestBase.checkAllSiteMetaDataFor3Sites( dsVsPort ));
     vm3.invoke(() -> WANTestBase.checkAllSiteMetaDataFor3Sites( dsVsPort ));
   }
-  
-  public void ___test_3Sites3Locators() {
+
+  @Ignore
+  @Test
+  public void test_3Sites3Locators() {
     final Set<String> site1LocatorsPort = new HashSet<String>();
     int site1Port1 = AvailablePortHelper.getRandomAvailablePortForDUnitSite();
     site1LocatorsPort.add("localhost["+site1Port1+"]");

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WanValidationsDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WanValidationsDUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WanValidationsDUnitTest.java
index c97e461..a3dcb5d 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WanValidationsDUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WanValidationsDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.wan.misc;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -111,7 +112,9 @@ public class WanValidationsDUnitTest extends WANTestBase {
    * We are gone support this configuration in upcoming releases
    */
 
-  public void DISABLED_DUETO_BUG51491_testParallelGatewaySenderForDistributedRegion() throws Exception {
+  @Ignore("Bug51491")
+  @Test
+  public void testParallelGatewaySenderForDistributedRegion() throws Exception {
     try {
       Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
       Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
@@ -239,7 +242,9 @@ public class WanValidationsDUnitTest extends WANTestBase {
    * 
    * @throws Exception
    */
-  public void ___testSameParallelGatewaySenderIdAcrossDifferentPartitionedRegion()
+  @Ignore
+  @Test
+  public void testSameParallelGatewaySenderIdAcrossDifferentPartitionedRegion()
       throws Exception {
     try {
       Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
@@ -696,32 +701,7 @@ public class WanValidationsDUnitTest extends WANTestBase {
       }
     }
   }
-  
-//  public void ___testGatewaySenderListener() {
-//    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-//        "createFirstLocatorWithDSId", new Object[] { 1 });
-//
-//    vm1.invoke(() -> WANTestBase.createCache( lnPort ));
-//    vm2.invoke(() -> WANTestBase.createCache( lnPort ));
-//
-//    vm1.invoke(() -> WANTestBase.createSenderWithListener(
-//        "ln", 2, false, 100, 10, false, false, null,
-//        true, true ));
-//    
-//   try {
-//      vm2.invoke(() -> WANTestBase.createSenderWithListener(
-//        "ln", 2, false, 100, 10, false, false, null,
-//        false, true ));
-//      fail("Expected IllegateStateException : GatewayEventFileters Should match");
-//    }
-//    catch (Exception e) {
-//      if (!(e.getCause() instanceof IllegalStateException)
-//          || !(e.getCause().getMessage()
-//              .contains("because another cache has the same Gateway Sender defined with GatewaySenderEventListener"))) {
-//        fail("Expected IllegalStateException", e);
-//      }
-//    }
-//  }
+
   
   @Test
   public void testIsDiskSynchronous() {
@@ -799,8 +779,10 @@ public class WanValidationsDUnitTest extends WANTestBase {
   /*
    * We are allowing number of dispatcher threads for parallel sender to differ
    * on number of machines
-   */ 
-  public void DISABLED_testDispatcherThreadsForParallelGatewaySender() {
+   */
+  @Ignore
+  @Test
+  public void testDispatcherThreadsForParallelGatewaySender() {
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
 
     createCacheInVMs(lnPort, vm1, vm2);
@@ -829,7 +811,9 @@ public class WanValidationsDUnitTest extends WANTestBase {
    * time of sender creation. policy KEY and Partition are same for PGS. Hence
    * disabling the tests
    */
-  public void DISABLED_testOrderPolicyForParallelGatewaySender() {
+  @Ignore
+  @Test
+  public void testOrderPolicyForParallelGatewaySender() {
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
 
     createCacheInVMs(lnPort, vm1, vm2);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPersistenceEnabledGatewaySenderDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPersistenceEnabledGatewaySenderDUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPersistenceEnabledGatewaySenderDUnitTest.java
index 855856e..be3c42d 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPersistenceEnabledGatewaySenderDUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPersistenceEnabledGatewaySenderDUnitTest.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;
 
@@ -1084,7 +1085,9 @@ public class ParallelWANPersistenceEnabledGatewaySenderDUnitTest extends WANTest
    * NOTE: This use case is not supported yet. 
    * For ParallelGatewaySender to start, it must be associated with a partitioned region. 
    */
-  public void NotSupported_testPersistentPartitionedRegionWithGatewaySenderPersistenceEnabled_Restart2() {
+  @Ignore("NotSupported")
+  @Test
+  public void testPersistentPartitionedRegionWithGatewaySenderPersistenceEnabled_Restart2() {
     //create locator on local site
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     //create locator on remote site
@@ -1192,7 +1195,9 @@ public class ParallelWANPersistenceEnabledGatewaySenderDUnitTest extends WANTest
    * NOTE: This use case is not supported for now. For persistent parallel gateway sender,
    * the PR to which it is attached should also be persistent.
    */
-  public void NotSupported_testNonPersistentPartitionedRegionWithGatewaySenderPersistenceEnabled_Restart() {
+  @Ignore("NotSupported")
+  @Test
+  public void testNonPersistentPartitionedRegionWithGatewaySenderPersistenceEnabled_Restart() {
     //create locator on local site
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     //create locator on remote site
@@ -1304,7 +1309,9 @@ public class ParallelWANPersistenceEnabledGatewaySenderDUnitTest extends WANTest
    * At present, customer is using this configuration and which is not recommended 
    * since it can lead to event loss of GatewaySender events.
    */
-  public void Bug50247_testPersistentPartitionedRegionWithGatewaySender_Restart() {
+  @Ignore("Bug50247")
+  @Test
+  public void testPersistentPartitionedRegionWithGatewaySender_Restart() {
     //create locator on local site
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     //create locator on remote site

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationDUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationDUnitTest.java
index 65daa98..804da23 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationDUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationDUnitTest.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;
 
@@ -1003,7 +1004,9 @@ public class ParallelWANPropagationDUnitTest extends WANTestBase {
         getTestMethodName() + "_PR", 3 ));
   }
 
-  public void disable_testParallelGatewaySenderQueueLocalSize() {
+  @Ignore
+  @Test
+  public void testParallelGatewaySenderQueueLocalSize() {
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANStatsDUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANStatsDUnitTest.java
index f39133e..16a5d92 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANStatsDUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANStatsDUnitTest.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;
 
@@ -273,7 +274,8 @@ public class ParallelWANStatsDUnitTest extends WANTestBase{
    * @throws Exception
    */
   @Category(FlakyTest.class) // GEODE-977: random ports, time sensitive, waitForCriterion
-  public void  testParallePropagationWithRemoteRegionDestroy() throws Exception {
+  @Test
+  public void testParallePropagationWithRemoteRegionDestroy() throws Exception {
     addIgnoredException("RegionDestroyedException");
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderEventListenerDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderEventListenerDUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderEventListenerDUnitTest.java
index ca7e77a..cb55a2a 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderEventListenerDUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderEventListenerDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.wan.serial;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -56,7 +57,9 @@ public class SerialGatewaySenderEventListenerDUnitTest extends WANTestBase {
    * Test validates whether the listener attached receives all the events.
    * this test hangs after the Darrel's checkin 36685. Need to work with Darrel.Commenting it out so that test suit will not hang 
    */
-  public void __testGatewaySenderEventListenerInvocationWithoutLocator() {
+  @Ignore
+  @Test
+  public void testGatewaySenderEventListenerInvocationWithoutLocator() {
     int mPort = AvailablePortHelper.getRandomAvailablePortForDUnitSite();
     vm4.invoke(() -> WANTestBase.createCacheWithoutLocator(mPort ));
     vm5.invoke(() -> WANTestBase.createCacheWithoutLocator(mPort ));
@@ -233,7 +236,9 @@ public class SerialGatewaySenderEventListenerDUnitTest extends WANTestBase {
   
   // Test start/stop/resume on listener invocation
   //this test hangs after the Darrel's checkin 36685. Need to work with Darrel.Commenting it out so that test suit will not hang
-  public void __testGatewaySenderEventListener_GatewayOperations() {
+  @Ignore
+  @Test
+  public void testGatewaySenderEventListener_GatewayOperations() {
 
     int mPort = AvailablePortHelper.getRandomAvailablePortForDUnitSite();
     vm4.invoke(() -> WANTestBase.createCacheWithoutLocator(mPort ));


[2/2] incubator-geode git commit: GEODE-1452: annotate disabled tests with @Ignore and rename

Posted by kl...@apache.org.
GEODE-1452: annotate disabled tests with @Ignore and rename

This closes #184


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

Branch: refs/heads/develop
Commit: 48f6e6ec56184eb92ddc4ccd75275dcb6fedecd7
Parents: cf3fb80
Author: gmeilen <gr...@gmail.com>
Authored: Fri Jul 1 11:46:44 2016 -0700
Committer: Kirk Lund <kl...@pivotal.io>
Committed: Mon Jul 11 10:36:21 2016 -0700

----------------------------------------------------------------------
 .../gemfire/modules/HibernateJUnitTest.java     |  11 +-
 .../cache/ClientServerTimeSyncDUnitTest.java    |  12 +-
 .../ExceptionHandlingJUnitTest.java             |   6 +-
 .../BaseLineAndCompareQueryPerfJUnitTest.java   |   1 -
 .../cache/query/QueryServiceJUnitTest.java      |   7 +-
 .../QueryParamsAuthorizationDUnitTest.java      |   7 +-
 .../CustomerOptimizationsJUnitTest.java         |  23 ++--
 .../query/functional/INOperatorJUnitTest.java   |   5 +-
 .../IUMRCompositeIteratorJUnitTest.java         |   5 +-
 .../query/functional/LimitClauseJUnitTest.java  |   5 +-
 .../MultiRegionIndexUsageJUnitTest.java         |  11 +-
 .../ResultsDataSerializabilityJUnitTest.java    |   5 +-
 .../CompiledJunctionInternalsJUnitTest.java     |   9 +-
 .../query/internal/QCompilerJUnitTest.java      |   5 +-
 .../index/IndexMaintainceJUnitTest.java         |   5 +-
 .../IndexTrackingQueryObserverDUnitTest.java    |   9 +-
 .../PRBasicIndexCreationDeadlockDUnitTest.java  |   6 +-
 .../query/transaction/QueryAndJtaJUnitTest.java |   6 +-
 .../ConcurrentLeaveDuringGIIDUnitTest.java      | 109 ++++++++---------
 .../gemfire/cache30/ReconnectDUnitTest.java     |   5 +-
 .../DistributedLockServiceDUnitTest.java        |   5 +-
 .../InternalDistributedSystemJUnitTest.java     |  13 +-
 .../gemfire/disttx/DistTXDebugDUnitTest.java    |   3 +-
 .../disttx/DistributedTransactionDUnitTest.java |   5 +-
 .../cache/ClientServerTransactionDUnitTest.java |  14 ++-
 .../internal/cache/GIIFlowControlDUnitTest.java |   9 +-
 .../LIFOEvictionAlgoEnabledRegionJUnitTest.java |   5 +-
 .../control/RebalanceOperationDUnitTest.java    |   5 +-
 ...tServerRegionFunctionExecutionDUnitTest.java |   7 +-
 .../cache/execute/PRTransactionDUnitTest.java   |   5 +-
 .../ha/BlockingHARegionQueueJUnitTest.java      |   5 +-
 .../cache/ha/HARQAddOperationJUnitTest.java     |   5 +-
 .../cache/partitioned/Bug51400DUnitTest.java    |   8 +-
 .../PersistentPartitionedRegionDUnitTest.java   |   7 +-
 .../PersistentRVVRecoveryDUnitTest.java         |   5 +-
 .../tier/sockets/AcceptorImplJUnitTest.java     | 118 ++-----------------
 .../CacheServerTransactionsDUnitTest.java       |   5 +-
 .../tier/sockets/ConnectionProxyJUnitTest.java  |  21 ++--
 .../InstantiatorPropagationDUnitTest.java       |   2 +-
 .../cache/query/cq/dunit/CqPerfDUnitTest.java   |   9 +-
 .../cq/dunit/CqPerfUsingPoolDUnitTest.java      |   9 +-
 .../CacheServerManagementDUnitTest.java         |   5 +-
 ...allelGatewaySenderOperation_1_DUnitTest.java |   5 +-
 .../ConcurrentWANPropogation_2_DUnitTest.java   |   5 +-
 .../cache/wan/misc/PDXNewWanDUnitTest.java      |   6 +-
 ...dRegion_ParallelWANPersistenceDUnitTest.java |  22 ++--
 ...dRegion_ParallelWANPropogationDUnitTest.java |  53 +++++++--
 .../wan/misc/WANConfigurationJUnitTest.java     |   5 +-
 .../wan/misc/WanAutoDiscoveryDUnitTest.java     |  11 +-
 .../cache/wan/misc/WanValidationsDUnitTest.java |  46 +++-----
 ...ersistenceEnabledGatewaySenderDUnitTest.java |  13 +-
 .../ParallelWANPropagationDUnitTest.java        |   5 +-
 .../wan/parallel/ParallelWANStatsDUnitTest.java |   4 +-
 ...rialGatewaySenderEventListenerDUnitTest.java |   9 +-
 54 files changed, 383 insertions(+), 323 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/extensions/geode-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/HibernateJUnitTest.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/HibernateJUnitTest.java b/extensions/geode-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/HibernateJUnitTest.java
index d2802c6..223a33b 100644
--- a/extensions/geode-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/HibernateJUnitTest.java
+++ b/extensions/geode-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/HibernateJUnitTest.java
@@ -28,6 +28,7 @@ import org.hibernate.SessionFactory;
 import org.hibernate.cfg.AnnotationConfiguration;
 import org.hibernate.cfg.Configuration;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 import org.slf4j.Logger;
@@ -132,7 +133,7 @@ public class HibernateJUnitTest {
   }
 
   @Test
-  public void testNothing() throws Exception {
+  public void testSomething() throws Exception {
     java.util.logging.Logger.getLogger("org.hibernate").setLevel(Level.ALL);
     log.info("SWAP:creating session factory In hibernateTestCase");
 
@@ -197,7 +198,9 @@ public class HibernateJUnitTest {
 
   }
 
-  public void _testInvalidation() {
+  @Ignore
+  @Test
+  public void testInvalidation() {
     Session s = getSessionFactory(null).openSession();
   }
 
@@ -278,7 +281,9 @@ public class HibernateJUnitTest {
     //    log.info(aPerson.getEvents()+"");
   }
 
-  public void _testQueryCache() throws Exception {
+  @Ignore
+  @Test
+  public void testQueryCache() throws Exception {
     Session session = getSessionFactory(null).openSession();
     Query q = session.createQuery("from Event");
     q.setCacheable(true);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/ClientServerTimeSyncDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/ClientServerTimeSyncDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/ClientServerTimeSyncDUnitTest.java
index 3267d3e..635fd65 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/ClientServerTimeSyncDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/ClientServerTimeSyncDUnitTest.java
@@ -46,7 +46,8 @@ public class ClientServerTimeSyncDUnitTest extends JUnit4CacheTestCase {
   }
 
   @Ignore("Bug 52327")
-  public void DISABLED_testClientTimeAdvances() {
+  @Test
+  public void testClientTimeAdvances() {
     Host host = Host.getHost(0);
     VM vm0 = host.getVM(0); // Server
     VM vm1 = host.getVM(1); // Client
@@ -117,14 +118,11 @@ public class ClientServerTimeSyncDUnitTest extends JUnit4CacheTestCase {
       vm1.invoke(() -> CacheTestCase.disconnectFromDS());
     }
   }
-  
-  @Test
-  public void testNothing() {
-    // place-holder to keep dunit runner from barfing
-  }
+
 
   @Ignore("not yet implemented")
-  public void DISABLED_testClientTimeSlowsDown() {
+  @Test
+  public void testClientTimeSlowsDown() {
     Host host = Host.getHost(0);
     VM vm0 = host.getVM(0); // Server
     VM vm1 = host.getVM(1); // Client

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/mapInterface/ExceptionHandlingJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/mapInterface/ExceptionHandlingJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/mapInterface/ExceptionHandlingJUnitTest.java
index 5ccb951..e63e267 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/mapInterface/ExceptionHandlingJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/mapInterface/ExceptionHandlingJUnitTest.java
@@ -80,8 +80,9 @@ public class ExceptionHandlingJUnitTest {
     }
   }
 
+  @Ignore
   @Test
-  public void _testNullPointerWithGet() {
+  public void testNullPointerWithGet() {
     boolean caught = false;
     try {
       testRegion.get(null);
@@ -108,8 +109,9 @@ public class ExceptionHandlingJUnitTest {
     }
   }
 
+  @Ignore
   @Test
-  public void _testNullPointerWithPut() {
+  public void testNullPointerWithPut() {
     boolean caught = false;
     try {
       testRegion.put(null,null);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/query/BaseLineAndCompareQueryPerfJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/BaseLineAndCompareQueryPerfJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/BaseLineAndCompareQueryPerfJUnitTest.java
index ccfc72d..58e5fd8 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/BaseLineAndCompareQueryPerfJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/BaseLineAndCompareQueryPerfJUnitTest.java
@@ -233,7 +233,6 @@ public class BaseLineAndCompareQueryPerfJUnitTest {
         printSummary();
         
     }//end of testPerf
-    //public void testPerfWithIndex(){}//end of testPerfWithIndex
     
  /**
   * Get the performance of Range query in an AND junction.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/query/QueryServiceJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/QueryServiceJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/QueryServiceJUnitTest.java
index 0c34de7..48bff1b 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/QueryServiceJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/QueryServiceJUnitTest.java
@@ -29,6 +29,7 @@ import java.util.Collection;
 
 import org.junit.After;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -161,8 +162,10 @@ public class QueryServiceJUnitTest {
       //CacheUtils.log("");
     }
   }
-  
-  public void atestGetIndex() throws Exception{
+
+  @Ignore
+  @Test
+  public void testGetIndex() throws Exception{
     CacheUtils.log("testGetIndex");
     QueryService qs = CacheUtils.getQueryService();
     Object testData[][] ={

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryParamsAuthorizationDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryParamsAuthorizationDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryParamsAuthorizationDUnitTest.java
index fc8b5bf..a8ef149 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryParamsAuthorizationDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryParamsAuthorizationDUnitTest.java
@@ -60,12 +60,9 @@ public class QueryParamsAuthorizationDUnitTest extends JUnit4CacheTestCase {
     super();
   }
 
-  @Test
-  public void testNothing() {
-    // remove when Bug #51079 is fixed
-  }
   @Ignore("Bug 51079")
-  public void DISABLED_testQueryParamsInAuthCallback() throws Exception {
+  @Test
+  public void testQueryParamsInAuthCallback() throws Exception {
     final Host host = Host.getHost(0);
     final VM server1 = host.getVM(0);
     final VM client = host.getVM(1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/CustomerOptimizationsJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/CustomerOptimizationsJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/CustomerOptimizationsJUnitTest.java
index 26e3aff..a31ca1c 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/CustomerOptimizationsJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/CustomerOptimizationsJUnitTest.java
@@ -24,6 +24,7 @@ import java.util.Set;
 
 import org.junit.After;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -106,8 +107,10 @@ public class CustomerOptimizationsJUnitTest
     
     CacheUtils.compareResultsOfWithAndWithoutIndex(sr, this);
   }
-  
-  public void _testProjectionEvaluationDuringIndexResults_UNIMPLEMENTED() throws QueryException {
+
+  @Ignore
+  @Test
+  public void testProjectionEvaluationDuringIndexResults_UNIMPLEMENTED() throws QueryException {
     QueryService qs = CacheUtils.getQueryService();
     String[] queries = new String[] {      
         "select  p.status from /pos p, p.positions pos where p.ID > 0 " ,
@@ -389,8 +392,10 @@ public class CustomerOptimizationsJUnitTest
     
     CacheUtils.compareResultsOfWithAndWithoutIndex(sr, this);
   }
-  
-  public void _testProjectionEvaluationDuringIndexResultsWithComplexWhereClause_UNIMPLEMENTED_1() throws QueryException {
+
+  @Ignore
+  @Test
+  public void testProjectionEvaluationDuringIndexResultsWithComplexWhereClause_UNIMPLEMENTED_1() throws QueryException {
     QueryService qs = CacheUtils.getQueryService();
     Region rgn = CacheUtils.getRegion("/pos");
     for(int i =100; i < 200; ++i) {
@@ -466,8 +471,10 @@ public class CustomerOptimizationsJUnitTest
     
     CacheUtils.compareResultsOfWithAndWithoutIndex(sr, this);
   }
-  
-  public void _testProjectionEvaluationDuringIndexResultsWithComplexWhereClause_UNIMPLEMENTED_2() throws QueryException {
+
+  @Ignore
+  @Test
+  public void testProjectionEvaluationDuringIndexResultsWithComplexWhereClause_UNIMPLEMENTED_2() throws QueryException {
     QueryService qs = CacheUtils.getQueryService();
     Region rgn = CacheUtils.getRegion("/pos");
     for(int i =100; i < 200; ++i) {
@@ -1123,7 +1130,9 @@ public class CustomerOptimizationsJUnitTest
   }
   
   //ideally rojection should have been evaluated while collecting index results
-  public void _testProjectionEvaluationOnORJunction_NOT_IMPLEMENTED() throws Exception{
+  @Ignore
+  @Test
+  public void testProjectionEvaluationOnORJunction_NOT_IMPLEMENTED() throws Exception{
     QueryService qs = CacheUtils.getQueryService();
     Region rgn = CacheUtils.getRegion("/pos");
     for(int i =100; i < 10000; ++i) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/INOperatorJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/INOperatorJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/INOperatorJUnitTest.java
index fbc887c..f4ba11d 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/INOperatorJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/INOperatorJUnitTest.java
@@ -30,6 +30,7 @@ import java.util.Set;
 
 import org.junit.After;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -79,7 +80,9 @@ public class INOperatorJUnitTest {
    * Test the decomposition of IN SET(..) that gets decomposed
    * into ORs so an index can be used
    */
-  public void _testInDecompositionWithFunctionalIndex() throws Exception {
+  @Ignore
+  @Test
+  public void testInDecompositionWithFunctionalIndex() throws Exception {
  
   }
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/IUMRCompositeIteratorJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/IUMRCompositeIteratorJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/IUMRCompositeIteratorJUnitTest.java
index 7c627c1..070d500 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/IUMRCompositeIteratorJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/IUMRCompositeIteratorJUnitTest.java
@@ -31,6 +31,7 @@ import java.util.Set;
 
 import org.junit.After;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -165,7 +166,9 @@ public class IUMRCompositeIteratorJUnitTest {
 
   }
 
-  public void _testQueryWithCompositeIter2() throws Exception {
+  @Ignore
+  @Test
+  public void testQueryWithCompositeIter2() throws Exception {
     QueryService qs;
     qs = CacheUtils.getQueryService();
     String queries[] = {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/LimitClauseJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/LimitClauseJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/LimitClauseJUnitTest.java
index 5280dfb..c46f964 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/LimitClauseJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/LimitClauseJUnitTest.java
@@ -31,6 +31,7 @@ import java.util.Set;
 
 import org.junit.After;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -512,7 +513,9 @@ public class LimitClauseJUnitTest {
    * 
    * Tests StructBag behaviour
    */
-  public void xtestLimitQueryForStructBagWithRangeIndex() {
+  @Ignore
+  @Test
+  public void testLimitQueryForStructBagWithRangeIndex() {
     try {
       Query query;
       SelectResults result;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/MultiRegionIndexUsageJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/MultiRegionIndexUsageJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/MultiRegionIndexUsageJUnitTest.java
index 6097be7..c57cb5c 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/MultiRegionIndexUsageJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/MultiRegionIndexUsageJUnitTest.java
@@ -31,6 +31,7 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 import org.junit.After;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -202,8 +203,9 @@ public class MultiRegionIndexUsageJUnitTest {
 
   }// end of test
 
-  //@Test
-  public void _testChangedFormClauseOrder2() throws Exception {
+  @Ignore
+  @Test
+  public void testChangedFormClauseOrder2() throws Exception {
     CacheUtils
         .log("------------- testChangedFormClauseOrder2 start------------- ");
     SelectResults rs[][] = new SelectResults[1][2];
@@ -601,8 +603,9 @@ public class MultiRegionIndexUsageJUnitTest {
 
   }// end of test
 
-  //@Test
-  public void _testFunctionUse2() throws Exception {
+  @Ignore
+  @Test
+  public void testFunctionUse2() throws Exception {
     CacheUtils.log("------------- testFunctionUse2 start------------- ");
     SelectResults rs[][] = new SelectResults[1][2];
     // Test Case No. IUMR019

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/ResultsDataSerializabilityJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/ResultsDataSerializabilityJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/ResultsDataSerializabilityJUnitTest.java
index cb45bad..6d4a3e0 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/ResultsDataSerializabilityJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/functional/ResultsDataSerializabilityJUnitTest.java
@@ -35,6 +35,7 @@ import java.util.List;
 
 import org.junit.After;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -116,7 +117,9 @@ public class ResultsDataSerializabilityJUnitTest {
   // network. Hence a dunit test is required for testing this functionality.
   
   /* test DataSerializability of a simple query result */
-  public void _testDataSerializability() throws Exception {
+  @Ignore
+  @Test
+  public void testDataSerializability() throws Exception {
               
     Region region = CacheUtils.createRegion("Portfolios", Portfolio.class);
     for(int i = 0; i < 10000; i++) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/CompiledJunctionInternalsJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/CompiledJunctionInternalsJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/CompiledJunctionInternalsJUnitTest.java
index c3e1a45..1f45ebb 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/CompiledJunctionInternalsJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/CompiledJunctionInternalsJUnitTest.java
@@ -36,6 +36,7 @@ import java.util.Set;
 
 import org.junit.After;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -1329,7 +1330,9 @@ RangeJunction related tests when part of GroupJunction,
    * Tests the creation of a single RangeJunction if the CompiledJunction only
    * contains same index condition without iter operand for OR
    */
-  public void _testOrganizedOperandsSingleRangeJunctionCreationWithNoIterOperandForOR() {
+  @Ignore
+  @Test
+  public void testOrganizedOperandsSingleRangeJunctionCreationWithNoIterOperandForOR() {
     LogWriter logger = CacheUtils.getLogger();
     try {
       CompiledComparison cv[] = null;
@@ -2664,7 +2667,9 @@ RangeJunction related tests when part of GroupJunction,
    * NotEqualConditionEvaluator.
    * 
    */
-  public void _testNotEqualCoupledWithUndefinedAndNotNull() {
+  @Ignore
+  @Test
+  public void testNotEqualCoupledWithUndefinedAndNotNull() {
     LogWriter logger = CacheUtils.getLogger();
     try {
       ExecutionContext context = new QueryExecutionContext(null, CacheUtils

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/QCompilerJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/QCompilerJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/QCompilerJUnitTest.java
index bcf0b65..96723d1 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/QCompilerJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/QCompilerJUnitTest.java
@@ -31,6 +31,7 @@ import java.util.TreeMap;
 
 import org.junit.After;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -346,7 +347,9 @@ public class QCompilerJUnitTest {
    * this the Like predicate is not transformed to compiled-junction
    * with > and < operator.
    */
-  public void XtestStringConditioningForLike_2() {
+  @Ignore
+  @Test
+  public void testStringConditioningForLike_2() {
     CompiledValue var = new CompiledPath(new CompiledID("p"), "ID");
     String s1 = "abc%";
     CompiledLiteral literal = new CompiledLiteral(s1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexMaintainceJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexMaintainceJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexMaintainceJUnitTest.java
index 3ee758b..b35dd25 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexMaintainceJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexMaintainceJUnitTest.java
@@ -30,6 +30,7 @@ import java.util.Collection;
 import org.junit.After;
 import org.junit.Before;
 import org.junit.FixMethodOrder;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 import org.junit.runners.MethodSorters;
@@ -219,7 +220,9 @@ public class IndexMaintainceJUnitTest {
   // !!!:ezoerner:20081030 disabled because modifying an object in place
   // and then putting it back into the cache breaks a CompactRangeIndex.
   // @todo file a ticket on this issue
-  public void _test002UpdateEntry() throws Exception {
+  @Ignore
+  @Test
+  public void test002UpdateEntry() throws Exception {
     IndexStatistics stats = index.getStatistics();
     CacheUtils.log(((CompactRangeIndex) index).dump());
     Portfolio p = (Portfolio) region.get("4");

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexTrackingQueryObserverDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexTrackingQueryObserverDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexTrackingQueryObserverDUnitTest.java
index 4e4d76a..e03f8f6 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexTrackingQueryObserverDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexTrackingQueryObserverDUnitTest.java
@@ -74,14 +74,11 @@ public class IndexTrackingQueryObserverDUnitTest extends JUnit4CacheTestCase {
   public IndexTrackingQueryObserverDUnitTest() {
     super();
   }
-  
-  @Test
-  public void testNothing() {
-    
-  }
+
   
   @Ignore("Disabled for bug 52321")
-  public void DISABLED_testIndexInfoOnRemotePartitionedRegion() throws Exception {
+  @Test
+  public void testIndexInfoOnRemotePartitionedRegion() throws Exception {
     final Host host = Host.getHost(0);
     VM ds0 = host.getVM(0);
     VM ds1 = host.getVM(1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicIndexCreationDeadlockDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicIndexCreationDeadlockDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicIndexCreationDeadlockDUnitTest.java
index 20041bd..fe1d2e7 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicIndexCreationDeadlockDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicIndexCreationDeadlockDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.cache.query.partitioned;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -83,12 +84,9 @@ public class PRBasicIndexCreationDeadlockDUnitTest extends
 
   public static volatile boolean hook_vm1, hook_vm2;
 
-  //Dummy test method to be removed when test is fixed
+  @Ignore
   @Test
   public void testIndexCreationMessageDiskRecoveryDeadLock() {
-  }
-
-  public void DISABLE_testIndexCreationMessageDiskRecoveryDeadLock() {
     Host host = Host.getHost(0);
     VM vm0 = host.getVM(0);
     VM vm1 = host.getVM(1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache/query/transaction/QueryAndJtaJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/transaction/QueryAndJtaJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/transaction/QueryAndJtaJUnitTest.java
index 162ffb1..968cd69 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache/query/transaction/QueryAndJtaJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache/query/transaction/QueryAndJtaJUnitTest.java
@@ -33,6 +33,7 @@ import javax.transaction.UserTransaction;
 
 import org.junit.After;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -413,8 +414,9 @@ public class QueryAndJtaJUnitTest {
   /*
    * Enable this test when indexes are made transactional.
    */
-  //@Test
-  public void _testFailedIndexUpdateOnJTACommitForPut() throws Exception {
+  @Ignore
+  @Test
+  public void testFailedIndexUpdateOnJTACommitForPut() throws Exception {
     Person.THROW_ON_INDEX = true;
     AttributesFactory af = new AttributesFactory();
     af.setDataPolicy(DataPolicy.REPLICATE);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache30/ConcurrentLeaveDuringGIIDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/ConcurrentLeaveDuringGIIDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/ConcurrentLeaveDuringGIIDUnitTest.java
index 19e37eb..7642909 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/ConcurrentLeaveDuringGIIDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/ConcurrentLeaveDuringGIIDUnitTest.java
@@ -1,29 +1,30 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache30;
-
-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.Ignore;
+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 com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionShortcut;
@@ -33,27 +34,27 @@ import com.gemstone.gemfire.internal.cache.DistributedRegion;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.InitialImageOperation;
 import com.gemstone.gemfire.internal.cache.InitialImageOperation.GIITestHook;
-import com.gemstone.gemfire.internal.cache.InitialImageOperation.GIITestHookType;
-import com.gemstone.gemfire.test.dunit.Host;
-import com.gemstone.gemfire.test.dunit.LogWriterUtils;
-import com.gemstone.gemfire.test.dunit.SerializableCallable;
-import com.gemstone.gemfire.test.dunit.SerializableRunnable;
-import com.gemstone.gemfire.test.dunit.VM;
-import com.gemstone.gemfire.test.dunit.Wait;
-import com.gemstone.gemfire.test.dunit.WaitCriterion;
+import com.gemstone.gemfire.internal.cache.InitialImageOperation.GIITestHookType;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.LogWriterUtils;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.Wait;
+import com.gemstone.gemfire.test.dunit.WaitCriterion;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.RegionMap;
 
-@Category(DistributedTest.class)
+@Category(DistributedTest.class)
 public class ConcurrentLeaveDuringGIIDUnitTest extends JUnit4CacheTestCase {
 
   public ConcurrentLeaveDuringGIIDUnitTest() {
     super();
   }
-  
-  @Test
-  public void testRemoveWhenBug50988IsFixed() {
-    // remove this placeholder
+  
+  @Test
+  public void testRemoveWhenBug50988IsFixed() {
+    // remove this placeholder
   }
   /**
    * In #48962 a member X has replicated region and is updating it.  Members A and B
@@ -73,7 +74,9 @@ public class ConcurrentLeaveDuringGIIDUnitTest extends JUnit4CacheTestCase {
    * A is then allowed to start its GII and pulls an image from B.
    * 
    */
-  public void bug50988_testBug48962() throws Exception {
+  @Ignore
+  @Test
+  public void testBug48962() throws Exception {
     VM X = Host.getHost(0).getVM(1);
     VM A = Host.getHost(0).getVM(2);
     VM B = Host.getHost(0).getVM(3);
@@ -129,20 +132,20 @@ public class ConcurrentLeaveDuringGIIDUnitTest extends JUnit4CacheTestCase {
         // use internal methods to get the region since it's still initializing
         GemFireCacheImpl cache = (GemFireCacheImpl)getCache(); 
         final RegionMap r = cache.getRegionByPathForProcessing(regionName).getRegionMap(); 
-
-        // X's update should have been propagated to A and put into the cache.
-        // If this throws an assertion error then there's no point in
-        // continuing the test because we didn't set up the initial
-        // condition needed for the next step.
-        WaitCriterion wc = new WaitCriterion() {
-          public boolean done() {
-            return r.containsKey("keyFromX");
-          }
-          public String description() {
-            return "waiting for region " + regionName + " to contain keyFromX";
-          }
-        };
-        Wait.waitForCriterion(wc, 20000, 1000, true);
+
+        // X's update should have been propagated to A and put into the cache.
+        // If this throws an assertion error then there's no point in
+        // continuing the test because we didn't set up the initial
+        // condition needed for the next step.
+        WaitCriterion wc = new WaitCriterion() {
+          public boolean done() {
+            return r.containsKey("keyFromX");
+          }
+          public String description() {
+            return "waiting for region " + regionName + " to contain keyFromX";
+          }
+        };
+        Wait.waitForCriterion(wc, 20000, 1000, true);
       }
     });
     

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/cache30/ReconnectDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/ReconnectDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/ReconnectDUnitTest.java
index f223487..59fc206 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/ReconnectDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/ReconnectDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.cache30;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -752,7 +753,9 @@ public class ReconnectDUnitTest extends JUnit4CacheTestCase
   
   // See #50944 before enabling the test.  This ticket has been closed with wontFix
   // for the 2014 8.0 release.
-  public void DISABLED_testReconnectWithRequiredRoleRegained()throws Throwable {
+  @Ignore
+  @Test
+  public void testReconnectWithRequiredRoleRegained()throws Throwable {
 
     final String rr1 = "RoleA";
     //final String rr2 = "RoleB";

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/distributed/DistributedLockServiceDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/distributed/DistributedLockServiceDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/distributed/DistributedLockServiceDUnitTest.java
index ebd0b95..f09fc9a 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/distributed/DistributedLockServiceDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/distributed/DistributedLockServiceDUnitTest.java
@@ -27,6 +27,7 @@ import java.util.Map;
 import java.util.Set;
 import java.util.concurrent.atomic.AtomicBoolean;
 
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -1462,7 +1463,9 @@ public class DistributedLockServiceDUnitTest extends JUnit4DistributedTestCase {
    * ensures that suspend and regular locks behave as ReadWriteLocks and
    * processing occurs in order.
    */
-  public void notestSuspendLockingBehaves() throws Exception {
+  @Ignore
+  @Test
+  public void testSuspendLockingBehaves() throws Exception {
     try {
       doTestSuspendLockingBehaves();
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystemJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystemJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystemJUnitTest.java
index 7cc475f..a59262e 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystemJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystemJUnitTest.java
@@ -26,6 +26,7 @@ import com.gemstone.gemfire.internal.logging.InternalLogWriter;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 import org.junit.After;
 import org.junit.Assert;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -277,7 +278,9 @@ public class InternalDistributedSystemJUnitTest
    *
    * @deprecated This test creates a "loner" distributed system
    */
-  public void _testEmptyLocators() {
+  @Ignore
+  @Test
+  public void testEmptyLocators() {
     Properties props = new Properties();
     props.put(MCAST_PORT, String.valueOf(0));
     props.put(LOCATORS, "");
@@ -386,7 +389,9 @@ public class InternalDistributedSystemJUnitTest
    * gemfire.ack-wait-threshold system property is set on this VM,
    * thus overriding the value passed into the API.
    */
-  public void _testGetAckWaitThreshold() {
+  @Ignore
+  @Test
+  public void testGetAckWaitThreshold() {
     String time = String.valueOf(DistributionConfig.MIN_ACK_WAIT_THRESHOLD);
     Properties props = new Properties();
     // a loner is all this test needs
@@ -402,7 +407,9 @@ public class InternalDistributedSystemJUnitTest
    * gemfire.ack-wait-threshold system property is set on this VM,
    * thus overriding the value passed into the API.
    */
-  public void _testInvalidAckWaitThreshold() {
+  @Ignore
+  @Test
+  public void testInvalidAckWaitThreshold() {
     Properties props = new Properties();
     props.put(ACK_WAIT_THRESHOLD, "blah");
     try {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistTXDebugDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistTXDebugDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistTXDebugDUnitTest.java
index 9f8e142..cc1773a 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistTXDebugDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistTXDebugDUnitTest.java
@@ -47,6 +47,8 @@ import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
 import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -879,7 +881,6 @@ public class DistTXDebugDUnitTest extends JUnit4CacheTestCase {
 //    accessor.invoke(TxOps);
   }
 
-  
   public void performTXRRtestOps(boolean makeDatNodeAsCoordinator) {
     createCacheInAllVms();
     Object[] prAttrs = new Object[] { "pregion1", 1, null, 3, null,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
index 6d9a172..52fff55 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
@@ -24,6 +24,7 @@ import java.util.Properties;
 import java.util.Set;
 import java.util.concurrent.CountDownLatch;
 
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -1301,7 +1302,9 @@ public class DistributedTransactionDUnitTest extends JUnit4CacheTestCase {
    * 1. On primary, the tx op is applied first followed by non-tx
    * 2. On secondary, non-tx op is applied first followed by tx.
    */
-  public void DISABLED_testConcurrentTXAndNonTXOperations() throws Exception {
+  @Ignore
+  @Test
+  public void testConcurrentTXAndNonTXOperations() throws Exception {
     Host host = Host.getHost(0);
     final VM server1 = host.getVM(0);
     final VM server2 = host.getVM(1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
index 69d3fe4..08953d5 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.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;
 
@@ -828,8 +829,9 @@ public class ClientServerTransactionDUnitTest extends RemoteTransactionDUnitTest
 	    });
 	  }
 
-  
-  public void disabled_testGetAllRollbackInServer() throws Exception {
+  @Ignore
+  @Test
+  public void testGetAllRollbackInServer() throws Exception {
     Host host = Host.getHost(0);
     VM server = host.getVM(0);
     createRegionsAndStartServer(server, false);
@@ -859,7 +861,9 @@ public class ClientServerTransactionDUnitTest extends RemoteTransactionDUnitTest
     });
   }
 
-  public void disabled_testGetAllRollbackInClient() throws Exception {
+  @Ignore
+  @Test
+  public void testGetAllRollbackInClient() throws Exception {
     Host host = Host.getHost(0);
     VM server = host.getVM(0);
     VM client = host.getVM(1);
@@ -1929,7 +1933,9 @@ public class ClientServerTransactionDUnitTest extends RemoteTransactionDUnitTest
   }
   
   //Disabled due to bug 47083
-  public void DISABLED_testCallbacks() {
+  @Ignore
+  @Test
+  public void testCallbacks() {
     Host host = Host.getHost(0);
     VM datastore = host.getVM(1);
     VM client = host.getVM(2);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/GIIFlowControlDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/GIIFlowControlDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/GIIFlowControlDUnitTest.java
index 405ff45..a935439 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/GIIFlowControlDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/GIIFlowControlDUnitTest.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;
 
@@ -239,13 +240,17 @@ public class GIIFlowControlDUnitTest extends JUnit4CacheTestCase {
   
   // DISABLED due to high failure rate due, apparently, to problems
   // with the flow-control statistics.  See internal ticket #52221
-  public void disabledtestCloseReceiverCacheNoHang() throws Throwable {
+  @Ignore
+  @Test
+  public void testCloseReceiverCacheNoHang() throws Throwable {
     doCloseTest(false);
   }
   
   // DISABLED due to high failure rate due, apparently, to problems
   // with the flow-control statistics.  See internal ticket #52221
-  public void disabledtestDisconnectReceiverNoHang() throws Throwable {
+  @Ignore
+  @Test
+  public void testDisconnectReceiverNoHang() throws Throwable {
     doCloseTest(true);
   }
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/LIFOEvictionAlgoEnabledRegionJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/LIFOEvictionAlgoEnabledRegionJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/LIFOEvictionAlgoEnabledRegionJUnitTest.java
index ef4d1f2..aee09f9 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/LIFOEvictionAlgoEnabledRegionJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/LIFOEvictionAlgoEnabledRegionJUnitTest.java
@@ -23,6 +23,7 @@ import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 import org.junit.After;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -300,7 +301,9 @@ public class LIFOEvictionAlgoEnabledRegionJUnitTest {
    * 1)Verify Entry value after faultin should be byte []<br>
    */
   // not using it. added as may needed if functionality gets added
-   public void _testFaultInEntryValueShouldbeSerialized() {
+  @Ignore
+  @Test
+  public void testFaultInEntryValueShouldbeSerialized() {
      try {
        assertNotNull(cache);
        LocalRegion rgn = (LocalRegion)cache.getRegion(Region.SEPARATOR + regionName);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/control/RebalanceOperationDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/control/RebalanceOperationDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/control/RebalanceOperationDUnitTest.java
index f11b41b..58436a8 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/control/RebalanceOperationDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/control/RebalanceOperationDUnitTest.java
@@ -40,6 +40,7 @@ import java.util.concurrent.CyclicBarrier;
 import java.util.concurrent.TimeUnit;
 import java.util.concurrent.TimeoutException;
 
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -237,7 +238,9 @@ public class RebalanceOperationDUnitTest extends JUnit4CacheTestCase {
   }
   
   /** Manual test.*/
-  public void z_testRedundancyLoop() {
+  @Ignore
+  @Test
+  public void testRedundancyLoop() {
     Host host = Host.getHost(0);
     VM vm0 = host.getVM(0);
     VM vm1 = host.getVM(1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionDUnitTest.java
index 569fec7..695c003 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionDUnitTest.java
@@ -31,6 +31,7 @@ import java.util.Iterator;
 import java.util.List;
 import java.util.Set;
 
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -142,8 +143,10 @@ public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServ
     createScenario_SingleConnection();
     client.invoke(() -> PRClientServerRegionFunctionExecutionDUnitTest.serverSingleKeyExecutionOnRegion_SingleConnection());
   }
-  
-  public void Bug47584_testServerSingleKeyExecution_Bug43513_OnServer() {
+
+  @Ignore("Bug47584")
+  @Test
+  public void testServerSingleKeyExecution_Bug43513_OnServer() {
     createScenario_SingleConnection();
     client.invoke(() -> PRClientServerRegionFunctionExecutionDUnitTest.serverSingleKeyExecutionOnServer_SingleConnection());
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRTransactionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRTransactionDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRTransactionDUnitTest.java
index b06887f..85d7173 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRTransactionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRTransactionDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.execute;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -432,7 +433,9 @@ public class PRTransactionDUnitTest extends PRColocationDUnitTest {
     }
   }
 
-  public void BUG46661DISABLEtestCacheListenerCallbacks() {
+  @Ignore("BUG46661")
+  @Test
+  public void testCacheListenerCallbacks() {
     createPopulateAndVerifyCoLocatedPRs(1);
 
     SerializableCallable registerListeners = new SerializableCallable() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/BlockingHARegionQueueJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/BlockingHARegionQueueJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/BlockingHARegionQueueJUnitTest.java
index ffb4771..a503ea4 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/BlockingHARegionQueueJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/BlockingHARegionQueueJUnitTest.java
@@ -23,6 +23,7 @@ import static org.junit.Assert.fail;
 
 import java.io.IOException;
 
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -170,7 +171,9 @@ public class BlockingHARegionQueueJUnitTest extends HARegionQueueJUnitTest
    */
   //fix for 40314 - capacity constraint is checked for primary only and
   //expiry is not applicable on primary so marking this test as invalid.
-  public void _testBlockingPutAndExpiry()
+  @Ignore
+  @Test
+  public void testBlockingPutAndExpiry()
   {
     try {
       HARegionQueueAttributes hrqa = new HARegionQueueAttributes();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQAddOperationJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQAddOperationJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQAddOperationJUnitTest.java
index e8bfafb..922dd12 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQAddOperationJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQAddOperationJUnitTest.java
@@ -27,6 +27,7 @@ import java.util.Map;
 import org.apache.logging.log4j.Logger;
 import org.junit.After;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -1054,7 +1055,9 @@ public class HARQAddOperationJUnitTest {
    * Behaviour of take() has been changed for relaible messaging feature. Region queue take()
    * operation will no longer add to the Dispatch Message Map. Hence disabling the test - SUYOG
    */
-  public void _testDispatchedMsgsMapUpdateOnTakes() throws Exception {
+  @Ignore
+  @Test
+  public void testDispatchedMsgsMapUpdateOnTakes() throws Exception {
     this.logWriter
         .info("HARQAddOperationJUnitTest : testDispatchedEventsMapUpdateOnTakes BEGIN");
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug51400DUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug51400DUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug51400DUnitTest.java
index 211e2f2..1caae7a 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug51400DUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug51400DUnitTest.java
@@ -24,6 +24,7 @@ import static org.junit.Assert.*;
 
 import java.util.Properties;
 
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -148,11 +149,10 @@ public class Bug51400DUnitTest extends JUnit4DistributedTestCase {
         + (isPrimary ? "primary." : "secondary."), numOfEvents.intValue(), qSize);
   }
 
+
+  @Ignore("ticket51932")
   @Test
-  public void testNothing() {
-    // remove when ticket #51932 is fixed
-  }
-  public void ticket51932_testDeadlock() throws Throwable {
+  public void testDeadlock() throws Throwable {
     int maxQSize = 5;
     // Set infinite ack interval so that the queue will not be drained.
     int ackInterval = Integer.MAX_VALUE;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionDUnitTest.java
index 7f224ca..6c37817 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionDUnitTest.java
@@ -257,7 +257,8 @@ public class PersistentPartitionedRegionDUnitTest extends PersistentPartitionedR
    * async writer thread.
    */
   @Ignore("Bug 50376")
-  public void DISABLED_testBadSerializationInAsyncThread() throws Throwable {
+  @Test
+  public void testBadSerializationInAsyncThread() throws Throwable {
     Host host = Host.getHost(0);
     VM vm0 = host.getVM(0);
     VM vm1 = host.getVM(1);
@@ -1227,7 +1228,9 @@ public class PersistentPartitionedRegionDUnitTest extends PersistentPartitionedR
    * if we restored redundancy while 
    * that bucket was offline.
    */
-  public void z_testThrowAwayUneededBucket() {
+  @Ignore
+  @Test
+  public void testThrowAwayUneededBucket() {
     Host host = Host.getHost(0);
     VM vm0 = host.getVM(0);
     VM vm1 = host.getVM(1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRVVRecoveryDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRVVRecoveryDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRVVRecoveryDUnitTest.java
index a7b15fd..dc4228c 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRVVRecoveryDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRVVRecoveryDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.persistence;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -258,7 +259,9 @@ public class PersistentRVVRecoveryDUnitTest extends PersistentReplicatedTestBase
    * start expiring based on their original time-stamp, NOT the time-stamp
    * assigned during scheduling for expiration after recovery.
    */
-  public void DISABLED_testLotsOfTombstonesExpiration() throws Throwable {
+  @Ignore
+  @Test
+  public void testLotsOfTombstonesExpiration() throws Throwable {
     Host host = Host.getHost(0);
     final VM vm0 = host.getVM(0);
     

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/AcceptorImplJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/AcceptorImplJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/AcceptorImplJUnitTest.java
index b703f00..69228af 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/AcceptorImplJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/AcceptorImplJUnitTest.java
@@ -16,22 +16,31 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
+import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.CacheException;
 import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.client.ServerRefusedConnectionException;
 import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
+import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.InternalCache;
+import com.gemstone.gemfire.internal.cache.tier.Acceptor;
+import com.gemstone.gemfire.internal.cache.tier.MessageType;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 import org.junit.After;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
 import java.io.IOException;
 import java.net.BindException;
+import java.net.Socket;
 import java.util.Collections;
 import java.util.Properties;
 
@@ -64,7 +73,9 @@ public class AcceptorImplJUnitTest
   /*
    * Test method for 'com.gemstone.gemfire.internal.cache.tier.sockets.AcceptorImpl(int, int, boolean, int, Cache)'
    */
-  public void foo_testConstructor() throws CacheException, IOException
+  @Ignore
+  @Test
+  public void testConstructor() throws CacheException, IOException
   {
     AcceptorImpl a1 = null, a2 = null, a3 = null;
     try {
@@ -165,109 +176,4 @@ public class AcceptorImplJUnitTest
     }
   }
 
-  /*
-   * Test method for 'com.gemstone.gemfire.internal.cache.tier.sockets.AcceptorImpl.start()'
-   * Since for CBB branch , the ping protocol has been modified such that the 
-   * server connection thread exits after recieving the ping protocol, using
-   * a non ping message to test the conenction limit 
-   */
-  /*public void disable_testStartAndAccept() throws IOException, ServerRefusedConnectionException
-  {
-    //LogWriter log = new LocalLogWriter(LogWriterImpl.INFO_LEVEL);
-    //Create a temporary test region
-	Region temp= null;  
-    AcceptorImpl ac = null;
-    Socket[] clis = null;
-    try{
-    	temp =cache.createRegion("testRoot", new AttributesFactory().create());
-    }catch(Exception ignore) {
-    	
-    }
-    // Test getting to the limit of connection
-    
-    Message putMsg= new Message(3);
-    try {
-      
-      int port2 = AvailablePort.getRandomAvailablePort( AvailablePort.SOCKET );
-      ac = new AcceptorImpl(
-        port2,
-        null,
-        false,
-        CacheServer.DEFAULT_SOCKET_BUFFER_SIZE,
-        CacheServer.DEFAULT_MAXIMUM_TIME_BETWEEN_PINGS,
-        this.cache,
-        AcceptorImpl.MINIMUM_MAX_CONNECTIONS,
-        CacheServer.DEFAULT_MAX_THREADS,
-        CacheServer.DEFAULT_MAXIMUM_MESSAGE_COUNT,
-        CacheServer.DEFAULT_MESSAGE_TIME_TO_LIVE,null,null);
-      ac.start();
-      putMsg.setMessageType(MessageType.PUT);
-      putMsg.setTransactionId(1);
-      putMsg.setNumberOfParts(4);
-      putMsg.addStringPart("testRoot");
-      putMsg.addStringOrObjPart("key1");
-      putMsg.addObjPart("key1", false);
-      putMsg.addBytesPart(EventID.getOptimizedByteArrayForEventID(1, 1));
- 
-      clis = new Socket[AcceptorImpl.MINIMUM_MAX_CONNECTIONS];
-      for(int i=0; i<clis.length; i++) {
-        clis[i] = new Socket((String) null, port2);
-        clis[i].setSoTimeout(1000);
-        clis[i].getOutputStream().write(Acceptor.CLIENT_TO_SERVER);
-        putMsg.setComms(clis[i], ServerConnection.allocateCommBuffer(1024));
-        HandShake.getHandShake().greet(clis[i], null);
-        putMsg.send();
-      }
-
-      // Test when we are over the max
-      Socket oneOver = new Socket((String) null, port2);
-      oneOver.setSoTimeout(3000);
-      oneOver.getOutputStream().write(Acceptor.CLIENT_TO_SERVER);
-      try {
-        HandShake.getHandShake().greet(oneOver, null);
-        fail("Expecting the server to halt accepting connects");
-      } catch (SocketTimeoutException expected) {
-      } finally {
-        oneOver.close();
-      }
-
-      final String expecteExceptions = "Unexpected IOException||java.io.InterruptedIOException||java.io.IOException||java.net.SocketException||java.net.SocketException: Broken pipe";
-      this.cache.getLogger().info("<ExpectedException action=add>" + expecteExceptions + "</ExpectedException>");
-      // Test recovery of some connections using a messy close on the connection
-      // (An ordered close sends a message regarding the close)
-      for (int j=0; j<=1; j++) {
-        clis[j].close();
-
-        // Wait for an available ServerConnection thread
-        ac.testWaitForAvailableWorkerThread();
-
-        // Wait for server to begin accepting connections
-        // this test method no longer exists ac.testWaitForAcceptorThread();
-        clis[j] = new Socket((String) null, port2);
-        clis[j].setSoTimeout(2000);
-        clis[j].getOutputStream().write(Acceptor.CLIENT_TO_SERVER);
-        putMsg.setComms(clis[j], ServerConnection.allocateCommBuffer(1024));
-        HandShake.getHandShake().greet(clis[j], null);
-        putMsg.send();
-      }
-      this.cache.getLogger().info("<ExpectedException action=remove>" + expecteExceptions + "</ExpectedException>");
-    } finally {
-      if (ac!=null)
-        ac.close();
-      if (clis!=null) {
-        for(int i=0; i<clis.length; i++) {
-          if (clis[i] != null)
-            clis[i].close();
-        }
-      }
-      try{
-    	  temp.destroyRegion();
-      }catch(Exception ignore) {
-    	  
-      }
-    }
-  }*/
-  @Test
-  public void testNothing() {
-  }
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerTransactionsDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerTransactionsDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerTransactionsDUnitTest.java
index d756c0a..5514871 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerTransactionsDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerTransactionsDUnitTest.java
@@ -23,6 +23,7 @@ import java.util.ArrayList;
 import java.util.List;
 import java.util.Properties;
 
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -374,7 +375,9 @@ public class CacheServerTransactionsDUnitTest extends JUnit4DistributedTestCase
    * Currently it is UnsupportedOperationException hence the test is commented 
    *
    */
-  public void YOGESH_testClientToServerCommits(){
+  @Ignore
+  @Test
+  public void testClientToServerCommits(){
     fail("Invoking bad method");
     int port1 = 0;
 //    Integer port1 = ((Integer)server1.invoke(() -> CacheServerTransactionsDUnitTest.createServerCache()));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ConnectionProxyJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ConnectionProxyJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ConnectionProxyJUnitTest.java
index 4b7afc0..7a63d09 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ConnectionProxyJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ConnectionProxyJUnitTest.java
@@ -39,6 +39,7 @@ import com.gemstone.gemfire.test.dunit.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 import org.junit.After;
 import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
@@ -115,20 +116,18 @@ public class ConnectionProxyJUnitTest
    * configured for the client <br>
    *
    */
-  public void DISABLE_testListenerOnServerSitForever()
+  @Ignore
+  @Test
+  public void testListenerOnServerSitForever() throws Exception
   {
     int port3 = AvailablePort.getRandomAvailablePort(AvailablePort.SOCKET);
     Region testRegion = null ;
-    try {
-      CacheServer server = this.cache.addCacheServer();
-      server.setMaximumTimeBetweenPings(10000);
-      server.setPort(port3);
-      server.start();
-    }
-    catch (Exception e) {
-      e.printStackTrace();
-      fail("Failed to create server");
-    }
+
+    CacheServer server = this.cache.addCacheServer();
+    server.setMaximumTimeBetweenPings(10000);
+    server.setPort(port3);
+    server.start();
+
     try {
       PoolFactory pf = PoolManager.createFactory();
       pf.addServer("localhost", port3);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/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 b087f3b..814ba44 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
@@ -769,7 +769,7 @@ public class InstantiatorPropagationDUnitTest extends JUnit4DistributedTestCase
    */
   @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 {
+  public void testInstantiatorsEventIdVerificationClientsAndServers() throws Exception {
     PORT1 = initServerCache(server1, 1);
     PORT2 = initServerCache(server2, 2);
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfDUnitTest.java
index 20b2a52..ef9e61b 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.cache.query.cq.dunit;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -85,7 +86,9 @@ public class CqPerfDUnitTest extends JUnit4CacheTestCase {
    * Tests the cq performance.
    * @throws Exception
    */
-  public void perf_testCQPerf() throws Exception {
+  @Ignore("perf")
+  @Test
+  public void testCQPerf() throws Exception {
     
     final Host host = Host.getHost(0);
     VM server = host.getVM(0);
@@ -897,7 +900,9 @@ public class CqPerfDUnitTest extends JUnit4CacheTestCase {
    * Performance test for Matching CQ optimization changes.
    * @throws Exception
    */
-  public void perf_testPerformanceForMatchingCQs() throws Exception {
+  @Ignore("perf")
+  @Test
+  public void testPerformanceForMatchingCQs() throws Exception {
     final Host host = Host.getHost(0);
     VM server1 = host.getVM(0);
     VM server2 = host.getVM(1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfUsingPoolDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfUsingPoolDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfUsingPoolDUnitTest.java
index 413230c..dcd3915 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfUsingPoolDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfUsingPoolDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.cache.query.cq.dunit;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -84,7 +85,9 @@ public class CqPerfUsingPoolDUnitTest extends JUnit4CacheTestCase {
    * Tests the cq performance.
    * @throws Exception
    */
-  public void perf_testCQPerf() throws Exception {
+  @Ignore("perf")
+  @Test
+  public void testCQPerf() throws Exception {
     
     final Host host = Host.getHost(0);
     VM server = host.getVM(0);
@@ -854,7 +857,9 @@ public class CqPerfUsingPoolDUnitTest extends JUnit4CacheTestCase {
    * Performance test for Matching CQ optimization changes.
    * @throws Exception
    */
-  public void perf_testPerformanceForMatchingCQs() throws Exception {
+  @Ignore("perf")
+  @Test
+  public void testPerformanceForMatchingCQs() throws Exception {
     final Host host = Host.getHost(0);
     VM server1 = host.getVM(0);
     VM server2 = host.getVM(1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-cq/src/test/java/com/gemstone/gemfire/management/CacheServerManagementDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/management/CacheServerManagementDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/management/CacheServerManagementDUnitTest.java
index 0405b3c..0acaa96 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/management/CacheServerManagementDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/management/CacheServerManagementDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.management;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -193,7 +194,9 @@ public class CacheServerManagementDUnitTest extends LocatorTestBase {
    */
 
   // renable when bug 46138
-  public void DISABLEDtestBug46049() throws Exception {
+  @Ignore("Bug46049")
+  @Test
+  public void testBug46049() throws Exception {
     final Host host = Host.getHost(0);
     VM locator = host.getVM(0);
     VM server = host.getVM(1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_1_DUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_1_DUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_1_DUnitTest.java
index b54ce5a..4645488 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_1_DUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_1_DUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.wan.concurrent;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -504,7 +505,9 @@ public class ConcurrentParallelGatewaySenderOperation_1_DUnitTest extends WANTes
    * stopped state, puts are simultaneously happening on the region by another thread.
    * @throws Exception
    */
-  public void Bug47553_testParallelPropagationSenderStartAfterStop_Scenario2() throws Exception {
+  @Ignore("Bug47553")
+  @Test
+  public void testParallelPropagationSenderStartAfterStop_Scenario2() throws Exception {
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentWANPropogation_2_DUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentWANPropogation_2_DUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentWANPropogation_2_DUnitTest.java
index 81aa808..4b8d6bf 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentWANPropogation_2_DUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentWANPropogation_2_DUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.wan.concurrent;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -92,7 +93,9 @@ public class ConcurrentWANPropogation_2_DUnitTest extends WANTestBase {
         getTestMethodName() + "_RR", 15, 240000 ));
   }
 
-  public void Bug46921_testSerialReplicatedWanWithPersistence() {
+  @Ignore("Bug46921")
+  @Test
+  public void testSerialReplicatedWanWithPersistence() {
 
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/PDXNewWanDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/PDXNewWanDUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/PDXNewWanDUnitTest.java
index 5eb6933..0f76ce8 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/PDXNewWanDUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/PDXNewWanDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.wan.misc;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -708,8 +709,9 @@ public class PDXNewWanDUnitTest extends WANTestBase{
   /**
    * When remote site bounces then we should send pdx event again.
    */
-  
-  public void Bug_testWANPDX_PR_SerialSender_RemoteSite_Bounce() {
+  @Ignore
+  @Test
+  public void testWANPDX_PR_SerialSender_RemoteSite_Bounce() {
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/48f6e6ec/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPersistenceDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPersistenceDUnitTest.java b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPersistenceDUnitTest.java
index c617ff1..e2810f1 100644
--- a/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPersistenceDUnitTest.java
+++ b/geode-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPersistenceDUnitTest.java
@@ -16,6 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.wan.misc;
 
+import org.junit.Ignore;
 import org.junit.experimental.categories.Category;
 import org.junit.Test;
 
@@ -42,11 +43,6 @@ public class ReplicatedRegion_ParallelWANPersistenceDUnitTest extends WANTestBas
 
   final String expectedExceptions = null;
 
-  @Test
-  public void testNothing() {
-    
-  }
-  
   /**Below test is disabled intentionally
   1> In this release 8.0, for rolling upgrade support queue name is changed to old style
   2>Comman parallel sender for different non colocated regions is not supported in 8.0 so no need to bother about 
@@ -54,7 +50,9 @@ public class ReplicatedRegion_ParallelWANPersistenceDUnitTest extends WANTestBas
   3> We have to enabled it in next release
   4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0*/
-  public void DISABLED_test_DR_PGSPERSISTENCE_VALIDATEQUEUE_Restart_Validate_Receiver() {
+  @Ignore
+  @Test
+  public void test_DR_PGSPERSISTENCE_VALIDATEQUEUE_Restart_Validate_Receiver() {
     //create locator on local site
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     //create locator on remote site
@@ -192,7 +190,9 @@ public class ReplicatedRegion_ParallelWANPersistenceDUnitTest extends WANTestBas
   3> We have to enabled it in next release
   4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0*/
-  public void DISABLED_test_DRPERSISTENCE_PGSPERSISTENCE_VALIDATEQUEUE_Restart_Validate_Receiver() {
+  @Ignore
+  @Test
+  public void test_DRPERSISTENCE_PGSPERSISTENCE_VALIDATEQUEUE_Restart_Validate_Receiver() {
     //create locator on local site
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     //create locator on remote site
@@ -343,7 +343,9 @@ public class ReplicatedRegion_ParallelWANPersistenceDUnitTest extends WANTestBas
   3> We have to enabled it in next release
   4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0*/
-  public void DISABLED_test_DRPERSISTENCE_PRPERSISTENCE_PGSPERSISTENCE_VALIDATEQUEUE_Restart_Validate_Receiver() {
+  @Ignore
+  @Test
+  public void test_DRPERSISTENCE_PRPERSISTENCE_PGSPERSISTENCE_VALIDATEQUEUE_Restart_Validate_Receiver() {
     //create locator on local site
     Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
     //create locator on remote site
@@ -557,7 +559,9 @@ public class ReplicatedRegion_ParallelWANPersistenceDUnitTest extends WANTestBas
   3> We have to enabled it in next release
   4> Version based rolling upgrade support should be provided. based on the version of the gemfire QSTRING should be used between 8.0 
      and version prior to 8.0*/
-  public void DISABLED_test_DRPERSISTENCE_PGSPERSISTENCE_4NODES_2NODESDOWN_Validate_Receiver()
+  @Ignore
+  @Test
+  public void test_DRPERSISTENCE_PGSPERSISTENCE_4NODES_2NODESDOWN_Validate_Receiver()
       throws Exception {
 
     Integer lnPort = (Integer) vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));