You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@shardingsphere.apache.org by zh...@apache.org on 2020/08/05 06:03:12 UTC

[shardingsphere] branch master updated: Remove ConfigurationLogger (#6631)

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

zhangyonglun 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 d2bcacc  Remove ConfigurationLogger (#6631)
d2bcacc is described below

commit d2bcacc08a94fad8381318891682abe7e2ddc43a
Author: Liang Zhang <te...@163.com>
AuthorDate: Wed Aug 5 14:02:57 2020 +0800

    Remove ConfigurationLogger (#6631)
---
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../core/schema/OrchestrationSchemaContexts.java   |   3 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../log/EncryptConfigurationLoggerTest.java        | 102 -------------------
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../log/MasterSlaveConfigurationLoggerTest.java    |  89 -----------------
 .../src/test/resources/logback-test.xml            |   1 -
 .../shadow/log/ShadowConfigurationLoggerTest.java  |  82 ----------------
 .../log/ShardingConfigurationLoggerTest.java       |  91 -----------------
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../infra/log/ConfigurationLogger.java             |  76 --------------
 .../infra/log/ConfigurationLoggerTest.java         | 109 ---------------------
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../org/apache/shardingsphere/proxy/Bootstrap.java |   8 --
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 .../src/test/resources/logback-test.xml            |   1 -
 32 files changed, 584 deletions(-)

diff --git a/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-common/src/test/resources/logback-test.xml b/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-common/src/test/resources/logback-test.xml
index 8515adc..51ee8b8 100644
--- a/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-common/src/test/resources/logback-test.xml
+++ b/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-common/src/test/resources/logback-test.xml
@@ -25,7 +25,6 @@
     <logger name="org.apache.shardingsphere" level="info" additivity="false">
         <appender-ref ref="console"/>
     </logger>
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-config/src/test/resources/logback-test.xml b/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-config/src/test/resources/logback-test.xml
index 8515adc..51ee8b8 100644
--- a/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-config/src/test/resources/logback-test.xml
+++ b/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-config/src/test/resources/logback-test.xml
@@ -25,7 +25,6 @@
     <logger name="org.apache.shardingsphere" level="info" additivity="false">
         <appender-ref ref="console"/>
     </logger>
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-facade/src/test/resources/logback-test.xml b/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-facade/src/test/resources/logback-test.xml
index 8515adc..51ee8b8 100644
--- a/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-facade/src/test/resources/logback-test.xml
+++ b/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-facade/src/test/resources/logback-test.xml
@@ -25,7 +25,6 @@
     <logger name="org.apache.shardingsphere" level="info" additivity="false">
         <appender-ref ref="console"/>
     </logger>
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-metadata/src/test/resources/logback-test.xml b/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-metadata/src/test/resources/logback-test.xml
index 8515adc..51ee8b8 100644
--- a/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-metadata/src/test/resources/logback-test.xml
+++ b/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-metadata/src/test/resources/logback-test.xml
@@ -25,7 +25,6 @@
     <logger name="org.apache.shardingsphere" level="info" additivity="false">
         <appender-ref ref="console"/>
     </logger>
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-registry/src/test/resources/logback-test.xml b/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-registry/src/test/resources/logback-test.xml
index 8515adc..51ee8b8 100644
--- a/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-registry/src/test/resources/logback-test.xml
+++ b/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-registry/src/test/resources/logback-test.xml
@@ -25,7 +25,6 @@
     <logger name="org.apache.shardingsphere" level="info" additivity="false">
         <appender-ref ref="console"/>
     </logger>
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-schema/src/main/java/org/apache/shardingsphere/orchestration/core/schema/OrchestrationSchemaContexts.java b/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-schema/src/main/java/org/apache/shardingsphere/orchestration/core/schema/OrchestrationSchemaContexts.java
index 6a685a2..63974ef 100644
--- a/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-schema/src/main/java/org/apache/shardingsphere/orchestration/core/schema/OrchestrationSchemaContexts.java
+++ b/shardingsphere-control-panel/shardingsphere-orchestration/shardingsphere-orchestration-core/shardingsphere-orchestration-core-schema/src/main/java/org/apache/shardingsphere/orchestration/core/schema/OrchestrationSchemaContexts.java
@@ -30,7 +30,6 @@ import org.apache.shardingsphere.infra.config.properties.ConfigurationPropertyKe
 import org.apache.shardingsphere.infra.database.type.DatabaseType;
 import org.apache.shardingsphere.infra.database.type.DatabaseTypes;
 import org.apache.shardingsphere.infra.executor.kernel.ExecutorKernel;
-import org.apache.shardingsphere.infra.log.ConfigurationLogger;
 import org.apache.shardingsphere.infra.metadata.ShardingSphereMetaData;
 import org.apache.shardingsphere.infra.metadata.schema.RuleSchemaMetaData;
 import org.apache.shardingsphere.infra.rule.ShardingSphereRule;
@@ -174,7 +173,6 @@ public abstract class OrchestrationSchemaContexts implements SchemaContexts {
      */
     @Subscribe
     public synchronized void renew(final PropertiesChangedEvent event) {
-        ConfigurationLogger.log(event.getProps());
         ConfigurationProperties props = new ConfigurationProperties(event.getProps());
         schemaContexts = new StandardSchemaContexts(getChangedSchemaContexts(props), schemaContexts.getAuthentication(), props);
     }
@@ -186,7 +184,6 @@ public abstract class OrchestrationSchemaContexts implements SchemaContexts {
      */
     @Subscribe
     public synchronized void renew(final AuthenticationChangedEvent event) {
-        ConfigurationLogger.log(event.getAuthentication());
         schemaContexts = new StandardSchemaContexts(schemaContexts.getSchemaContexts(), event.getAuthentication(), schemaContexts.getProps());
     }
     
diff --git a/shardingsphere-db-protocol/shardingsphere-db-protocol-core/src/test/resources/logback-test.xml b/shardingsphere-db-protocol/shardingsphere-db-protocol-core/src/test/resources/logback-test.xml
index c60060b..c698274 100644
--- a/shardingsphere-db-protocol/shardingsphere-db-protocol-core/src/test/resources/logback-test.xml
+++ b/shardingsphere-db-protocol/shardingsphere-db-protocol-core/src/test/resources/logback-test.xml
@@ -25,7 +25,6 @@
     <logger name="org.apache.shardingsphere" level="info" additivity="false">
         <appender-ref ref="console"/>
     </logger>
-    <logger name="org.apache.shardingsphere.core.util.ConfigurationLogger" level="off" />
     
     <root>
         <level value="error" />
diff --git a/shardingsphere-features/shardingsphere-encrypt/shardingsphere-encrypt-common/src/test/java/org/apache/shardingsphere/encrypt/log/EncryptConfigurationLoggerTest.java b/shardingsphere-features/shardingsphere-encrypt/shardingsphere-encrypt-common/src/test/java/org/apache/shardingsphere/encrypt/log/EncryptConfigurationLoggerTest.java
deleted file mode 100644
index d57ef9e..0000000
--- a/shardingsphere-features/shardingsphere-encrypt/shardingsphere-encrypt-common/src/test/java/org/apache/shardingsphere/encrypt/log/EncryptConfigurationLoggerTest.java
+++ /dev/null
@@ -1,102 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.shardingsphere.encrypt.log;
-
-import com.google.common.collect.ImmutableMap;
-import lombok.SneakyThrows;
-import org.apache.shardingsphere.encrypt.api.config.EncryptRuleConfiguration;
-import org.apache.shardingsphere.encrypt.api.config.rule.EncryptColumnRuleConfiguration;
-import org.apache.shardingsphere.encrypt.api.config.rule.EncryptTableRuleConfiguration;
-import org.apache.shardingsphere.infra.config.algorithm.ShardingSphereAlgorithmConfiguration;
-import org.apache.shardingsphere.infra.log.ConfigurationLogger;
-import org.junit.Before;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.mockito.Mock;
-import org.mockito.junit.MockitoJUnitRunner;
-import org.slf4j.Logger;
-
-import java.lang.reflect.Field;
-import java.lang.reflect.Modifier;
-import java.util.Collections;
-import java.util.Properties;
-
-import static org.hamcrest.CoreMatchers.is;
-import static org.junit.Assert.assertThat;
-import static org.mockito.ArgumentMatchers.anyString;
-import static org.mockito.Mockito.doAnswer;
-
-@RunWith(MockitoJUnitRunner.class)
-public final class EncryptConfigurationLoggerTest {
-    
-    @Mock
-    private Logger log;
-    
-    @Before
-    @SneakyThrows
-    public void setLog() {
-        setFinalStaticField(ConfigurationLogger.class.getDeclaredField("log"), log);
-    }
-    
-    @SneakyThrows
-    private void setFinalStaticField(final Field field, final Object newValue) {
-        field.setAccessible(true);
-        Field modifiersField = Field.class.getDeclaredField("modifiers");
-        modifiersField.setAccessible(true);
-        modifiersField.setInt(field, field.getModifiers() & ~Modifier.FINAL);
-        field.set(null, newValue);
-    }
-    
-    @Test
-    public void assertLogEncryptRuleConfiguration() {
-        String yaml = "rules:\n"
-                + "- !ENCRYPT\n"
-                + "  encryptors:\n"
-                + "    aes_encryptor:\n"
-                + "      props:\n"
-                + "        aes.key.value: 123456abc\n"
-                + "      type: AES\n"
-                + "  tables:\n"
-                + "    t_encrypt:\n"
-                + "      columns:\n"
-                + "        user_id:\n"
-                + "          assistedQueryColumn: user_assisted\n"
-                + "          cipherColumn: user_encrypt\n"
-                + "          encryptorName: aes_encryptor\n"
-                + "          plainColumn: user_decrypt\n";
-        assertLogInfo(yaml);
-        ConfigurationLogger.log(Collections.singletonList(getEncryptConfiguration()));
-    }
-    
-    private EncryptRuleConfiguration getEncryptConfiguration() {
-        Properties props = new Properties();
-        props.put("aes.key.value", "123456abc");
-        ShardingSphereAlgorithmConfiguration encryptAlgorithmConfiguration = new ShardingSphereAlgorithmConfiguration("AES", props);
-        EncryptTableRuleConfiguration encryptTableRuleConfiguration = new EncryptTableRuleConfiguration(
-                "t_encrypt", Collections.singleton(new EncryptColumnRuleConfiguration("user_id", "user_encrypt", "user_assisted", "user_decrypt", "aes_encryptor")));
-        return new EncryptRuleConfiguration(Collections.singleton(encryptTableRuleConfiguration), ImmutableMap.of("aes_encryptor", encryptAlgorithmConfiguration));
-    }
-    
-    private void assertLogInfo(final String logContent) {
-        doAnswer(invocationOnMock -> {
-            assertThat(invocationOnMock.getArgument(1).toString(), is("Rule configurations: "));
-            assertThat(invocationOnMock.getArgument(2).toString(), is(logContent));
-            return null;
-        }).when(log).info(anyString(), anyString(), anyString());
-    }
-}
diff --git a/shardingsphere-features/shardingsphere-encrypt/shardingsphere-encrypt-rewrite/src/test/resources/logback-test.xml b/shardingsphere-features/shardingsphere-encrypt/shardingsphere-encrypt-rewrite/src/test/resources/logback-test.xml
index 4bf4528..79df19b 100644
--- a/shardingsphere-features/shardingsphere-encrypt/shardingsphere-encrypt-rewrite/src/test/resources/logback-test.xml
+++ b/shardingsphere-features/shardingsphere-encrypt/shardingsphere-encrypt-rewrite/src/test/resources/logback-test.xml
@@ -26,7 +26,6 @@
         <appender-ref ref="console"/>
     </logger>
     <logger name="org.apache.shardingsphere.infra.executor.sql.jdbc.executor.ExecutorExceptionHandler" level="off" />
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-features/shardingsphere-encrypt/shardingsphere-encrypt-spring/shardingsphere-encrypt-spring-boot-starter/src/test/resources/logback-test.xml b/shardingsphere-features/shardingsphere-encrypt/shardingsphere-encrypt-spring/shardingsphere-encrypt-spring-boot-starter/src/test/resources/logback-test.xml
index 297e842..7dae754 100644
--- a/shardingsphere-features/shardingsphere-encrypt/shardingsphere-encrypt-spring/shardingsphere-encrypt-spring-boot-starter/src/test/resources/logback-test.xml
+++ b/shardingsphere-features/shardingsphere-encrypt/shardingsphere-encrypt-spring/shardingsphere-encrypt-spring-boot-starter/src/test/resources/logback-test.xml
@@ -26,7 +26,6 @@
         <appender-ref ref="console"/>
     </logger>
     <logger name="org.apache.shardingsphere.core.execute.threadlocal.ExecutorExceptionHandler" level="off" />
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-features/shardingsphere-master-slave/shardingsphere-master-slave-common/src/test/java/org/apache/shardingsphere/masterslave/log/MasterSlaveConfigurationLoggerTest.java b/shardingsphere-features/shardingsphere-master-slave/shardingsphere-master-slave-common/src/test/java/org/apache/shardingsphere/masterslave/log/MasterSlaveConfigurationLoggerTest.java
deleted file mode 100644
index e4cfbab..0000000
--- a/shardingsphere-features/shardingsphere-master-slave/shardingsphere-master-slave-common/src/test/java/org/apache/shardingsphere/masterslave/log/MasterSlaveConfigurationLoggerTest.java
+++ /dev/null
@@ -1,89 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.shardingsphere.masterslave.log;
-
-import lombok.SneakyThrows;
-import org.apache.shardingsphere.masterslave.api.config.rule.MasterSlaveDataSourceRuleConfiguration;
-import org.apache.shardingsphere.masterslave.api.config.MasterSlaveRuleConfiguration;
-import org.apache.shardingsphere.infra.log.ConfigurationLogger;
-import org.junit.Before;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.mockito.Mock;
-import org.mockito.junit.MockitoJUnitRunner;
-import org.slf4j.Logger;
-
-import java.lang.reflect.Field;
-import java.lang.reflect.Modifier;
-import java.util.Arrays;
-import java.util.Collections;
-
-import static org.hamcrest.CoreMatchers.is;
-import static org.junit.Assert.assertThat;
-import static org.mockito.ArgumentMatchers.anyString;
-import static org.mockito.Mockito.doAnswer;
-
-@RunWith(MockitoJUnitRunner.class)
-public final class MasterSlaveConfigurationLoggerTest {
-    
-    @Mock
-    private Logger log;
-    
-    @Before
-    @SneakyThrows
-    public void setLog() {
-        setFinalStaticField(ConfigurationLogger.class.getDeclaredField("log"), log);
-    }
-    
-    @SneakyThrows
-    private void setFinalStaticField(final Field field, final Object newValue) {
-        field.setAccessible(true);
-        Field modifiersField = Field.class.getDeclaredField("modifiers");
-        modifiersField.setAccessible(true);
-        modifiersField.setInt(field, field.getModifiers() & ~Modifier.FINAL);
-        field.set(null, newValue);
-    }
-    
-    @Test
-    public void assertLogMasterSlaveRuleConfiguration() {
-        String yaml = "rules:\n"
-                + "- !MASTER_SLAVE\n"
-                + "  dataSources:\n"
-                + "    ms_ds:\n"
-                + "      masterDataSourceName: master_ds\n"
-                + "      name: ms_ds\n"
-                + "      slaveDataSourceNames:\n"
-                + "      - slave_ds_0\n"
-                + "      - slave_ds_1\n";
-        assertLogInfo(yaml);
-        ConfigurationLogger.log(Collections.singletonList(getMasterSlaveRuleConfiguration()));
-    }
-    
-    private MasterSlaveRuleConfiguration getMasterSlaveRuleConfiguration() {
-        return new MasterSlaveRuleConfiguration(
-                Collections.singleton(new MasterSlaveDataSourceRuleConfiguration("ms_ds", "master_ds", Arrays.asList("slave_ds_0", "slave_ds_1"), null)), Collections.emptyMap());
-    }
-    
-    private void assertLogInfo(final String logContent) {
-        doAnswer(invocationOnMock -> {
-            assertThat(invocationOnMock.getArgument(1).toString(), is("Rule configurations: "));
-            assertThat(invocationOnMock.getArgument(2).toString(), is(logContent));
-            return null;
-        }).when(log).info(anyString(), anyString(), anyString());
-    }
-}
diff --git a/shardingsphere-features/shardingsphere-master-slave/shardingsphere-master-slave-spring/shardingsphere-master-slave-spring-boot-starter/src/test/resources/logback-test.xml b/shardingsphere-features/shardingsphere-master-slave/shardingsphere-master-slave-spring/shardingsphere-master-slave-spring-boot-starter/src/test/resources/logback-test.xml
index 297e842..7dae754 100644
--- a/shardingsphere-features/shardingsphere-master-slave/shardingsphere-master-slave-spring/shardingsphere-master-slave-spring-boot-starter/src/test/resources/logback-test.xml
+++ b/shardingsphere-features/shardingsphere-master-slave/shardingsphere-master-slave-spring/shardingsphere-master-slave-spring-boot-starter/src/test/resources/logback-test.xml
@@ -26,7 +26,6 @@
         <appender-ref ref="console"/>
     </logger>
     <logger name="org.apache.shardingsphere.core.execute.threadlocal.ExecutorExceptionHandler" level="off" />
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-features/shardingsphere-shadow/shardingsphere-shadow-common/src/test/java/org/apache/shardingsphere/shadow/log/ShadowConfigurationLoggerTest.java b/shardingsphere-features/shardingsphere-shadow/shardingsphere-shadow-common/src/test/java/org/apache/shardingsphere/shadow/log/ShadowConfigurationLoggerTest.java
deleted file mode 100644
index 416faeb..0000000
--- a/shardingsphere-features/shardingsphere-shadow/shardingsphere-shadow-common/src/test/java/org/apache/shardingsphere/shadow/log/ShadowConfigurationLoggerTest.java
+++ /dev/null
@@ -1,82 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.shardingsphere.shadow.log;
-
-import lombok.SneakyThrows;
-import org.apache.shardingsphere.shadow.api.config.ShadowRuleConfiguration;
-import org.apache.shardingsphere.infra.log.ConfigurationLogger;
-import org.junit.Before;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.mockito.Mock;
-import org.mockito.junit.MockitoJUnitRunner;
-import org.slf4j.Logger;
-
-import java.lang.reflect.Field;
-import java.lang.reflect.Modifier;
-import java.util.Collections;
-
-import static org.hamcrest.CoreMatchers.is;
-import static org.junit.Assert.assertThat;
-import static org.mockito.ArgumentMatchers.anyString;
-import static org.mockito.Mockito.doAnswer;
-
-@RunWith(MockitoJUnitRunner.class)
-public final class ShadowConfigurationLoggerTest {
-    
-    @Mock
-    private Logger log;
-    
-    @Before
-    @SneakyThrows
-    public void setLog() {
-        setFinalStaticField(ConfigurationLogger.class.getDeclaredField("log"), log);
-    }
-    
-    @SneakyThrows
-    private void setFinalStaticField(final Field field, final Object newValue) {
-        field.setAccessible(true);
-        Field modifiersField = Field.class.getDeclaredField("modifiers");
-        modifiersField.setAccessible(true);
-        modifiersField.setInt(field, field.getModifiers() & ~Modifier.FINAL);
-        field.set(null, newValue);
-    }
-    
-    @Test
-    public void assertLogShadowRuleConfiguration() {
-        String yaml = "rules:\n"
-                + "- !SHADOW\n"
-                + "  column: shadow\n"
-                + "  shadowMappings:\n"
-                + "    ds: shadow_ds\n";
-        assertLogInfo(yaml);
-        ConfigurationLogger.log(Collections.singletonList(getShadowRuleConfiguration()));
-    }
-    
-    private ShadowRuleConfiguration getShadowRuleConfiguration() {
-        return new ShadowRuleConfiguration("shadow", Collections.singletonMap("ds", "shadow_ds"));
-    }
-    
-    private void assertLogInfo(final String logContent) {
-        doAnswer(invocationOnMock -> {
-            assertThat(invocationOnMock.getArgument(1).toString(), is("Rule configurations: "));
-            assertThat(invocationOnMock.getArgument(2).toString(), is(logContent));
-            return null;
-        }).when(log).info(anyString(), anyString(), anyString());
-    }
-}
diff --git a/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-common/src/test/java/org/apache/shardingsphere/sharding/log/ShardingConfigurationLoggerTest.java b/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-common/src/test/java/org/apache/shardingsphere/sharding/log/ShardingConfigurationLoggerTest.java
deleted file mode 100644
index 270f292..0000000
--- a/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-common/src/test/java/org/apache/shardingsphere/sharding/log/ShardingConfigurationLoggerTest.java
+++ /dev/null
@@ -1,91 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.shardingsphere.sharding.log;
-
-import lombok.SneakyThrows;
-import org.apache.shardingsphere.infra.log.ConfigurationLogger;
-import org.apache.shardingsphere.sharding.api.config.ShardingRuleConfiguration;
-import org.apache.shardingsphere.sharding.api.config.rule.ShardingTableRuleConfiguration;
-import org.apache.shardingsphere.sharding.api.config.strategy.sharding.NoneShardingStrategyConfiguration;
-import org.junit.Before;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.mockito.Mock;
-import org.mockito.junit.MockitoJUnitRunner;
-import org.slf4j.Logger;
-
-import java.lang.reflect.Field;
-import java.lang.reflect.Modifier;
-import java.util.Collections;
-
-import static org.hamcrest.CoreMatchers.is;
-import static org.junit.Assert.assertThat;
-import static org.mockito.ArgumentMatchers.anyString;
-import static org.mockito.Mockito.doAnswer;
-
-@RunWith(MockitoJUnitRunner.class)
-public final class ShardingConfigurationLoggerTest {
-    
-    @Mock
-    private Logger log;
-    
-    @Before
-    @SneakyThrows
-    public void setLog() {
-        setFinalStaticField(ConfigurationLogger.class.getDeclaredField("log"), log);
-    }
-    
-    @SneakyThrows
-    private void setFinalStaticField(final Field field, final Object newValue) {
-        field.setAccessible(true);
-        Field modifiersField = Field.class.getDeclaredField("modifiers");
-        modifiersField.setAccessible(true);
-        modifiersField.setInt(field, field.getModifiers() & ~Modifier.FINAL);
-        field.set(null, newValue);
-    }
-    
-    @Test
-    public void assertLogShardingRuleConfiguration() {
-        String yaml = "rules:\n"
-                + "- !SHARDING\n"
-                + "  tables:\n"
-                + "    user:\n"
-                + "      actualDataNodes: ds_${0}.user_${0..1}\n"
-                + "      logicTable: user\n"
-                + "      tableStrategy:\n"
-                + "        none: ''\n";
-        assertLogInfo(yaml);
-        ConfigurationLogger.log(Collections.singletonList(getShardingRuleConfiguration()));
-    }
-    
-    private ShardingRuleConfiguration getShardingRuleConfiguration() {
-        ShardingRuleConfiguration result = new ShardingRuleConfiguration();
-        ShardingTableRuleConfiguration shardingTableRuleConfiguration = new ShardingTableRuleConfiguration("user", "ds_${0}.user_${0..1}");
-        shardingTableRuleConfiguration.setTableShardingStrategy(new NoneShardingStrategyConfiguration());
-        result.getTables().add(shardingTableRuleConfiguration);
-        return result;
-    }
-    
-    private void assertLogInfo(final String logContent) {
-        doAnswer(invocationOnMock -> {
-            assertThat(invocationOnMock.getArgument(1).toString(), is("Rule configurations: "));
-            assertThat(invocationOnMock.getArgument(2).toString(), is(logContent));
-            return null;
-        }).when(log).info(anyString(), anyString(), anyString());
-    }
-}
diff --git a/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-common/src/test/resources/logback-test.xml b/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-common/src/test/resources/logback-test.xml
index 4bf4528..79df19b 100644
--- a/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-common/src/test/resources/logback-test.xml
+++ b/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-common/src/test/resources/logback-test.xml
@@ -26,7 +26,6 @@
         <appender-ref ref="console"/>
     </logger>
     <logger name="org.apache.shardingsphere.infra.executor.sql.jdbc.executor.ExecutorExceptionHandler" level="off" />
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-rewrite/src/test/resources/logback-test.xml b/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-rewrite/src/test/resources/logback-test.xml
index 4bf4528..79df19b 100644
--- a/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-rewrite/src/test/resources/logback-test.xml
+++ b/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-rewrite/src/test/resources/logback-test.xml
@@ -26,7 +26,6 @@
         <appender-ref ref="console"/>
     </logger>
     <logger name="org.apache.shardingsphere.infra.executor.sql.jdbc.executor.ExecutorExceptionHandler" level="off" />
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-spring/shardingsphere-sharding-spring-boot-starter/src/test/resources/logback-test.xml b/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-spring/shardingsphere-sharding-spring-boot-starter/src/test/resources/logback-test.xml
index 297e842..7dae754 100644
--- a/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-spring/shardingsphere-sharding-spring-boot-starter/src/test/resources/logback-test.xml
+++ b/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-spring/shardingsphere-sharding-spring-boot-starter/src/test/resources/logback-test.xml
@@ -26,7 +26,6 @@
         <appender-ref ref="console"/>
     </logger>
     <logger name="org.apache.shardingsphere.core.execute.threadlocal.ExecutorExceptionHandler" level="off" />
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-infra/shardingsphere-infra-common/src/main/java/org/apache/shardingsphere/infra/log/ConfigurationLogger.java b/shardingsphere-infra/shardingsphere-infra-common/src/main/java/org/apache/shardingsphere/infra/log/ConfigurationLogger.java
deleted file mode 100644
index ac4b155..0000000
--- a/shardingsphere-infra/shardingsphere-infra-common/src/main/java/org/apache/shardingsphere/infra/log/ConfigurationLogger.java
+++ /dev/null
@@ -1,76 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.shardingsphere.infra.log;
-
-import lombok.AccessLevel;
-import lombok.NoArgsConstructor;
-import lombok.extern.slf4j.Slf4j;
-import org.apache.shardingsphere.infra.auth.Authentication;
-import org.apache.shardingsphere.infra.auth.yaml.swapper.AuthenticationYamlSwapper;
-import org.apache.shardingsphere.infra.config.RuleConfiguration;
-import org.apache.shardingsphere.infra.yaml.config.YamlRootRuleConfigurations;
-import org.apache.shardingsphere.infra.yaml.engine.YamlEngine;
-import org.apache.shardingsphere.infra.yaml.swapper.YamlRuleConfigurationSwapperEngine;
-
-import java.util.Collection;
-import java.util.Properties;
-
-/**
- * Configuration logger.
- */
-@NoArgsConstructor(access = AccessLevel.PRIVATE)
-@Slf4j
-public final class ConfigurationLogger {
-    
-    /**
-     * Log rule configuration.
-     *
-     * @param ruleConfigurations rule configurations
-     */
-    public static void log(final Collection<RuleConfiguration> ruleConfigurations) {
-        YamlRootRuleConfigurations yamlRuleConfigurations = new YamlRootRuleConfigurations();
-        yamlRuleConfigurations.setRules(new YamlRuleConfigurationSwapperEngine().swapToYamlConfigurations(ruleConfigurations));
-        log("Rule configurations: ", YamlEngine.marshal(yamlRuleConfigurations));
-    }
-    
-    /**
-     * Log authentication.
-     *
-     * @param authentication authentication
-     */
-    public static void log(final Authentication authentication) {
-        if (null != authentication) {
-            log(authentication.getClass().getSimpleName(), YamlEngine.marshal(new AuthenticationYamlSwapper().swapToYamlConfiguration(authentication)));
-        }
-    }
-    
-    /**
-     * Log properties.
-     *
-     * @param props properties
-     */
-    public static void log(final Properties props) {
-        if (null != props) {
-            log(props.getClass().getSimpleName(), YamlEngine.marshal(props));
-        }
-    }
-    
-    private static void log(final String type, final String logContent) {
-        log.info("{}:\n{}", type, logContent);
-    }
-}
diff --git a/shardingsphere-infra/shardingsphere-infra-common/src/test/java/org/apache/shardingsphere/infra/log/ConfigurationLoggerTest.java b/shardingsphere-infra/shardingsphere-infra-common/src/test/java/org/apache/shardingsphere/infra/log/ConfigurationLoggerTest.java
deleted file mode 100644
index aa8e6c9..0000000
--- a/shardingsphere-infra/shardingsphere-infra-common/src/test/java/org/apache/shardingsphere/infra/log/ConfigurationLoggerTest.java
+++ /dev/null
@@ -1,109 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.shardingsphere.infra.log;
-
-import lombok.SneakyThrows;
-import org.apache.shardingsphere.infra.auth.Authentication;
-import org.apache.shardingsphere.infra.auth.ProxyUser;
-import org.apache.shardingsphere.infra.config.properties.ConfigurationPropertyKey;
-import org.junit.Before;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.mockito.Mock;
-import org.mockito.junit.MockitoJUnitRunner;
-import org.slf4j.Logger;
-
-import java.lang.reflect.Field;
-import java.lang.reflect.Modifier;
-import java.util.Collections;
-import java.util.Properties;
-
-import static org.hamcrest.CoreMatchers.is;
-import static org.junit.Assert.assertThat;
-import static org.mockito.ArgumentMatchers.anyString;
-import static org.mockito.Mockito.doAnswer;
-
-@RunWith(MockitoJUnitRunner.class)
-public final class ConfigurationLoggerTest {
-    
-    @Mock
-    private Logger log;
-    
-    @Before
-    @SneakyThrows
-    public void setLog() {
-        setFinalStaticField(ConfigurationLogger.class.getDeclaredField("log"), log);
-    }
-    
-    @SneakyThrows
-    private void setFinalStaticField(final Field field, final Object newValue) {
-        field.setAccessible(true);
-        Field modifiersField = Field.class.getDeclaredField("modifiers");
-        modifiersField.setAccessible(true);
-        modifiersField.setInt(field, field.getModifiers() & ~Modifier.FINAL);
-        field.set(null, newValue);
-    }
-    
-    @Test
-    public void assertLogEmptyRuleConfigurations() {
-        String yaml = "{}\n"; 
-        assertLogInfo("Rule configurations: ", yaml);
-        ConfigurationLogger.log(Collections.emptyList());
-    }
-    
-    @Test
-    public void assertLogAuthentication() {
-        String yaml = ""
-                + "users:\n"
-                + "  root:\n"
-                + "    authorizedSchemas: sharding_db\n"
-                + "    password: '123456'\n";
-        assertLogInfo(Authentication.class.getSimpleName(), yaml);
-        ConfigurationLogger.log(getAuthentication());
-    }
-    
-    private Authentication getAuthentication() {
-        Authentication result = new Authentication();
-        result.getUsers().put("root", new ProxyUser("123456", Collections.singletonList("sharding_db")));
-        return result;
-    }
-    
-    @Test
-    public void assertLogProperties() {
-        String yaml = ""
-                + "sql.simple: 'true'\n"
-                + "sql.show: 'true'\n";
-        assertLogInfo(Properties.class.getSimpleName(), yaml);
-        ConfigurationLogger.log(getProperties());
-    }
-    
-    private Properties getProperties() {
-        Properties result = new Properties();
-        result.put(ConfigurationPropertyKey.SQL_SHOW.getKey(), Boolean.TRUE.toString());
-        result.put(ConfigurationPropertyKey.SQL_SIMPLE.getKey(), Boolean.TRUE.toString());
-        return result;
-    }
-    
-    private void assertLogInfo(final String type, final String logContent) {
-        doAnswer(invocationOnMock -> {
-            assertThat(invocationOnMock.getArgument(1).toString(), is(type));
-            assertThat(invocationOnMock.getArgument(2).toString(), is(logContent));
-            return null;
-        }).when(log).info(anyString(), anyString(), anyString());
-    }
-}
diff --git a/shardingsphere-infra/shardingsphere-infra-executor/src/test/resources/logback-test.xml b/shardingsphere-infra/shardingsphere-infra-executor/src/test/resources/logback-test.xml
index cd38e73..5124d60 100644
--- a/shardingsphere-infra/shardingsphere-infra-executor/src/test/resources/logback-test.xml
+++ b/shardingsphere-infra/shardingsphere-infra-executor/src/test/resources/logback-test.xml
@@ -26,7 +26,6 @@
         <appender-ref ref="console"/>
     </logger>
     <logger name="org.apache.shardingsphere.infra.executor.sql.resourced.jdbc.executor.ExecutorExceptionHandler" level="off" />
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-integration-test/shardingsphere-test-suite/src/test/resources/logback-test.xml b/shardingsphere-integration-test/shardingsphere-test-suite/src/test/resources/logback-test.xml
index cd38e73..5124d60 100644
--- a/shardingsphere-integration-test/shardingsphere-test-suite/src/test/resources/logback-test.xml
+++ b/shardingsphere-integration-test/shardingsphere-test-suite/src/test/resources/logback-test.xml
@@ -26,7 +26,6 @@
         <appender-ref ref="console"/>
     </logger>
     <logger name="org.apache.shardingsphere.infra.executor.sql.resourced.jdbc.executor.ExecutorExceptionHandler" level="off" />
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-jdbc/shardingsphere-jdbc-core/src/test/resources/logback-test.xml b/shardingsphere-jdbc/shardingsphere-jdbc-core/src/test/resources/logback-test.xml
index cd38e73..5124d60 100644
--- a/shardingsphere-jdbc/shardingsphere-jdbc-core/src/test/resources/logback-test.xml
+++ b/shardingsphere-jdbc/shardingsphere-jdbc-core/src/test/resources/logback-test.xml
@@ -26,7 +26,6 @@
         <appender-ref ref="console"/>
     </logger>
     <logger name="org.apache.shardingsphere.infra.executor.sql.resourced.jdbc.executor.ExecutorExceptionHandler" level="off" />
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-jdbc/shardingsphere-jdbc-orchestration/src/test/resources/logback-test.xml b/shardingsphere-jdbc/shardingsphere-jdbc-orchestration/src/test/resources/logback-test.xml
index 5fb68a2..91f75f4 100644
--- a/shardingsphere-jdbc/shardingsphere-jdbc-orchestration/src/test/resources/logback-test.xml
+++ b/shardingsphere-jdbc/shardingsphere-jdbc-orchestration/src/test/resources/logback-test.xml
@@ -25,7 +25,6 @@
     <logger name="org.apache.shardingsphere" level="warn" additivity="false">
         <appender-ref ref="console"/>
     </logger>
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-core-spring/shardingsphere-jdbc-core-spring-boot-starter/src/test/resources/logback-test.xml b/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-core-spring/shardingsphere-jdbc-core-spring-boot-starter/src/test/resources/logback-test.xml
index 297e842..7dae754 100644
--- a/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-core-spring/shardingsphere-jdbc-core-spring-boot-starter/src/test/resources/logback-test.xml
+++ b/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-core-spring/shardingsphere-jdbc-core-spring-boot-starter/src/test/resources/logback-test.xml
@@ -26,7 +26,6 @@
         <appender-ref ref="console"/>
     </logger>
     <logger name="org.apache.shardingsphere.core.execute.threadlocal.ExecutorExceptionHandler" level="off" />
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-core-spring/shardingsphere-jdbc-core-spring-namespace/src/test/resources/logback-test.xml b/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-core-spring/shardingsphere-jdbc-core-spring-namespace/src/test/resources/logback-test.xml
index 5fb68a2..91f75f4 100644
--- a/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-core-spring/shardingsphere-jdbc-core-spring-namespace/src/test/resources/logback-test.xml
+++ b/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-core-spring/shardingsphere-jdbc-core-spring-namespace/src/test/resources/logback-test.xml
@@ -25,7 +25,6 @@
     <logger name="org.apache.shardingsphere" level="warn" additivity="false">
         <appender-ref ref="console"/>
     </logger>
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-orchestration-spring/shardingsphere-jdbc-orchestration-spring-boot-starter/src/test/resources/logback-test.xml b/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-orchestration-spring/shardingsphere-jdbc-orchestration-spring-boot-starter/src/test/resources/logback-test.xml
index 297e842..7dae754 100644
--- a/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-orchestration-spring/shardingsphere-jdbc-orchestration-spring-boot-starter/src/test/resources/logback-test.xml
+++ b/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-orchestration-spring/shardingsphere-jdbc-orchestration-spring-boot-starter/src/test/resources/logback-test.xml
@@ -26,7 +26,6 @@
         <appender-ref ref="console"/>
     </logger>
     <logger name="org.apache.shardingsphere.core.execute.threadlocal.ExecutorExceptionHandler" level="off" />
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-orchestration-spring/shardingsphere-jdbc-orchestration-spring-namespace/src/test/resources/logback-test.xml b/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-orchestration-spring/shardingsphere-jdbc-orchestration-spring-namespace/src/test/resources/logback-test.xml
index 5fb68a2..91f75f4 100644
--- a/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-orchestration-spring/shardingsphere-jdbc-orchestration-spring-namespace/src/test/resources/logback-test.xml
+++ b/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-orchestration-spring/shardingsphere-jdbc-orchestration-spring-namespace/src/test/resources/logback-test.xml
@@ -25,7 +25,6 @@
     <logger name="org.apache.shardingsphere" level="warn" additivity="false">
         <appender-ref ref="console"/>
     </logger>
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-transaction-spring/src/test/resources/logback-test.xml b/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-transaction-spring/src/test/resources/logback-test.xml
index d3bf1c9..3274d1c 100644
--- a/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-transaction-spring/src/test/resources/logback-test.xml
+++ b/shardingsphere-jdbc/shardingsphere-jdbc-spring/shardingsphere-jdbc-transaction-spring/src/test/resources/logback-test.xml
@@ -25,7 +25,6 @@
     <logger name="org.apache.shardingsphere" level="warn" additivity="false">
         <appender-ref ref="console"/>
     </logger>
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-proxy/shardingsphere-proxy-bootstrap/src/main/java/org/apache/shardingsphere/proxy/Bootstrap.java b/shardingsphere-proxy/shardingsphere-proxy-bootstrap/src/main/java/org/apache/shardingsphere/proxy/Bootstrap.java
index 102b613..3a03e0f 100644
--- a/shardingsphere-proxy/shardingsphere-proxy-bootstrap/src/main/java/org/apache/shardingsphere/proxy/Bootstrap.java
+++ b/shardingsphere-proxy/shardingsphere-proxy-bootstrap/src/main/java/org/apache/shardingsphere/proxy/Bootstrap.java
@@ -26,7 +26,6 @@ import org.apache.shardingsphere.control.panel.spi.opentracing.OpenTracingConfig
 import org.apache.shardingsphere.db.protocol.mysql.constant.MySQLServerInfo;
 import org.apache.shardingsphere.infra.config.properties.ConfigurationPropertyKey;
 import org.apache.shardingsphere.infra.constant.Constants;
-import org.apache.shardingsphere.infra.log.ConfigurationLogger;
 import org.apache.shardingsphere.kernel.context.SchemaContexts;
 import org.apache.shardingsphere.kernel.context.SchemaContextsBuilder;
 import org.apache.shardingsphere.orchestration.core.facade.OrchestrationFacade;
@@ -76,19 +75,12 @@ public final class Bootstrap {
     }
     
     private static void init(final ProxyConfiguration proxyConfig, final int port, final boolean orchestrationEnabled) throws SQLException {
-        log(proxyConfig);
         initSchemaContexts(proxyConfig, orchestrationEnabled);
         initControlPanelFacade(proxyConfig);
         setDatabaseServerInfo();
         ShardingSphereProxy.getInstance().start(port);
     }
     
-    private static void log(final ProxyConfiguration proxyConfig) {
-        proxyConfig.getSchemaRules().values().forEach(ConfigurationLogger::log);
-        ConfigurationLogger.log(proxyConfig.getAuthentication());
-        ConfigurationLogger.log(proxyConfig.getProps());
-    }
-    
     private static void initSchemaContexts(final ProxyConfiguration proxyConfig, final boolean orchestrationEnabled) throws SQLException {
         ProxyDataSourceContext dataSourceContext = new ProxyDataSourceContext(proxyConfig.getSchemaDataSources());
         SchemaContextsBuilder schemaContextsBuilder = new SchemaContextsBuilder(
diff --git a/shardingsphere-transaction/shardingsphere-transaction-2pc/shardingsphere-transaction-xa/shardingsphere-transaction-xa-core/src/test/resources/logback-test.xml b/shardingsphere-transaction/shardingsphere-transaction-2pc/shardingsphere-transaction-xa/shardingsphere-transaction-xa-core/src/test/resources/logback-test.xml
index f652196..d51c9d7 100644
--- a/shardingsphere-transaction/shardingsphere-transaction-2pc/shardingsphere-transaction-xa/shardingsphere-transaction-xa-core/src/test/resources/logback-test.xml
+++ b/shardingsphere-transaction/shardingsphere-transaction-2pc/shardingsphere-transaction-xa/shardingsphere-transaction-xa-core/src/test/resources/logback-test.xml
@@ -26,7 +26,6 @@
         <appender-ref ref="console"/>
     </logger>
     <logger name="org.apache.shardingsphere.transaction.xa.manager.XATransactionManagerLoader" level="off" />
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-transaction/shardingsphere-transaction-base/shardingsphere-transaction-base-seata-at/src/test/resources/logback-test.xml b/shardingsphere-transaction/shardingsphere-transaction-base/shardingsphere-transaction-base-seata-at/src/test/resources/logback-test.xml
index 8515adc..51ee8b8 100644
--- a/shardingsphere-transaction/shardingsphere-transaction-base/shardingsphere-transaction-base-seata-at/src/test/resources/logback-test.xml
+++ b/shardingsphere-transaction/shardingsphere-transaction-base/shardingsphere-transaction-base-seata-at/src/test/resources/logback-test.xml
@@ -25,7 +25,6 @@
     <logger name="org.apache.shardingsphere" level="info" additivity="false">
         <appender-ref ref="console"/>
     </logger>
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>
diff --git a/shardingsphere-transaction/shardingsphere-transaction-core/src/test/resources/logback-test.xml b/shardingsphere-transaction/shardingsphere-transaction-core/src/test/resources/logback-test.xml
index 76fc83c..96cba99 100644
--- a/shardingsphere-transaction/shardingsphere-transaction-core/src/test/resources/logback-test.xml
+++ b/shardingsphere-transaction/shardingsphere-transaction-core/src/test/resources/logback-test.xml
@@ -26,7 +26,6 @@
         <appender-ref ref="console"/>
     </logger>
     <logger name="org.apache.shardingsphere.transaction.ShardingTransactionManagerEngine" level="off" />
-    <logger name="org.apache.shardingsphere.infra.log.ConfigurationLogger" level="off" />
     <logger name="ShardingSphere-metadata" level="off" />
     
     <root>