You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by na...@apache.org on 2022/12/02 08:51:32 UTC

[ignite-extensions] branch master updated: IGNITE-18251 Remove test suites from ignite-extensions. (#194)

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

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


The following commit(s) were added to refs/heads/master by this push:
     new 0ea0c88f IGNITE-18251 Remove test suites from ignite-extensions. (#194)
0ea0c88f is described below

commit 0ea0c88f6daf96225fec01a78af40078a88b329b
Author: Ilya Shishkov <sh...@gmail.com>
AuthorDate: Fri Dec 2 11:51:28 2022 +0300

    IGNITE-18251 Remove test suites from ignite-extensions. (#194)
---
 .../ignite/testsuites/IgniteAopSelfTestSuite.java  |  62 ------------
 .../checkpoint/s3/S3CheckpointManagerSelfTest.java |   6 +-
 .../spi/checkpoint/s3/S3CheckpointSpiSelfTest.java |  14 +--
 ...eckpointSpiStartStopBucketEndpointSelfTest.java |   6 +-
 ...CheckpointSpiStartStopSSEAlgorithmSelfTest.java |   6 +-
 .../s3/S3CheckpointSpiStartStopSelfTest.java       |   6 +-
 .../checkpoint/s3/S3SessionCheckpointSelfTest.java |   6 +-
 .../s3/TcpDiscoveryS3IpFinderAbstractSelfTest.java |   6 +-
 ...ryS3IpFinderAwsCredentialsProviderSelfTest.java |   4 +-
 ...pDiscoveryS3IpFinderAwsCredentialsSelfTest.java |   6 +-
 ...pDiscoveryS3IpFinderBucketEndpointSelfTest.java |   6 +-
 ...TcpDiscoveryS3IpFinderSSEAlgorithmSelfTest.java |   6 +-
 .../ignite/testsuites/IgniteElbTestSuite.java      |  32 ------
 .../ignite/testsuites/IgniteS3TestSuite.java       | 109 ---------------------
 .../ignite/util/IgniteS3TestConfiguration.java     |  61 ++++++++++++
 ...TcpDiscoveryAzureBlobStoreIpFinderSelfTest.java |  14 +--
 .../IgniteAzureTestConfiguration.java}             |  11 +--
 .../stream/camel/IgniteCamelStreamerTestSuite.java |  29 ------
 .../org/apache/ignite/cdc/IgniteCdcTestSuite.java  |  40 --------
 .../cloud/TcpDiscoveryCloudIpFinderSelfTest.java   |  12 +--
 .../IgniteCloudTestConfiguration.java}             |  11 +--
 .../sink/flink/FlinkIgniteSinkSelfTestSuite.java   |  29 ------
 .../flink/FlinkIgniteSourceSelfTestSuite.java      |  30 ------
 .../ignite/stream/flume/IgniteSinkTestSuite.java   |  29 ------
 .../TcpDiscoveryGoogleStorageIpFinderSelfTest.java |   8 +-
 .../IgniteGCETestConfiguration.java}               |  11 +--
 .../examples/SpatialQueryExampleSelfTest.java      |  13 +++
 .../IgniteGeospatialLgplExamplesSelfTestSuite.java |  46 ---------
 .../testsuites/GeoSpatialIndexingTestSuite.java    |  36 -------
 .../examples/HibernateL2CacheExampleSelfTest.java  |  11 +++
 .../IgniteLgplExamplesSelfTestSuite.java           |  45 ---------
 .../testsuites/IgniteHibernate5TestSuite.java      |  50 ----------
 .../stream/jms11/IgniteJmsStreamerTestSuite.java   |  34 -------
 modules/kafka-ext/pom.xml                          |   4 +
 .../kafka/IgniteKafkaStreamerSelfTestSuite.java    |  38 -------
 .../org/apache/ignite/IgniteMesosTestSuite.java    |  32 ------
 .../stream/mqtt/IgniteMqttStreamerTestSuite.java   |  32 ------
 .../apache/ignite/osgi/IgniteOsgiTestSuite.java    |  32 ------
 ...IgnitePerformanceStatisticsReportTestSuite.java |  32 ------
 .../stream/pubsub/PubSubStreamerTestSuite.java     |  29 ------
 .../stream/rocketmq/RocketMQStreamerTestSuite.java |  31 ------
 .../spark/examples/IgniteDataFrameSelfTest.java    |  11 +++
 .../examples/JavaIgniteDataFrameSelfTest.java      |  11 +++
 .../spark/examples/SharedRDDExampleSelfTest.java   |  11 +++
 .../IgniteExamplesSparkSelfTestSuite.java          |  48 ---------
 .../ignite/testsuites/IgniteRDDTestSuite.java      |  36 -------
 .../apache/ignite/spark/IgniteDataFrameSuite.scala |  46 ---------
 .../testsuites/IgniteSpringCacheTestSuite.java     |  44 ---------
 .../IgniteSpringDataExamplesTestSuite.java         |  29 ------
 .../testsuites/IgniteSpringDataTestSuite.java      |  48 ---------
 .../testsuites/IgniteSpringSessionTestSuite.java   |  36 -------
 .../IgniteSpringTransactionsTestSuite.java         |  42 --------
 .../storm/IgniteStormStreamerSelfTestSuite.java    |  31 ------
 .../IgniteCacheTopologyValidatorTestSuite.java     |  27 -----
 .../twitter/IgniteTwitterStreamerTestSuite.java    |  31 ------
 .../org/apache/ignite/IgniteYarnTestSuite.java     |  32 ------
 .../zeromq/IgniteZeroMqStreamerTestSuite.java      |  31 ------
 .../zookeeper-ip-finder/examples/pom.xml           |  50 ----------
 .../src/main/java/ZookeeperIpFinderExample.java    |  74 --------------
 .../zookeeper-ip-finder/pom.xml                    |   6 ++
 .../ipfinder/zk/ZookeeperIpFinderTestSuite.java    |  32 ------
 61 files changed, 190 insertions(+), 1511 deletions(-)

diff --git a/modules/aop-ext/src/test/java/org/apache/ignite/testsuites/IgniteAopSelfTestSuite.java b/modules/aop-ext/src/test/java/org/apache/ignite/testsuites/IgniteAopSelfTestSuite.java
deleted file mode 100644
index abf98791..00000000
--- a/modules/aop-ext/src/test/java/org/apache/ignite/testsuites/IgniteAopSelfTestSuite.java
+++ /dev/null
@@ -1,62 +0,0 @@
-/*
- * 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.testsuites;
-
-import org.apache.ignite.gridify.BasicAopSelfTest;
-import org.apache.ignite.gridify.GridifySetToXXXNonSpringAopSelfTest;
-import org.apache.ignite.gridify.GridifySetToXXXSpringAopSelfTest;
-import org.apache.ignite.gridify.NonSpringAopSelfTest;
-import org.apache.ignite.gridify.SpringAopSelfTest;
-import org.apache.ignite.gridify.hierarchy.GridifyHierarchyTest;
-import org.apache.ignite.internal.marshaller.optimized.OptimizedMarshallerAopTest;
-import org.apache.ignite.testframework.GridTestUtils;
-import org.apache.ignite.tools.junit.JUnitTeamcityReporter;
-import org.junit.BeforeClass;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-import org.test.gridify.ExternalNonSpringAopSelfTest;
-
-import static org.apache.ignite.IgniteSystemProperties.IGNITE_OVERRIDE_MCAST_GRP;
-
-/**
- * AOP test suite.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    // Test configuration.
-    BasicAopSelfTest.class,
-
-    SpringAopSelfTest.class,
-    NonSpringAopSelfTest.class,
-    GridifySetToXXXSpringAopSelfTest.class,
-    GridifySetToXXXNonSpringAopSelfTest.class,
-    ExternalNonSpringAopSelfTest.class,
-
-    OptimizedMarshallerAopTest.class,
-    GridifyHierarchyTest.class
-})
-public class IgniteAopSelfTestSuite {
-    /** */
-    @BeforeClass
-    public static void init() {
-        JUnitTeamcityReporter.suite = IgniteAopSelfTestSuite.class.getName();
-
-        // Examples
-        System.setProperty(IGNITE_OVERRIDE_MCAST_GRP, GridTestUtils.getNextMulticastGroup(IgniteAopSelfTestSuite.class));
-    }
-}
diff --git a/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointManagerSelfTest.java b/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointManagerSelfTest.java
index 02a62cca..a815ded4 100644
--- a/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointManagerSelfTest.java
+++ b/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointManagerSelfTest.java
@@ -21,7 +21,7 @@ import com.amazonaws.auth.AWSCredentials;
 import com.amazonaws.auth.BasicAWSCredentials;
 import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.internal.managers.checkpoint.GridCheckpointManagerAbstractSelfTest;
-import org.apache.ignite.testsuites.IgniteS3TestSuite;
+import org.apache.ignite.util.IgniteS3TestConfiguration;
 import org.junit.Ignore;
 import org.junit.Test;
 
@@ -37,8 +37,8 @@ public class S3CheckpointManagerSelfTest extends GridCheckpointManagerAbstractSe
 
         S3CheckpointSpi spi = new S3CheckpointSpi();
 
-        AWSCredentials cred = new BasicAWSCredentials(IgniteS3TestSuite.getAccessKey(),
-            IgniteS3TestSuite.getSecretKey());
+        AWSCredentials cred = new BasicAWSCredentials(IgniteS3TestConfiguration.getAccessKey(),
+            IgniteS3TestConfiguration.getSecretKey());
 
         spi.setAwsCredentials(cred);
 
diff --git a/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiSelfTest.java b/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiSelfTest.java
index 9b51da26..ef6d3048 100644
--- a/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiSelfTest.java
+++ b/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiSelfTest.java
@@ -37,7 +37,7 @@ import org.apache.ignite.spi.checkpoint.GridCheckpointTestState;
 import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.junits.spi.GridSpiAbstractTest;
 import org.apache.ignite.testframework.junits.spi.GridSpiTest;
-import org.apache.ignite.testsuites.IgniteS3TestSuite;
+import org.apache.ignite.util.IgniteS3TestConfiguration;
 import org.junit.Ignore;
 import org.junit.Test;
 
