You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by ip...@apache.org on 2019/06/05 11:05:50 UTC

[ignite] branch master updated: IGNITE-11708 Fix IgniteConfigVariationsAbstractTest to enable variation tests execution - Fixes #6434.

This is an automated email from the ASF dual-hosted git repository.

ipavlukhin pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/ignite.git


The following commit(s) were added to refs/heads/master by this push:
     new 18126a8  IGNITE-11708 Fix IgniteConfigVariationsAbstractTest to enable variation tests execution - Fixes #6434.
18126a8 is described below

commit 18126a896635646ae4f2ca8c282a55fc2e4d6e05
Author: Fedotov <va...@gmail.com>
AuthorDate: Wed Jun 5 14:05:00 2019 +0300

    IGNITE-11708 Fix IgniteConfigVariationsAbstractTest to enable variation tests execution - Fixes #6434.
    
    Signed-off-by: ipavlukhin <vo...@gmail.com>
---
 .../IgniteCacheConfigVariationsFullApiTest.java    | 13 ++++++
 .../IgniteCacheReadThroughEvictionSelfTest.java    |  4 ++
 .../cache/WithKeepBinaryCacheFullApiTest.java      |  3 ++
 .../IgniteServiceConfigVariationsFullApiTest.java  |  2 +
 .../ConfigVariationsTestSuiteBuilder.java          | 29 +++----------
 .../junits/IgniteConfigVariationsAbstractTest.java | 50 +++++++---------------
 .../test/ConfigVariationsExecutionTest.java        | 42 ++++++++++++++++++
 .../test/ConfigVariationsTestSuiteBuilderTest.java | 25 ++++++-----
 .../ignite/testsuites/IgniteBasicTestSuite.java    |  2 +
 .../testsuites/IgniteCacheMvccTestSuite5.java      |  2 +
 .../ignite/testsuites/IgniteCacheTestSuite5.java   |  2 +-
 .../IgniteCacheConfigVariationsQueryTest.java      |  3 ++
 12 files changed, 106 insertions(+), 71 deletions(-)

diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheConfigVariationsFullApiTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheConfigVariationsFullApiTest.java
index c0eba3a..74d9442 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheConfigVariationsFullApiTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheConfigVariationsFullApiTest.java
@@ -87,6 +87,7 @@ import org.apache.ignite.transactions.Transaction;
 import org.apache.ignite.transactions.TransactionConcurrency;
 import org.apache.ignite.transactions.TransactionIsolation;
 import org.jetbrains.annotations.Nullable;
+import org.junit.Ignore;
 import org.junit.Test;
 
 import static java.util.concurrent.TimeUnit.MILLISECONDS;
