You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@shardingsphere.apache.org by su...@apache.org on 2022/12/05 12:54:57 UTC

[shardingsphere] branch master updated: Rename package name of scaling test (#22676)

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

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


The following commit(s) were added to refs/heads/master by this push:
     new 03b77b2f921 Rename package name of scaling test (#22676)
03b77b2f921 is described below

commit 03b77b2f921005a1fbd8b268bc8967f9ee0f864a
Author: Liang Zhang <zh...@apache.org>
AuthorDate: Mon Dec 5 20:54:51 2022 +0800

    Rename package name of scaling test (#22676)
    
    * Rename package name of fixture test
    
    * Rename package name of scaling test
---
 .../e2e}/data/pipeline/cases/base/BaseITCase.java  | 18 +++++------
 .../pipeline/cases/base/BaseIncrementTask.java     |  2 +-
 .../createtable/CreateTableSQLGeneratorIT.java     | 16 +++++-----
 .../cases/migration/AbstractMigrationITCase.java   | 10 +++---
 .../migration/general/MySQLMigrationGeneralIT.java | 19 ++++++------
 .../general/PostgreSQLMigrationGeneralIT.java      | 36 ++++++++++++----------
 .../primarykey/TextPrimaryKeyMigrationIT.java      | 21 +++++++------
 .../pipeline/cases/task/MySQLIncrementTask.java    |  6 ++--
 .../cases/task/PostgreSQLIncrementTask.java        |  6 ++--
 .../data/pipeline/command/ExtraSQLCommand.java     |  2 +-
 .../pipeline/command/MigrationDistSQLCommand.java  |  2 +-
 .../CreateTableSQLGeneratorAssertionEntity.java    |  2 +-
 ...reateTableSQLGeneratorAssertionsRootEntity.java |  2 +-
 .../entity/CreateTableSQLGeneratorInputEntity.java |  2 +-
 .../CreateTableSQLGeneratorOutputEntity.java       |  2 +-
 .../pipeline/env/IntegrationTestEnvironment.java   |  4 +--
 .../data/pipeline/env/enums/ITEnvTypeEnum.java     |  2 +-
 .../container/compose/BaseContainerComposer.java   |  2 +-
 .../container/compose/DockerContainerComposer.java |  6 ++--
 .../container/compose/NativeContainerComposer.java |  4 +--
 ...gProxyClusterContainerConfigurationFactory.java |  2 +-
 .../framework/helper/ScalingCaseHelper.java        |  4 +--
 .../framework/param/ScalingParameterized.java      |  2 +-
 .../pipeline/framework/watcher/ScalingWatcher.java |  8 ++---
 .../data/pipeline/logger/PipelineLoggerFilter.java |  2 +-
 .../util/AutoIncrementKeyGenerateAlgorithm.java    |  2 +-
 .../data/pipeline/util/DockerImageVersion.java     |  2 +-
 .../scaling/src/test/resources/logback-test.xml    |  2 +-
 28 files changed, 96 insertions(+), 92 deletions(-)

diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/base/BaseITCase.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/base/BaseITCase.java
similarity index 94%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/base/BaseITCase.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/base/BaseITCase.java
index 4eaf5f6b404..a909bff60d6 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/base/BaseITCase.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/base/BaseITCase.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.cases.base;
+package org.apache.shardingsphere.test.e2e.data.pipeline.cases.base;
 
 import com.google.common.base.Strings;
 import lombok.AccessLevel;
@@ -26,14 +26,14 @@ import org.apache.shardingsphere.data.pipeline.api.job.JobStatus;
 import org.apache.shardingsphere.data.pipeline.core.util.ThreadUtil;
 import org.apache.shardingsphere.infra.database.metadata.url.JdbcUrlAppender;
 import org.apache.shardingsphere.infra.database.type.DatabaseType;
-import org.apache.shardingsphere.integration.data.pipeline.command.ExtraSQLCommand;
-import org.apache.shardingsphere.integration.data.pipeline.env.IntegrationTestEnvironment;
-import org.apache.shardingsphere.integration.data.pipeline.env.enums.ITEnvTypeEnum;
-import org.apache.shardingsphere.integration.data.pipeline.framework.container.compose.BaseContainerComposer;
-import org.apache.shardingsphere.integration.data.pipeline.framework.container.compose.DockerContainerComposer;
-import org.apache.shardingsphere.integration.data.pipeline.framework.container.compose.NativeContainerComposer;
-import org.apache.shardingsphere.integration.data.pipeline.framework.param.ScalingParameterized;
-import org.apache.shardingsphere.integration.data.pipeline.framework.watcher.ScalingWatcher;
+import org.apache.shardingsphere.test.e2e.data.pipeline.command.ExtraSQLCommand;
+import org.apache.shardingsphere.test.e2e.data.pipeline.env.IntegrationTestEnvironment;
+import org.apache.shardingsphere.test.e2e.data.pipeline.env.enums.ITEnvTypeEnum;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.container.compose.BaseContainerComposer;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.container.compose.DockerContainerComposer;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.container.compose.NativeContainerComposer;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.param.ScalingParameterized;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.watcher.ScalingWatcher;
 import org.apache.shardingsphere.test.e2e.env.container.atomic.constants.ProxyContainerConstants;
 import org.apache.shardingsphere.test.e2e.env.container.atomic.storage.DockerStorageContainer;
 import org.apache.shardingsphere.test.e2e.env.container.atomic.util.DatabaseTypeUtil;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/base/BaseIncrementTask.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/base/BaseIncrementTask.java
similarity index 92%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/base/BaseIncrementTask.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/base/BaseIncrementTask.java
index c1d85b5e40f..344f53c23f9 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/base/BaseIncrementTask.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/base/BaseIncrementTask.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.cases.base;
+package org.apache.shardingsphere.test.e2e.data.pipeline.cases.base;
 
 public abstract class BaseIncrementTask implements Runnable {
     
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/createtable/CreateTableSQLGeneratorIT.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/createtable/CreateTableSQLGeneratorIT.java
similarity index 90%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/createtable/CreateTableSQLGeneratorIT.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/createtable/CreateTableSQLGeneratorIT.java
index bb4a0802767..9ddc114a377 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/createtable/CreateTableSQLGeneratorIT.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/createtable/CreateTableSQLGeneratorIT.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.cases.createtable;
+package org.apache.shardingsphere.test.e2e.data.pipeline.cases.createtable;
 
 import lombok.extern.slf4j.Slf4j;
 import org.apache.shardingsphere.data.pipeline.spi.ddlgenerator.CreateTableSQLGeneratorFactory;
@@ -23,13 +23,13 @@ import org.apache.shardingsphere.infra.database.type.DatabaseType;
 import org.apache.shardingsphere.infra.database.type.dialect.MySQLDatabaseType;
 import org.apache.shardingsphere.infra.database.type.dialect.OpenGaussDatabaseType;
 import org.apache.shardingsphere.infra.database.type.dialect.PostgreSQLDatabaseType;
-import org.apache.shardingsphere.integration.data.pipeline.entity.CreateTableSQLGeneratorAssertionEntity;
-import org.apache.shardingsphere.integration.data.pipeline.entity.CreateTableSQLGeneratorAssertionsRootEntity;
-import org.apache.shardingsphere.integration.data.pipeline.entity.CreateTableSQLGeneratorOutputEntity;
-import org.apache.shardingsphere.integration.data.pipeline.env.IntegrationTestEnvironment;
-import org.apache.shardingsphere.integration.data.pipeline.env.enums.ITEnvTypeEnum;
-import org.apache.shardingsphere.integration.data.pipeline.framework.param.ScalingParameterized;
-import org.apache.shardingsphere.integration.data.pipeline.util.DockerImageVersion;
+import org.apache.shardingsphere.test.e2e.data.pipeline.entity.CreateTableSQLGeneratorAssertionEntity;
+import org.apache.shardingsphere.test.e2e.data.pipeline.entity.CreateTableSQLGeneratorAssertionsRootEntity;
+import org.apache.shardingsphere.test.e2e.data.pipeline.entity.CreateTableSQLGeneratorOutputEntity;
+import org.apache.shardingsphere.test.e2e.data.pipeline.env.IntegrationTestEnvironment;
+import org.apache.shardingsphere.test.e2e.data.pipeline.env.enums.ITEnvTypeEnum;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.param.ScalingParameterized;
+import org.apache.shardingsphere.test.e2e.data.pipeline.util.DockerImageVersion;
 import org.apache.shardingsphere.test.e2e.env.container.atomic.constants.StorageContainerConstants;
 import org.apache.shardingsphere.test.e2e.env.container.atomic.storage.DockerStorageContainer;
 import org.apache.shardingsphere.test.e2e.env.container.atomic.storage.StorageContainerFactory;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/migration/AbstractMigrationITCase.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/AbstractMigrationITCase.java
similarity index 95%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/migration/AbstractMigrationITCase.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/AbstractMigrationITCase.java
index 02f17daa4bd..9357d12c1e2 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/migration/AbstractMigrationITCase.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/AbstractMigrationITCase.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.cases.migration;
+package org.apache.shardingsphere.test.e2e.data.pipeline.cases.migration;
 
 import com.google.common.base.Strings;
 import lombok.Getter;
 import lombok.extern.slf4j.Slf4j;
 import org.apache.shardingsphere.data.pipeline.core.util.ThreadUtil;
-import org.apache.shardingsphere.integration.data.pipeline.cases.base.BaseITCase;
-import org.apache.shardingsphere.integration.data.pipeline.command.MigrationDistSQLCommand;
-import org.apache.shardingsphere.integration.data.pipeline.env.enums.ITEnvTypeEnum;
-import org.apache.shardingsphere.integration.data.pipeline.framework.param.ScalingParameterized;
+import org.apache.shardingsphere.test.e2e.data.pipeline.cases.base.BaseITCase;
+import org.apache.shardingsphere.test.e2e.data.pipeline.command.MigrationDistSQLCommand;
+import org.apache.shardingsphere.test.e2e.data.pipeline.env.enums.ITEnvTypeEnum;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.param.ScalingParameterized;
 import org.apache.shardingsphere.test.e2e.env.container.atomic.util.DatabaseTypeUtil;
 import org.opengauss.util.PSQLException;
 
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/migration/general/MySQLMigrationGeneralIT.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/general/MySQLMigrationGeneralIT.java
similarity index 85%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/migration/general/MySQLMigrationGeneralIT.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/general/MySQLMigrationGeneralIT.java
index 73f9a39aad4..a7a18fcab28 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/migration/general/MySQLMigrationGeneralIT.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/general/MySQLMigrationGeneralIT.java
@@ -15,17 +15,18 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.cases.migration.general;
+package org.apache.shardingsphere.test.e2e.data.pipeline.cases.migration.general;
 
 import lombok.extern.slf4j.Slf4j;
 import org.apache.commons.lang3.tuple.Pair;
 import org.apache.shardingsphere.infra.database.type.dialect.MySQLDatabaseType;
-import org.apache.shardingsphere.integration.data.pipeline.cases.migration.AbstractMigrationITCase;
-import org.apache.shardingsphere.integration.data.pipeline.cases.task.MySQLIncrementTask;
-import org.apache.shardingsphere.integration.data.pipeline.env.enums.ITEnvTypeEnum;
-import org.apache.shardingsphere.integration.data.pipeline.framework.helper.ScalingCaseHelper;
-import org.apache.shardingsphere.integration.data.pipeline.framework.param.ScalingParameterized;
+import org.apache.shardingsphere.test.e2e.data.pipeline.cases.migration.AbstractMigrationITCase;
+import org.apache.shardingsphere.test.e2e.data.pipeline.cases.task.MySQLIncrementTask;
+import org.apache.shardingsphere.test.e2e.data.pipeline.env.enums.ITEnvTypeEnum;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.helper.ScalingCaseHelper;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.param.ScalingParameterized;
 import org.apache.shardingsphere.sharding.algorithm.keygen.SnowflakeKeyGenerateAlgorithm;
+import org.apache.shardingsphere.test.e2e.data.pipeline.cases.base.BaseITCase;
 import org.junit.Test;
 import org.junit.runner.RunWith;
 import org.junit.runners.Parameterized;
@@ -61,11 +62,11 @@ public final class MySQLMigrationGeneralIT extends AbstractMigrationITCase {
     @Parameters(name = "{0}")
     public static Collection<ScalingParameterized> getParameters() {
         Collection<ScalingParameterized> result = new LinkedList<>();
-        if (ENV.getItEnvType() == ITEnvTypeEnum.NONE) {
+        if (BaseITCase.ENV.getItEnvType() == ITEnvTypeEnum.NONE) {
             return result;
         }
         MySQLDatabaseType databaseType = new MySQLDatabaseType();
-        for (String each : ENV.listStorageContainerImages(databaseType)) {
+        for (String each : BaseITCase.ENV.listStorageContainerImages(databaseType)) {
             result.add(new ScalingParameterized(databaseType, each, "env/scenario/general/mysql.xml"));
         }
         return result;
@@ -106,7 +107,7 @@ public final class MySQLMigrationGeneralIT extends AbstractMigrationITCase {
         }
         List<String> lastJobIds = listJobId();
         assertThat(lastJobIds.size(), is(0));
-        assertGreaterThanOrderTableInitRows(TABLE_INIT_ROW_COUNT, "");
+        assertGreaterThanOrderTableInitRows(BaseITCase.TABLE_INIT_ROW_COUNT, "");
     }
     
     private void assertMigrationSuccessById(final String jobId, final String algorithmType) throws SQLException, InterruptedException {
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/migration/general/PostgreSQLMigrationGeneralIT.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/general/PostgreSQLMigrationGeneralIT.java
similarity index 75%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/migration/general/PostgreSQLMigrationGeneralIT.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/general/PostgreSQLMigrationGeneralIT.java
index 54de9982287..2db81bf8670 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/migration/general/PostgreSQLMigrationGeneralIT.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/general/PostgreSQLMigrationGeneralIT.java
@@ -15,18 +15,19 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.cases.migration.general;
+package org.apache.shardingsphere.test.e2e.data.pipeline.cases.migration.general;
 
 import lombok.extern.slf4j.Slf4j;
 import org.apache.commons.lang3.tuple.Pair;
 import org.apache.shardingsphere.infra.database.type.dialect.OpenGaussDatabaseType;
 import org.apache.shardingsphere.infra.database.type.dialect.PostgreSQLDatabaseType;
-import org.apache.shardingsphere.integration.data.pipeline.cases.migration.AbstractMigrationITCase;
-import org.apache.shardingsphere.integration.data.pipeline.cases.task.PostgreSQLIncrementTask;
-import org.apache.shardingsphere.integration.data.pipeline.env.enums.ITEnvTypeEnum;
-import org.apache.shardingsphere.integration.data.pipeline.framework.helper.ScalingCaseHelper;
-import org.apache.shardingsphere.integration.data.pipeline.framework.param.ScalingParameterized;
+import org.apache.shardingsphere.test.e2e.data.pipeline.cases.migration.AbstractMigrationITCase;
+import org.apache.shardingsphere.test.e2e.data.pipeline.cases.task.PostgreSQLIncrementTask;
+import org.apache.shardingsphere.test.e2e.data.pipeline.env.enums.ITEnvTypeEnum;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.helper.ScalingCaseHelper;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.param.ScalingParameterized;
 import org.apache.shardingsphere.sharding.algorithm.keygen.SnowflakeKeyGenerateAlgorithm;
+import org.apache.shardingsphere.test.e2e.data.pipeline.cases.base.BaseITCase;
 import org.junit.Test;
 import org.junit.runner.RunWith;
 import org.junit.runners.Parameterized;
@@ -65,13 +66,13 @@ public final class PostgreSQLMigrationGeneralIT extends AbstractMigrationITCase
     @Parameters(name = "{0}")
     public static Collection<ScalingParameterized> getParameters() {
         Collection<ScalingParameterized> result = new LinkedList<>();
-        if (ENV.getItEnvType() == ITEnvTypeEnum.NONE) {
+        if (BaseITCase.ENV.getItEnvType() == ITEnvTypeEnum.NONE) {
             return result;
         }
-        for (String each : ENV.listStorageContainerImages(new PostgreSQLDatabaseType())) {
+        for (String each : BaseITCase.ENV.listStorageContainerImages(new PostgreSQLDatabaseType())) {
             result.add(new ScalingParameterized(new PostgreSQLDatabaseType(), each, "env/scenario/general/postgresql.xml"));
         }
-        for (String each : ENV.listStorageContainerImages(new OpenGaussDatabaseType())) {
+        for (String each : BaseITCase.ENV.listStorageContainerImages(new OpenGaussDatabaseType())) {
             result.add(new ScalingParameterized(new OpenGaussDatabaseType(), each, "env/scenario/general/postgresql.xml"));
         }
         return result;
@@ -80,16 +81,16 @@ public final class PostgreSQLMigrationGeneralIT extends AbstractMigrationITCase
     @Test
     public void assertMigrationSuccess() throws SQLException, InterruptedException {
         addMigrationProcessConfig();
-        createSourceSchema(SCHEMA_NAME);
+        createSourceSchema(BaseITCase.SCHEMA_NAME);
         createSourceOrderTable();
         createSourceOrderItemTable();
-        createSourceTableIndexList(SCHEMA_NAME);
-        createSourceCommentOnList(SCHEMA_NAME);
+        createSourceTableIndexList(BaseITCase.SCHEMA_NAME);
+        createSourceCommentOnList(BaseITCase.SCHEMA_NAME);
         addMigrationSourceResource();
         addMigrationTargetResource();
         createTargetOrderTableRule();
         createTargetOrderItemTableRule();
-        Pair<List<Object[]>, List<Object[]>> dataPair = ScalingCaseHelper.generateFullInsertData(parameterized.getDatabaseType(), TABLE_INIT_ROW_COUNT);
+        Pair<List<Object[]>, List<Object[]>> dataPair = ScalingCaseHelper.generateFullInsertData(parameterized.getDatabaseType(), BaseITCase.TABLE_INIT_ROW_COUNT);
         JdbcTemplate jdbcTemplate = new JdbcTemplate(getSourceDataSource());
         log.info("init data begin: {}", LocalDateTime.now());
         jdbcTemplate.batchUpdate(getExtraSQLCommand().getFullInsertOrder(getSourceTableOrderName()), dataPair.getLeft());
@@ -102,21 +103,22 @@ public final class PostgreSQLMigrationGeneralIT extends AbstractMigrationITCase
         }
         List<String> lastJobIds = listJobId();
         assertThat(lastJobIds.size(), is(0));
-        assertGreaterThanOrderTableInitRows(TABLE_INIT_ROW_COUNT, SCHEMA_NAME);
+        assertGreaterThanOrderTableInitRows(BaseITCase.TABLE_INIT_ROW_COUNT, BaseITCase.SCHEMA_NAME);
     }
     
     private void checkOrderMigration(final JdbcTemplate jdbcTemplate) throws SQLException, InterruptedException {
         startMigrationWithSchema(getSourceTableOrderName(), "t_order");
-        startIncrementTask(new PostgreSQLIncrementTask(jdbcTemplate, SCHEMA_NAME, getSourceTableOrderName(), 20));
+        startIncrementTask(new PostgreSQLIncrementTask(jdbcTemplate, BaseITCase.SCHEMA_NAME, getSourceTableOrderName(), 20));
         String jobId = getJobIdByTableName(getSourceTableOrderName());
         waitIncrementTaskFinished(String.format("SHOW MIGRATION STATUS '%s'", jobId));
         stopMigrationByJobId(jobId);
         long recordId = new SnowflakeKeyGenerateAlgorithm().generateKey();
-        sourceExecuteWithLog(String.format("INSERT INTO %s (order_id,user_id,status) VALUES (%s, %s, '%s')", String.join(".", SCHEMA_NAME, getSourceTableOrderName()), recordId, 1, "afterStop"));
+        sourceExecuteWithLog(
+                String.format("INSERT INTO %s (order_id,user_id,status) VALUES (%s, %s, '%s')", String.join(".", BaseITCase.SCHEMA_NAME, getSourceTableOrderName()), recordId, 1, "afterStop"));
         startMigrationByJobId(jobId);
         // must refresh firstly, otherwise proxy can't get schema and table info
         proxyExecuteWithLog("REFRESH TABLE METADATA;", 2);
-        assertProxyOrderRecordExist(recordId, String.join(".", SCHEMA_NAME, getTargetTableOrderName()));
+        assertProxyOrderRecordExist(recordId, String.join(".", BaseITCase.SCHEMA_NAME, getTargetTableOrderName()));
         assertCheckMigrationSuccess(jobId, "DATA_MATCH");
     }
     
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/migration/primarykey/TextPrimaryKeyMigrationIT.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/primarykey/TextPrimaryKeyMigrationIT.java
similarity index 83%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/migration/primarykey/TextPrimaryKeyMigrationIT.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/primarykey/TextPrimaryKeyMigrationIT.java
index abcbec62c26..d3dc08fc77e 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/migration/primarykey/TextPrimaryKeyMigrationIT.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/primarykey/TextPrimaryKeyMigrationIT.java
@@ -15,16 +15,17 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.cases.migration.primarykey;
+package org.apache.shardingsphere.test.e2e.data.pipeline.cases.migration.primarykey;
 
 import lombok.extern.slf4j.Slf4j;
 import org.apache.shardingsphere.infra.database.type.dialect.MySQLDatabaseType;
 import org.apache.shardingsphere.infra.database.type.dialect.OpenGaussDatabaseType;
 import org.apache.shardingsphere.infra.database.type.dialect.PostgreSQLDatabaseType;
-import org.apache.shardingsphere.integration.data.pipeline.cases.migration.AbstractMigrationITCase;
-import org.apache.shardingsphere.integration.data.pipeline.env.enums.ITEnvTypeEnum;
-import org.apache.shardingsphere.integration.data.pipeline.framework.param.ScalingParameterized;
+import org.apache.shardingsphere.test.e2e.data.pipeline.cases.migration.AbstractMigrationITCase;
+import org.apache.shardingsphere.test.e2e.data.pipeline.env.enums.ITEnvTypeEnum;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.param.ScalingParameterized;
 import org.apache.shardingsphere.sharding.algorithm.keygen.UUIDKeyGenerateAlgorithm;
+import org.apache.shardingsphere.test.e2e.data.pipeline.cases.base.BaseITCase;
 import org.apache.shardingsphere.test.e2e.env.container.atomic.util.DatabaseTypeUtil;
 import org.junit.Test;
 import org.junit.runner.RunWith;
@@ -63,17 +64,17 @@ public class TextPrimaryKeyMigrationIT extends AbstractMigrationITCase {
     @Parameters(name = "{0}")
     public static Collection<ScalingParameterized> getParameters() {
         Collection<ScalingParameterized> result = new LinkedList<>();
-        if (ENV.getItEnvType() == ITEnvTypeEnum.NONE) {
+        if (BaseITCase.ENV.getItEnvType() == ITEnvTypeEnum.NONE) {
             return result;
         }
-        for (String version : ENV.listStorageContainerImages(new MySQLDatabaseType())) {
+        for (String version : BaseITCase.ENV.listStorageContainerImages(new MySQLDatabaseType())) {
             result.add(new ScalingParameterized(new MySQLDatabaseType(), version, "env/scenario/primary_key/text_primary_key/mysql.xml"));
             result.add(new ScalingParameterized(new MySQLDatabaseType(), version, "env/scenario/primary_key/unique_key/mysql.xml"));
         }
-        for (String version : ENV.listStorageContainerImages(new PostgreSQLDatabaseType())) {
+        for (String version : BaseITCase.ENV.listStorageContainerImages(new PostgreSQLDatabaseType())) {
             result.add(new ScalingParameterized(new PostgreSQLDatabaseType(), version, "env/scenario/primary_key/text_primary_key/postgresql.xml"));
         }
-        for (String version : ENV.listStorageContainerImages(new OpenGaussDatabaseType())) {
+        for (String version : BaseITCase.ENV.listStorageContainerImages(new OpenGaussDatabaseType())) {
             result.add(new ScalingParameterized(new OpenGaussDatabaseType(), version, "env/scenario/primary_key/text_primary_key/postgresql.xml"));
         }
         return result;
@@ -92,7 +93,7 @@ public class TextPrimaryKeyMigrationIT extends AbstractMigrationITCase {
         sourceExecuteWithLog(String.format("INSERT INTO %s (order_id,user_id,status) VALUES (%s, %s, '%s')", getSourceTableOrderName(), "1000000000", 1, "afterStop"));
         waitIncrementTaskFinished(String.format("SHOW MIGRATION STATUS '%s'", jobId));
         assertCheckMigrationSuccess(jobId, "DATA_MATCH");
-        if (ENV.getItEnvType() == ITEnvTypeEnum.DOCKER) {
+        if (BaseITCase.ENV.getItEnvType() == ITEnvTypeEnum.DOCKER) {
             commitMigrationByJobId(jobId);
             List<String> lastJobIds = listJobId();
             assertThat(lastJobIds.size(), is(0));
@@ -104,7 +105,7 @@ public class TextPrimaryKeyMigrationIT extends AbstractMigrationITCase {
         UUIDKeyGenerateAlgorithm keyGenerateAlgorithm = new UUIDKeyGenerateAlgorithm();
         try (Connection connection = getSourceDataSource().getConnection()) {
             PreparedStatement preparedStatement = connection.prepareStatement(String.format("INSERT INTO %s (order_id,user_id,status) VALUES (?,?,?)", getSourceTableOrderName()));
-            for (int i = 0; i < TABLE_INIT_ROW_COUNT * 2; i++) {
+            for (int i = 0; i < BaseITCase.TABLE_INIT_ROW_COUNT * 2; i++) {
                 preparedStatement.setObject(1, keyGenerateAlgorithm.generateKey());
                 preparedStatement.setObject(2, ThreadLocalRandom.current().nextInt(0, 6));
                 preparedStatement.setObject(3, "OK");
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/task/MySQLIncrementTask.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/task/MySQLIncrementTask.java
similarity index 94%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/task/MySQLIncrementTask.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/task/MySQLIncrementTask.java
index 9879c4181b5..03e013be3ee 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/task/MySQLIncrementTask.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/task/MySQLIncrementTask.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.cases.task;
+package org.apache.shardingsphere.test.e2e.data.pipeline.cases.task;
 
 import lombok.RequiredArgsConstructor;
 import lombok.extern.slf4j.Slf4j;
 import org.apache.commons.lang3.RandomStringUtils;
-import org.apache.shardingsphere.integration.data.pipeline.cases.base.BaseIncrementTask;
-import org.apache.shardingsphere.integration.data.pipeline.framework.helper.ScalingCaseHelper;
+import org.apache.shardingsphere.test.e2e.data.pipeline.cases.base.BaseIncrementTask;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.helper.ScalingCaseHelper;
 import org.apache.shardingsphere.sharding.spi.KeyGenerateAlgorithm;
 import org.springframework.jdbc.core.JdbcTemplate;
 
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/task/PostgreSQLIncrementTask.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/task/PostgreSQLIncrementTask.java
similarity index 94%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/task/PostgreSQLIncrementTask.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/task/PostgreSQLIncrementTask.java
index 32b5ef8e7b4..c5794304d6e 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/cases/task/PostgreSQLIncrementTask.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/task/PostgreSQLIncrementTask.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.cases.task;
+package org.apache.shardingsphere.test.e2e.data.pipeline.cases.task;
 
 import com.google.common.base.Strings;
 import lombok.RequiredArgsConstructor;
 import lombok.extern.slf4j.Slf4j;
-import org.apache.shardingsphere.integration.data.pipeline.cases.base.BaseIncrementTask;
-import org.apache.shardingsphere.integration.data.pipeline.framework.helper.ScalingCaseHelper;
+import org.apache.shardingsphere.test.e2e.data.pipeline.cases.base.BaseIncrementTask;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.helper.ScalingCaseHelper;
 import org.apache.shardingsphere.sharding.algorithm.keygen.SnowflakeKeyGenerateAlgorithm;
 import org.apache.shardingsphere.sharding.spi.KeyGenerateAlgorithm;
 import org.springframework.jdbc.core.JdbcTemplate;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/command/ExtraSQLCommand.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/command/ExtraSQLCommand.java
similarity index 96%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/command/ExtraSQLCommand.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/command/ExtraSQLCommand.java
index 53c233e8161..a1779462245 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/command/ExtraSQLCommand.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/command/ExtraSQLCommand.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.command;
+package org.apache.shardingsphere.test.e2e.data.pipeline.command;
 
 import lombok.Getter;
 import lombok.Setter;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/command/MigrationDistSQLCommand.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/command/MigrationDistSQLCommand.java
similarity index 97%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/command/MigrationDistSQLCommand.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/command/MigrationDistSQLCommand.java
index a28dcac84f1..6bf0966fbba 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/command/MigrationDistSQLCommand.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/command/MigrationDistSQLCommand.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.command;
+package org.apache.shardingsphere.test.e2e.data.pipeline.command;
 
 import lombok.Getter;
 import lombok.Setter;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/entity/CreateTableSQLGeneratorAssertionEntity.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/entity/CreateTableSQLGeneratorAssertionEntity.java
similarity index 95%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/entity/CreateTableSQLGeneratorAssertionEntity.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/entity/CreateTableSQLGeneratorAssertionEntity.java
index c9005565909..e28ef0ca7bb 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/entity/CreateTableSQLGeneratorAssertionEntity.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/entity/CreateTableSQLGeneratorAssertionEntity.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.entity;
+package org.apache.shardingsphere.test.e2e.data.pipeline.entity;
 
 import lombok.Getter;
 import lombok.Setter;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/entity/CreateTableSQLGeneratorAssertionsRootEntity.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/entity/CreateTableSQLGeneratorAssertionsRootEntity.java
similarity index 95%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/entity/CreateTableSQLGeneratorAssertionsRootEntity.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/entity/CreateTableSQLGeneratorAssertionsRootEntity.java
index beeec456f50..ba9332461e7 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/entity/CreateTableSQLGeneratorAssertionsRootEntity.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/entity/CreateTableSQLGeneratorAssertionsRootEntity.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.entity;
+package org.apache.shardingsphere.test.e2e.data.pipeline.entity;
 
 import lombok.Getter;
 
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/entity/CreateTableSQLGeneratorInputEntity.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/entity/CreateTableSQLGeneratorInputEntity.java
similarity index 95%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/entity/CreateTableSQLGeneratorInputEntity.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/entity/CreateTableSQLGeneratorInputEntity.java
index f0c2cbb13c9..4ccebb6c8ea 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/entity/CreateTableSQLGeneratorInputEntity.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/entity/CreateTableSQLGeneratorInputEntity.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.entity;
+package org.apache.shardingsphere.test.e2e.data.pipeline.entity;
 
 import lombok.Getter;
 import lombok.Setter;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/entity/CreateTableSQLGeneratorOutputEntity.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/entity/CreateTableSQLGeneratorOutputEntity.java
similarity index 95%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/entity/CreateTableSQLGeneratorOutputEntity.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/entity/CreateTableSQLGeneratorOutputEntity.java
index 33167ce1cbf..4bec171f953 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/entity/CreateTableSQLGeneratorOutputEntity.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/entity/CreateTableSQLGeneratorOutputEntity.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.entity;
+package org.apache.shardingsphere.test.e2e.data.pipeline.entity;
 
 import lombok.Getter;
 import lombok.Setter;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/env/IntegrationTestEnvironment.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/env/IntegrationTestEnvironment.java
similarity index 97%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/env/IntegrationTestEnvironment.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/env/IntegrationTestEnvironment.java
index 62f677686ae..e9f7c6661f2 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/env/IntegrationTestEnvironment.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/env/IntegrationTestEnvironment.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.env;
+package org.apache.shardingsphere.test.e2e.data.pipeline.env;
 
 import com.google.common.base.Strings;
 import lombok.Getter;
 import lombok.SneakyThrows;
 import org.apache.shardingsphere.infra.database.type.DatabaseType;
-import org.apache.shardingsphere.integration.data.pipeline.env.enums.ITEnvTypeEnum;
+import org.apache.shardingsphere.test.e2e.data.pipeline.env.enums.ITEnvTypeEnum;
 import org.apache.shardingsphere.test.e2e.env.container.atomic.constants.StorageContainerConstants;
 
 import java.io.IOException;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/env/enums/ITEnvTypeEnum.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/env/enums/ITEnvTypeEnum.java
similarity index 92%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/env/enums/ITEnvTypeEnum.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/env/enums/ITEnvTypeEnum.java
index 42ac83cabfa..7331bebd886 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/env/enums/ITEnvTypeEnum.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/env/enums/ITEnvTypeEnum.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.env.enums;
+package org.apache.shardingsphere.test.e2e.data.pipeline.env.enums;
 
 public enum ITEnvTypeEnum {
     
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/container/compose/BaseContainerComposer.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/compose/BaseContainerComposer.java
similarity index 94%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/container/compose/BaseContainerComposer.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/compose/BaseContainerComposer.java
index a8a8cec1b9f..c167cf1c5cb 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/container/compose/BaseContainerComposer.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/compose/BaseContainerComposer.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.framework.container.compose;
+package org.apache.shardingsphere.test.e2e.data.pipeline.framework.container.compose;
 
 import lombok.Getter;
 import org.apache.shardingsphere.test.e2e.env.container.atomic.ITContainers;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/container/compose/DockerContainerComposer.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/compose/DockerContainerComposer.java
similarity index 93%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/container/compose/DockerContainerComposer.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/compose/DockerContainerComposer.java
index 486c957d97f..26179c38cbb 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/container/compose/DockerContainerComposer.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/compose/DockerContainerComposer.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.framework.container.compose;
+package org.apache.shardingsphere.test.e2e.data.pipeline.framework.container.compose;
 
 import lombok.Getter;
 import org.apache.shardingsphere.infra.database.type.DatabaseType;
-import org.apache.shardingsphere.integration.data.pipeline.framework.container.config.proxy.ScalingProxyClusterContainerConfigurationFactory;
-import org.apache.shardingsphere.integration.data.pipeline.util.DockerImageVersion;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.container.config.proxy.ScalingProxyClusterContainerConfigurationFactory;
+import org.apache.shardingsphere.test.e2e.data.pipeline.util.DockerImageVersion;
 import org.apache.shardingsphere.test.e2e.env.container.atomic.adapter.AdapterContainerFactory;
 import org.apache.shardingsphere.test.e2e.env.container.atomic.adapter.config.AdaptorContainerConfiguration;
 import org.apache.shardingsphere.test.e2e.env.container.atomic.adapter.impl.ShardingSphereProxyClusterContainer;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/container/compose/NativeContainerComposer.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/compose/NativeContainerComposer.java
similarity index 96%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/container/compose/NativeContainerComposer.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/compose/NativeContainerComposer.java
index 619695bf9a1..974ec790119 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/container/compose/NativeContainerComposer.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/compose/NativeContainerComposer.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.framework.container.compose;
+package org.apache.shardingsphere.test.e2e.data.pipeline.framework.container.compose;
 
 import lombok.SneakyThrows;
 import org.apache.shardingsphere.infra.database.metadata.url.JdbcUrlAppender;
 import org.apache.shardingsphere.infra.database.type.DatabaseType;
-import org.apache.shardingsphere.integration.data.pipeline.env.IntegrationTestEnvironment;
+import org.apache.shardingsphere.test.e2e.data.pipeline.env.IntegrationTestEnvironment;
 import org.apache.shardingsphere.test.e2e.env.runtime.DataSourceEnvironment;
 
 import java.sql.Connection;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/container/config/proxy/ScalingProxyClusterContainerConfigurationFactory.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/config/proxy/ScalingProxyClusterContainerConfigurationFactory.java
similarity index 97%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/container/config/proxy/ScalingProxyClusterContainerConfigurationFactory.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/config/proxy/ScalingProxyClusterContainerConfigurationFactory.java
index 8848eea2050..f77068c13a9 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/container/config/proxy/ScalingProxyClusterContainerConfigurationFactory.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/config/proxy/ScalingProxyClusterContainerConfigurationFactory.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.framework.container.config.proxy;
+package org.apache.shardingsphere.test.e2e.data.pipeline.framework.container.config.proxy;
 
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/helper/ScalingCaseHelper.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/helper/ScalingCaseHelper.java
similarity index 96%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/helper/ScalingCaseHelper.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/helper/ScalingCaseHelper.java
index 7e98234e7b3..77f375f7140 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/helper/ScalingCaseHelper.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/helper/ScalingCaseHelper.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.framework.helper;
+package org.apache.shardingsphere.test.e2e.data.pipeline.framework.helper;
 
 import org.apache.commons.lang3.RandomStringUtils;
 import org.apache.commons.lang3.tuple.Pair;
 import org.apache.shardingsphere.infra.database.type.DatabaseType;
 import org.apache.shardingsphere.infra.database.type.dialect.MySQLDatabaseType;
-import org.apache.shardingsphere.integration.data.pipeline.util.AutoIncrementKeyGenerateAlgorithm;
+import org.apache.shardingsphere.test.e2e.data.pipeline.util.AutoIncrementKeyGenerateAlgorithm;
 import org.apache.shardingsphere.sharding.algorithm.keygen.SnowflakeKeyGenerateAlgorithm;
 
 import java.math.BigDecimal;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/param/ScalingParameterized.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/param/ScalingParameterized.java
similarity index 93%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/param/ScalingParameterized.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/param/ScalingParameterized.java
index e99962d43d6..b8d3a6ce54e 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/param/ScalingParameterized.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/param/ScalingParameterized.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.framework.param;
+package org.apache.shardingsphere.test.e2e.data.pipeline.framework.param;
 
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/watcher/ScalingWatcher.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/watcher/ScalingWatcher.java
similarity index 89%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/watcher/ScalingWatcher.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/watcher/ScalingWatcher.java
index e87a72d9189..7537287ceb5 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/framework/watcher/ScalingWatcher.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/watcher/ScalingWatcher.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.framework.watcher;
+package org.apache.shardingsphere.test.e2e.data.pipeline.framework.watcher;
 
 import lombok.RequiredArgsConstructor;
 import lombok.extern.slf4j.Slf4j;
 import org.apache.shardingsphere.infra.database.type.DatabaseType;
-import org.apache.shardingsphere.integration.data.pipeline.framework.container.compose.BaseContainerComposer;
-import org.apache.shardingsphere.integration.data.pipeline.framework.container.compose.DockerContainerComposer;
-import org.apache.shardingsphere.integration.data.pipeline.framework.container.compose.NativeContainerComposer;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.container.compose.BaseContainerComposer;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.container.compose.DockerContainerComposer;
+import org.apache.shardingsphere.test.e2e.data.pipeline.framework.container.compose.NativeContainerComposer;
 import org.apache.shardingsphere.mode.repository.cluster.ClusterPersistRepository;
 import org.apache.shardingsphere.mode.repository.cluster.ClusterPersistRepositoryConfiguration;
 import org.apache.shardingsphere.mode.repository.cluster.zookeeper.ZookeeperRepository;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/logger/PipelineLoggerFilter.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/logger/PipelineLoggerFilter.java
similarity index 96%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/logger/PipelineLoggerFilter.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/logger/PipelineLoggerFilter.java
index 7b3896069af..ea34154c044 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/logger/PipelineLoggerFilter.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/logger/PipelineLoggerFilter.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.logger;
+package org.apache.shardingsphere.test.e2e.data.pipeline.logger;
 
 import ch.qos.logback.classic.spi.ILoggingEvent;
 import ch.qos.logback.core.filter.Filter;
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/util/AutoIncrementKeyGenerateAlgorithm.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/util/AutoIncrementKeyGenerateAlgorithm.java
similarity index 95%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/util/AutoIncrementKeyGenerateAlgorithm.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/util/AutoIncrementKeyGenerateAlgorithm.java
index 00011b10ff4..69f884bb7a1 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/util/AutoIncrementKeyGenerateAlgorithm.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/util/AutoIncrementKeyGenerateAlgorithm.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.util;
+package org.apache.shardingsphere.test.e2e.data.pipeline.util;
 
 import org.apache.shardingsphere.sharding.spi.KeyGenerateAlgorithm;
 
diff --git a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/util/DockerImageVersion.java b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/util/DockerImageVersion.java
similarity index 95%
rename from test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/util/DockerImageVersion.java
rename to test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/util/DockerImageVersion.java
index 4970c88339f..87dd3b3ae1a 100644
--- a/test/e2e/scaling/src/test/java/org/apache/shardingsphere/integration/data/pipeline/util/DockerImageVersion.java
+++ b/test/e2e/scaling/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/util/DockerImageVersion.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package org.apache.shardingsphere.integration.data.pipeline.util;
+package org.apache.shardingsphere.test.e2e.data.pipeline.util;
 
 /**
  * Docker image version util.
diff --git a/test/e2e/scaling/src/test/resources/logback-test.xml b/test/e2e/scaling/src/test/resources/logback-test.xml
index 36a017c8d4e..32f24684b39 100644
--- a/test/e2e/scaling/src/test/resources/logback-test.xml
+++ b/test/e2e/scaling/src/test/resources/logback-test.xml
@@ -18,7 +18,7 @@
 
 <configuration>
     <appender name="console" class="ch.qos.logback.core.ConsoleAppender">
-        <filter class="org.apache.shardingsphere.integration.data.pipeline.logger.PipelineLoggerFilter" />
+        <filter class="org.apache.shardingsphere.test.e2e.data.pipeline.logger.PipelineLoggerFilter" />
         <encoder>
             <pattern>[%-5level] %d{yyyy-MM-dd HH:mm:ss.SSS} [%thread] %logger{36} - %msg%n</pattern>
         </encoder>