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

totalo 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 2402347d0eb Remove useless @slf4j (#29513)
2402347d0eb is described below

commit 2402347d0ebfa3f20929f2902f98117fe5aa5022
Author: Liang Zhang <[email protected]>
AuthorDate: Sat Dec 23 14:42:40 2023 +0800

    Remove useless @slf4j (#29513)
    
    * Refactor ImporterConfiguration
    
    * Remove useless @Slf4j on MigrationJob
    
    * Remove useless @Slf4j
    
    * Remove useless @Slf4j
---
 .../core/exporter/impl/proxy/ProxyMetaDataInfoExporter.java  |  2 --
 .../table/DataMatchTableDataConsistencyChecker.java          |  2 --
 .../AbstractStreamingSingleTableInventoryCalculator.java     |  2 --
 .../calculator/RecordSingleTableInventoryCalculator.java     |  8 +++-----
 .../data/pipeline/core/importer/ImporterConfiguration.java   | 12 ++----------
 .../data/pipeline/core/job/type/JobCodeRegistry.java         |  2 --
 .../data/pipeline/core/task/IncrementalTask.java             |  6 ++----
 .../data/pipeline/core/task/InventoryTask.java               |  6 ++----
 .../data/pipeline/core/task/TaskExecuteCallback.java         |  2 +-
 .../OpenGaussPipelineJobDataSourcePrepareOption.java         |  2 --
 .../postgresql/ingest/PostgreSQLIngestPositionManager.java   |  2 +-
 .../data/pipeline/cdc/core/importer/sink/CDCSocketSink.java  |  8 +++-----
 .../data/pipeline/cdc/core/task/CDCIncrementalTask.java      |  6 ++----
 .../data/pipeline/cdc/core/task/CDCInventoryTask.java        |  4 +---
 .../data/pipeline/cdc/util/ColumnValueConvertUtils.java      |  2 --
 .../data/pipeline/scenario/migration/MigrationJob.java       |  2 --
 .../globalclock/type/tso/provider/RedisTSOProvider.java      |  2 --
 .../transaction/ShardingSphereTransactionManagerEngine.java  |  2 --
 .../at/SeataATShardingSphereTransactionManagerTest.java      |  2 --
 .../status/cluster/service/ClusterStatusService.java         |  2 --
 .../zookeeper/listener/SessionConnectionListener.java        |  2 +-
 .../admin/executor/AbstractDatabaseMetaDataExecutor.java     |  2 --
 .../proxy/backend/hbase/context/HBaseMetaDataRefresher.java  |  2 --
 .../hbase/converter/type/HBaseSelectOperationConverter.java  |  2 --
 .../shardingsphere/proxy/arguments/BootstrapArguments.java   |  2 --
 .../org/apache/shardingsphere/proxy/frontend/CDCServer.java  |  2 --
 .../agent/jdbc/project/service/impl/OrderServiceImpl.java    |  2 +-
 .../test/e2e/agent/jaeger/asserts/SpanAssert.java            |  2 --
 .../adapter/impl/ShardingSphereProxyStandaloneContainer.java |  2 --
 .../env/container/atomic/storage/DockerStorageContainer.java |  2 --
 .../cases/migration/primarykey/MariaDBMigrationE2EIT.java    |  2 --
 .../framework/container/compose/DockerContainerComposer.java |  2 --
 .../cases/alterresource/CloseResourceTestCase.java           |  2 --
 .../transaction/cases/cursor/OpenGaussCursorTestCase.java    |  2 --
 .../cases/deadlock/TransactionDeadlockTestCase.java          |  2 +-
 .../transaction/cases/readonly/MySQLSetReadOnlyTestCase.java |  2 --
 .../test/e2e/transaction/engine/base/JdbcDataSource.java     |  2 --
 .../framework/container/compose/DockerContainerComposer.java |  2 +-
 .../apache/shardingsphere/test/e2e/cases/value/SQLValue.java |  2 --
 39 files changed, 21 insertions(+), 93 deletions(-)

diff --git 
a/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/exporter/impl/proxy/ProxyMetaDataInfoExporter.java
 
b/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/exporter/impl/proxy/ProxyMetaDataInfoExporter.java
index f74bb146b90..376827ab6cd 100644
--- 
a/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/exporter/impl/proxy/ProxyMetaDataInfoExporter.java
+++ 
b/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/exporter/impl/proxy/ProxyMetaDataInfoExporter.java
@@ -17,7 +17,6 @@
 
 package 
org.apache.shardingsphere.agent.plugin.metrics.core.exporter.impl.proxy;
 
-import lombok.extern.slf4j.Slf4j;
 import 
org.apache.shardingsphere.agent.plugin.metrics.core.collector.MetricsCollectorRegistry;
 import 
org.apache.shardingsphere.agent.plugin.metrics.core.collector.type.GaugeMetricFamilyMetricsCollector;
 import 
org.apache.shardingsphere.agent.plugin.metrics.core.config.MetricCollectorType;
@@ -32,7 +31,6 @@ import java.util.Optional;
 /**
  * Proxy meta data information exporter.
  */
-@Slf4j
 public final class ProxyMetaDataInfoExporter implements MetricsExporter {
     
     private final MetricConfiguration config = new 
MetricConfiguration("proxy_meta_data_info",
diff --git 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/consistencycheck/table/DataMatchTableDataConsistencyChecker.java
 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/consistencycheck/table/DataMatchTableDataConsistencyChecker.java
index 410c64c4af2..84236229316 100644
--- 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/consistencycheck/table/DataMatchTableDataConsistencyChecker.java
+++ 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/consistencycheck/table/DataMatchTableDataConsistencyChecker.java
@@ -18,7 +18,6 @@
 package org.apache.shardingsphere.data.pipeline.core.consistencycheck.table;
 
 import com.google.common.base.Strings;
-import lombok.extern.slf4j.Slf4j;
 import 
org.apache.shardingsphere.data.pipeline.core.consistencycheck.table.calculator.RecordSingleTableInventoryCalculator;
 import 
org.apache.shardingsphere.data.pipeline.core.consistencycheck.table.calculator.SingleTableInventoryCalculator;
 import 
org.apache.shardingsphere.data.pipeline.core.exception.param.PipelineInvalidParameterException;
@@ -33,7 +32,6 @@ import java.util.Properties;
  * Data match table data consistency checker.
  */
 @SPIDescription("Match raw data of records.")
-@Slf4j
 public final class DataMatchTableDataConsistencyChecker implements 
TableDataConsistencyChecker {
     
     private static final String CHUNK_SIZE_KEY = "chunk-size";
diff --git 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/consistencycheck/table/calculator/AbstractStreamingSingleTableInventoryCalculator.java
 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/consistencycheck/table/calculator/AbstractStreamingSingleTableInventoryCalculator.java
index d9f945de172..2317c98f20e 100644
--- 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/consistencycheck/table/calculator/AbstractStreamingSingleTableInventoryCalculator.java
+++ 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/consistencycheck/table/calculator/AbstractStreamingSingleTableInventoryCalculator.java
@@ -19,7 +19,6 @@ package 
org.apache.shardingsphere.data.pipeline.core.consistencycheck.table.calc
 
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
-import lombok.extern.slf4j.Slf4j;
 import 
org.apache.shardingsphere.data.pipeline.core.consistencycheck.result.SingleTableInventoryCalculatedResult;
 
 import java.util.Iterator;
@@ -32,7 +31,6 @@ import java.util.concurrent.atomic.AtomicReference;
  * Abstract streaming single table inventory calculator.
  */
 @Getter
-@Slf4j
 public abstract class AbstractStreamingSingleTableInventoryCalculator extends 
AbstractSingleTableInventoryCalculator {
     
     @Override
diff --git 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/consistencycheck/table/calculator/RecordSingleTableInventoryCalculator.java
 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/consistencycheck/table/calculator/RecordSingleTableInventoryCalculator.java
index 2b1c2f24f76..e3231bd7d03 100644
--- 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/consistencycheck/table/calculator/RecordSingleTableInventoryCalculator.java
+++ 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/consistencycheck/table/calculator/RecordSingleTableInventoryCalculator.java
@@ -18,13 +18,12 @@
 package 
org.apache.shardingsphere.data.pipeline.core.consistencycheck.table.calculator;
 
 import lombok.RequiredArgsConstructor;
-import lombok.extern.slf4j.Slf4j;
-import 
org.apache.shardingsphere.data.pipeline.core.query.JDBCStreamQueryBuilder;
-import 
org.apache.shardingsphere.data.pipeline.core.sqlbuilder.sql.PipelineDataConsistencyCalculateSQLBuilder;
 import 
org.apache.shardingsphere.data.pipeline.core.consistencycheck.result.RecordSingleTableInventoryCalculatedResult;
 import 
org.apache.shardingsphere.data.pipeline.core.consistencycheck.result.SingleTableInventoryCalculatedResult;
-import 
org.apache.shardingsphere.data.pipeline.core.ingest.dumper.ColumnValueReaderEngine;
 import 
org.apache.shardingsphere.data.pipeline.core.exception.data.PipelineTableDataConsistencyCheckLoadingFailedException;
+import 
org.apache.shardingsphere.data.pipeline.core.ingest.dumper.ColumnValueReaderEngine;
+import 
org.apache.shardingsphere.data.pipeline.core.query.JDBCStreamQueryBuilder;
+import 
org.apache.shardingsphere.data.pipeline.core.sqlbuilder.sql.PipelineDataConsistencyCalculateSQLBuilder;
 import org.apache.shardingsphere.infra.database.mysql.type.MySQLDatabaseType;
 import 
org.apache.shardingsphere.infra.exception.core.ShardingSpherePreconditions;
 import 
org.apache.shardingsphere.infra.exception.core.external.sql.type.kernel.category.PipelineSQLException;
@@ -47,7 +46,6 @@ import java.util.Optional;
  * Record single table inventory calculator.
  */
 @RequiredArgsConstructor
-@Slf4j
 public final class RecordSingleTableInventoryCalculator extends 
AbstractStreamingSingleTableInventoryCalculator {
     
     private final int chunkSize;
diff --git 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/importer/ImporterConfiguration.java
 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/importer/ImporterConfiguration.java
index d2b8fc59b9a..92649efcf23 100644
--- 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/importer/ImporterConfiguration.java
+++ 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/importer/ImporterConfiguration.java
@@ -58,15 +58,6 @@ public final class ImporterConfiguration {
     
     private final int concurrency;
     
-    /**
-     * Get logic table names.
-     *
-     * @return logic table names
-     */
-    public Collection<String> getLogicTableNames() {
-        return 
Collections.unmodifiableList(shardingColumnsMap.keySet().stream().map(CaseInsensitiveIdentifier::toString).collect(Collectors.toList()));
-    }
-    
     /**
      * Get sharding columns.
      *
@@ -94,6 +85,7 @@ public final class ImporterConfiguration {
      * @return qualified tables
      */
     public Collection<CaseInsensitiveQualifiedTable> getQualifiedTables() {
-        return getLogicTableNames().stream().map(each -> new 
CaseInsensitiveQualifiedTable(tableAndSchemaNameMapper.getSchemaName(each), 
each)).collect(Collectors.toList());
+        return shardingColumnsMap.keySet().stream()
+                .map(CaseInsensitiveIdentifier::toString).map(each -> new 
CaseInsensitiveQualifiedTable(tableAndSchemaNameMapper.getSchemaName(each), 
each)).collect(Collectors.toList());
     }
 }
diff --git 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/job/type/JobCodeRegistry.java
 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/job/type/JobCodeRegistry.java
index b4b624ec7ec..768482d0f4e 100644
--- 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/job/type/JobCodeRegistry.java
+++ 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/job/type/JobCodeRegistry.java
@@ -20,7 +20,6 @@ package org.apache.shardingsphere.data.pipeline.core.job.type;
 import com.google.common.base.Preconditions;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
-import lombok.extern.slf4j.Slf4j;
 import org.apache.shardingsphere.infra.spi.ShardingSphereServiceLoader;
 
 import java.util.HashMap;
@@ -30,7 +29,6 @@ import java.util.Map;
  * Job code registry.
  */
 @NoArgsConstructor(access = AccessLevel.PRIVATE)
-@Slf4j
 public final class JobCodeRegistry {
     
     private static final Map<String, PipelineJobType> JOB_CODE_AND_TYPE_MAP = 
new HashMap<>();
diff --git 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/IncrementalTask.java
 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/IncrementalTask.java
index 445e8775489..bc72f79800c 100644
--- 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/IncrementalTask.java
+++ 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/IncrementalTask.java
@@ -20,11 +20,10 @@ package org.apache.shardingsphere.data.pipeline.core.task;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
 import lombok.ToString;
-import lombok.extern.slf4j.Slf4j;
-import org.apache.shardingsphere.data.pipeline.core.ingest.dumper.Dumper;
 import org.apache.shardingsphere.data.pipeline.core.execute.ExecuteEngine;
-import 
org.apache.shardingsphere.data.pipeline.core.task.progress.IncrementalTaskProgress;
 import org.apache.shardingsphere.data.pipeline.core.importer.Importer;
+import org.apache.shardingsphere.data.pipeline.core.ingest.dumper.Dumper;
+import 
org.apache.shardingsphere.data.pipeline.core.task.progress.IncrementalTaskProgress;
 
 import java.util.Collection;
 import java.util.LinkedList;
@@ -34,7 +33,6 @@ import java.util.concurrent.CompletableFuture;
  * Incremental task.
  */
 @RequiredArgsConstructor
-@Slf4j
 @ToString(exclude = {"incrementalExecuteEngine", "dumper", "importers", 
"taskProgress"})
 public final class IncrementalTask implements PipelineTask {
     
diff --git 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/InventoryTask.java
 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/InventoryTask.java
index 84a60690c0b..dc603f47709 100644
--- 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/InventoryTask.java
+++ 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/InventoryTask.java
@@ -20,12 +20,11 @@ package org.apache.shardingsphere.data.pipeline.core.task;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
 import lombok.ToString;
-import lombok.extern.slf4j.Slf4j;
+import org.apache.shardingsphere.data.pipeline.core.execute.ExecuteEngine;
+import org.apache.shardingsphere.data.pipeline.core.importer.Importer;
 import org.apache.shardingsphere.data.pipeline.core.ingest.dumper.Dumper;
 import 
org.apache.shardingsphere.data.pipeline.core.ingest.position.IngestPosition;
-import org.apache.shardingsphere.data.pipeline.core.execute.ExecuteEngine;
 import 
org.apache.shardingsphere.data.pipeline.core.task.progress.InventoryTaskProgress;
-import org.apache.shardingsphere.data.pipeline.core.importer.Importer;
 
 import java.util.Collection;
 import java.util.LinkedList;
@@ -37,7 +36,6 @@ import java.util.concurrent.atomic.AtomicReference;
  */
 @RequiredArgsConstructor
 @ToString(exclude = {"inventoryDumperExecuteEngine", 
"inventoryImporterExecuteEngine", "dumper", "importer"})
-@Slf4j
 public final class InventoryTask implements PipelineTask {
     
     @Getter
diff --git 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/TaskExecuteCallback.java
 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/TaskExecuteCallback.java
index 9c9bbf22f85..280c7345f10 100644
--- 
a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/TaskExecuteCallback.java
+++ 
b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/TaskExecuteCallback.java
@@ -25,8 +25,8 @@ import 
org.apache.shardingsphere.data.pipeline.core.execute.ExecuteCallback;
 /**
  * Task execute callback.
  */
-@Slf4j
 @RequiredArgsConstructor
+@Slf4j
 public final class TaskExecuteCallback implements ExecuteCallback {
     
     private final PipelineTask task;
diff --git 
a/kernel/data-pipeline/dialect/opengauss/src/main/java/org/apache/shardingsphere/data/pipeline/opengauss/prepare/datasource/OpenGaussPipelineJobDataSourcePrepareOption.java
 
b/kernel/data-pipeline/dialect/opengauss/src/main/java/org/apache/shardingsphere/data/pipeline/opengauss/prepare/datasource/OpenGaussPipelineJobDataSourcePrepareOption.java
index 2771c5d9353..f31c598427b 100644
--- 
a/kernel/data-pipeline/dialect/opengauss/src/main/java/org/apache/shardingsphere/data/pipeline/opengauss/prepare/datasource/OpenGaussPipelineJobDataSourcePrepareOption.java
+++ 
b/kernel/data-pipeline/dialect/opengauss/src/main/java/org/apache/shardingsphere/data/pipeline/opengauss/prepare/datasource/OpenGaussPipelineJobDataSourcePrepareOption.java
@@ -17,7 +17,6 @@
 
 package org.apache.shardingsphere.data.pipeline.opengauss.prepare.datasource;
 
-import lombok.extern.slf4j.Slf4j;
 import 
org.apache.shardingsphere.data.pipeline.core.preparer.datasource.option.DialectPipelineJobDataSourcePrepareOption;
 
 import java.util.Arrays;
@@ -26,7 +25,6 @@ import java.util.Collection;
 /**
  * Pipeline job data source prepare option for openGauss.
  */
-@Slf4j
 public final class OpenGaussPipelineJobDataSourcePrepareOption implements 
DialectPipelineJobDataSourcePrepareOption {
     
     @Override
diff --git 
a/kernel/data-pipeline/dialect/postgresql/src/main/java/org/apache/shardingsphere/data/pipeline/postgresql/ingest/PostgreSQLIngestPositionManager.java
 
b/kernel/data-pipeline/dialect/postgresql/src/main/java/org/apache/shardingsphere/data/pipeline/postgresql/ingest/PostgreSQLIngestPositionManager.java
index 103469de326..d3db37369bd 100644
--- 
a/kernel/data-pipeline/dialect/postgresql/src/main/java/org/apache/shardingsphere/data/pipeline/postgresql/ingest/PostgreSQLIngestPositionManager.java
+++ 
b/kernel/data-pipeline/dialect/postgresql/src/main/java/org/apache/shardingsphere/data/pipeline/postgresql/ingest/PostgreSQLIngestPositionManager.java
@@ -32,7 +32,7 @@ import java.sql.ResultSet;
 import java.sql.SQLException;
 
 /**
- * Ingest position manager for PostgreSQ.
+ * Ingest position manager for PostgreSQL.
  */
 @Slf4j
 public final class PostgreSQLIngestPositionManager implements 
DialectIngestPositionManager {
diff --git 
a/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/core/importer/sink/CDCSocketSink.java
 
b/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/core/importer/sink/CDCSocketSink.java
index 724c2d70924..8f5c3eca0a5 100644
--- 
a/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/core/importer/sink/CDCSocketSink.java
+++ 
b/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/core/importer/sink/CDCSocketSink.java
@@ -20,15 +20,14 @@ package 
org.apache.shardingsphere.data.pipeline.cdc.core.importer.sink;
 import io.netty.channel.Channel;
 import lombok.Getter;
 import lombok.SneakyThrows;
-import lombok.extern.slf4j.Slf4j;
-import org.apache.shardingsphere.data.pipeline.core.ingest.record.DataRecord;
-import org.apache.shardingsphere.data.pipeline.core.ingest.record.Record;
 import org.apache.shardingsphere.data.pipeline.cdc.generator.CDCResponseUtils;
 import 
org.apache.shardingsphere.data.pipeline.cdc.protocol.response.CDCResponse.ResponseCase;
 import 
org.apache.shardingsphere.data.pipeline.cdc.protocol.response.DataRecordResult;
 import 
org.apache.shardingsphere.data.pipeline.cdc.util.DataRecordResultConvertUtils;
-import 
org.apache.shardingsphere.data.pipeline.core.job.progress.listener.PipelineJobProgressUpdatedParameter;
 import org.apache.shardingsphere.data.pipeline.core.importer.sink.PipelineSink;
+import org.apache.shardingsphere.data.pipeline.core.ingest.record.DataRecord;
+import org.apache.shardingsphere.data.pipeline.core.ingest.record.Record;
+import 
org.apache.shardingsphere.data.pipeline.core.job.progress.listener.PipelineJobProgressUpdatedParameter;
 import 
org.apache.shardingsphere.infra.exception.core.external.sql.sqlstate.XOpenSQLState;
 import 
org.apache.shardingsphere.infra.metadata.database.ShardingSphereDatabase;
 
@@ -46,7 +45,6 @@ import java.util.concurrent.locks.ReentrantLock;
 /**
  * CDC socket sink.
  */
-@Slf4j
 public final class CDCSocketSink implements PipelineSink {
     
     private static final long DEFAULT_TIMEOUT_MILLISECONDS = 100L;
diff --git 
a/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/core/task/CDCIncrementalTask.java
 
b/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/core/task/CDCIncrementalTask.java
index b220cdf7684..bad45b3ed20 100644
--- 
a/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/core/task/CDCIncrementalTask.java
+++ 
b/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/core/task/CDCIncrementalTask.java
@@ -20,13 +20,12 @@ package 
org.apache.shardingsphere.data.pipeline.cdc.core.task;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
 import lombok.ToString;
-import lombok.extern.slf4j.Slf4j;
-import org.apache.shardingsphere.data.pipeline.core.ingest.dumper.Dumper;
 import org.apache.shardingsphere.data.pipeline.core.execute.ExecuteEngine;
-import 
org.apache.shardingsphere.data.pipeline.core.task.progress.IncrementalTaskProgress;
 import org.apache.shardingsphere.data.pipeline.core.importer.Importer;
+import org.apache.shardingsphere.data.pipeline.core.ingest.dumper.Dumper;
 import org.apache.shardingsphere.data.pipeline.core.task.PipelineTask;
 import org.apache.shardingsphere.data.pipeline.core.task.TaskExecuteCallback;
+import 
org.apache.shardingsphere.data.pipeline.core.task.progress.IncrementalTaskProgress;
 
 import javax.annotation.Nullable;
 import java.util.Collection;
@@ -37,7 +36,6 @@ import java.util.concurrent.CompletableFuture;
  * CDC incremental task.
  */
 @RequiredArgsConstructor
-@Slf4j
 @ToString(exclude = {"incrementalExecuteEngine", "dumper", "importer", 
"taskProgress"})
 public final class CDCIncrementalTask implements PipelineTask {
     
diff --git 
a/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/core/task/CDCInventoryTask.java
 
b/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/core/task/CDCInventoryTask.java
index 294ac2147be..841b3da6cc9 100644
--- 
a/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/core/task/CDCInventoryTask.java
+++ 
b/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/core/task/CDCInventoryTask.java
@@ -20,12 +20,11 @@ package 
org.apache.shardingsphere.data.pipeline.cdc.core.task;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
 import lombok.ToString;
-import lombok.extern.slf4j.Slf4j;
 import org.apache.shardingsphere.data.pipeline.core.execute.ExecuteEngine;
 import org.apache.shardingsphere.data.pipeline.core.importer.Importer;
 import org.apache.shardingsphere.data.pipeline.core.ingest.dumper.Dumper;
-import 
org.apache.shardingsphere.data.pipeline.core.ingest.position.type.finished.IngestFinishedPosition;
 import 
org.apache.shardingsphere.data.pipeline.core.ingest.position.IngestPosition;
+import 
org.apache.shardingsphere.data.pipeline.core.ingest.position.type.finished.IngestFinishedPosition;
 import org.apache.shardingsphere.data.pipeline.core.task.PipelineTask;
 import org.apache.shardingsphere.data.pipeline.core.task.TaskExecuteCallback;
 import 
org.apache.shardingsphere.data.pipeline.core.task.progress.InventoryTaskProgress;
@@ -42,7 +41,6 @@ import java.util.concurrent.atomic.AtomicReference;
  */
 @RequiredArgsConstructor
 @ToString(exclude = {"inventoryDumperExecuteEngine", 
"inventoryImporterExecuteEngine", "dumper", "importer"})
-@Slf4j
 public final class CDCInventoryTask implements PipelineTask {
     
     @Getter
diff --git 
a/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/util/ColumnValueConvertUtils.java
 
b/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/util/ColumnValueConvertUtils.java
index 1398aaa36a5..1f61502d80a 100644
--- 
a/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/util/ColumnValueConvertUtils.java
+++ 
b/kernel/data-pipeline/scenario/cdc/core/src/main/java/org/apache/shardingsphere/data/pipeline/cdc/util/ColumnValueConvertUtils.java
@@ -30,7 +30,6 @@ import com.google.protobuf.StringValue;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 import lombok.SneakyThrows;
-import lombok.extern.slf4j.Slf4j;
 
 import java.math.BigDecimal;
 import java.math.BigInteger;
@@ -52,7 +51,6 @@ import java.util.Date;
  * Column value convert utility class.
  */
 @NoArgsConstructor(access = AccessLevel.PRIVATE)
-@Slf4j
 public final class ColumnValueConvertUtils {
     
     /**
diff --git 
a/kernel/data-pipeline/scenario/migration/src/main/java/org/apache/shardingsphere/data/pipeline/scenario/migration/MigrationJob.java
 
b/kernel/data-pipeline/scenario/migration/src/main/java/org/apache/shardingsphere/data/pipeline/scenario/migration/MigrationJob.java
index 503a07e7159..8b4c7dceb6f 100644
--- 
a/kernel/data-pipeline/scenario/migration/src/main/java/org/apache/shardingsphere/data/pipeline/scenario/migration/MigrationJob.java
+++ 
b/kernel/data-pipeline/scenario/migration/src/main/java/org/apache/shardingsphere/data/pipeline/scenario/migration/MigrationJob.java
@@ -17,7 +17,6 @@
 
 package org.apache.shardingsphere.data.pipeline.scenario.migration;
 
-import lombok.extern.slf4j.Slf4j;
 import 
org.apache.shardingsphere.data.pipeline.api.PipelineDataSourceConfiguration;
 import 
org.apache.shardingsphere.data.pipeline.api.type.ShardingSpherePipelineDataSourceConfiguration;
 import 
org.apache.shardingsphere.data.pipeline.core.context.TransmissionProcessContext;
@@ -52,7 +51,6 @@ import java.util.stream.Collectors;
 /**
  * Migration job.
  */
-@Slf4j
 public final class MigrationJob extends 
AbstractSeparablePipelineJob<MigrationJobConfiguration, 
MigrationJobItemContext, TransmissionJobItemProgress> {
     
     private final MigrationJobPreparer jobPreparer = new 
MigrationJobPreparer();
diff --git 
a/kernel/global-clock/type/tso/provider/redis/src/main/java/org/apache/shardingsphere/globalclock/type/tso/provider/RedisTSOProvider.java
 
b/kernel/global-clock/type/tso/provider/redis/src/main/java/org/apache/shardingsphere/globalclock/type/tso/provider/RedisTSOProvider.java
index f423463e7bf..48b69f7d39a 100644
--- 
a/kernel/global-clock/type/tso/provider/redis/src/main/java/org/apache/shardingsphere/globalclock/type/tso/provider/RedisTSOProvider.java
+++ 
b/kernel/global-clock/type/tso/provider/redis/src/main/java/org/apache/shardingsphere/globalclock/type/tso/provider/RedisTSOProvider.java
@@ -18,7 +18,6 @@
 package org.apache.shardingsphere.globalclock.type.tso.provider;
 
 import com.google.common.base.Strings;
-import lombok.extern.slf4j.Slf4j;
 import redis.clients.jedis.Jedis;
 import redis.clients.jedis.JedisPool;
 import redis.clients.jedis.JedisPoolConfig;
@@ -29,7 +28,6 @@ import java.util.concurrent.atomic.AtomicBoolean;
 /**
  * Redis timestamp oracle provider.
  */
-@Slf4j
 public final class RedisTSOProvider implements TSOProvider {
     
     private static final String CSN_KEY = "csn";
diff --git 
a/kernel/transaction/core/src/main/java/org/apache/shardingsphere/transaction/ShardingSphereTransactionManagerEngine.java
 
b/kernel/transaction/core/src/main/java/org/apache/shardingsphere/transaction/ShardingSphereTransactionManagerEngine.java
index 4e7e867e65c..96a4d101715 100644
--- 
a/kernel/transaction/core/src/main/java/org/apache/shardingsphere/transaction/ShardingSphereTransactionManagerEngine.java
+++ 
b/kernel/transaction/core/src/main/java/org/apache/shardingsphere/transaction/ShardingSphereTransactionManagerEngine.java
@@ -17,7 +17,6 @@
 
 package org.apache.shardingsphere.transaction;
 
-import lombok.extern.slf4j.Slf4j;
 import org.apache.shardingsphere.infra.database.core.type.DatabaseType;
 import 
org.apache.shardingsphere.infra.exception.core.ShardingSpherePreconditions;
 import org.apache.shardingsphere.infra.spi.type.typed.TypedSPILoader;
@@ -31,7 +30,6 @@ import java.util.Map;
 /**
  * ShardingSphere transaction manager engine.
  */
-@Slf4j
 public final class ShardingSphereTransactionManagerEngine {
     
     private final TransactionType transactionType;
diff --git 
a/kernel/transaction/type/base/seata-at/src/test/java/org/apache/shardingsphere/transaction/base/seata/at/SeataATShardingSphereTransactionManagerTest.java
 
b/kernel/transaction/type/base/seata-at/src/test/java/org/apache/shardingsphere/transaction/base/seata/at/SeataATShardingSphereTransactionManagerTest.java
index ed0709b2221..5ca0caf94c6 100644
--- 
a/kernel/transaction/type/base/seata-at/src/test/java/org/apache/shardingsphere/transaction/base/seata/at/SeataATShardingSphereTransactionManagerTest.java
+++ 
b/kernel/transaction/type/base/seata-at/src/test/java/org/apache/shardingsphere/transaction/base/seata/at/SeataATShardingSphereTransactionManagerTest.java
@@ -34,7 +34,6 @@ import io.seata.rm.datasource.ConnectionProxy;
 import io.seata.rm.datasource.DataSourceProxy;
 import io.seata.tm.api.GlobalTransactionContext;
 import lombok.SneakyThrows;
-import lombok.extern.slf4j.Slf4j;
 import org.apache.shardingsphere.infra.database.core.type.DatabaseType;
 import org.apache.shardingsphere.infra.spi.type.typed.TypedSPILoader;
 import org.apache.shardingsphere.test.fixture.jdbc.MockedDataSource;
@@ -63,7 +62,6 @@ import static org.junit.jupiter.api.Assertions.assertThrows;
 import static org.junit.jupiter.api.Assertions.assertTrue;
 import static org.junit.jupiter.api.Assertions.fail;
 
-@Slf4j
 class SeataATShardingSphereTransactionManagerTest {
     
     private static final MockSeataServer MOCK_SEATA_SERVER = new 
MockSeataServer();
diff --git 
a/mode/type/cluster/core/src/main/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/registry/status/cluster/service/ClusterStatusService.java
 
b/mode/type/cluster/core/src/main/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/registry/status/cluster/service/ClusterStatusService.java
index 19f1c445acc..03045139976 100644
--- 
a/mode/type/cluster/core/src/main/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/registry/status/cluster/service/ClusterStatusService.java
+++ 
b/mode/type/cluster/core/src/main/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/registry/status/cluster/service/ClusterStatusService.java
@@ -18,7 +18,6 @@
 package 
org.apache.shardingsphere.mode.manager.cluster.coordinator.registry.status.cluster.service;
 
 import lombok.RequiredArgsConstructor;
-import lombok.extern.slf4j.Slf4j;
 import org.apache.shardingsphere.infra.state.cluster.ClusterStateContext;
 import org.apache.shardingsphere.metadata.persist.node.ComputeNode;
 import 
org.apache.shardingsphere.mode.repository.cluster.ClusterPersistRepository;
@@ -27,7 +26,6 @@ import 
org.apache.shardingsphere.mode.repository.cluster.ClusterPersistRepositor
  * Cluster status service.
  */
 @RequiredArgsConstructor
-@Slf4j
 public final class ClusterStatusService {
     
     private final ClusterPersistRepository repository;
diff --git 
a/mode/type/cluster/repository/provider/zookeeper/src/main/java/org/apache/shardingsphere/mode/repository/cluster/zookeeper/listener/SessionConnectionListener.java
 
b/mode/type/cluster/repository/provider/zookeeper/src/main/java/org/apache/shardingsphere/mode/repository/cluster/zookeeper/listener/SessionConnectionListener.java
index 1cb08a94473..a4288ae55cf 100644
--- 
a/mode/type/cluster/repository/provider/zookeeper/src/main/java/org/apache/shardingsphere/mode/repository/cluster/zookeeper/listener/SessionConnectionListener.java
+++ 
b/mode/type/cluster/repository/provider/zookeeper/src/main/java/org/apache/shardingsphere/mode/repository/cluster/zookeeper/listener/SessionConnectionListener.java
@@ -35,8 +35,8 @@ import java.util.Properties;
 /**
  * Session connection state listener.
  */
-@Slf4j
 @RequiredArgsConstructor
+@Slf4j
 public final class SessionConnectionListener implements 
ConnectionStateListener {
     
     private static final int RECONNECT_INTERVAL_SECONDS = 5;
diff --git 
a/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/handler/admin/executor/AbstractDatabaseMetaDataExecutor.java
 
b/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/handler/admin/executor/AbstractDatabaseMetaDataExecutor.java
index 634c6f7893e..460a7333dc8 100644
--- 
a/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/handler/admin/executor/AbstractDatabaseMetaDataExecutor.java
+++ 
b/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/handler/admin/executor/AbstractDatabaseMetaDataExecutor.java
@@ -20,7 +20,6 @@ package 
org.apache.shardingsphere.proxy.backend.handler.admin.executor;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
 import lombok.SneakyThrows;
-import lombok.extern.slf4j.Slf4j;
 import org.apache.shardingsphere.authority.checker.AuthorityChecker;
 import org.apache.shardingsphere.authority.rule.AuthorityRule;
 import 
org.apache.shardingsphere.infra.executor.sql.execute.result.query.QueryResultMetaData;
@@ -139,7 +138,6 @@ public abstract class AbstractDatabaseMetaDataExecutor 
implements DatabaseAdminQ
      * Default database meta data executor, execute sql directly in the 
database to obtain the result source data.
      */
     @RequiredArgsConstructor
-    @Slf4j
     public static class DefaultDatabaseMetaDataExecutor extends 
AbstractDatabaseMetaDataExecutor {
         
         private final String sql;
diff --git 
a/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/context/HBaseMetaDataRefresher.java
 
b/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/context/HBaseMetaDataRefresher.java
index fc3785b5535..3f5de3a8a3a 100644
--- 
a/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/context/HBaseMetaDataRefresher.java
+++ 
b/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/context/HBaseMetaDataRefresher.java
@@ -18,14 +18,12 @@
 package org.apache.shardingsphere.proxy.backend.hbase.context;
 
 import lombok.RequiredArgsConstructor;
-import lombok.extern.slf4j.Slf4j;
 import 
org.apache.shardingsphere.proxy.backend.hbase.exception.HBaseOperationException;
 
 /**
  * HBase meta data refresher.
  */
 @RequiredArgsConstructor
-@Slf4j
 public final class HBaseMetaDataRefresher implements Runnable {
     
     private final HBaseContext context;
diff --git 
a/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/converter/type/HBaseSelectOperationConverter.java
 
b/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/converter/type/HBaseSelectOperationConverter.java
index 96609e98805..a3622346517 100644
--- 
a/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/converter/type/HBaseSelectOperationConverter.java
+++ 
b/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/converter/type/HBaseSelectOperationConverter.java
@@ -19,7 +19,6 @@ package 
org.apache.shardingsphere.proxy.backend.hbase.converter.type;
 
 import com.google.common.base.Preconditions;
 import lombok.RequiredArgsConstructor;
-import lombok.extern.slf4j.Slf4j;
 import org.apache.hadoop.hbase.client.Get;
 import org.apache.hadoop.hbase.client.Query;
 import org.apache.hadoop.hbase.client.Scan;
@@ -50,7 +49,6 @@ import java.util.stream.Collectors;
  * HBase select operation converter.
  */
 @RequiredArgsConstructor
-@Slf4j
 public final class HBaseSelectOperationConverter implements 
HBaseOperationConverter {
     
     private final SQLStatementContext sqlStatementContext;
diff --git 
a/proxy/bootstrap/src/main/java/org/apache/shardingsphere/proxy/arguments/BootstrapArguments.java
 
b/proxy/bootstrap/src/main/java/org/apache/shardingsphere/proxy/arguments/BootstrapArguments.java
index 3a002fd1276..2942e9c3de0 100644
--- 
a/proxy/bootstrap/src/main/java/org/apache/shardingsphere/proxy/arguments/BootstrapArguments.java
+++ 
b/proxy/bootstrap/src/main/java/org/apache/shardingsphere/proxy/arguments/BootstrapArguments.java
@@ -19,7 +19,6 @@ package org.apache.shardingsphere.proxy.arguments;
 
 import com.google.common.net.InetAddresses;
 import lombok.RequiredArgsConstructor;
-import lombok.extern.slf4j.Slf4j;
 
 import java.nio.file.InvalidPathException;
 import java.nio.file.Paths;
@@ -32,7 +31,6 @@ import java.util.stream.Collectors;
 /**
  * Bootstrap arguments.
  */
-@Slf4j
 @RequiredArgsConstructor
 public final class BootstrapArguments {
     
diff --git 
a/proxy/frontend/core/src/main/java/org/apache/shardingsphere/proxy/frontend/CDCServer.java
 
b/proxy/frontend/core/src/main/java/org/apache/shardingsphere/proxy/frontend/CDCServer.java
index 15023e3c4ec..0e2c9f645b0 100644
--- 
a/proxy/frontend/core/src/main/java/org/apache/shardingsphere/proxy/frontend/CDCServer.java
+++ 
b/proxy/frontend/core/src/main/java/org/apache/shardingsphere/proxy/frontend/CDCServer.java
@@ -31,7 +31,6 @@ import io.netty.channel.socket.nio.NioServerSocketChannel;
 import io.netty.handler.logging.LogLevel;
 import io.netty.handler.logging.LoggingHandler;
 import lombok.RequiredArgsConstructor;
-import lombok.extern.slf4j.Slf4j;
 import 
org.apache.shardingsphere.proxy.frontend.netty.CDCServerHandlerInitializer;
 
 import java.util.ArrayList;
@@ -40,7 +39,6 @@ import java.util.List;
 /**
  * CDC server.
  */
-@Slf4j
 @RequiredArgsConstructor
 public final class CDCServer extends Thread {
     
diff --git 
a/test/e2e/agent/jdbc-project/src/main/java/org/apache/shardingsphere/test/e2e/agent/jdbc/project/service/impl/OrderServiceImpl.java
 
b/test/e2e/agent/jdbc-project/src/main/java/org/apache/shardingsphere/test/e2e/agent/jdbc/project/service/impl/OrderServiceImpl.java
index 3b3795ce7a2..57a1fc8f50c 100644
--- 
a/test/e2e/agent/jdbc-project/src/main/java/org/apache/shardingsphere/test/e2e/agent/jdbc/project/service/impl/OrderServiceImpl.java
+++ 
b/test/e2e/agent/jdbc-project/src/main/java/org/apache/shardingsphere/test/e2e/agent/jdbc/project/service/impl/OrderServiceImpl.java
@@ -35,8 +35,8 @@ import java.util.LinkedList;
 /**
  * Order service impl.
  */
-@Slf4j
 @RequiredArgsConstructor
+@Slf4j
 public final class OrderServiceImpl implements OrderService {
     
     private final Connection connection;
diff --git 
a/test/e2e/agent/plugins/tracing/jaeger/src/test/java/org/apache/shardingsphere/test/e2e/agent/jaeger/asserts/SpanAssert.java
 
b/test/e2e/agent/plugins/tracing/jaeger/src/test/java/org/apache/shardingsphere/test/e2e/agent/jaeger/asserts/SpanAssert.java
index 669c26699c9..71bbf7488f1 100644
--- 
a/test/e2e/agent/plugins/tracing/jaeger/src/test/java/org/apache/shardingsphere/test/e2e/agent/jaeger/asserts/SpanAssert.java
+++ 
b/test/e2e/agent/plugins/tracing/jaeger/src/test/java/org/apache/shardingsphere/test/e2e/agent/jaeger/asserts/SpanAssert.java
@@ -19,7 +19,6 @@ package 
org.apache.shardingsphere.test.e2e.agent.jaeger.asserts;
 
 import com.google.common.collect.ImmutableMap;
 import lombok.SneakyThrows;
-import lombok.extern.slf4j.Slf4j;
 import org.apache.shardingsphere.infra.util.json.JsonUtils;
 import org.apache.shardingsphere.test.e2e.agent.common.util.OkHttpUtils;
 import org.apache.shardingsphere.test.e2e.agent.jaeger.cases.SpanTestCase;
@@ -42,7 +41,6 @@ import static org.junit.jupiter.api.Assertions.assertTrue;
 /**
  * Span assert.
  */
-@Slf4j
 public final class SpanAssert {
     
     /**
diff --git 
a/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/adapter/impl/ShardingSphereProxyStandaloneContainer.java
 
b/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/adapter/impl/ShardingSphereProxyStandaloneContainer.java
index a94150c5630..7113beccbb7 100644
--- 
a/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/adapter/impl/ShardingSphereProxyStandaloneContainer.java
+++ 
b/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/adapter/impl/ShardingSphereProxyStandaloneContainer.java
@@ -17,7 +17,6 @@
 
 package org.apache.shardingsphere.test.e2e.env.container.atomic.adapter.impl;
 
-import lombok.extern.slf4j.Slf4j;
 import org.apache.shardingsphere.infra.database.core.type.DatabaseType;
 import 
org.apache.shardingsphere.test.e2e.env.container.atomic.DockerITContainer;
 import 
org.apache.shardingsphere.test.e2e.env.container.atomic.adapter.AdapterContainer;
@@ -35,7 +34,6 @@ import java.util.concurrent.atomic.AtomicReference;
 /**
  * ShardingSphere proxy container.
  */
-@Slf4j
 public final class ShardingSphereProxyStandaloneContainer extends 
DockerITContainer implements AdapterContainer {
     
     private static final String PROPERTY_AGENT_HOME = "AGENT_HOME";
diff --git 
a/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/DockerStorageContainer.java
 
b/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/DockerStorageContainer.java
index 6633a297320..2f3d8a71186 100644
--- 
a/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/DockerStorageContainer.java
+++ 
b/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/DockerStorageContainer.java
@@ -19,7 +19,6 @@ package 
org.apache.shardingsphere.test.e2e.env.container.atomic.storage;
 
 import com.google.common.base.Strings;
 import lombok.Getter;
-import lombok.extern.slf4j.Slf4j;
 import org.apache.shardingsphere.infra.database.core.type.DatabaseType;
 import 
org.apache.shardingsphere.test.e2e.env.container.atomic.DockerITContainer;
 import 
org.apache.shardingsphere.test.e2e.env.container.atomic.constants.StorageContainerConstants;
@@ -41,7 +40,6 @@ import java.util.stream.Collectors;
  * Docker storage container.
  */
 @Getter
-@Slf4j
 public abstract class DockerStorageContainer extends DockerITContainer 
implements StorageContainer {
     
     private static final String READY_USER = "ready_user";
diff --git 
a/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/primarykey/MariaDBMigrationE2EIT.java
 
b/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/primarykey/MariaDBMigrationE2EIT.java
index 2537bf62dd9..770641ba997 100644
--- 
a/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/primarykey/MariaDBMigrationE2EIT.java
+++ 
b/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/primarykey/MariaDBMigrationE2EIT.java
@@ -17,7 +17,6 @@
 
 package 
org.apache.shardingsphere.test.e2e.data.pipeline.cases.migration.primarykey;
 
-import lombok.extern.slf4j.Slf4j;
 import 
org.apache.shardingsphere.data.pipeline.scenario.migration.MigrationJobType;
 import org.apache.shardingsphere.infra.database.core.type.DatabaseType;
 import org.apache.shardingsphere.infra.spi.type.typed.TypedSPILoader;
@@ -48,7 +47,6 @@ import static org.junit.jupiter.api.Assertions.assertTrue;
 // TODO Use MariaDB docker image
 @Disabled
 @PipelineE2ESettings(fetchSingle = true, database = 
@PipelineE2EDatabaseSettings(type = "MySQL", scenarioFiles = 
"env/common/none.xml"))
-@Slf4j
 class MariaDBMigrationE2EIT extends AbstractMigrationE2EIT {
     
     private static final String SOURCE_TABLE_NAME = "t_order";
diff --git 
a/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/compose/DockerContainerComposer.java
 
b/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/compose/DockerContainerComposer.java
index 66e0e88f47a..f0315de7294 100644
--- 
a/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/compose/DockerContainerComposer.java
+++ 
b/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/compose/DockerContainerComposer.java
@@ -18,7 +18,6 @@
 package 
org.apache.shardingsphere.test.e2e.data.pipeline.framework.container.compose;
 
 import lombok.Getter;
-import lombok.extern.slf4j.Slf4j;
 import org.apache.shardingsphere.infra.database.core.type.DatabaseType;
 import org.apache.shardingsphere.infra.database.mysql.type.MySQLDatabaseType;
 import org.apache.shardingsphere.infra.database.oracle.type.OracleDatabaseType;
@@ -46,7 +45,6 @@ import java.util.List;
 /**
  * Composed container, include governance container and database container.
  */
-@Slf4j
 public final class DockerContainerComposer extends BaseContainerComposer {
     
     private final DatabaseType databaseType;
diff --git 
a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/alterresource/CloseResourceTestCase.java
 
b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/alterresource/CloseResourceTestCase.java
index a35dc008183..4fc95f77bb7 100644
--- 
a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/alterresource/CloseResourceTestCase.java
+++ 
b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/alterresource/CloseResourceTestCase.java
@@ -17,7 +17,6 @@
 
 package org.apache.shardingsphere.test.e2e.transaction.cases.alterresource;
 
-import lombok.extern.slf4j.Slf4j;
 import 
org.apache.shardingsphere.test.e2e.transaction.cases.base.BaseTransactionTestCase;
 import 
org.apache.shardingsphere.test.e2e.transaction.engine.base.TransactionContainerComposer;
 import 
org.apache.shardingsphere.test.e2e.transaction.engine.base.TransactionTestCase;
@@ -30,7 +29,6 @@ import java.sql.SQLException;
  * Integration test of close resource.
  */
 @TransactionTestCase(adapters = TransactionTestConstants.PROXY, scenario = 
"closeResource")
-@Slf4j
 public final class CloseResourceTestCase extends BaseTransactionTestCase {
     
     public CloseResourceTestCase(final TransactionTestCaseParameter 
testCaseParam) {
diff --git 
a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/cursor/OpenGaussCursorTestCase.java
 
b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/cursor/OpenGaussCursorTestCase.java
index 88423ef2c8a..40165293495 100644
--- 
a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/cursor/OpenGaussCursorTestCase.java
+++ 
b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/cursor/OpenGaussCursorTestCase.java
@@ -17,7 +17,6 @@
 
 package org.apache.shardingsphere.test.e2e.transaction.cases.cursor;
 
-import lombok.extern.slf4j.Slf4j;
 import 
org.apache.shardingsphere.test.e2e.transaction.cases.base.BaseTransactionTestCase;
 import 
org.apache.shardingsphere.test.e2e.transaction.engine.base.TransactionContainerComposer;
 import 
org.apache.shardingsphere.test.e2e.transaction.engine.base.TransactionTestCase;
@@ -39,7 +38,6 @@ import static org.junit.jupiter.api.Assertions.fail;
  * OpenGauss cursor transaction integration test.
  */
 @TransactionTestCase(dbTypes = TransactionTestConstants.OPENGAUSS, adapters = 
TransactionTestConstants.PROXY, scenario = "cursor")
-@Slf4j
 public final class OpenGaussCursorTestCase extends BaseTransactionTestCase {
     
     private final CursorSQLCommand cursorSQLCommand;
diff --git 
a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/deadlock/TransactionDeadlockTestCase.java
 
b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/deadlock/TransactionDeadlockTestCase.java
index 130fcf0d9b6..8a8f1d7e9b1 100644
--- 
a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/deadlock/TransactionDeadlockTestCase.java
+++ 
b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/deadlock/TransactionDeadlockTestCase.java
@@ -39,8 +39,8 @@ import static org.hamcrest.MatcherAssert.assertThat;
 /**
  * Transaction deadlock test case.
  */
-@Slf4j
 @TransactionTestCase(dbTypes = TransactionTestConstants.MYSQL)
+@Slf4j
 public final class TransactionDeadlockTestCase extends BaseTransactionTestCase 
{
     
     private final CyclicBarrier barrier = new CyclicBarrier(2);
diff --git 
a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/readonly/MySQLSetReadOnlyTestCase.java
 
b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/readonly/MySQLSetReadOnlyTestCase.java
index ba286048fed..5202d0723ca 100644
--- 
a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/readonly/MySQLSetReadOnlyTestCase.java
+++ 
b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/cases/readonly/MySQLSetReadOnlyTestCase.java
@@ -17,7 +17,6 @@
 
 package org.apache.shardingsphere.test.e2e.transaction.cases.readonly;
 
-import lombok.extern.slf4j.Slf4j;
 import 
org.apache.shardingsphere.test.e2e.transaction.engine.base.TransactionContainerComposer;
 import 
org.apache.shardingsphere.test.e2e.transaction.engine.base.TransactionTestCase;
 import 
org.apache.shardingsphere.test.e2e.transaction.engine.constants.TransactionTestConstants;
@@ -33,7 +32,6 @@ import static org.junit.jupiter.api.Assertions.fail;
  * MySQL set read only transaction integration test.
  */
 @TransactionTestCase(dbTypes = TransactionTestConstants.MYSQL)
-@Slf4j
 public final class MySQLSetReadOnlyTestCase extends SetReadOnlyTestCase {
     
     public MySQLSetReadOnlyTestCase(final TransactionTestCaseParameter 
testCaseParam) {
diff --git 
a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/engine/base/JdbcDataSource.java
 
b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/engine/base/JdbcDataSource.java
index c74b5c7f7d3..7ea36d44d6f 100644
--- 
a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/engine/base/JdbcDataSource.java
+++ 
b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/engine/base/JdbcDataSource.java
@@ -17,7 +17,6 @@
 
 package org.apache.shardingsphere.test.e2e.transaction.engine.base;
 
-import lombok.extern.slf4j.Slf4j;
 import 
org.apache.shardingsphere.test.e2e.transaction.framework.container.compose.DockerContainerComposer;
 
 import java.sql.Connection;
@@ -26,7 +25,6 @@ import java.sql.SQLException;
 /**
  * JDBC data source.
  */
-@Slf4j
 public final class JdbcDataSource extends AutoDataSource {
     
     private final DockerContainerComposer containerComposer;
diff --git 
a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/compose/DockerContainerComposer.java
 
b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/compose/DockerContainerComposer.java
index 2960fd7b22b..d8860c589ad 100644
--- 
a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/compose/DockerContainerComposer.java
+++ 
b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/compose/DockerContainerComposer.java
@@ -41,8 +41,8 @@ import java.util.Objects;
 /**
  * Composed container, include governance container and database container.
  */
-@Slf4j
 @Getter
+@Slf4j
 public final class DockerContainerComposer extends BaseContainerComposer {
     
     private final DatabaseType databaseType;
diff --git 
a/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/cases/value/SQLValue.java
 
b/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/cases/value/SQLValue.java
index f98c4e4fedb..746ce1a7463 100644
--- 
a/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/cases/value/SQLValue.java
+++ 
b/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/cases/value/SQLValue.java
@@ -18,7 +18,6 @@
 package org.apache.shardingsphere.test.e2e.cases.value;
 
 import lombok.Getter;
-import lombok.extern.slf4j.Slf4j;
 import org.apache.shardingsphere.infra.util.datetime.DateTimeFormatterFactory;
 
 import java.math.BigDecimal;
@@ -33,7 +32,6 @@ import java.time.LocalTime;
 /**
  * SQL value.
  */
-@Slf4j
 public final class SQLValue {
     
     @Getter

Reply via email to