@@ -55,8 +55,8 @@ public class S3CheckpointSpiSelfTest extends GridSpiAbstractTest<S3CheckpointSpi
 
     /** {@inheritDoc} */
     @Override protected void spiConfigure(S3CheckpointSpi spi) throws Exception {
-        AWSCredentials cred = new BasicAWSCredentials(IgniteS3TestSuite.getAccessKey(),
-            IgniteS3TestSuite.getSecretKey());
+        AWSCredentials cred = new BasicAWSCredentials(IgniteS3TestConfiguration.getAccessKey(),
+            IgniteS3TestConfiguration.getSecretKey());
 
         spi.setAwsCredentials(cred);
 
@@ -69,8 +69,8 @@ public class S3CheckpointSpiSelfTest extends GridSpiAbstractTest<S3CheckpointSpi
      * @throws Exception If error.
      */
     @Override protected void afterSpiStopped() throws Exception {
-        AWSCredentials cred = new BasicAWSCredentials(IgniteS3TestSuite.getAccessKey(),
-            IgniteS3TestSuite.getSecretKey());
+        AWSCredentials cred = new BasicAWSCredentials(IgniteS3TestConfiguration.getAccessKey(),
+            IgniteS3TestConfiguration.getSecretKey());
 
         AmazonS3 s3 = new AmazonS3Client(cred);
 
@@ -241,11 +241,11 @@ public class S3CheckpointSpiSelfTest extends GridSpiAbstractTest<S3CheckpointSpi
     static String getBucketNameSuffix() {
         String bucketNameSuffix;
         try {
-            bucketNameSuffix = IgniteS3TestSuite.getBucketName(
+            bucketNameSuffix = IgniteS3TestConfiguration.getBucketName(
                 "unit-test-" + InetAddress.getLocalHost().getHostName().toLowerCase());
         }
         catch (UnknownHostException e) {
-            bucketNameSuffix = IgniteS3TestSuite.getBucketName(
+            bucketNameSuffix = IgniteS3TestConfiguration.getBucketName(
                 "unit-test-rnd-" + ThreadLocalRandom.current().nextInt(100));
         }
 
diff --git a/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopBucketEndpointSelfTest.java b/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopBucketEndpointSelfTest.java
index 2e1bd9b2..ce7ba1e8 100644
--- a/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopBucketEndpointSelfTest.java
+++ b/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopBucketEndpointSelfTest.java
@@ -21,7 +21,7 @@ import com.amazonaws.auth.AWSCredentials;
 import com.amazonaws.auth.BasicAWSCredentials;
 import org.apache.ignite.spi.GridSpiStartStopAbstractTest;
 import org.apache.ignite.testframework.junits.spi.GridSpiTest;
-import org.apache.ignite.testsuites.IgniteS3TestSuite;
+import org.apache.ignite.util.IgniteS3TestConfiguration;
 import org.junit.Ignore;
 import org.junit.Test;
 
@@ -32,8 +32,8 @@ import org.junit.Test;
 public class S3CheckpointSpiStartStopBucketEndpointSelfTest extends GridSpiStartStopAbstractTest<S3CheckpointSpi> {
     /** {@inheritDoc} */
     @Override protected void spiConfigure(S3CheckpointSpi spi) throws Exception {
-        AWSCredentials cred = new BasicAWSCredentials(IgniteS3TestSuite.getAccessKey(),
-            IgniteS3TestSuite.getSecretKey());
+        AWSCredentials cred = new BasicAWSCredentials(IgniteS3TestConfiguration.getAccessKey(),
+            IgniteS3TestConfiguration.getSecretKey());
 
         spi.setAwsCredentials(cred);
         spi.setBucketNameSuffix(S3CheckpointSpiSelfTest.getBucketNameSuffix() + "-e");
diff --git a/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopSSEAlgorithmSelfTest.java b/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopSSEAlgorithmSelfTest.java
index 916c79b4..00ce1533 100644
--- a/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopSSEAlgorithmSelfTest.java
+++ b/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopSSEAlgorithmSelfTest.java
@@ -21,7 +21,7 @@ import com.amazonaws.auth.AWSCredentials;
 import com.amazonaws.auth.BasicAWSCredentials;
 import org.apache.ignite.spi.GridSpiStartStopAbstractTest;
 import org.apache.ignite.testframework.junits.spi.GridSpiTest;
-import org.apache.ignite.testsuites.IgniteS3TestSuite;
+import org.apache.ignite.util.IgniteS3TestConfiguration;
 import org.junit.Ignore;
 import org.junit.Test;
 
@@ -32,8 +32,8 @@ import org.junit.Test;
 public class S3CheckpointSpiStartStopSSEAlgorithmSelfTest extends GridSpiStartStopAbstractTest<S3CheckpointSpi> {
     /** {@inheritDoc} */
     @Override protected void spiConfigure(S3CheckpointSpi spi) throws Exception {
-        AWSCredentials cred = new BasicAWSCredentials(IgniteS3TestSuite.getAccessKey(),
-            IgniteS3TestSuite.getSecretKey());
+        AWSCredentials cred = new BasicAWSCredentials(IgniteS3TestConfiguration.getAccessKey(),
+            IgniteS3TestConfiguration.getSecretKey());
 
         spi.setAwsCredentials(cred);
         spi.setBucketNameSuffix(S3CheckpointSpiSelfTest.getBucketNameSuffix());
diff --git a/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopSelfTest.java b/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopSelfTest.java
index eadefaf9..7a8cb5ea 100644
--- a/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopSelfTest.java
+++ b/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopSelfTest.java
@@ -21,7 +21,7 @@ import com.amazonaws.auth.AWSCredentials;
 import com.amazonaws.auth.BasicAWSCredentials;
 import org.apache.ignite.spi.GridSpiStartStopAbstractTest;
 import org.apache.ignite.testframework.junits.spi.GridSpiTest;
-import org.apache.ignite.testsuites.IgniteS3TestSuite;
+import org.apache.ignite.util.IgniteS3TestConfiguration;
 import org.junit.Ignore;
 import org.junit.Test;
 
@@ -32,8 +32,8 @@ import org.junit.Test;
 public class S3CheckpointSpiStartStopSelfTest extends GridSpiStartStopAbstractTest<S3CheckpointSpi> {
     /** {@inheritDoc} */
     @Override protected void spiConfigure(S3CheckpointSpi spi) throws Exception {
-        AWSCredentials cred = new BasicAWSCredentials(IgniteS3TestSuite.getAccessKey(),
-            IgniteS3TestSuite.getSecretKey());
+        AWSCredentials cred = new BasicAWSCredentials(IgniteS3TestConfiguration.getAccessKey(),
+            IgniteS3TestConfiguration.getSecretKey());
 
         spi.setAwsCredentials(cred);
 
diff --git a/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3SessionCheckpointSelfTest.java b/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3SessionCheckpointSelfTest.java
index 43c0e269..c7aba7a8 100644
--- a/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3SessionCheckpointSelfTest.java
+++ b/modules/aws-ext/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3SessionCheckpointSelfTest.java
@@ -22,7 +22,7 @@ import com.amazonaws.auth.BasicAWSCredentials;
 import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.session.GridSessionCheckpointAbstractSelfTest;
 import org.apache.ignite.session.GridSessionCheckpointSelfTest;
-import org.apache.ignite.testsuites.IgniteS3TestSuite;
+import org.apache.ignite.util.IgniteS3TestConfiguration;
 import org.junit.Ignore;
 import org.junit.Test;
 
@@ -40,8 +40,8 @@ public class S3SessionCheckpointSelfTest extends GridSessionCheckpointAbstractSe
 
         S3CheckpointSpi spi = new S3CheckpointSpi();
 
-        AWSCredentials cred = new BasicAWSCredentials(IgniteS3TestSuite.getAccessKey(),
-            IgniteS3TestSuite.getSecretKey());
+        AWSCredentials cred = new BasicAWSCredentials(IgniteS3TestConfiguration.getAccessKey(),
+            IgniteS3TestConfiguration.getSecretKey());
 
         spi.setAwsCredentials(cred);
 
diff --git a/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderAbstractSelfTest.java b/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderAbstractSelfTest.java
index 685a8d6f..ae250cbf 100644
--- a/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderAbstractSelfTest.java
+++ b/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderAbstractSelfTest.java
@@ -25,7 +25,7 @@ import java.util.concurrent.ThreadLocalRandom;
 import org.apache.ignite.internal.util.typedef.internal.U;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAbstractSelfTest;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.EncryptionService;
-import org.apache.ignite.testsuites.IgniteS3TestSuite;
+import org.apache.ignite.util.IgniteS3TestConfiguration;
 import org.jetbrains.annotations.Nullable;
 import org.junit.Ignore;
 import org.junit.Test;
@@ -155,11 +155,11 @@ public abstract class TcpDiscoveryS3IpFinderAbstractSelfTest
     static String getBucketName() {
         String bucketName;
         try {
-            bucketName = IgniteS3TestSuite.getBucketName(
+            bucketName = IgniteS3TestConfiguration.getBucketName(
                 "ip-finder-unit-test-" + InetAddress.getLocalHost().getHostName().toLowerCase());
         }
         catch (UnknownHostException e) {
-            bucketName = IgniteS3TestSuite.getBucketName(
+            bucketName = IgniteS3TestConfiguration.getBucketName(
                 "ip-finder-unit-test-rnd-" + ThreadLocalRandom.current().nextInt(100));
         }
 
diff --git a/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderAwsCredentialsProviderSelfTest.java b/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderAwsCredentialsProviderSelfTest.java
index dc3aa581..e0ee2af7 100644
--- a/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderAwsCredentialsProviderSelfTest.java
+++ b/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderAwsCredentialsProviderSelfTest.java
@@ -19,7 +19,7 @@ package org.apache.ignite.spi.discovery.tcp.ipfinder.s3;
 
 import com.amazonaws.auth.AWSStaticCredentialsProvider;
 import com.amazonaws.auth.BasicAWSCredentials;
-import org.apache.ignite.testsuites.IgniteS3TestSuite;
+import org.apache.ignite.util.IgniteS3TestConfiguration;
 import org.junit.Test;
 
 /**
@@ -38,7 +38,7 @@ public class TcpDiscoveryS3IpFinderAwsCredentialsProviderSelfTest extends TcpDis
     /** {@inheritDoc} */
     @Override protected void setAwsCredentials(TcpDiscoveryS3IpFinder finder) {
         finder.setAwsCredentialsProvider(new AWSStaticCredentialsProvider(
-            new BasicAWSCredentials(IgniteS3TestSuite.getAccessKey(), IgniteS3TestSuite.getSecretKey())));
+            new BasicAWSCredentials(IgniteS3TestConfiguration.getAccessKey(), IgniteS3TestConfiguration.getSecretKey())));
     }
 
     /** {@inheritDoc} */
diff --git a/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderAwsCredentialsSelfTest.java b/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderAwsCredentialsSelfTest.java
index 64dfc7b2..bac1f58b 100644
--- a/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderAwsCredentialsSelfTest.java
+++ b/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderAwsCredentialsSelfTest.java
@@ -18,7 +18,7 @@
 package org.apache.ignite.spi.discovery.tcp.ipfinder.s3;
 
 import com.amazonaws.auth.BasicAWSCredentials;
-import org.apache.ignite.testsuites.IgniteS3TestSuite;
+import org.apache.ignite.util.IgniteS3TestConfiguration;
 import org.junit.Test;
 
 /**
@@ -36,8 +36,8 @@ public class TcpDiscoveryS3IpFinderAwsCredentialsSelfTest extends TcpDiscoveryS3
 
     /** {@inheritDoc} */
     @Override protected void setAwsCredentials(TcpDiscoveryS3IpFinder finder) {
-        finder.setAwsCredentials(new BasicAWSCredentials(IgniteS3TestSuite.getAccessKey(),
-            IgniteS3TestSuite.getSecretKey()));
+        finder.setAwsCredentials(new BasicAWSCredentials(IgniteS3TestConfiguration.getAccessKey(),
+            IgniteS3TestConfiguration.getSecretKey()));
     }
 
     /** {@inheritDoc} */
diff --git a/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderBucketEndpointSelfTest.java b/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderBucketEndpointSelfTest.java
index 9b280e85..ac161bf0 100644
--- a/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderBucketEndpointSelfTest.java
+++ b/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderBucketEndpointSelfTest.java
@@ -18,7 +18,7 @@
 package org.apache.ignite.spi.discovery.tcp.ipfinder.s3;
 
 import com.amazonaws.auth.BasicAWSCredentials;
-import org.apache.ignite.testsuites.IgniteS3TestSuite;
+import org.apache.ignite.util.IgniteS3TestConfiguration;
 import org.junit.Test;
 
 /**
@@ -38,8 +38,8 @@ public class TcpDiscoveryS3IpFinderBucketEndpointSelfTest extends TcpDiscoveryS3
 
     /** {@inheritDoc} */
     @Override protected void setAwsCredentials(TcpDiscoveryS3IpFinder finder) {
-        finder.setAwsCredentials(new BasicAWSCredentials(IgniteS3TestSuite.getAccessKey(),
-            IgniteS3TestSuite.getSecretKey()));
+        finder.setAwsCredentials(new BasicAWSCredentials(IgniteS3TestConfiguration.getAccessKey(),
+            IgniteS3TestConfiguration.getSecretKey()));
     }
 
     /** {@inheritDoc} */
diff --git a/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderSSEAlgorithmSelfTest.java b/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderSSEAlgorithmSelfTest.java
index d13c7c34..cb574411 100644
--- a/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderSSEAlgorithmSelfTest.java
+++ b/modules/aws-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/s3/TcpDiscoveryS3IpFinderSSEAlgorithmSelfTest.java
@@ -18,7 +18,7 @@
 package org.apache.ignite.spi.discovery.tcp.ipfinder.s3;
 
 import com.amazonaws.auth.BasicAWSCredentials;
-import org.apache.ignite.testsuites.IgniteS3TestSuite;
+import org.apache.ignite.util.IgniteS3TestConfiguration;
 import org.junit.Test;
 
 /**
@@ -38,8 +38,8 @@ public class TcpDiscoveryS3IpFinderSSEAlgorithmSelfTest extends TcpDiscoveryS3Ip
 
     /** {@inheritDoc} */
     @Override protected void setAwsCredentials(TcpDiscoveryS3IpFinder finder) {
-        finder.setAwsCredentials(new BasicAWSCredentials(IgniteS3TestSuite.getAccessKey(),
-            IgniteS3TestSuite.getSecretKey()));
+        finder.setAwsCredentials(new BasicAWSCredentials(IgniteS3TestConfiguration.getAccessKey(),
+            IgniteS3TestConfiguration.getSecretKey()));
     }
 
     /** {@inheritDoc} */
diff --git a/modules/aws-ext/src/test/java/org/apache/ignite/testsuites/IgniteElbTestSuite.java b/modules/aws-ext/src/test/java/org/apache/ignite/testsuites/IgniteElbTestSuite.java
deleted file mode 100644
index bc9ece0e..00000000
--- a/modules/aws-ext/src/test/java/org/apache/ignite/testsuites/IgniteElbTestSuite.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/*
- * 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.testsuites;
-
-import org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryAlbIpFinderSelfTest;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryElbIpFinderSelfTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * ELB IP finder test suite.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({TcpDiscoveryElbIpFinderSelfTest.class,
-                     TcpDiscoveryAlbIpFinderSelfTest.class})
-public class IgniteElbTestSuite {
-}
diff --git a/modules/aws-ext/src/test/java/org/apache/ignite/testsuites/IgniteS3TestSuite.java b/modules/aws-ext/src/test/java/org/apache/ignite/testsuites/IgniteS3TestSuite.java
deleted file mode 100644
index 00969260..00000000
--- a/modules/aws-ext/src/test/java/org/apache/ignite/testsuites/IgniteS3TestSuite.java
+++ /dev/null
@@ -1,109 +0,0 @@
-/*
- * 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.testsuites;
-
-import org.apache.ignite.internal.util.typedef.X;
-import org.apache.ignite.spi.checkpoint.s3.S3CheckpointManagerSelfTest;
-import org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiConfigSelfTest;
-import org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiSelfTest;
-import org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiStartStopBucketEndpointSelfTest;
-import org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiStartStopSSEAlgorithmSelfTest;
-import org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiStartStopSelfTest;
-import org.apache.ignite.spi.checkpoint.s3.S3SessionCheckpointSelfTest;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinderAwsCredentialsProviderSelfTest;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinderAwsCredentialsSelfTest;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinderBucketEndpointSelfTest;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinderClientSideEncryptionSelfTest;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinderKeyPrefixSelfTest;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinderSSEAlgorithmSelfTest;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.s3.client.DummyObjectListingTest;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.s3.client.DummyS3ClientTest;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AsymmetricKeyEncryptionServiceTest;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AwsKmsEncryptionServiceTest;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.MockEncryptionServiceTest;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.SymmetricKeyEncryptionServiceTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * S3 integration tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    // Checkpoint SPI.
-    S3CheckpointSpiConfigSelfTest.class,
-    S3CheckpointSpiSelfTest.class,
-    S3CheckpointSpiStartStopSelfTest.class,
-    S3CheckpointManagerSelfTest.class,
-    S3SessionCheckpointSelfTest.class,
-    S3CheckpointSpiStartStopBucketEndpointSelfTest.class,
-    S3CheckpointSpiStartStopSSEAlgorithmSelfTest.class,
-
-    // S3 Encryption tests.
-    MockEncryptionServiceTest.class,
-    AwsKmsEncryptionServiceTest.class,
-    SymmetricKeyEncryptionServiceTest.class,
-    AsymmetricKeyEncryptionServiceTest.class,
-
-    // S3 IP finder.
-    DummyS3ClientTest.class,
-    DummyObjectListingTest.class,
-    TcpDiscoveryS3IpFinderAwsCredentialsSelfTest.class,
-    TcpDiscoveryS3IpFinderAwsCredentialsProviderSelfTest.class,
-    TcpDiscoveryS3IpFinderBucketEndpointSelfTest.class,
-    TcpDiscoveryS3IpFinderSSEAlgorithmSelfTest.class,
-    TcpDiscoveryS3IpFinderKeyPrefixSelfTest.class,
-    TcpDiscoveryS3IpFinderClientSideEncryptionSelfTest.class,
-})
-public class IgniteS3TestSuite {
-    /**
-     * @return Access key.
-     */
-    public static String getAccessKey() {
-        return getRequiredEnvVar("test.amazon.access.key");
-    }
-
-    /**
-     * @return Access key.
-     */
-    public static String getSecretKey() {
-        return getRequiredEnvVar("test.amazon.secret.key");
-    }
-
-    /**
-     * @param dfltBucketName Default bucket name.
-     * @return Bucket name.
-     */
-    public static String getBucketName(final String dfltBucketName) {
-        String val = X.getSystemOrEnv("test.s3.bucket.name");
-
-        return val == null ? dfltBucketName : val;
-    }
-
-    /**
-     * @param name Name of environment.
-     * @return Environment variable value.
-     */
-    private static String getRequiredEnvVar(String name) {
-        String key = X.getSystemOrEnv(name);
-
-        assert key != null : String.format("Environment variable '%s' is not set", name);
-
-        return key;
-    }
-}
diff --git a/modules/aws-ext/src/test/java/org/apache/ignite/util/IgniteS3TestConfiguration.java b/modules/aws-ext/src/test/java/org/apache/ignite/util/IgniteS3TestConfiguration.java
new file mode 100644
index 00000000..6409b354
--- /dev/null
+++ b/modules/aws-ext/src/test/java/org/apache/ignite/util/IgniteS3TestConfiguration.java
@@ -0,0 +1,61 @@
+/*
+ * 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.util;
+
+import org.apache.ignite.internal.util.typedef.X;
+
+/**
+ * S3 tests configuration.
+ */
+public final class IgniteS3TestConfiguration {
+    /**
+     * @return Access key.
+     */
+    public static String getAccessKey() {
+        return getRequiredEnvVar("test.amazon.access.key");
+    }
+
+    /**
+     * @return Access key.
+     */
+    public static String getSecretKey() {
+        return getRequiredEnvVar("test.amazon.secret.key");
+    }
+
+    /**
+     * @param dfltBucketName Default bucket name.
+     * @return Bucket name.
+     */
+    public static String getBucketName(final String dfltBucketName) {
+        String val = X.getSystemOrEnv("test.s3.bucket.name");
+
+        return val == null ? dfltBucketName : val;
+    }
+
+    /**
+     * @param name Name of environment.
+     * @return Environment variable value.
+     */
+    private static String getRequiredEnvVar(String name) {
+        String key = X.getSystemOrEnv(name);
+
+        assert key != null : String.format("Environment variable '%s' is not set", name);
+
+        return key;
+    }
+}
diff --git a/modules/azure-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/azure/TcpDiscoveryAzureBlobStoreIpFinderSelfTest.java b/modules/azure-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/azure/TcpDiscoveryAzureBlobStoreIpFinderSelfTest.java
index 9e8ac18f..92c26429 100644
--- a/modules/azure-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/azure/TcpDiscoveryAzureBlobStoreIpFinderSelfTest.java
+++ b/modules/azure-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/azure/TcpDiscoveryAzureBlobStoreIpFinderSelfTest.java
@@ -25,7 +25,7 @@ import com.azure.storage.blob.BlobServiceClientBuilder;
 import com.azure.storage.common.StorageSharedKeyCredential;
 import org.apache.ignite.internal.util.typedef.internal.U;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAbstractSelfTest;
-import org.apache.ignite.testsuites.IgniteAzureTestSuite;
+import org.apache.ignite.util.IgniteAzureTestConfiguration;
 
 /** */
 public class TcpDiscoveryAzureBlobStoreIpFinderSelfTest
@@ -55,9 +55,9 @@ public class TcpDiscoveryAzureBlobStoreIpFinderSelfTest
 
         try {
             BlobContainerClient container =
-                new BlobServiceClientBuilder().endpoint(IgniteAzureTestSuite.getEndpoint()).credential(
-                    new StorageSharedKeyCredential(IgniteAzureTestSuite.getAccountName(),
-                        IgniteAzureTestSuite.getAccountKey())).buildClient().getBlobContainerClient(containerName);
+                new BlobServiceClientBuilder().endpoint(IgniteAzureTestConfiguration.getEndpoint()).credential(
+                    new StorageSharedKeyCredential(IgniteAzureTestConfiguration.getAccountName(),
+                        IgniteAzureTestConfiguration.getAccountKey())).buildClient().getBlobContainerClient(containerName);
 
             if (container.exists())
                 container.delete();
@@ -75,9 +75,9 @@ public class TcpDiscoveryAzureBlobStoreIpFinderSelfTest
 
         assert finder.isShared() : "Ip finder must be shared by default.";
 
-        finder.setAccountName(IgniteAzureTestSuite.getAccountName());
-        finder.setAccountKey(IgniteAzureTestSuite.getAccountKey());
-        finder.setAccountEndpoint(IgniteAzureTestSuite.getEndpoint());
+        finder.setAccountName(IgniteAzureTestConfiguration.getAccountName());
+        finder.setAccountKey(IgniteAzureTestConfiguration.getAccountKey());
+        finder.setAccountEndpoint(IgniteAzureTestConfiguration.getEndpoint());
 
         finder.setContainerName(containerName);
 
diff --git a/modules/azure-ext/src/test/java/org/apache/ignite/testsuites/IgniteAzureTestSuite.java b/modules/azure-ext/src/test/java/org/apache/ignite/util/IgniteAzureTestConfiguration.java
similarity index 82%
rename from modules/azure-ext/src/test/java/org/apache/ignite/testsuites/IgniteAzureTestSuite.java
rename to modules/azure-ext/src/test/java/org/apache/ignite/util/IgniteAzureTestConfiguration.java
index 2bc01a9e..9b731aa1 100644
--- a/modules/azure-ext/src/test/java/org/apache/ignite/testsuites/IgniteAzureTestSuite.java
+++ b/modules/azure-ext/src/test/java/org/apache/ignite/util/IgniteAzureTestConfiguration.java
@@ -1,4 +1,3 @@
-package org.apache.ignite.testsuites;
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
@@ -15,18 +14,14 @@ package org.apache.ignite.testsuites;
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
+package org.apache.ignite.util;
 
 import org.apache.ignite.internal.util.typedef.X;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.azure.TcpDiscoveryAzureBlobStoreIpFinderSelfTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
 
 /**
- * Azure integration tests
+ * Azure tests configuration.
  */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({TcpDiscoveryAzureBlobStoreIpFinderSelfTest.class})
-public class IgniteAzureTestSuite {
+public class IgniteAzureTestConfiguration {
     /**
      * @return Account Name
      */
diff --git a/modules/camel-ext/src/test/java/org/apache/ignite/stream/camel/IgniteCamelStreamerTestSuite.java b/modules/camel-ext/src/test/java/org/apache/ignite/stream/camel/IgniteCamelStreamerTestSuite.java
deleted file mode 100644
index 7028a5c6..00000000
--- a/modules/camel-ext/src/test/java/org/apache/ignite/stream/camel/IgniteCamelStreamerTestSuite.java
+++ /dev/null
@@ -1,29 +0,0 @@
-/*
- * 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.stream.camel;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Camel streamer tests. Included into 'Streamers' run configuration.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({IgniteCamelStreamerTest.class})
-public class IgniteCamelStreamerTestSuite {
-}
diff --git a/modules/cdc-ext/src/test/java/org/apache/ignite/cdc/IgniteCdcTestSuite.java b/modules/cdc-ext/src/test/java/org/apache/ignite/cdc/IgniteCdcTestSuite.java
deleted file mode 100644
index 43e7db62..00000000
--- a/modules/cdc-ext/src/test/java/org/apache/ignite/cdc/IgniteCdcTestSuite.java
+++ /dev/null
@@ -1,40 +0,0 @@
-/*
- * 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.cdc;
-
-import org.apache.ignite.cdc.kafka.CdcKafkaReplicationAppsTest;
-import org.apache.ignite.cdc.kafka.CdcKafkaReplicationTest;
-import org.apache.ignite.cdc.kafka.KafkaToIgniteLoaderTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Cdc test suite.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    CacheConflictOperationsTest.class,
-    CacheConflictOperationsWithFieldTest.class,
-    CdcIgniteToIgniteReplicationTest.class,
-    KafkaToIgniteLoaderTest.class,
-    CdcKafkaReplicationTest.class,
-    CdcKafkaReplicationAppsTest.class,
-    ConflictResolverRestartTest.class
-})
-public class IgniteCdcTestSuite {
-}
diff --git a/modules/cloud-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/cloud/TcpDiscoveryCloudIpFinderSelfTest.java b/modules/cloud-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/cloud/TcpDiscoveryCloudIpFinderSelfTest.java
index 378769c1..47b93c18 100644
--- a/modules/cloud-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/cloud/TcpDiscoveryCloudIpFinderSelfTest.java
+++ b/modules/cloud-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/cloud/TcpDiscoveryCloudIpFinderSelfTest.java
@@ -22,7 +22,7 @@ import java.util.Collection;
 import com.google.common.collect.ImmutableList;
 import org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAbstractSelfTest;
-import org.apache.ignite.testsuites.IgniteCloudTestSuite;
+import org.apache.ignite.util.IgniteCloudTestConfiguration;
 import org.junit.Ignore;
 import org.junit.Test;
 
@@ -93,14 +93,14 @@ public class TcpDiscoveryCloudIpFinderSelfTest extends
         injectLogger(ipFinder);
 
         ipFinder.setProvider(provider);
-        ipFinder.setIdentity(IgniteCloudTestSuite.getAccessKey(provider));
-        ipFinder.setRegions(IgniteCloudTestSuite.getRegions(provider));
-        ipFinder.setZones(IgniteCloudTestSuite.getZones(provider));
+        ipFinder.setIdentity(IgniteCloudTestConfiguration.getAccessKey(provider));
+        ipFinder.setRegions(IgniteCloudTestConfiguration.getRegions(provider));
+        ipFinder.setZones(IgniteCloudTestConfiguration.getZones(provider));
 
         if (provider.equals("google-compute-engine"))
-            ipFinder.setCredentialPath(IgniteCloudTestSuite.getSecretKey(provider));
+            ipFinder.setCredentialPath(IgniteCloudTestConfiguration.getSecretKey(provider));
         else
-            ipFinder.setCredential(IgniteCloudTestSuite.getSecretKey(provider));
+            ipFinder.setCredential(IgniteCloudTestConfiguration.getSecretKey(provider));
 
         Collection<InetSocketAddress> addresses = ipFinder.getRegisteredAddresses();
 
diff --git a/modules/cloud-ext/src/test/java/org/apache/ignite/testsuites/IgniteCloudTestSuite.java b/modules/cloud-ext/src/test/java/org/apache/ignite/util/IgniteCloudTestConfiguration.java
similarity index 89%
rename from modules/cloud-ext/src/test/java/org/apache/ignite/testsuites/IgniteCloudTestSuite.java
rename to modules/cloud-ext/src/test/java/org/apache/ignite/util/IgniteCloudTestConfiguration.java
index f8780f40..81cc6010 100644
--- a/modules/cloud-ext/src/test/java/org/apache/ignite/testsuites/IgniteCloudTestSuite.java
+++ b/modules/cloud-ext/src/test/java/org/apache/ignite/util/IgniteCloudTestConfiguration.java
@@ -15,20 +15,15 @@
  * limitations under the License.
  */
 
-package org.apache.ignite.testsuites;
+package org.apache.ignite.util;
 
 import java.util.Collection;
 import java.util.LinkedList;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinderSelfTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
 
 /**
- * Ignite Cloud integration test.
+ * Ignite Cloud tests configuration.
  */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({TcpDiscoveryCloudIpFinderSelfTest.class})
-public class IgniteCloudTestSuite {
+public class IgniteCloudTestConfiguration {
     /**
      * <a href="http://jclouds.apache.org/guides/google/">Service Account email<a/> for GCE.
      * <a href="http://jclouds.apache.org/guides/aws/">Access Key ID</a> for Amazon.
diff --git a/modules/flink-ext/src/test/java/org/apache/ignite/sink/flink/FlinkIgniteSinkSelfTestSuite.java b/modules/flink-ext/src/test/java/org/apache/ignite/sink/flink/FlinkIgniteSinkSelfTestSuite.java
deleted file mode 100644
index 7890e4cd..00000000
--- a/modules/flink-ext/src/test/java/org/apache/ignite/sink/flink/FlinkIgniteSinkSelfTestSuite.java
+++ /dev/null
@@ -1,29 +0,0 @@
-/*
- * 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.sink.flink;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Apache Flink sink tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({FlinkIgniteSinkSelfTest.class})
-public class FlinkIgniteSinkSelfTestSuite {
-}
diff --git a/modules/flink-ext/src/test/java/org/apache/ignite/source/flink/FlinkIgniteSourceSelfTestSuite.java b/modules/flink-ext/src/test/java/org/apache/ignite/source/flink/FlinkIgniteSourceSelfTestSuite.java
deleted file mode 100644
index 70704024..00000000
--- a/modules/flink-ext/src/test/java/org/apache/ignite/source/flink/FlinkIgniteSourceSelfTestSuite.java
+++ /dev/null
@@ -1,30 +0,0 @@
-/*
- * 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.source.flink;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Apache Flink source tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({FlinkIgniteSourceSelfTest.class})
-public class FlinkIgniteSourceSelfTestSuite {
-}
-
diff --git a/modules/flume-ext/src/test/java/org/apache/ignite/stream/flume/IgniteSinkTestSuite.java b/modules/flume-ext/src/test/java/org/apache/ignite/stream/flume/IgniteSinkTestSuite.java
deleted file mode 100644
index 300777da..00000000
--- a/modules/flume-ext/src/test/java/org/apache/ignite/stream/flume/IgniteSinkTestSuite.java
+++ /dev/null
@@ -1,29 +0,0 @@
-/*
- * 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.stream.flume;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Tests for a Flume sink for Ignite.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({IgniteSinkTest.class})
-public class IgniteSinkTestSuite {
-}
diff --git a/modules/gce-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/gce/TcpDiscoveryGoogleStorageIpFinderSelfTest.java b/modules/gce-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/gce/TcpDiscoveryGoogleStorageIpFinderSelfTest.java
index 1b3d94c6..e2f32ba9 100644
--- a/modules/gce-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/gce/TcpDiscoveryGoogleStorageIpFinderSelfTest.java
+++ b/modules/gce-ext/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/gce/TcpDiscoveryGoogleStorageIpFinderSelfTest.java
@@ -23,7 +23,7 @@ import java.net.InetSocketAddress;
 import java.util.Collection;
 import org.apache.ignite.internal.util.typedef.internal.U;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAbstractSelfTest;
-import org.apache.ignite.testsuites.IgniteGCETestSuite;
+import org.apache.ignite.util.IgniteGCETestConfiguration;
 
 /**
  * Google Cloud Storage based IP finder tests.
@@ -71,9 +71,9 @@ public class TcpDiscoveryGoogleStorageIpFinderSelfTest
 
         assert finder.isShared() : "Ip finder must be shared by default.";
 
-        finder.setServiceAccountId(IgniteGCETestSuite.getServiceAccountId());
-        finder.setServiceAccountP12FilePath(IgniteGCETestSuite.getP12FilePath());
-        finder.setProjectName(IgniteGCETestSuite.getProjectName());
+        finder.setServiceAccountId(IgniteGCETestConfiguration.getServiceAccountId());
+        finder.setServiceAccountP12FilePath(IgniteGCETestConfiguration.getP12FilePath());
+        finder.setProjectName(IgniteGCETestConfiguration.getProjectName());
 
         // Bucket name must be unique across the whole GCE platform.
         finder.setBucketName(bucketName);
diff --git a/modules/gce-ext/src/test/java/org/apache/ignite/testsuites/IgniteGCETestSuite.java b/modules/gce-ext/src/test/java/org/apache/ignite/util/IgniteGCETestConfiguration.java
similarity index 81%
rename from modules/gce-ext/src/test/java/org/apache/ignite/testsuites/IgniteGCETestSuite.java
rename to modules/gce-ext/src/test/java/org/apache/ignite/util/IgniteGCETestConfiguration.java
index 98680e55..0c8c0422 100644
--- a/modules/gce-ext/src/test/java/org/apache/ignite/testsuites/IgniteGCETestSuite.java
+++ b/modules/gce-ext/src/test/java/org/apache/ignite/util/IgniteGCETestConfiguration.java
@@ -15,19 +15,14 @@
  * limitations under the License.
  */
 
-package org.apache.ignite.testsuites;
+package org.apache.ignite.util;
 
 import org.apache.ignite.internal.util.typedef.X;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinderSelfTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
 
 /**
- * Google Compute Engine integration tests.
+ * Google Compute Engine tests configuration.
  */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({TcpDiscoveryGoogleStorageIpFinderSelfTest.class})
-public class IgniteGCETestSuite {
+public class IgniteGCETestConfiguration {
     /**
      * @return Service Account Id.
      */
diff --git a/modules/geospatial-ext/examples/src/test/java/org/apache/ignite/examples/SpatialQueryExampleSelfTest.java b/modules/geospatial-ext/examples/src/test/java/org/apache/ignite/examples/SpatialQueryExampleSelfTest.java
index ea88cff9..40f9804a 100644
--- a/modules/geospatial-ext/examples/src/test/java/org/apache/ignite/examples/SpatialQueryExampleSelfTest.java
+++ b/modules/geospatial-ext/examples/src/test/java/org/apache/ignite/examples/SpatialQueryExampleSelfTest.java
@@ -18,13 +18,26 @@
 package org.apache.ignite.examples;
 
 import org.apache.ignite.examples.datagrid.SpatialQueryExample;
+import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.junits.common.GridAbstractExamplesTest;
+import org.junit.BeforeClass;
 import org.junit.Test;
 
+import static org.apache.ignite.IgniteSystemProperties.IGNITE_OVERRIDE_MCAST_GRP;
+
 /**
  * Tests {@link SpatialQueryExample}.
  */
 public class SpatialQueryExampleSelfTest extends GridAbstractExamplesTest {
+    /**
+     *
+     */
+    @BeforeClass
+    public static void init() {
+        System.setProperty(IGNITE_OVERRIDE_MCAST_GRP,
+            GridTestUtils.getNextMulticastGroup(SpatialQueryExampleSelfTest.class));
+    }
+
     /**
      * @throws Exception If failed.
      */
diff --git a/modules/geospatial-ext/examples/src/test/java/org/apache/ignite/testsuites/IgniteGeospatialLgplExamplesSelfTestSuite.java b/modules/geospatial-ext/examples/src/test/java/org/apache/ignite/testsuites/IgniteGeospatialLgplExamplesSelfTestSuite.java
deleted file mode 100644
index 97b81ec8..00000000
--- a/modules/geospatial-ext/examples/src/test/java/org/apache/ignite/testsuites/IgniteGeospatialLgplExamplesSelfTestSuite.java
+++ /dev/null
@@ -1,46 +0,0 @@
-/*
- *  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.testsuites;
-
-import org.apache.ignite.examples.SpatialQueryExampleMultiNodeSelfTest;
-import org.apache.ignite.examples.SpatialQueryExampleSelfTest;
-import org.apache.ignite.testframework.GridTestUtils;
-import org.junit.BeforeClass;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-import static org.apache.ignite.IgniteSystemProperties.IGNITE_OVERRIDE_MCAST_GRP;
-
-/**
- * Examples test suite. <p> Contains only Spring ignite examples tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    SpatialQueryExampleSelfTest.class,
-
-    // Multi-node.
-    SpatialQueryExampleMultiNodeSelfTest.class
-})
-public class IgniteGeospatialLgplExamplesSelfTestSuite {
-    /** */
-    @BeforeClass
-    public static void init() {
-        System.setProperty(IGNITE_OVERRIDE_MCAST_GRP,
-            GridTestUtils.getNextMulticastGroup(IgniteGeospatialLgplExamplesSelfTestSuite.class));
-    }
-}
diff --git a/modules/geospatial-ext/geospatial/src/test/java/org/apache/ignite/testsuites/GeoSpatialIndexingTestSuite.java b/modules/geospatial-ext/geospatial/src/test/java/org/apache/ignite/testsuites/GeoSpatialIndexingTestSuite.java
deleted file mode 100644
index f5cd2962..00000000
--- a/modules/geospatial-ext/geospatial/src/test/java/org/apache/ignite/testsuites/GeoSpatialIndexingTestSuite.java
+++ /dev/null
@@ -1,36 +0,0 @@
-/*
- * 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.testsuites;
-
-import org.apache.ignite.internal.processors.query.h2.H2IndexesSystemViewTest;
-import org.apache.ignite.internal.processors.query.h2.H2IndexingGeoSelfTest;
-import org.apache.ignite.internal.processors.query.h2.H2IndexingSegmentedGeoSelfTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Geospatial indexing tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    H2IndexingGeoSelfTest.class,
-    H2IndexingSegmentedGeoSelfTest.class,
-    H2IndexesSystemViewTest.class
-})
-public class GeoSpatialIndexingTestSuite {
-}
diff --git a/modules/hibernate-ext/examples/src/test/java/org/apache/ignite/examples/HibernateL2CacheExampleSelfTest.java b/modules/hibernate-ext/examples/src/test/java/org/apache/ignite/examples/HibernateL2CacheExampleSelfTest.java
index 93e24b06..feef594c 100644
--- a/modules/hibernate-ext/examples/src/test/java/org/apache/ignite/examples/HibernateL2CacheExampleSelfTest.java
+++ b/modules/hibernate-ext/examples/src/test/java/org/apache/ignite/examples/HibernateL2CacheExampleSelfTest.java
@@ -18,13 +18,24 @@
 package org.apache.ignite.examples;
 
 import org.apache.ignite.examples.datagrid.hibernate.HibernateL2CacheExample;
+import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.junits.common.GridAbstractExamplesTest;
+import org.junit.BeforeClass;
 import org.junit.Test;
 
+import static org.apache.ignite.IgniteSystemProperties.IGNITE_OVERRIDE_MCAST_GRP;
+
 /**
  * Tests the {@link HibernateL2CacheExample}.
  */
 public class HibernateL2CacheExampleSelfTest extends GridAbstractExamplesTest {
+    /** */
+    @BeforeClass
+    public static void init() {
+        System.setProperty(IGNITE_OVERRIDE_MCAST_GRP,
+            GridTestUtils.getNextMulticastGroup(HibernateL2CacheExampleSelfTest.class));
+    }
+
     /** */
     @Test
     public void testHibernateL2CacheExample() {
diff --git a/modules/hibernate-ext/examples/src/test/java/org/apache/ignite/testsuites/IgniteLgplExamplesSelfTestSuite.java b/modules/hibernate-ext/examples/src/test/java/org/apache/ignite/testsuites/IgniteLgplExamplesSelfTestSuite.java
deleted file mode 100644
index f12494bd..00000000
--- a/modules/hibernate-ext/examples/src/test/java/org/apache/ignite/testsuites/IgniteLgplExamplesSelfTestSuite.java
+++ /dev/null
@@ -1,45 +0,0 @@
-/*
- *  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.testsuites;
-
-import org.apache.ignite.examples.HibernateL2CacheExampleMultiNodeSelfTest;
-import org.apache.ignite.examples.HibernateL2CacheExampleSelfTest;
-import org.apache.ignite.testframework.GridTestUtils;
-import org.junit.BeforeClass;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-import static org.apache.ignite.IgniteSystemProperties.IGNITE_OVERRIDE_MCAST_GRP;
-
-/**
- * Examples test suite. <p> Contains only Spring ignite examples tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    HibernateL2CacheExampleSelfTest.class,
-
-    // Multi-node.
-    HibernateL2CacheExampleMultiNodeSelfTest.class
-})
-public class IgniteLgplExamplesSelfTestSuite {
-    /** */
-    @BeforeClass
-    public static void init() {
-        System.setProperty(IGNITE_OVERRIDE_MCAST_GRP,
-            GridTestUtils.getNextMulticastGroup(IgniteLgplExamplesSelfTestSuite.class));
-    }
-}
diff --git a/modules/hibernate-ext/hibernate/src/test/java/org/apache/ignite/testsuites/IgniteHibernate5TestSuite.java b/modules/hibernate-ext/hibernate/src/test/java/org/apache/ignite/testsuites/IgniteHibernate5TestSuite.java
deleted file mode 100644
index 268fff67..00000000
--- a/modules/hibernate-ext/hibernate/src/test/java/org/apache/ignite/testsuites/IgniteHibernate5TestSuite.java
+++ /dev/null
@@ -1,50 +0,0 @@
-/*
- * 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.testsuites;
-
-import org.apache.ignite.cache.hibernate.HibernateL2CacheConfigurationSelfTest;
-import org.apache.ignite.cache.hibernate.HibernateL2CacheMultiJvmTest;
-import org.apache.ignite.cache.hibernate.HibernateL2CacheSelfTest;
-import org.apache.ignite.cache.hibernate.HibernateL2CacheStrategySelfTest;
-import org.apache.ignite.cache.hibernate.HibernateL2CacheTransactionalSelfTest;
-import org.apache.ignite.cache.hibernate.HibernateL2CacheTransactionalUseSyncSelfTest;
-import org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreNodeRestartTest;
-import org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreSelfTest;
-import org.apache.ignite.cache.store.hibernate.CacheHibernateStoreFactorySelfTest;
-import org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListenerSelfTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Hibernate integration tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    HibernateL2CacheSelfTest.class,
-    HibernateL2CacheTransactionalSelfTest.class,
-    HibernateL2CacheTransactionalUseSyncSelfTest.class,
-    HibernateL2CacheConfigurationSelfTest.class,
-    HibernateL2CacheStrategySelfTest.class,
-    HibernateL2CacheMultiJvmTest.class,
-    CacheHibernateBlobStoreSelfTest.class,
-    CacheHibernateBlobStoreNodeRestartTest.class,
-    CacheHibernateStoreSessionListenerSelfTest.class,
-    CacheHibernateStoreFactorySelfTest.class
-})
-public class IgniteHibernate5TestSuite {
-}
diff --git a/modules/jms11-ext/src/test/java/org/apache/ignite/stream/jms11/IgniteJmsStreamerTestSuite.java b/modules/jms11-ext/src/test/java/org/apache/ignite/stream/jms11/IgniteJmsStreamerTestSuite.java
deleted file mode 100644
index 303b6b21..00000000
--- a/modules/jms11-ext/src/test/java/org/apache/ignite/stream/jms11/IgniteJmsStreamerTestSuite.java
+++ /dev/null
@@ -1,34 +0,0 @@
-/*
- * 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.stream.jms11;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * JMS streamer tests.
- *
- * @author Raul Kripalani
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    IgniteJmsStreamerTest.class
-})
-public class IgniteJmsStreamerTestSuite {
-    // No-op.
-}
diff --git a/modules/kafka-ext/pom.xml b/modules/kafka-ext/pom.xml
index f8b30624..9ad95b4e 100644
--- a/modules/kafka-ext/pom.xml
+++ b/modules/kafka-ext/pom.xml
@@ -105,6 +105,10 @@
                     <artifactId>guava</artifactId>
                     <groupId>com.google.guava</groupId>
                 </exclusion>
+                <exclusion>
+                    <groupId>org.junit.jupiter</groupId>
+                    <artifactId>junit-jupiter-api</artifactId>
+                </exclusion>
             </exclusions>
         </dependency>
 
diff --git a/modules/kafka-ext/src/test/java/org/apache/ignite/stream/kafka/IgniteKafkaStreamerSelfTestSuite.java b/modules/kafka-ext/src/test/java/org/apache/ignite/stream/kafka/IgniteKafkaStreamerSelfTestSuite.java
deleted file mode 100644
index c88fba8e..00000000
--- a/modules/kafka-ext/src/test/java/org/apache/ignite/stream/kafka/IgniteKafkaStreamerSelfTestSuite.java
+++ /dev/null
@@ -1,38 +0,0 @@
-/*
- * 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.stream.kafka;
-
-import org.apache.ignite.stream.kafka.connect.IgniteSinkConnectorTest;
-import org.apache.ignite.stream.kafka.connect.IgniteSourceConnectorTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Apache Kafka streamers tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    // Kafka streamer.
-    KafkaIgniteStreamerSelfTest.class,
-
-    // Kafka streamers via Connect API.
-    IgniteSinkConnectorTest.class,
-    IgniteSourceConnectorTest.class
-})
-public class IgniteKafkaStreamerSelfTestSuite {
-}
diff --git a/modules/mesos-ext/src/test/java/org/apache/ignite/IgniteMesosTestSuite.java b/modules/mesos-ext/src/test/java/org/apache/ignite/IgniteMesosTestSuite.java
deleted file mode 100644
index bab4b737..00000000
--- a/modules/mesos-ext/src/test/java/org/apache/ignite/IgniteMesosTestSuite.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/*
- * 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;
-
-import org.apache.ignite.mesos.IgniteSchedulerSelfTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Apache Mesos integration tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    IgniteSchedulerSelfTest.class
-})
-public class IgniteMesosTestSuite {
-}
diff --git a/modules/mqtt-ext/src/test/java/org/apache/ignite/stream/mqtt/IgniteMqttStreamerTestSuite.java b/modules/mqtt-ext/src/test/java/org/apache/ignite/stream/mqtt/IgniteMqttStreamerTestSuite.java
deleted file mode 100644
index ed0c2f79..00000000
--- a/modules/mqtt-ext/src/test/java/org/apache/ignite/stream/mqtt/IgniteMqttStreamerTestSuite.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/*
- * 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.stream.mqtt;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * MQTT streamer tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    IgniteMqttStreamerTest.class
-})
-public class IgniteMqttStreamerTestSuite {
-
-}
diff --git a/modules/osgi-ext/osgi/src/test/java/org/apache/ignite/osgi/IgniteOsgiTestSuite.java b/modules/osgi-ext/osgi/src/test/java/org/apache/ignite/osgi/IgniteOsgiTestSuite.java
deleted file mode 100644
index 0a3d69c8..00000000
--- a/modules/osgi-ext/osgi/src/test/java/org/apache/ignite/osgi/IgniteOsgiTestSuite.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/*
- * 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.osgi;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Test suite for OSGi-related test cases.
- * <p>
- * NOTE: Have to use JUnit 4 annotations because Pax Exam is built on JUnit 4.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({IgniteOsgiServiceTest.class, IgniteKarafFeaturesInstallationTest.class})
-public class IgniteOsgiTestSuite {
-    // No-op.
-}
diff --git a/modules/performance-statistics-ext/src/test/java/org/apache/ignite/internal/performancestatistics/IgnitePerformanceStatisticsReportTestSuite.java b/modules/performance-statistics-ext/src/test/java/org/apache/ignite/internal/performancestatistics/IgnitePerformanceStatisticsReportTestSuite.java
deleted file mode 100644
index c21ddb28..00000000
--- a/modules/performance-statistics-ext/src/test/java/org/apache/ignite/internal/performancestatistics/IgnitePerformanceStatisticsReportTestSuite.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/*
- * 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.internal.performancestatistics;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Performance statistics report tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    PerformanceStatisticsReportSelfTest.class,
-    PerformanceStatisticsPrinterTest.class
-})
-public class IgnitePerformanceStatisticsReportTestSuite {
-}
diff --git a/modules/pub-sub-ext/src/test/java/org/apache/ignite/stream/pubsub/PubSubStreamerTestSuite.java b/modules/pub-sub-ext/src/test/java/org/apache/ignite/stream/pubsub/PubSubStreamerTestSuite.java
deleted file mode 100644
index fd51b018..00000000
--- a/modules/pub-sub-ext/src/test/java/org/apache/ignite/stream/pubsub/PubSubStreamerTestSuite.java
+++ /dev/null
@@ -1,29 +0,0 @@
-/*
- * 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.stream.pubsub;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Pub/Sub streamer tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({PubSubStreamerSelfTest.class})
-public class PubSubStreamerTestSuite {
-}
diff --git a/modules/rocketmq-ext/src/test/java/org/apache/ignite/stream/rocketmq/RocketMQStreamerTestSuite.java b/modules/rocketmq-ext/src/test/java/org/apache/ignite/stream/rocketmq/RocketMQStreamerTestSuite.java
deleted file mode 100644
index c0d502bb..00000000
--- a/modules/rocketmq-ext/src/test/java/org/apache/ignite/stream/rocketmq/RocketMQStreamerTestSuite.java
+++ /dev/null
@@ -1,31 +0,0 @@
-/*
- *  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.stream.rocketmq;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Apache RocketMQ streamers tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    RocketMQStreamerTest.class
-})
-public class RocketMQStreamerTestSuite {
-}
diff --git a/modules/spark-ext/examples/src/test/java/org/apache/ignite/spark/examples/IgniteDataFrameSelfTest.java b/modules/spark-ext/examples/src/test/java/org/apache/ignite/spark/examples/IgniteDataFrameSelfTest.java
index fb58627e..dcb01ce3 100644
--- a/modules/spark-ext/examples/src/test/java/org/apache/ignite/spark/examples/IgniteDataFrameSelfTest.java
+++ b/modules/spark-ext/examples/src/test/java/org/apache/ignite/spark/examples/IgniteDataFrameSelfTest.java
@@ -21,15 +21,26 @@ import org.apache.ignite.examples.spark.IgniteCatalogExample;
 import org.apache.ignite.examples.spark.IgniteDataFrameExample;
 import org.apache.ignite.examples.spark.IgniteDataFrameJoinExample;
 import org.apache.ignite.examples.spark.IgniteDataFrameWriteExample;
+import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.junits.common.GridAbstractExamplesTest;
+import org.junit.BeforeClass;
 import org.junit.Test;
 
+import static org.apache.ignite.IgniteSystemProperties.IGNITE_OVERRIDE_MCAST_GRP;
+
 /**
  */
 public class IgniteDataFrameSelfTest extends GridAbstractExamplesTest {
     /** */
     static final String[] EMPTY_ARGS = new String[0];
 
+    /** */
+    @BeforeClass
+    public static void init() {
+        System.setProperty(IGNITE_OVERRIDE_MCAST_GRP,
+            GridTestUtils.getNextMulticastGroup(IgniteDataFrameSelfTest.class));
+    }
+
     /**
      * @throws Exception If failed.
      */
diff --git a/modules/spark-ext/examples/src/test/java/org/apache/ignite/spark/examples/JavaIgniteDataFrameSelfTest.java b/modules/spark-ext/examples/src/test/java/org/apache/ignite/spark/examples/JavaIgniteDataFrameSelfTest.java
index 0e0f6b26..c44b2ee0 100644
--- a/modules/spark-ext/examples/src/test/java/org/apache/ignite/spark/examples/JavaIgniteDataFrameSelfTest.java
+++ b/modules/spark-ext/examples/src/test/java/org/apache/ignite/spark/examples/JavaIgniteDataFrameSelfTest.java
@@ -21,15 +21,26 @@ import org.apache.ignite.examples.spark.JavaIgniteCatalogExample;
 import org.apache.ignite.examples.spark.JavaIgniteDataFrameExample;
 import org.apache.ignite.examples.spark.JavaIgniteDataFrameJoinExample;
 import org.apache.ignite.examples.spark.JavaIgniteDataFrameWriteExample;
+import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.junits.common.GridAbstractExamplesTest;
+import org.junit.BeforeClass;
 import org.junit.Test;
 
+import static org.apache.ignite.IgniteSystemProperties.IGNITE_OVERRIDE_MCAST_GRP;
+
 /**
  */
 public class JavaIgniteDataFrameSelfTest extends GridAbstractExamplesTest {
     /** */
     static final String[] EMPTY_ARGS = new String[0];
 
+    /** */
+    @BeforeClass
+    public static void init() {
+        System.setProperty(IGNITE_OVERRIDE_MCAST_GRP,
+            GridTestUtils.getNextMulticastGroup(JavaIgniteDataFrameSelfTest.class));
+    }
+
     /**
      * @throws Exception If failed.
      */
diff --git a/modules/spark-ext/examples/src/test/java/org/apache/ignite/spark/examples/SharedRDDExampleSelfTest.java b/modules/spark-ext/examples/src/test/java/org/apache/ignite/spark/examples/SharedRDDExampleSelfTest.java
index 300dfa87..224f84bc 100644
--- a/modules/spark-ext/examples/src/test/java/org/apache/ignite/spark/examples/SharedRDDExampleSelfTest.java
+++ b/modules/spark-ext/examples/src/test/java/org/apache/ignite/spark/examples/SharedRDDExampleSelfTest.java
@@ -18,10 +18,14 @@
 package org.apache.ignite.spark.examples;
 
 import org.apache.ignite.examples.spark.SharedRDDExample;
+import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.junits.common.GridAbstractExamplesTest;
+import org.junit.BeforeClass;
 import org.junit.Ignore;
 import org.junit.Test;
 
+import static org.apache.ignite.IgniteSystemProperties.IGNITE_OVERRIDE_MCAST_GRP;
+
 /**
  * SharedRDD  examples self test.
  */
@@ -29,6 +33,13 @@ public class SharedRDDExampleSelfTest extends GridAbstractExamplesTest {
     /** */
     static final String[] EMPTY_ARGS = new String[0];
 
+    /** */
+    @BeforeClass
+    public static void init() {
+        System.setProperty(IGNITE_OVERRIDE_MCAST_GRP,
+            GridTestUtils.getNextMulticastGroup(SharedRDDExampleSelfTest.class));
+    }
+
     /**
      * TODO: IGNITE-12054 Only one SparkContext may be running in this JVM (see SPARK-2243).
      * @throws Exception If failed.
diff --git a/modules/spark-ext/examples/src/test/java/org/apache/ignite/spark/testsuites/IgniteExamplesSparkSelfTestSuite.java b/modules/spark-ext/examples/src/test/java/org/apache/ignite/spark/testsuites/IgniteExamplesSparkSelfTestSuite.java
deleted file mode 100644
index 5b75bb11..00000000
--- a/modules/spark-ext/examples/src/test/java/org/apache/ignite/spark/testsuites/IgniteExamplesSparkSelfTestSuite.java
+++ /dev/null
@@ -1,48 +0,0 @@
-/*
- * 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.spark.testsuites;
-
-import org.apache.ignite.spark.examples.IgniteDataFrameSelfTest;
-import org.apache.ignite.spark.examples.JavaIgniteDataFrameSelfTest;
-import org.apache.ignite.spark.examples.SharedRDDExampleSelfTest;
-import org.apache.ignite.testframework.GridTestUtils;
-import org.junit.BeforeClass;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-import static org.apache.ignite.IgniteSystemProperties.IGNITE_OVERRIDE_MCAST_GRP;
-
-/**
- * Examples test suite.
- * <p>
- * Contains only Spring ignite examples tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    SharedRDDExampleSelfTest.class,
-    IgniteDataFrameSelfTest.class,
-    JavaIgniteDataFrameSelfTest.class,
-})
-public class IgniteExamplesSparkSelfTestSuite {
-    /** */
-    @BeforeClass
-    public static void init() {
-        System.setProperty(IGNITE_OVERRIDE_MCAST_GRP,
-            GridTestUtils.getNextMulticastGroup(IgniteExamplesSparkSelfTestSuite.class));
-    }
-}
diff --git a/modules/spark-ext/spark/src/test/java/org/apache/ignite/testsuites/IgniteRDDTestSuite.java b/modules/spark-ext/spark/src/test/java/org/apache/ignite/testsuites/IgniteRDDTestSuite.java
deleted file mode 100644
index bde086d7..00000000
--- a/modules/spark-ext/spark/src/test/java/org/apache/ignite/testsuites/IgniteRDDTestSuite.java
+++ /dev/null
@@ -1,36 +0,0 @@
-/*
- * 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.testsuites;
-
-import org.apache.ignite.spark.JavaEmbeddedIgniteRDDSelfTest;
-import org.apache.ignite.spark.JavaEmbeddedIgniteRDDWithLocalStoreSelfTest;
-import org.apache.ignite.spark.JavaStandaloneIgniteRDDSelfTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Test suit for Ignite RDD
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    JavaEmbeddedIgniteRDDSelfTest.class,
-    JavaStandaloneIgniteRDDSelfTest.class,
-    JavaEmbeddedIgniteRDDWithLocalStoreSelfTest.class
-})
-public class IgniteRDDTestSuite {
-}
diff --git a/modules/spark-ext/spark/src/test/scala/org/apache/ignite/spark/IgniteDataFrameSuite.scala b/modules/spark-ext/spark/src/test/scala/org/apache/ignite/spark/IgniteDataFrameSuite.scala
deleted file mode 100644
index 903acb43..00000000
--- a/modules/spark-ext/spark/src/test/scala/org/apache/ignite/spark/IgniteDataFrameSuite.scala
+++ /dev/null
@@ -1,46 +0,0 @@
-/*
- * 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.spark
-
-import org.apache.spark.sql.ignite.IgniteSparkSessionSpec
-import org.junit.runner.RunWith
-import org.scalatest.Suites
-import org.scalatestplus.junit.JUnitRunner
-
-/**
-  * Test suite for Spark DataFrame API implementation.
-  */
-@RunWith(classOf[JUnitRunner])
-class IgniteDataFrameSuite extends Suites (
-    new IgniteDataFrameSchemaSpec,
-    new IgniteSQLDataFrameSpec,
-    new IgniteSQLDataFrameWriteSpec,
-    new IgniteSQLDataFrameIgniteSessionWriteSpec,
-    new IgniteDataFrameWrongConfigSpec,
-    new IgniteCatalogSpec,
-    new IgniteOptimizationSpec,
-    new IgniteOptimizationStringFuncSpec,
-    new IgniteOptimizationMathFuncSpec,
-    new IgniteOptimizationAggregationFuncSpec,
-    new IgniteOptimizationSystemFuncSpec,
-    new IgniteOptimizationJoinSpec,
-    new IgniteOptimizationDateFuncSpec,
-    new IgniteOptimizationDisableEnableSpec,
-    new IgniteSparkSessionSpec,
-    new IgniteRDDSpec
-)
diff --git a/modules/spring-cache-ext/src/test/java/org/apache/ignite/testsuites/IgniteSpringCacheTestSuite.java b/modules/spring-cache-ext/src/test/java/org/apache/ignite/testsuites/IgniteSpringCacheTestSuite.java
deleted file mode 100644
index 560df16e..00000000
--- a/modules/spring-cache-ext/src/test/java/org/apache/ignite/testsuites/IgniteSpringCacheTestSuite.java
+++ /dev/null
@@ -1,44 +0,0 @@
-/*
- * 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.testsuites;
-
-import org.apache.ignite.cache.spring.GridSpringCacheManagerMultiJvmSelfTest;
-import org.apache.ignite.cache.spring.GridSpringCacheManagerSelfTest;
-import org.apache.ignite.cache.spring.GridSpringCacheManagerSpringBeanSelfTest;
-import org.apache.ignite.cache.spring.IgniteClientSpringCacheManagerTest;
-import org.apache.ignite.cache.spring.IgniteSpringCacheCompatibilityTest;
-import org.apache.ignite.cache.spring.SpringCacheManagerContextInjectionTest;
-import org.apache.ignite.cache.spring.SpringCacheTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Ignite Spring Cache tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    GridSpringCacheManagerSelfTest.class,
-    GridSpringCacheManagerSpringBeanSelfTest.class,
-    SpringCacheManagerContextInjectionTest.class,
-    SpringCacheTest.class,
-    GridSpringCacheManagerMultiJvmSelfTest.class,
-    IgniteClientSpringCacheManagerTest.class,
-    IgniteSpringCacheCompatibilityTest.class
-})
-public class IgniteSpringCacheTestSuite {
-}
diff --git a/modules/spring-data-ext/examples/src/test/java/org/apache/ignite/springdata/examples/IgniteSpringDataExamplesTestSuite.java b/modules/spring-data-ext/examples/src/test/java/org/apache/ignite/springdata/examples/IgniteSpringDataExamplesTestSuite.java
deleted file mode 100644
index 4777f033..00000000
--- a/modules/spring-data-ext/examples/src/test/java/org/apache/ignite/springdata/examples/IgniteSpringDataExamplesTestSuite.java
+++ /dev/null
@@ -1,29 +0,0 @@
-/*
- * 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.springdata.examples;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/** */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    SpringDataExampleTest.class
-})
-public class IgniteSpringDataExamplesTestSuite {
-}
diff --git a/modules/spring-data-ext/spring-data/src/test/java/org/apache/ignite/testsuites/IgniteSpringDataTestSuite.java b/modules/spring-data-ext/spring-data/src/test/java/org/apache/ignite/testsuites/IgniteSpringDataTestSuite.java
deleted file mode 100644
index 5eb926e0..00000000
--- a/modules/spring-data-ext/spring-data/src/test/java/org/apache/ignite/testsuites/IgniteSpringDataTestSuite.java
+++ /dev/null
@@ -1,48 +0,0 @@
-/*
- * 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.testsuites;
-
-import org.apache.ignite.springdata.IgniteClientSpringDataCompoundKeyTest;
-import org.apache.ignite.springdata.IgniteClientSpringDataCrudSelfTest;
-import org.apache.ignite.springdata.IgniteClientSpringDataQueriesSelfTest;
-import org.apache.ignite.springdata.IgniteSpringDataCompoundExtendedKeyTest;
-import org.apache.ignite.springdata.IgniteSpringDataCompoundKeyTest;
-import org.apache.ignite.springdata.IgniteSpringDataConnectionConfigurationTest;
-import org.apache.ignite.springdata.IgniteSpringDataCrudSelfExpressionTest;
-import org.apache.ignite.springdata.IgniteSpringDataCrudSelfTest;
-import org.apache.ignite.springdata.IgniteSpringDataQueriesSelfTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Ignite Spring Data test suite.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    IgniteSpringDataCrudSelfTest.class,
-    IgniteSpringDataQueriesSelfTest.class,
-    IgniteSpringDataCrudSelfExpressionTest.class,
-    IgniteSpringDataCompoundKeyTest.class,
-    IgniteSpringDataCompoundExtendedKeyTest.class,
-    IgniteSpringDataConnectionConfigurationTest.class,
-    IgniteClientSpringDataCrudSelfTest.class,
-    IgniteClientSpringDataQueriesSelfTest.class,
-    IgniteClientSpringDataCompoundKeyTest.class
-})
-public class IgniteSpringDataTestSuite {
-}
diff --git a/modules/spring-session-ext/src/test/java/org/apache/ignite/testsuites/IgniteSpringSessionTestSuite.java b/modules/spring-session-ext/src/test/java/org/apache/ignite/testsuites/IgniteSpringSessionTestSuite.java
deleted file mode 100644
index 0e10c8e6..00000000
--- a/modules/spring-session-ext/src/test/java/org/apache/ignite/testsuites/IgniteSpringSessionTestSuite.java
+++ /dev/null
@@ -1,36 +0,0 @@
-/*
- * 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.testsuites;
-
-import org.apache.ignite.spring.sessions.EmbeddedIgniteIndexedSessionRepositoryITest;
-import org.apache.ignite.spring.sessions.IgniteHttpSessionConfigurationTest;
-import org.apache.ignite.spring.sessions.IgniteIndexedSessionRepositoryTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Ignite Spring Session Test Suite
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    EmbeddedIgniteIndexedSessionRepositoryITest.class,
-    IgniteHttpSessionConfigurationTest.class,
-    IgniteIndexedSessionRepositoryTest.class
-})
-public class IgniteSpringSessionTestSuite {
-}
diff --git a/modules/spring-tx-ext/spring-tx/src/test/java/org/apache/ignite/testsuites/IgniteSpringTransactionsTestSuite.java b/modules/spring-tx-ext/spring-tx/src/test/java/org/apache/ignite/testsuites/IgniteSpringTransactionsTestSuite.java
deleted file mode 100644
index 643d71ee..00000000
--- a/modules/spring-tx-ext/spring-tx/src/test/java/org/apache/ignite/testsuites/IgniteSpringTransactionsTestSuite.java
+++ /dev/null
@@ -1,42 +0,0 @@
-/*
- * 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.testsuites;
-
-import org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListenerSelfTest;
-import org.apache.ignite.transactions.spring.GridSpringTransactionManagerSelfTest;
-import org.apache.ignite.transactions.spring.GridSpringTransactionManagerSpringBeanSelfTest;
-import org.apache.ignite.transactions.spring.IgniteClientSpringTransactionManagerTest;
-import org.apache.ignite.transactions.spring.IgniteSpringTransactionsCompatibilityTest;
-import org.apache.ignite.transactions.spring.SpringTransactionManagerContextInjectionTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Ignite Spring Transactions tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    GridSpringTransactionManagerSelfTest.class,
-    GridSpringTransactionManagerSpringBeanSelfTest.class,
-    IgniteClientSpringTransactionManagerTest.class,
-    SpringTransactionManagerContextInjectionTest.class,
-    CacheSpringStoreSessionListenerSelfTest.class,
-    IgniteSpringTransactionsCompatibilityTest.class
-})
-public class IgniteSpringTransactionsTestSuite {
-}
diff --git a/modules/storm-ext/src/test/java/org/apache/ignite/stream/storm/IgniteStormStreamerSelfTestSuite.java b/modules/storm-ext/src/test/java/org/apache/ignite/stream/storm/IgniteStormStreamerSelfTestSuite.java
deleted file mode 100644
index 94d44377..00000000
--- a/modules/storm-ext/src/test/java/org/apache/ignite/stream/storm/IgniteStormStreamerSelfTestSuite.java
+++ /dev/null
@@ -1,31 +0,0 @@
-/*
- * 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.stream.storm;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Apache Storm streamer tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    StormIgniteStreamerSelfTest.class
-})
-public class IgniteStormStreamerSelfTestSuite {
-}
diff --git a/modules/topology-validator-ext/src/test/java/org/apache/ignite/plugin/cache/IgniteCacheTopologyValidatorTestSuite.java b/modules/topology-validator-ext/src/test/java/org/apache/ignite/plugin/cache/IgniteCacheTopologyValidatorTestSuite.java
deleted file mode 100644
index 322da1fc..00000000
--- a/modules/topology-validator-ext/src/test/java/org/apache/ignite/plugin/cache/IgniteCacheTopologyValidatorTestSuite.java
+++ /dev/null
@@ -1,27 +0,0 @@
-/*
- * 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.plugin.cache;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/** Ignite topology validator test suite. */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({IgniteCacheTopologyValidatorTest.class})
-public class IgniteCacheTopologyValidatorTestSuite {
-}
diff --git a/modules/twitter-ext/src/test/java/org/apache/ignite/stream/twitter/IgniteTwitterStreamerTestSuite.java b/modules/twitter-ext/src/test/java/org/apache/ignite/stream/twitter/IgniteTwitterStreamerTestSuite.java
deleted file mode 100644
index 5234af76..00000000
--- a/modules/twitter-ext/src/test/java/org/apache/ignite/stream/twitter/IgniteTwitterStreamerTestSuite.java
+++ /dev/null
@@ -1,31 +0,0 @@
-/*
- * 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.stream.twitter;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Twitter streamer tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    IgniteTwitterStreamerTest.class
-})
-public class IgniteTwitterStreamerTestSuite {
-}
diff --git a/modules/yarn-ext/src/test/java/org/apache/ignite/IgniteYarnTestSuite.java b/modules/yarn-ext/src/test/java/org/apache/ignite/IgniteYarnTestSuite.java
deleted file mode 100644
index 9bc5c280..00000000
--- a/modules/yarn-ext/src/test/java/org/apache/ignite/IgniteYarnTestSuite.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/*
- * 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;
-
-import org.apache.ignite.yarn.IgniteApplicationMasterSelfTest;
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Apache Hadoop Yarn integration tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    IgniteApplicationMasterSelfTest.class
-})
-public class IgniteYarnTestSuite {
-}
diff --git a/modules/zeromq-ext/src/test/java/org/apache/ignite/stream/zeromq/IgniteZeroMqStreamerTestSuite.java b/modules/zeromq-ext/src/test/java/org/apache/ignite/stream/zeromq/IgniteZeroMqStreamerTestSuite.java
deleted file mode 100644
index 93f4f477..00000000
--- a/modules/zeromq-ext/src/test/java/org/apache/ignite/stream/zeromq/IgniteZeroMqStreamerTestSuite.java
+++ /dev/null
@@ -1,31 +0,0 @@
-/*
- * 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.stream.zeromq;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * ZeroMQ streamer tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    IgniteZeroMqStreamerTest.class
-})
-public class IgniteZeroMqStreamerTestSuite {
-}
diff --git a/modules/zookeeper-ip-finder-ext/zookeeper-ip-finder/examples/pom.xml b/modules/zookeeper-ip-finder-ext/zookeeper-ip-finder/examples/pom.xml
deleted file mode 100644
index 0c7476db..00000000
--- a/modules/zookeeper-ip-finder-ext/zookeeper-ip-finder/examples/pom.xml
+++ /dev/null
@@ -1,50 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-
-<!--
-  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.
--->
-
-<!--
-    POM file.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0"
-         xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-    <modelVersion>4.0.0</modelVersion>
-
-    <parent>
-        <groupId>org.apache.ignite</groupId>
-        <artifactId>ignite-zookeeper-ip-finder-parent</artifactId>
-        <version>${revision}</version>
-        <relativePath>../parent/pom.xml</relativePath>
-    </parent>
-
-    <artifactId>ignite-zookeeper-ip-finder-ext-examples</artifactId>
-
-    <dependencies>
-        <dependency>
-            <groupId>org.apache.ignite</groupId>
-            <artifactId>ignite-core</artifactId>
-            <version>${ignite.version}</version>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.ignite</groupId>
-            <artifactId>ignite-zookeeper-ip-finder-ext</artifactId>
-            <version>${revision}</version>
-        </dependency>
-    </dependencies>
-</project>
diff --git a/modules/zookeeper-ip-finder-ext/zookeeper-ip-finder/examples/src/main/java/ZookeeperIpFinderExample.java b/modules/zookeeper-ip-finder-ext/zookeeper-ip-finder/examples/src/main/java/ZookeeperIpFinderExample.java
deleted file mode 100644
index ff56ef2c..00000000
--- a/modules/zookeeper-ip-finder-ext/zookeeper-ip-finder/examples/src/main/java/ZookeeperIpFinderExample.java
+++ /dev/null
@@ -1,74 +0,0 @@
-/*
- * 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.
- */
-
-import java.util.stream.Collectors;
-import org.apache.ignite.Ignite;
-import org.apache.ignite.Ignition;
-import org.apache.ignite.cluster.ClusterNode;
-import org.apache.ignite.configuration.IgniteConfiguration;
-import org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder;
-
-/**
- * This example demonstrates starting Ignite cluster with configured {@link TcpDiscoveryZookeeperIpFinder}
- * to discover other nodes.
- * <p>
- * To start the example, you should:
- * <ol>
- *  <li>Start Apache ZooKeeper. See <a href="https://zookeeper.apache.org">Apache ZooKeeper</a>.</li>
- *  <li>Make sure that the Apache ZooKeeper connection string is correct. See {@link ZK_CONNECT_STRING}.</li>
- *  <li>Start example using {@link ZookeeperIpFinderExample}.</li>
- * </ol>
- */
-public class ZookeeperIpFinderExample {
-    /** The Apache ZooKeeper connection string. Comma separated host:port pairs, each corresponding to a zk server. */
-    private static final String ZK_CONNECT_STRING = "localhost:2181";
-
-    /**
-     * Start example.
-     *
-     * @param args Command line arguments, none required.
-     */
-    public static void main(String[] args) {
-        try (Ignite server1 = Ignition.start(configuration("server1"));
-             Ignite server2 =  Ignition.start(configuration("server2"))) {
-            System.out.println();
-            System.out.println("Zookeeper Ip Finder example started.");
-
-            System.out.println();
-            System.out.format(">>> Nodes identifiers [%s].\n",
-                server1.cluster().nodes().stream().map(ClusterNode::id).collect(Collectors.toList()));
-        }
-    }
-
-    /**
-     * Returns a new instance of Ignite configuration.
-     *
-     * @param igniteInstanceName Ignite instance name.
-     */
-    private static IgniteConfiguration configuration(String igniteInstanceName) {
-        IgniteConfiguration cfg = new IgniteConfiguration();
-
-        cfg.setDiscoverySpi(new TcpDiscoverySpi()
-            .setIpFinder(new TcpDiscoveryZookeeperIpFinder()
-                .setZkConnectionString(ZK_CONNECT_STRING)));
-
-        cfg.setIgniteInstanceName(igniteInstanceName);
-
-        return cfg;
-    }
-}
diff --git a/modules/zookeeper-ip-finder-ext/zookeeper-ip-finder/pom.xml b/modules/zookeeper-ip-finder-ext/zookeeper-ip-finder/pom.xml
index a8e76f11..1999a854 100644
--- a/modules/zookeeper-ip-finder-ext/zookeeper-ip-finder/pom.xml
+++ b/modules/zookeeper-ip-finder-ext/zookeeper-ip-finder/pom.xml
@@ -131,6 +131,12 @@
             <artifactId>curator-test</artifactId>
             <version>${curator.version}</version>
             <scope>test</scope>
+            <exclusions>
+                <exclusion>
+                    <groupId>org.junit.jupiter</groupId>
+                    <artifactId>junit-jupiter-api</artifactId>
+                </exclusion>
+            </exclusions>
         </dependency>
 
         <dependency>
diff --git a/modules/zookeeper-ip-finder-ext/zookeeper-ip-finder/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/zk/ZookeeperIpFinderTestSuite.java b/modules/zookeeper-ip-finder-ext/zookeeper-ip-finder/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/zk/ZookeeperIpFinderTestSuite.java
deleted file mode 100644
index a5b6d8fa..00000000
--- a/modules/zookeeper-ip-finder-ext/zookeeper-ip-finder/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/zk/ZookeeperIpFinderTestSuite.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/*
- * 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.spi.discovery.tcp.ipfinder.zk;
-
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
-
-/**
- * Zookeeper IP Finder tests.
- */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    ZookeeperIpFinderTest.class
-})
-public class ZookeeperIpFinderTestSuite {
-
-}