@@ -1311,6 +1312,7 @@ public class IgniteCacheConfigVariationsFullApiTest extends IgniteCacheConfigVar
     /**
      * @throws Exception If failed.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11885")
     @Test
     public void testInvokeSequentialOptimisticNoStart() throws Exception {
         runInAllDataModes(new TestRunnable() {
@@ -1323,6 +1325,7 @@ public class IgniteCacheConfigVariationsFullApiTest extends IgniteCacheConfigVar
     /**
      * @throws Exception If failed.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11885")
     @Test
     public void testInvokeSequentialPessimisticNoStart() throws Exception {
         runInAllDataModes(new TestRunnable() {
@@ -1335,6 +1338,7 @@ public class IgniteCacheConfigVariationsFullApiTest extends IgniteCacheConfigVar
     /**
      * @throws Exception If failed.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11885")
     @Test
     public void testInvokeSequentialOptimisticWithStart() throws Exception {
         runInAllDataModes(new TestRunnable() {
@@ -1347,6 +1351,7 @@ public class IgniteCacheConfigVariationsFullApiTest extends IgniteCacheConfigVar
     /**
      * @throws Exception If failed.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11885")
     @Test
     public void testInvokeSequentialPessimisticWithStart() throws Exception {
         runInAllDataModes(new TestRunnable() {
@@ -1959,6 +1964,7 @@ public class IgniteCacheConfigVariationsFullApiTest extends IgniteCacheConfigVar
     /**
      * @throws Exception In case of error.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11885")
     @Test
     public void testNullInTx() throws Exception {
         if (!txShouldBeUsed())
@@ -3694,6 +3700,7 @@ public class IgniteCacheConfigVariationsFullApiTest extends IgniteCacheConfigVar
     /**
      * @throws Exception In case of error.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11885")
     @Test
     public void testLoadAll() throws Exception {
         if (!storeEnabled())
@@ -3782,6 +3789,7 @@ public class IgniteCacheConfigVariationsFullApiTest extends IgniteCacheConfigVar
     /**
      * @throws Exception In case of error.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11885")
     @Test
     public void testClear() throws Exception {
         IgniteCache<String, Integer> cache = jcache();
@@ -4228,6 +4236,7 @@ public class IgniteCacheConfigVariationsFullApiTest extends IgniteCacheConfigVar
      *
      * @throws Exception If failed.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11885")
     @Test
     public void testPeekExpired() throws Exception {
         final IgniteCache<String, Integer> c = jcache();
@@ -4574,6 +4583,7 @@ public class IgniteCacheConfigVariationsFullApiTest extends IgniteCacheConfigVar
     /**
      * @throws Exception In case of error.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11885")
     @Test
     public void testLocalEvict() throws Exception {
         IgniteCache<String, Integer> cache = jcache();
@@ -5997,6 +6007,7 @@ public class IgniteCacheConfigVariationsFullApiTest extends IgniteCacheConfigVar
     /**
      * @throws Exception If failed.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11850")
     @Test
     public void testGetOutTx() throws Exception {
         checkGetOutTx(false, false);
@@ -6005,6 +6016,7 @@ public class IgniteCacheConfigVariationsFullApiTest extends IgniteCacheConfigVar
     /**
      * @throws Exception If failed.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11850")
     @Test
     public void testGetOutTxAsyncOld() throws Exception {
         checkGetOutTx(true, true);
@@ -6013,6 +6025,7 @@ public class IgniteCacheConfigVariationsFullApiTest extends IgniteCacheConfigVar
     /**
      * @throws Exception If failed.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11850")
     @Test
     public void testGetOutTxAsync() throws Exception {
         checkGetOutTx(true, false);
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheReadThroughEvictionSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheReadThroughEvictionSelfTest.java
index a349e7e..3c39ac0 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheReadThroughEvictionSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheReadThroughEvictionSelfTest.java
@@ -36,6 +36,7 @@ import org.apache.ignite.internal.util.typedef.internal.U;
 import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.MvccFeatureChecker;
 import org.apache.ignite.testframework.junits.IgniteCacheConfigVariationsAbstractTest;
+import org.junit.Ignore;
 import org.junit.Test;
 
 /**
@@ -64,6 +65,7 @@ public class IgniteCacheReadThroughEvictionSelfTest extends IgniteCacheConfigVar
     /**
      * @throws Exception if failed.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11849")
     @Test
     public void testReadThroughWithExpirePolicy() throws Exception {
         MvccFeatureChecker.skipIfNotSupported(MvccFeatureChecker.Feature.EXPIRATION);
@@ -107,6 +109,7 @@ public class IgniteCacheReadThroughEvictionSelfTest extends IgniteCacheConfigVar
     /**
      * @throws Exception if failed.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11849")
     @Test
     public void testReadThroughExpirePolicyConfigured() throws Exception {
         MvccFeatureChecker.skipIfNotSupported(MvccFeatureChecker.Feature.EXPIRATION);
@@ -202,6 +205,7 @@ public class IgniteCacheReadThroughEvictionSelfTest extends IgniteCacheConfigVar
     /**
      * @throws Exception if failed.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11849")
     @Test
     public void testReadThroughSkipStore() throws Exception {
         Ignite ig = testedGrid();
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/WithKeepBinaryCacheFullApiTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/WithKeepBinaryCacheFullApiTest.java
index 9e3606e..275c343 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/WithKeepBinaryCacheFullApiTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/WithKeepBinaryCacheFullApiTest.java
@@ -36,6 +36,7 @@ import org.apache.ignite.testframework.junits.IgniteCacheConfigVariationsAbstrac
 import org.apache.ignite.transactions.Transaction;
 import org.apache.ignite.transactions.TransactionConcurrency;
 import org.apache.ignite.transactions.TransactionIsolation;
+import org.junit.Ignore;
 import org.junit.Test;
 
 import static org.apache.ignite.cache.CacheAtomicityMode.TRANSACTIONAL;
@@ -751,6 +752,7 @@ public class WithKeepBinaryCacheFullApiTest extends IgniteCacheConfigVariationsA
      * @throws Exception If failed.
      */
     @SuppressWarnings("serial")
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11884")
     @Test
     public void testInvokeAll() throws Exception {
         runInAllDataModes(new TestRunnable() {
@@ -935,6 +937,7 @@ public class WithKeepBinaryCacheFullApiTest extends IgniteCacheConfigVariationsA
      * @throws Exception If failed.
      */
     @SuppressWarnings("serial")
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11884")
     @Test
     public void testInvokeAllAsync() throws Exception {
         runInAllDataModes(new TestRunnable() {
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/service/IgniteServiceConfigVariationsFullApiTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/service/IgniteServiceConfigVariationsFullApiTest.java
index 311fc82..3b6ae6f 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/service/IgniteServiceConfigVariationsFullApiTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/service/IgniteServiceConfigVariationsFullApiTest.java
@@ -35,6 +35,7 @@ import org.apache.ignite.services.ServiceContext;
 import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.configvariations.Parameters;
 import org.apache.ignite.testframework.junits.IgniteConfigVariationsAbstractTest;
+import org.junit.Ignore;
 import org.junit.Test;
 
 /**
@@ -121,6 +122,7 @@ public class IgniteServiceConfigVariationsFullApiTest extends IgniteConfigVariat
      *
      * @throws Exception If failed.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11883")
     @Test
     public void testKeyAffinityDeploy() throws Exception {
         runInAllDataModes(new ServiceTestRunnable(false, new DeployClosure() {
diff --git a/modules/core/src/test/java/org/apache/ignite/testframework/configvariations/ConfigVariationsTestSuiteBuilder.java b/modules/core/src/test/java/org/apache/ignite/testframework/configvariations/ConfigVariationsTestSuiteBuilder.java
index a8b3b44..a8cb941 100644
--- a/modules/core/src/test/java/org/apache/ignite/testframework/configvariations/ConfigVariationsTestSuiteBuilder.java
+++ b/modules/core/src/test/java/org/apache/ignite/testframework/configvariations/ConfigVariationsTestSuiteBuilder.java
@@ -28,12 +28,7 @@ import java.util.stream.Collectors;
 import javassist.ClassClassPath;
 import javassist.ClassPool;
 import javassist.CtClass;
-import javassist.CtMethod;
-import javassist.CtNewMethod;
-import javassist.bytecode.AnnotationsAttribute;
-import javassist.bytecode.ClassFile;
-import javassist.bytecode.ConstPool;
-import javassist.bytecode.annotation.Annotation;
+import javassist.CtNewConstructor;
 import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.testframework.junits.IgniteCacheConfigVariationsAbstractTest;
@@ -431,22 +426,12 @@ public class ConfigVariationsTestSuiteBuilder {
         try {
             cl.setSuperclass(cp.get(cls.getName()));
 
-            CtMethod mtd = CtNewMethod.make("public static void init() { "
-                + "injectTestsConfiguration("
-                + ConfigVariationsTestSuiteBuilder.class.getName()
-                + ".getCfg(\"" + clsName + "\")); }", cl);
-
-            // Create and add annotation.
-            ClassFile ccFile = cl.getClassFile();
-            ConstPool constpool = ccFile.getConstPool();
-
-            AnnotationsAttribute attr = new AnnotationsAttribute(constpool, AnnotationsAttribute.visibleTag);
-            Annotation annot = new Annotation("org.junit.BeforeClass", constpool);
-
-            attr.addAnnotation(annot);
-            mtd.getMethodInfo().addAttribute(attr);
-
-            cl.addMethod(mtd);
+            cl.addConstructor(CtNewConstructor.make("public " + clsName + "() { "
+                    + "this.testsCfg = "
+                    + ConfigVariationsTestSuiteBuilder.class.getName()
+                    + ".getCfg(\"" + clsName + "\"); "
+                    + "}"
+                , cl));
 
             return cl.toClass();
         }
diff --git a/modules/core/src/test/java/org/apache/ignite/testframework/junits/IgniteConfigVariationsAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/testframework/junits/IgniteConfigVariationsAbstractTest.java
index 6ab78fb..d21fddc 100644
--- a/modules/core/src/test/java/org/apache/ignite/testframework/junits/IgniteConfigVariationsAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/testframework/junits/IgniteConfigVariationsAbstractTest.java
@@ -38,30 +38,15 @@ import org.apache.ignite.internal.util.typedef.internal.U;
 import org.apache.ignite.marshaller.jdk.JdkMarshaller;
 import org.apache.ignite.testframework.configvariations.ConfigVariations;
 import org.apache.ignite.testframework.configvariations.ConfigVariationsFactory;
+import org.apache.ignite.testframework.configvariations.ConfigVariationsTestSuiteBuilder;
 import org.apache.ignite.testframework.configvariations.VariationsTestsConfig;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
-import org.junit.Rule;
-import org.junit.rules.RuleChain;
-import org.junit.rules.TestRule;
-import org.junit.runners.model.Statement;
+import org.junit.Before;
 
 /**
  * Common abstract test for Ignite tests based on configurations variations.
  */
 public abstract class IgniteConfigVariationsAbstractTest extends GridCommonAbstractTest {
-    /** Manages test execution and reporting. */
-    private final TestRule rulePrivate = (base, description) -> new Statement() {
-        @Override public void evaluate() {
-            assert getName() != null : "getName returned null";
-
-            testsCfg = testsCfgInjected;
-        }
-    };
-
-    /** Manages first and last test execution. */
-    @Rule public RuleChain runRule
-        = RuleChain.outerRule(rulePrivate).around(super.nameAndRunRulesChain);
-
     /** */
     protected static final int SERVER_NODE_IDX = 0;
 
@@ -74,15 +59,16 @@ public abstract class IgniteConfigVariationsAbstractTest extends GridCommonAbstr
     /** */
     private static final File workDir = new File(U.getIgniteHome() + File.separator + "workOfConfigVariationsTests");
 
-    /** Dummy initial stub to just let people launch test classes not from suite. */
+    /**
+     * Dummy initial stub to just let people launch test classes not from suite.
+     * Real configurations are assigned dynamically through reflection in
+     * {@link ConfigVariationsTestSuiteBuilder#makeTestClass(String, VariationsTestsConfig)} method.
+     */
     protected VariationsTestsConfig testsCfg = dummyCfg();
 
     /** */
     protected volatile DataMode dataMode = DataMode.PLANE_OBJECT;
 
-    /** See {@link IgniteConfigVariationsAbstractTest#injectTestsConfiguration} */
-    private static VariationsTestsConfig testsCfgInjected = dummyCfg();
-
     /** {@inheritDoc} */
     @Override public String getTestIgniteInstanceName(int idx) {
         return getTestIgniteInstanceName() + idx;
@@ -93,21 +79,17 @@ public abstract class IgniteConfigVariationsAbstractTest extends GridCommonAbstr
         return "testGrid";
     }
 
-    /**
-     * Invoked by reflection from {@code ConfigVariationsTestSuiteBuilder}.
-     *
-     * @param testsCfgInjected Tests configuration.
-     */
-    @SuppressWarnings("unused")
-    protected static void injectTestsConfiguration(VariationsTestsConfig testsCfgInjected) {
-        IgniteConfigVariationsAbstractTest.testsCfgInjected = testsCfgInjected;
-    }
-
     /** {@inheritDoc} */
     @Override protected boolean isSafeTopology() {
         return false;
     }
 
+    /** Check that test name is not null. */
+    @Before
+    public void checkTestName() {
+        assert getName() != null : "getName returned null";
+    }
+
     /** {@inheritDoc} */
     @Override protected void beforeTestsStarted() throws Exception {
         assert testsCfg != null;
@@ -174,9 +156,7 @@ public abstract class IgniteConfigVariationsAbstractTest extends GridCommonAbstr
     protected void unconditionalCleanupAfterTests() {
         testedNodeIdx = 0;
 
-        testsCfgInjected = testsCfg = dummyCfg();
-
-        stopAllGrids();
+        testsCfg = dummyCfg();
     }
 
     /**
@@ -394,7 +374,7 @@ public abstract class IgniteConfigVariationsAbstractTest extends GridCommonAbstr
     }
 
     /** */
-    private static VariationsTestsConfig dummyCfg() {
+    private VariationsTestsConfig dummyCfg() {
         return new VariationsTestsConfig(
             new ConfigVariationsFactory(null, new int[] {0}, ConfigVariations.cacheBasicSet(), new int[] {0}),
             "Dummy config", false, null, 1, false);
diff --git a/modules/core/src/test/java/org/apache/ignite/testframework/test/ConfigVariationsExecutionTest.java b/modules/core/src/test/java/org/apache/ignite/testframework/test/ConfigVariationsExecutionTest.java
new file mode 100644
index 0000000..14cb206
--- /dev/null
+++ b/modules/core/src/test/java/org/apache/ignite/testframework/test/ConfigVariationsExecutionTest.java
@@ -0,0 +1,42 @@
+/*
+ * 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 org.apache.ignite.testframework.test;
+
+import org.apache.ignite.testframework.junits.IgniteConfigVariationsAbstractTest;
+import org.junit.AfterClass;
+import org.junit.Test;
+
+/**
+ * Test for {@link IgniteConfigVariationsAbstractTest} subclasses execution.
+ */
+public class ConfigVariationsExecutionTest extends IgniteConfigVariationsAbstractTest {
+    /** Boolean for checking test execution */
+    private static boolean testExecuted;
+
+    /** Executes after test class. Checks that {@link #testCheck()} method was executed indeed. */
+    @AfterClass
+    public static void validatetestExecution() {
+        assertTrue(testExecuted);
+    }
+
+    /** JUnit test method. */
+    @Test
+    public void testCheck() {
+        testExecuted = true;
+    }
+}
diff --git a/modules/core/src/test/java/org/apache/ignite/testframework/test/ConfigVariationsTestSuiteBuilderTest.java b/modules/core/src/test/java/org/apache/ignite/testframework/test/ConfigVariationsTestSuiteBuilderTest.java
index 0178315..4525b60 100644
--- a/modules/core/src/test/java/org/apache/ignite/testframework/test/ConfigVariationsTestSuiteBuilderTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/testframework/test/ConfigVariationsTestSuiteBuilderTest.java
@@ -394,16 +394,6 @@ public class ConfigVariationsTestSuiteBuilderTest {
         /** IMPL NOTE new instances may be created rather arbitrarily, eg per every test case. */
         private final int testClsId = testInstCnt.getAndIncrement();
 
-        /**
-         * IMPL NOTE default config doesn't stop nodes.
-         */
-        @BeforeClass
-        public static void init() {
-            IgniteConfigVariationsAbstractTest.injectTestsConfiguration(new VariationsTestsConfig(
-                new ConfigVariationsFactory(null, new int[] {0}, ConfigVariations.cacheBasicSet(),
-                    new int[] {0}), "Dummy config", true, null, 1, false));
-        }
-
         /** {@inheritDoc} */
         @Override protected IgniteConfiguration getConfiguration(String igniteInstanceName) throws Exception {
             IgniteConfiguration cfg = super.getConfiguration(igniteInstanceName);
@@ -415,20 +405,30 @@ public class ConfigVariationsTestSuiteBuilderTest {
 
         /** {@inheritDoc} */
         @Override protected void beforeTestsStarted() throws Exception {
-            processStage("beforeTestsStarted", 0,  1);
+            // IMPL NOTE default config doesn't stop nodes.
+            testsCfg = new VariationsTestsConfig(
+                new ConfigVariationsFactory(null, new int[] {0}, ConfigVariations.cacheBasicSet(),
+                    new int[] {0}), "Dummy config", true, null, 1,
+                false);
+
+            processStage("beforeTestsStarted", 0, 1);
 
             super.beforeTestsStarted();
         }
 
         /** {@inheritDoc} */
         @Override protected void beforeTest() throws Exception {
+            testsCfg = new VariationsTestsConfig(
+                new ConfigVariationsFactory(null, new int[] {0}, ConfigVariations.cacheBasicSet(),
+                    new int[] {0}), "Dummy config", true, null, 1,
+                false);
+
             processStage("beforeTest", 1, 2);
 
             super.beforeTest();
         }
 
         /** */
-        @Ignore("https://issues.apache.org/jira/browse/IGNITE-11708")
         @Test
         public void test1() {
             processStage("test1", 2, 3);
@@ -436,7 +436,6 @@ public class ConfigVariationsTestSuiteBuilderTest {
         }
 
         /** */
-        @Ignore("https://issues.apache.org/jira/browse/IGNITE-11708")
         @Test
         public void test2() {
             processStage("test2", 2, 3);
diff --git a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBasicTestSuite.java b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBasicTestSuite.java
index 1bbca8a..c9ee1f3 100644
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBasicTestSuite.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBasicTestSuite.java
@@ -95,6 +95,7 @@ import org.apache.ignite.plugin.PluginNodeValidationTest;
 import org.apache.ignite.plugin.security.SecurityPermissionSetBuilderTest;
 import org.apache.ignite.spi.GridSpiLocalHostInjectionTest;
 import org.apache.ignite.startup.properties.NotStringSystemPropertyTest;
+import org.apache.ignite.testframework.test.ConfigVariationsExecutionTest;
 import org.apache.ignite.testframework.test.ConfigVariationsTestSuiteBuilderTest;
 import org.apache.ignite.testframework.test.ListeningTestLoggerTest;
 import org.apache.ignite.testframework.test.ParametersTest;
@@ -230,6 +231,7 @@ import org.junit.runners.Suite;
         ParametersTest.class,
         VariationsIteratorTest.class,
         NotStringSystemPropertyTest.class,
+        ConfigVariationsExecutionTest.class,
         ConfigVariationsTestSuiteBuilderTest.class,
 
     DeadLockOnNodeLeftExchangeTest.class,
diff --git a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMvccTestSuite5.java b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMvccTestSuite5.java
index ec4f981..5a6b244 100644
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMvccTestSuite5.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMvccTestSuite5.java
@@ -34,6 +34,7 @@ import org.apache.ignite.internal.processors.cache.ClusterStateReplicatedSelfTes
 import org.apache.ignite.internal.processors.cache.ConcurrentCacheStartTest;
 import org.apache.ignite.internal.processors.cache.EntryVersionConsistencyReadThroughTest;
 import org.apache.ignite.internal.processors.cache.IgniteCachePutStackOverflowSelfTest;
+import org.apache.ignite.internal.processors.cache.IgniteCacheReadThroughEvictionsVariationsSuite;
 import org.apache.ignite.internal.processors.cache.IgniteCacheStoreCollectionTest;
 import org.apache.ignite.internal.processors.cache.PartitionsExchangeOnDiscoveryHistoryOverflowTest;
 import org.apache.ignite.internal.processors.cache.distributed.CacheLateAffinityAssignmentNodeJoinValidationTest;
@@ -87,6 +88,7 @@ public class IgniteCacheMvccTestSuite5 {
         ignoredTests.add(PartitionsExchangeOnDiscoveryHistoryOverflowTest.class);
         ignoredTests.add(GridCachePartitionExchangeManagerHistSizeTest.class);
         ignoredTests.add(ConcurrentCacheStartTest.class);
+        ignoredTests.add(IgniteCacheReadThroughEvictionsVariationsSuite.class);
 
         return IgniteCacheTestSuite5.suite(ignoredTests);
     }
diff --git a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheTestSuite5.java b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheTestSuite5.java
index e58b38d..56d0b84 100644
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheTestSuite5.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheTestSuite5.java
@@ -118,7 +118,7 @@ public class IgniteCacheTestSuite5 {
 
         GridTestUtils.addTestIfNeeded(suite, ConcurrentCacheStartTest.class, ignoredTests);
 
-        suite.add(IgniteCacheReadThroughEvictionsVariationsSuite.class);
+        GridTestUtils.addTestIfNeeded(suite, IgniteCacheReadThroughEvictionsVariationsSuite.class, ignoredTests);
 
         //GridTestUtils.addTestIfNeeded(suite, GridCacheAtomicPreloadSelfTest.class, ignoredTests);
         //GridTestUtils.addTestIfNeeded(suite, IgniteCacheContainsKeyColocatedAtomicSelfTest.class, ignoredTests);
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheConfigVariationsQueryTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheConfigVariationsQueryTest.java
index 052555e..474a597 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheConfigVariationsQueryTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheConfigVariationsQueryTest.java
@@ -38,6 +38,7 @@ import org.apache.ignite.events.Event;
 import org.apache.ignite.lang.IgniteBiPredicate;
 import org.apache.ignite.lang.IgnitePredicate;
 import org.apache.ignite.testframework.junits.IgniteCacheConfigVariationsAbstractTest;
+import org.junit.Ignore;
 import org.junit.Test;
 
 import static java.util.concurrent.TimeUnit.MILLISECONDS;
@@ -211,6 +212,7 @@ public class IgniteCacheConfigVariationsQueryTest extends IgniteCacheConfigVaria
     /**
      * @throws Exception If failed.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11886")
     @Test
     public void testLocalScanQuery() throws Exception {
         runInAllDataModes(new TestRunnable() {
@@ -249,6 +251,7 @@ public class IgniteCacheConfigVariationsQueryTest extends IgniteCacheConfigVaria
     /**
      * @throws Exception If failed.
      */
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11886")
     @Test
     public void testScanQueryLocalFilter() throws Exception {
         runInAllDataModes(new TestRunnable() {