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 2023/05/05 11:01:19 UTC

[shardingsphere] branch master updated: Remove useless property `proxy-hint-enabled` (#25469)

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

zhaojinchao 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 950e7a4627b Remove useless property `proxy-hint-enabled` (#25469)
950e7a4627b is described below

commit 950e7a4627bb30cefc371a373321e3c6a925f5ff
Author: Raigor <ra...@gmail.com>
AuthorDate: Fri May 5 19:01:02 2023 +0800

    Remove useless property `proxy-hint-enabled` (#25469)
---
 docs/blog/content/material/proxyIntroduce.cn.md           |  1 -
 .../distsql/syntax/ral/show-dist-variable.cn.md           |  1 -
 .../distsql/syntax/ral/show-dist-variable.en.md           |  1 -
 .../shardingsphere-proxy/yaml-config/props.cn.md          |  1 -
 .../shardingsphere-proxy/yaml-config/props.en.md          |  1 -
 .../src/main/resources/template/proxy/server.ftl          |  1 -
 .../src/main/resources/conf/server.yaml                   |  1 -
 .../src/main/resources/server/server.yaml                 |  1 -
 .../src/main/resources/conf/server.yaml                   |  1 -
 .../infra/config/props/ConfigurationPropertyKey.java      |  7 +------
 .../infra/config/props/ConfigurationPropertiesTest.java   |  3 ---
 .../ral/queryable/ShowDistVariablesExecutorTest.java      |  2 +-
 proxy/bootstrap/src/main/resources/conf/server.yaml       |  1 -
 .../proxy/frontend/state/impl/OKProxyState.java           |  5 +----
 .../proxy/frontend/state/impl/OKProxyStateTest.java       | 15 ---------------
 .../file/src/test/resources/docker/proxy/conf/server.yaml |  1 -
 .../src/test/resources/docker/proxy/conf/server.yaml      |  1 -
 .../src/test/resources/docker/proxy/conf/server.yaml      |  1 -
 .../src/test/resources/docker/proxy/conf/server.yaml      |  1 -
 .../pipeline/src/test/resources/env/mysql/server-5.yaml   |  1 -
 .../pipeline/src/test/resources/env/mysql/server-8.yaml   |  1 -
 .../pipeline/src/test/resources/env/opengauss/server.yaml |  1 -
 .../src/test/resources/env/postgresql/server.yaml         |  1 -
 .../env/common/cluster/proxy/zookeeper/conf/server.yaml   |  1 -
 .../env/common/standalone/proxy/conf/server.yaml          |  1 -
 .../transaction/src/test/resources/env/mysql/server.yaml  |  1 -
 .../src/test/resources/env/opengauss/server.yaml          |  1 -
 .../src/test/resources/env/postgresql/server.yaml         |  1 -
 .../cases/ral/dataset/empty_rules/show_dist_variables.xml |  1 -
 .../resources/env/common/cluster/proxy/conf/server.yaml   |  1 -
 .../env/common/standalone/proxy/conf/server.yaml          |  1 -
 31 files changed, 3 insertions(+), 55 deletions(-)

diff --git a/docs/blog/content/material/proxyIntroduce.cn.md b/docs/blog/content/material/proxyIntroduce.cn.md
index 1a1d46fc6b1..a2f79894d58 100644
--- a/docs/blog/content/material/proxyIntroduce.cn.md
+++ b/docs/blog/content/material/proxyIntroduce.cn.md
@@ -134,7 +134,6 @@ props: # 公用配置
  kernel-executor-size: 16  # Infinite by default.
  proxy-frontend-flush-threshold: 128  # The default value is 128.
  proxy-opentracing-enabled: false
- proxy-hint-enabled: false
  sql-show: false
  check-table-metadata-enabled: false
    # Proxy backend query fetch size. A larger value may increase the memory usage of ShardingSphere Proxy.
diff --git a/docs/document/content/user-manual/shardingsphere-proxy/distsql/syntax/ral/show-dist-variable.cn.md b/docs/document/content/user-manual/shardingsphere-proxy/distsql/syntax/ral/show-dist-variable.cn.md
index 938abf0f884..b651d7f62f8 100644
--- a/docs/document/content/user-manual/shardingsphere-proxy/distsql/syntax/ral/show-dist-variable.cn.md
+++ b/docs/document/content/user-manual/shardingsphere-proxy/distsql/syntax/ral/show-dist-variable.cn.md
@@ -55,7 +55,6 @@ mysql> SHOW DIST VARIABLES;
 | sql_federation_type                   | NONE           |
 | proxy_frontend_database_protocol_type |                |
 | proxy_frontend_flush_threshold        | 128            |
-| proxy_hint_enabled                    | false          |
 | proxy_backend_query_fetch_size        | -1             |
 | proxy_frontend_executor_size          | 0              |
 | proxy_backend_executor_suitable       | OLAP           |
diff --git a/docs/document/content/user-manual/shardingsphere-proxy/distsql/syntax/ral/show-dist-variable.en.md b/docs/document/content/user-manual/shardingsphere-proxy/distsql/syntax/ral/show-dist-variable.en.md
index 580907d31d9..f1c5a49d274 100644
--- a/docs/document/content/user-manual/shardingsphere-proxy/distsql/syntax/ral/show-dist-variable.en.md
+++ b/docs/document/content/user-manual/shardingsphere-proxy/distsql/syntax/ral/show-dist-variable.en.md
@@ -55,7 +55,6 @@ mysql> SHOW DIST VARIABLES;
 | sql_federation_type                   | NONE           |
 | proxy_frontend_database_protocol_type |                |
 | proxy_frontend_flush_threshold        | 128            |
-| proxy_hint_enabled                    | false          |
 | proxy_backend_query_fetch_size        | -1             |
 | proxy_frontend_executor_size          | 0              |
 | proxy_backend_executor_suitable       | OLAP           |
diff --git a/docs/document/content/user-manual/shardingsphere-proxy/yaml-config/props.cn.md b/docs/document/content/user-manual/shardingsphere-proxy/yaml-config/props.cn.md
index a708e0b3e0c..f755b1e27b0 100644
--- a/docs/document/content/user-manual/shardingsphere-proxy/yaml-config/props.cn.md
+++ b/docs/document/content/user-manual/shardingsphere-proxy/yaml-config/props.cn.md
@@ -19,7 +19,6 @@ Apache ShardingSphere 提供了丰富的系统配置属性,用户可通过 `se
 | max-connections-size-per-query (?)        | int       | 一次查询请求在每个数据库实例中所能使用的最大连接数。                                                                                                             | 1        | 是      |
 | check-table-metadata-enabled (?)          | boolean   | 在程序启动和更新时,是否检查分片元数据的结构一致性。                                                                                                             | false    | 是      |
 | proxy-frontend-flush-threshold (?)        | int       | 在 ShardingSphere-Proxy 中设置传输数据条数的 IO 刷新阈值。                                                                                             | 128      | 是      |
-| proxy-hint-enabled (?)                    | boolean   | 是否允许在 ShardingSphere-Proxy 中使用 Hint。使用 Hint 会将 Proxy 的线程处理模型由 IO 多路复用变更为每个请求一个独立的线程,会降低 Proxy 的吞吐量。                                    | false    | 是      |
 | proxy-backend-query-fetch-size (?)        | int       | Proxy 后端与数据库交互的每次获取数据行数(使用游标的情况下)。数值增大可能会增加 ShardingSphere Proxy 的内存使用。默认值为 -1,代表设置为 JDBC 驱动的最小值。                                      | -1       | 是      |
 | proxy-frontend-executor-size (?)          | int       | Proxy 前端 Netty 线程池线程数量,默认值 0 代表使用 Netty 默认值。                                                                                           | 0        | 否      |
 | proxy-frontend-max-connections (?)        | int       | 允许连接 Proxy 的最大客户端数量,默认值 0 代表不限制。                                                                                                       | 0        | 是      |
diff --git a/docs/document/content/user-manual/shardingsphere-proxy/yaml-config/props.en.md b/docs/document/content/user-manual/shardingsphere-proxy/yaml-config/props.en.md
index ba538fcb3d7..cfb3e281698 100644
--- a/docs/document/content/user-manual/shardingsphere-proxy/yaml-config/props.en.md
+++ b/docs/document/content/user-manual/shardingsphere-proxy/yaml-config/props.en.md
@@ -19,7 +19,6 @@ Apache ShardingSphere provides a wealth of system configuration properties, whic
 | max-connections-size-per-query (?)        | int         | The maximum number of connections that a query request can use in each database instance.                                                                                                                                                                                                          | 1               | True             |
 | check-table-metadata-enabled (?)          | boolean     | Whether shard metadata is checked for structural consistency when the program is started and updated.                                                                                                                                                                                              | false           | True             |
 | proxy-frontend-flush-threshold (?)        | int         | Set the I/O refresh threshold for the number of transmitted data items in ShardingSphere-Proxy.                                                                                                                                                                                                    | 128             | True             |
-| proxy-hint-enabled (?)                    | boolean     | Whether Hint is allowed in ShardingSphere-Proxy. Using Hint changes the Proxy's threading model from IO multiplexing to a separate thread per request, reducing Proxy's throughput.                                                                                                                | false           | True             |
 | proxy-backend-query-fetch-size (?)        | int         | The number of rows of data obtained when the backend Proxy interacts with databases (using a cursor). A larger number may increase the occupied memory of ShardingSphere-Proxy. The default value of -1 indicates the minimum value for JDBC driver.                                               | -1              | True             |
 | proxy-frontend-executor-size (?)          | int         | The number of threads in the Netty thread pool of front-end Proxy.                                                                                                                                                                                                                                 | 0               | False            |
 | proxy-frontend-max-connections (?)        | int         | The maximum number of clients that can be connected to Proxy. The default value of 0 indicates that there's no limit.                                                                                                                                                                              | 0               | True             |
diff --git a/examples/shardingsphere-example-generator/src/main/resources/template/proxy/server.ftl b/examples/shardingsphere-example-generator/src/main/resources/template/proxy/server.ftl
index 55879776db3..4f96b92717b 100644
--- a/examples/shardingsphere-example-generator/src/main/resources/template/proxy/server.ftl
+++ b/examples/shardingsphere-example-generator/src/main/resources/template/proxy/server.ftl
@@ -35,7 +35,6 @@ props:
   max-connections-size-per-query: 1
   executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: false
   sql-show: false
   check-table-metadata-enabled: false
   sql-simple: false
diff --git a/examples/shardingsphere-proxy-example/shardingsphere-proxy-boot-mybatis-example/src/main/resources/conf/server.yaml b/examples/shardingsphere-proxy-example/shardingsphere-proxy-boot-mybatis-example/src/main/resources/conf/server.yaml
index 6c58214380f..f0c06271b70 100644
--- a/examples/shardingsphere-proxy-example/shardingsphere-proxy-boot-mybatis-example/src/main/resources/conf/server.yaml
+++ b/examples/shardingsphere-proxy-example/shardingsphere-proxy-boot-mybatis-example/src/main/resources/conf/server.yaml
@@ -47,6 +47,5 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: false
   sql-show: false
   check-table-metadata-enabled: false
diff --git a/examples/shardingsphere-proxy-example/shardingsphere-proxy-distsql-example/src/main/resources/server/server.yaml b/examples/shardingsphere-proxy-example/shardingsphere-proxy-distsql-example/src/main/resources/server/server.yaml
index d93a9d599b3..4949ace90eb 100644
--- a/examples/shardingsphere-proxy-example/shardingsphere-proxy-distsql-example/src/main/resources/server/server.yaml
+++ b/examples/shardingsphere-proxy-example/shardingsphere-proxy-distsql-example/src/main/resources/server/server.yaml
@@ -54,7 +54,6 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: true
   sql-show: false
   check-table-metadata-enabled: false
     # Proxy backend query fetch size. A larger value may increase the memory usage of ShardingSphere Proxy.
diff --git a/examples/shardingsphere-proxy-example/shardingsphere-proxy-hint-example/src/main/resources/conf/server.yaml b/examples/shardingsphere-proxy-example/shardingsphere-proxy-hint-example/src/main/resources/conf/server.yaml
index c860a3e13bf..c11c26266ac 100644
--- a/examples/shardingsphere-proxy-example/shardingsphere-proxy-hint-example/src/main/resources/conf/server.yaml
+++ b/examples/shardingsphere-proxy-example/shardingsphere-proxy-hint-example/src/main/resources/conf/server.yaml
@@ -45,6 +45,5 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: true
   sql-show: true
   check-table-metadata-enabled: false
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/config/props/ConfigurationPropertyKey.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/config/props/ConfigurationPropertyKey.java
index 4b193791504..332ab5fc7ab 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/config/props/ConfigurationPropertyKey.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/config/props/ConfigurationPropertyKey.java
@@ -73,15 +73,10 @@ public enum ConfigurationPropertyKey implements TypedPropertyKey {
     PROXY_FRONTEND_DATABASE_PROTOCOL_TYPE("proxy-frontend-database-protocol-type", "", String.class, false),
     
     /**
-     * Flush threshold for every records from databases for ShardingSphere-Proxy.
+     * Flush threshold for every record from databases for ShardingSphere-Proxy.
      */
     PROXY_FRONTEND_FLUSH_THRESHOLD("proxy-frontend-flush-threshold", String.valueOf(128), int.class, false),
     
-    /**
-     * Whether enable hint for ShardingSphere-Proxy.
-     */
-    PROXY_HINT_ENABLED("proxy-hint-enabled", String.valueOf(Boolean.FALSE), boolean.class, false),
-    
     /**
      * Proxy backend query fetch size. A larger value may increase the memory usage of ShardingSphere Proxy.
      * The default value is -1, which means set the minimum value for different JDBC drivers.
diff --git a/infra/common/src/test/java/org/apache/shardingsphere/infra/config/props/ConfigurationPropertiesTest.java b/infra/common/src/test/java/org/apache/shardingsphere/infra/config/props/ConfigurationPropertiesTest.java
index fb41998a9f2..c1db06c4752 100644
--- a/infra/common/src/test/java/org/apache/shardingsphere/infra/config/props/ConfigurationPropertiesTest.java
+++ b/infra/common/src/test/java/org/apache/shardingsphere/infra/config/props/ConfigurationPropertiesTest.java
@@ -42,7 +42,6 @@ class ConfigurationPropertiesTest {
         assertThat(actual.getValue(ConfigurationPropertyKey.SQL_FEDERATION_TYPE), is("ORIGINAL"));
         assertThat(actual.getValue(ConfigurationPropertyKey.PROXY_FRONTEND_DATABASE_PROTOCOL_TYPE), is("PostgreSQL"));
         assertThat(actual.getValue(ConfigurationPropertyKey.PROXY_FRONTEND_FLUSH_THRESHOLD), is(20));
-        assertTrue((Boolean) actual.getValue(ConfigurationPropertyKey.PROXY_HINT_ENABLED));
         assertThat(actual.getValue(ConfigurationPropertyKey.PROXY_BACKEND_QUERY_FETCH_SIZE), is(20));
         assertThat(actual.getValue(ConfigurationPropertyKey.PROXY_FRONTEND_EXECUTOR_SIZE), is(20));
         assertThat(actual.getValue(ConfigurationPropertyKey.PROXY_FRONTEND_MAX_CONNECTIONS), is(20));
@@ -62,7 +61,6 @@ class ConfigurationPropertiesTest {
                 new Property(ConfigurationPropertyKey.SQL_FEDERATION_TYPE.getKey(), "ORIGINAL"),
                 new Property(ConfigurationPropertyKey.PROXY_FRONTEND_DATABASE_PROTOCOL_TYPE.getKey(), "PostgreSQL"),
                 new Property(ConfigurationPropertyKey.PROXY_FRONTEND_FLUSH_THRESHOLD.getKey(), "20"),
-                new Property(ConfigurationPropertyKey.PROXY_HINT_ENABLED.getKey(), Boolean.TRUE.toString()),
                 new Property(ConfigurationPropertyKey.PROXY_BACKEND_QUERY_FETCH_SIZE.getKey(), "20"),
                 new Property(ConfigurationPropertyKey.PROXY_FRONTEND_EXECUTOR_SIZE.getKey(), "20"),
                 new Property(ConfigurationPropertyKey.PROXY_FRONTEND_MAX_CONNECTIONS.getKey(), "20"),
@@ -83,7 +81,6 @@ class ConfigurationPropertiesTest {
         assertThat(actual.getValue(ConfigurationPropertyKey.SQL_FEDERATION_TYPE), is("NONE"));
         assertThat(actual.getValue(ConfigurationPropertyKey.PROXY_FRONTEND_DATABASE_PROTOCOL_TYPE), is(""));
         assertThat(actual.getValue(ConfigurationPropertyKey.PROXY_FRONTEND_FLUSH_THRESHOLD), is(128));
-        assertFalse((Boolean) actual.getValue(ConfigurationPropertyKey.PROXY_HINT_ENABLED));
         assertThat(actual.getValue(ConfigurationPropertyKey.PROXY_BACKEND_QUERY_FETCH_SIZE), is(-1));
         assertThat(actual.getValue(ConfigurationPropertyKey.PROXY_FRONTEND_EXECUTOR_SIZE), is(0));
         assertThat(actual.getValue(ConfigurationPropertyKey.PROXY_FRONTEND_MAX_CONNECTIONS), is(0));
diff --git a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ShowDistVariablesExecutorTest.java b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ShowDistVariablesExecutorTest.java
index f463637b6b5..d85edaa8446 100644
--- a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ShowDistVariablesExecutorTest.java
+++ b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ShowDistVariablesExecutorTest.java
@@ -63,7 +63,7 @@ class ShowDistVariablesExecutorTest {
         when(metaData.getGlobalRuleMetaData()).thenReturn(new ShardingSphereRuleMetaData(Collections.singleton(new LoggingRule(new DefaultLoggingRuleConfigurationBuilder().build()))));
         ShowDistVariablesExecutor executor = new ShowDistVariablesExecutor();
         Collection<LocalDataQueryResultRow> actual = executor.getRows(metaData, connectionSession, mock(ShowDistVariablesStatement.class));
-        assertThat(actual.size(), is(24));
+        assertThat(actual.size(), is(23));
         LocalDataQueryResultRow row = actual.iterator().next();
         assertThat(row.getCell(1), is("agent_plugins_enabled"));
         assertThat(row.getCell(2), is("true"));
diff --git a/proxy/bootstrap/src/main/resources/conf/server.yaml b/proxy/bootstrap/src/main/resources/conf/server.yaml
index 862b722c8ab..759e4aba29d 100644
--- a/proxy/bootstrap/src/main/resources/conf/server.yaml
+++ b/proxy/bootstrap/src/main/resources/conf/server.yaml
@@ -68,7 +68,6 @@
 #  max-connections-size-per-query: 1
 #  kernel-executor-size: 16  # Infinite by default.
 #  proxy-frontend-flush-threshold: 128  # The default value is 128.
-#  proxy-hint-enabled: false
 #  # sql-show is the same as props in logger ShardingSphere-SQL, and its priority is lower than logging rule
 #  sql-show: false
 #  check-table-metadata-enabled: false
diff --git a/proxy/frontend/core/src/main/java/org/apache/shardingsphere/proxy/frontend/state/impl/OKProxyState.java b/proxy/frontend/core/src/main/java/org/apache/shardingsphere/proxy/frontend/state/impl/OKProxyState.java
index 2ef8c0eede9..e3d71f5d1ad 100644
--- a/proxy/frontend/core/src/main/java/org/apache/shardingsphere/proxy/frontend/state/impl/OKProxyState.java
+++ b/proxy/frontend/core/src/main/java/org/apache/shardingsphere/proxy/frontend/state/impl/OKProxyState.java
@@ -18,8 +18,6 @@
 package org.apache.shardingsphere.proxy.frontend.state.impl;
 
 import io.netty.channel.ChannelHandlerContext;
-import org.apache.shardingsphere.infra.config.props.ConfigurationPropertyKey;
-import org.apache.shardingsphere.proxy.backend.context.ProxyContext;
 import org.apache.shardingsphere.proxy.backend.session.ConnectionSession;
 import org.apache.shardingsphere.proxy.frontend.command.CommandExecutorTask;
 import org.apache.shardingsphere.proxy.frontend.executor.ConnectionThreadExecutorGroup;
@@ -48,7 +46,6 @@ public final class OKProxyState implements ProxyState {
     }
     
     private boolean requireOccupyThreadForConnection(final ConnectionSession connectionSession) {
-        return ProxyContext.getInstance().getContextManager().getMetaDataContexts().getMetaData().getProps().<Boolean>getValue(ConfigurationPropertyKey.PROXY_HINT_ENABLED)
-                || TransactionType.isDistributedTransaction(connectionSession.getTransactionStatus().getTransactionType());
+        return TransactionType.isDistributedTransaction(connectionSession.getTransactionStatus().getTransactionType());
     }
 }
diff --git a/proxy/frontend/core/src/test/java/org/apache/shardingsphere/proxy/frontend/state/impl/OKProxyStateTest.java b/proxy/frontend/core/src/test/java/org/apache/shardingsphere/proxy/frontend/state/impl/OKProxyStateTest.java
index bc2417e9482..b4f4d47f877 100644
--- a/proxy/frontend/core/src/test/java/org/apache/shardingsphere/proxy/frontend/state/impl/OKProxyStateTest.java
+++ b/proxy/frontend/core/src/test/java/org/apache/shardingsphere/proxy/frontend/state/impl/OKProxyStateTest.java
@@ -20,7 +20,6 @@ package org.apache.shardingsphere.proxy.frontend.state.impl;
 import io.netty.channel.ChannelHandlerContext;
 import io.netty.channel.embedded.EmbeddedChannel;
 import lombok.SneakyThrows;
-import org.apache.shardingsphere.infra.config.props.ConfigurationPropertyKey;
 import org.apache.shardingsphere.mode.manager.ContextManager;
 import org.apache.shardingsphere.proxy.backend.context.ProxyContext;
 import org.apache.shardingsphere.proxy.backend.session.ConnectionSession;
@@ -62,23 +61,9 @@ class OKProxyStateTest {
         context.channel().close().syncUninterruptibly();
     }
     
-    @Test
-    void assertExecuteWithProxyHintEnabled() {
-        ContextManager contextManager = mock(ContextManager.class, RETURNS_DEEP_STUBS);
-        when(contextManager.getMetaDataContexts().getMetaData().getProps().<Boolean>getValue(ConfigurationPropertyKey.PROXY_HINT_ENABLED)).thenReturn(true);
-        when(ProxyContext.getInstance().getContextManager()).thenReturn(contextManager);
-        ConnectionSession connectionSession = mock(ConnectionSession.class, RETURNS_DEEP_STUBS);
-        when(connectionSession.getConnectionId()).thenReturn(1);
-        ExecutorService executorService = registerMockExecutorService(1);
-        new OKProxyState().execute(context, null, mock(DatabaseProtocolFrontendEngine.class), connectionSession);
-        verify(executorService).execute(any(CommandExecutorTask.class));
-        ConnectionThreadExecutorGroup.getInstance().unregisterAndAwaitTermination(1);
-    }
-    
     @Test
     void assertExecuteWithDistributedTransaction() {
         ContextManager contextManager = mock(ContextManager.class, RETURNS_DEEP_STUBS);
-        when(contextManager.getMetaDataContexts().getMetaData().getProps().<Boolean>getValue(ConfigurationPropertyKey.PROXY_HINT_ENABLED)).thenReturn(false);
         when(ProxyContext.getInstance().getContextManager()).thenReturn(contextManager);
         ConnectionSession connectionSession = mock(ConnectionSession.class, RETURNS_DEEP_STUBS);
         when(connectionSession.getTransactionStatus().getTransactionType()).thenReturn(TransactionType.XA);
diff --git a/test/e2e/agent/plugins/logging/file/src/test/resources/docker/proxy/conf/server.yaml b/test/e2e/agent/plugins/logging/file/src/test/resources/docker/proxy/conf/server.yaml
index 5108e6a4a05..9e68d5da3bc 100644
--- a/test/e2e/agent/plugins/logging/file/src/test/resources/docker/proxy/conf/server.yaml
+++ b/test/e2e/agent/plugins/logging/file/src/test/resources/docker/proxy/conf/server.yaml
@@ -26,5 +26,4 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: false
   sql-show: true
diff --git a/test/e2e/agent/plugins/metrics/prometheus/src/test/resources/docker/proxy/conf/server.yaml b/test/e2e/agent/plugins/metrics/prometheus/src/test/resources/docker/proxy/conf/server.yaml
index 5108e6a4a05..9e68d5da3bc 100644
--- a/test/e2e/agent/plugins/metrics/prometheus/src/test/resources/docker/proxy/conf/server.yaml
+++ b/test/e2e/agent/plugins/metrics/prometheus/src/test/resources/docker/proxy/conf/server.yaml
@@ -26,5 +26,4 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: false
   sql-show: true
diff --git a/test/e2e/agent/plugins/tracing/jaeger/src/test/resources/docker/proxy/conf/server.yaml b/test/e2e/agent/plugins/tracing/jaeger/src/test/resources/docker/proxy/conf/server.yaml
index 5108e6a4a05..9e68d5da3bc 100644
--- a/test/e2e/agent/plugins/tracing/jaeger/src/test/resources/docker/proxy/conf/server.yaml
+++ b/test/e2e/agent/plugins/tracing/jaeger/src/test/resources/docker/proxy/conf/server.yaml
@@ -26,5 +26,4 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: false
   sql-show: true
diff --git a/test/e2e/agent/plugins/tracing/zipkin/src/test/resources/docker/proxy/conf/server.yaml b/test/e2e/agent/plugins/tracing/zipkin/src/test/resources/docker/proxy/conf/server.yaml
index 5108e6a4a05..9e68d5da3bc 100644
--- a/test/e2e/agent/plugins/tracing/zipkin/src/test/resources/docker/proxy/conf/server.yaml
+++ b/test/e2e/agent/plugins/tracing/zipkin/src/test/resources/docker/proxy/conf/server.yaml
@@ -26,5 +26,4 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: false
   sql-show: true
diff --git a/test/e2e/operation/pipeline/src/test/resources/env/mysql/server-5.yaml b/test/e2e/operation/pipeline/src/test/resources/env/mysql/server-5.yaml
index 4b6bbf9ccd5..b0589d5d196 100644
--- a/test/e2e/operation/pipeline/src/test/resources/env/mysql/server-5.yaml
+++ b/test/e2e/operation/pipeline/src/test/resources/env/mysql/server-5.yaml
@@ -38,7 +38,6 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: true
   sql-show: false
   sql-federation-type: ADVANCED
   cdc-server-port: 33071 # CDC server port
diff --git a/test/e2e/operation/pipeline/src/test/resources/env/mysql/server-8.yaml b/test/e2e/operation/pipeline/src/test/resources/env/mysql/server-8.yaml
index 4b6bbf9ccd5..b0589d5d196 100644
--- a/test/e2e/operation/pipeline/src/test/resources/env/mysql/server-8.yaml
+++ b/test/e2e/operation/pipeline/src/test/resources/env/mysql/server-8.yaml
@@ -38,7 +38,6 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: true
   sql-show: false
   sql-federation-type: ADVANCED
   cdc-server-port: 33071 # CDC server port
diff --git a/test/e2e/operation/pipeline/src/test/resources/env/opengauss/server.yaml b/test/e2e/operation/pipeline/src/test/resources/env/opengauss/server.yaml
index 59698e8f31e..30b5b3638fb 100644
--- a/test/e2e/operation/pipeline/src/test/resources/env/opengauss/server.yaml
+++ b/test/e2e/operation/pipeline/src/test/resources/env/opengauss/server.yaml
@@ -38,7 +38,6 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: false
   sql-show: false
   check-table-metadata-enabled: false
   proxy-backend-query-fetch-size: -1
diff --git a/test/e2e/operation/pipeline/src/test/resources/env/postgresql/server.yaml b/test/e2e/operation/pipeline/src/test/resources/env/postgresql/server.yaml
index 6a583247a65..90e89776444 100644
--- a/test/e2e/operation/pipeline/src/test/resources/env/postgresql/server.yaml
+++ b/test/e2e/operation/pipeline/src/test/resources/env/postgresql/server.yaml
@@ -38,7 +38,6 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: false
   sql-show: false
   check-table-metadata-enabled: false
   # Proxy backend query fetch size. A larger value may increase the memory usage of ShardingSphere Proxy.
diff --git a/test/e2e/operation/showprocesslist/src/test/resources/env/common/cluster/proxy/zookeeper/conf/server.yaml b/test/e2e/operation/showprocesslist/src/test/resources/env/common/cluster/proxy/zookeeper/conf/server.yaml
index 9125b104244..e44c23b7035 100644
--- a/test/e2e/operation/showprocesslist/src/test/resources/env/common/cluster/proxy/zookeeper/conf/server.yaml
+++ b/test/e2e/operation/showprocesslist/src/test/resources/env/common/cluster/proxy/zookeeper/conf/server.yaml
@@ -38,7 +38,6 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: true
   sql-show: false
   sql-federation-type: ADVANCED
   proxy-frontend-ssl-enabled: true
diff --git a/test/e2e/operation/showprocesslist/src/test/resources/env/common/standalone/proxy/conf/server.yaml b/test/e2e/operation/showprocesslist/src/test/resources/env/common/standalone/proxy/conf/server.yaml
index 20839622ed5..bd37ca8a514 100644
--- a/test/e2e/operation/showprocesslist/src/test/resources/env/common/standalone/proxy/conf/server.yaml
+++ b/test/e2e/operation/showprocesslist/src/test/resources/env/common/standalone/proxy/conf/server.yaml
@@ -26,7 +26,6 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: true
   sql-show: false
   sql-federation-type: ADVANCED
   proxy-frontend-ssl-enabled: true
diff --git a/test/e2e/operation/transaction/src/test/resources/env/mysql/server.yaml b/test/e2e/operation/transaction/src/test/resources/env/mysql/server.yaml
index 69732d66f53..a692fc13c06 100644
--- a/test/e2e/operation/transaction/src/test/resources/env/mysql/server.yaml
+++ b/test/e2e/operation/transaction/src/test/resources/env/mysql/server.yaml
@@ -38,7 +38,6 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: true
   sql-show: true
   sql-federation-type: ADVANCED
   proxy-frontend-ssl-enabled: true
diff --git a/test/e2e/operation/transaction/src/test/resources/env/opengauss/server.yaml b/test/e2e/operation/transaction/src/test/resources/env/opengauss/server.yaml
index bfcddffb782..7aa63fd99f4 100644
--- a/test/e2e/operation/transaction/src/test/resources/env/opengauss/server.yaml
+++ b/test/e2e/operation/transaction/src/test/resources/env/opengauss/server.yaml
@@ -38,7 +38,6 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: false
   sql-show: true
   check-table-metadata-enabled: false
   proxy-backend-query-fetch-size: -1
diff --git a/test/e2e/operation/transaction/src/test/resources/env/postgresql/server.yaml b/test/e2e/operation/transaction/src/test/resources/env/postgresql/server.yaml
index 5678ed2d71b..174f8e3be4f 100644
--- a/test/e2e/operation/transaction/src/test/resources/env/postgresql/server.yaml
+++ b/test/e2e/operation/transaction/src/test/resources/env/postgresql/server.yaml
@@ -38,7 +38,6 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: false
   sql-show: true
   check-table-metadata-enabled: false
   # Proxy backend query fetch size. A larger value may increase the memory usage of ShardingSphere Proxy.
diff --git a/test/e2e/sql/src/test/resources/cases/ral/dataset/empty_rules/show_dist_variables.xml b/test/e2e/sql/src/test/resources/cases/ral/dataset/empty_rules/show_dist_variables.xml
index 5da71f86cbc..a942da627c7 100644
--- a/test/e2e/sql/src/test/resources/cases/ral/dataset/empty_rules/show_dist_variables.xml
+++ b/test/e2e/sql/src/test/resources/cases/ral/dataset/empty_rules/show_dist_variables.xml
@@ -33,7 +33,6 @@
     <row values="proxy_frontend_executor_size| 0" />
     <row values="proxy_frontend_flush_threshold| 128" />
     <row values="proxy_frontend_max_connections| 0" />
-    <row values="proxy_hint_enabled| true" />
     <row values="proxy_instance_type| Proxy" />
     <row values="proxy_meta_data_collector_enabled| true" />
     <row values="proxy_mysql_default_version| 5.7.22" />
diff --git a/test/e2e/sql/src/test/resources/env/common/cluster/proxy/conf/server.yaml b/test/e2e/sql/src/test/resources/env/common/cluster/proxy/conf/server.yaml
index cb6d3fb631b..ab29902fa76 100644
--- a/test/e2e/sql/src/test/resources/env/common/cluster/proxy/conf/server.yaml
+++ b/test/e2e/sql/src/test/resources/env/common/cluster/proxy/conf/server.yaml
@@ -47,7 +47,6 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: true
   sql-show: false
   sql-federation-type: ADVANCED
   proxy-frontend-ssl-enabled: true
diff --git a/test/e2e/sql/src/test/resources/env/common/standalone/proxy/conf/server.yaml b/test/e2e/sql/src/test/resources/env/common/standalone/proxy/conf/server.yaml
index 313da7553ea..24356e0981a 100644
--- a/test/e2e/sql/src/test/resources/env/common/standalone/proxy/conf/server.yaml
+++ b/test/e2e/sql/src/test/resources/env/common/standalone/proxy/conf/server.yaml
@@ -47,7 +47,6 @@ props:
   max-connections-size-per-query: 1
   kernel-executor-size: 16  # Infinite by default.
   proxy-frontend-flush-threshold: 128  # The default value is 128.
-  proxy-hint-enabled: true
   sql-show: false
   sql-federation-type: ADVANCED
   proxy-frontend-ssl-enabled: true