You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@shardingsphere.apache.org by ji...@apache.org on 2023/02/16 05:11:38 UTC

[shardingsphere] branch master updated: Remove useless DistSQL (#24187)

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

jianglongtao 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 b4b950e083a Remove useless DistSQL (#24187)
b4b950e083a is described below

commit b4b950e083add685df328a2811e46739a37adb8b
Author: Zichao <57...@users.noreply.github.com>
AuthorDate: Thu Feb 16 13:11:30 2023 +0800

    Remove useless DistSQL (#24187)
---
 .../plugin/PluginLifecycleServiceManagerTest.java  |  7 ++---
 distsql/parser/src/main/antlr4/imports/Keyword.g4  | 12 --------
 .../parser/src/main/antlr4/imports/RALStatement.g4 | 12 --------
 .../parser/autogen/KernelDistSQLStatement.g4       |  3 --
 .../core/kernel/KernelDistSQLStatementVisitor.java | 21 --------------
 .../ral/updatable/ApplyDistSQLStatement.java       | 26 -----------------
 .../ral/updatable/DiscardDistSQLStatement.java     | 26 -----------------
 .../ral/updatable/PrepareDistSQLStatement.java     | 26 -----------------
 .../distsql/ral/RALBackendHandlerFactory.java      |  9 ------
 .../distsql/ral/updatable/ApplyDistSQLHandler.java | 33 ----------------------
 .../ral/updatable/DiscardDistSQLHandler.java       | 33 ----------------------
 .../ral/updatable/PrepareDistSQLHandler.java       | 33 ----------------------
 .../src/main/resources/case/ral/updatable.xml      |  4 ---
 .../main/resources/sql/supported/ral/updatable.xml |  4 ---
 14 files changed, 3 insertions(+), 246 deletions(-)

diff --git a/agent/core/src/test/java/org/apache/shardingsphere/agent/core/plugin/PluginLifecycleServiceManagerTest.java b/agent/core/src/test/java/org/apache/shardingsphere/agent/core/plugin/PluginLifecycleServiceManagerTest.java
index a69a25ae23f..68ba1bb36ff 100644
--- a/agent/core/src/test/java/org/apache/shardingsphere/agent/core/plugin/PluginLifecycleServiceManagerTest.java
+++ b/agent/core/src/test/java/org/apache/shardingsphere/agent/core/plugin/PluginLifecycleServiceManagerTest.java
@@ -39,7 +39,7 @@ import org.apache.shardingsphere.agent.api.PluginConfiguration;
 import org.junit.Test;
 
 public final class PluginLifecycleServiceManagerTest {
-
+    
     @Test
     public void assertInitPluginLifecycleService() {
         Map<String, PluginConfiguration> pluginConfigs = new HashMap<>();
@@ -47,7 +47,7 @@ public final class PluginLifecycleServiceManagerTest {
         PluginLifecycleServiceManager.init(pluginConfigs, pluginJars, new MultipleParentClassLoader(new LinkedList<>()),
                 true);
     }
-
+    
     @Test
     public void assertInitPluginLifecycleServiceWithMap() {
         Map<String, PluginConfiguration> stringPluginConfigurationMap = new HashMap<>();
@@ -56,7 +56,7 @@ public final class PluginLifecycleServiceManagerTest {
         PluginLifecycleServiceManager.init(stringPluginConfigurationMap, pluginJars,
                 new MultipleParentClassLoader(new LinkedList<>()), true);
     }
-
+    
     @Test
     public void assertInitPluginLifecycleServiceWithMockHandler() throws MalformedURLException {
         Map<String, PluginConfiguration> pluginConfigs = new HashMap<>();
@@ -70,4 +70,3 @@ public final class PluginLifecycleServiceManagerTest {
         verify(urlStreamHandlerFactory).createURLStreamHandler((String) any());
     }
 }
-
diff --git a/distsql/parser/src/main/antlr4/imports/Keyword.g4 b/distsql/parser/src/main/antlr4/imports/Keyword.g4
index b6d7fc8ffeb..a5dd16dad7c 100644
--- a/distsql/parser/src/main/antlr4/imports/Keyword.g4
+++ b/distsql/parser/src/main/antlr4/imports/Keyword.g4
@@ -247,18 +247,6 @@ UNUSED
     : U N U S E D
     ;
 
-PREPARE
-    : P R E P A R E
-    ;
-
-DISTSQL
-    : D I S T S Q L
-    ;
-
-APPLY
-    : A P P L Y
-    ;
-
 DISCARD
     : D I S C A R D
     ;
diff --git a/distsql/parser/src/main/antlr4/imports/RALStatement.g4 b/distsql/parser/src/main/antlr4/imports/RALStatement.g4
index 60ce52e0dd7..ab1b60f635b 100644
--- a/distsql/parser/src/main/antlr4/imports/RALStatement.g4
+++ b/distsql/parser/src/main/antlr4/imports/RALStatement.g4
@@ -170,15 +170,3 @@ label
 intValue
     : INT_
     ;
-
-prepareDistSQL
-    : PREPARE DISTSQL
-    ;
-
-applyDistSQL
-    : APPLY DISTSQL
-    ;
-
-discardDistSQL
-    : DISCARD DISTSQL
-    ;
diff --git a/distsql/parser/src/main/antlr4/org/apache/shardingsphere/distsql/parser/autogen/KernelDistSQLStatement.g4 b/distsql/parser/src/main/antlr4/org/apache/shardingsphere/distsql/parser/autogen/KernelDistSQLStatement.g4
index e68aa315834..6afc813ed47 100644
--- a/distsql/parser/src/main/antlr4/org/apache/shardingsphere/distsql/parser/autogen/KernelDistSQLStatement.g4
+++ b/distsql/parser/src/main/antlr4/org/apache/shardingsphere/distsql/parser/autogen/KernelDistSQLStatement.g4
@@ -38,9 +38,6 @@ execute
     | unlabelComputeNode
     | countSingleTable
     | alterComputeNode
-    | prepareDistSQL
-    | applyDistSQL
-    | discardDistSQL
     | showLogicalTables
     | showSingleTable
     | showDefaultSingleTableStorageUnit
diff --git a/distsql/parser/src/main/java/org/apache/shardingsphere/distsql/parser/core/kernel/KernelDistSQLStatementVisitor.java b/distsql/parser/src/main/java/org/apache/shardingsphere/distsql/parser/core/kernel/KernelDistSQLStatementVisitor.java
index dc2c45c4361..c1396ed58f5 100644
--- a/distsql/parser/src/main/java/org/apache/shardingsphere/distsql/parser/core/kernel/KernelDistSQLStatementVisitor.java
+++ b/distsql/parser/src/main/java/org/apache/shardingsphere/distsql/parser/core/kernel/KernelDistSQLStatementVisitor.java
@@ -23,14 +23,12 @@ import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementPa
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.AlterComputeNodeContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.AlterMigrationRuleContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.AlterStorageUnitContext;
-import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.ApplyDistSQLContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.BatchSizeContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.ClearHintContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.ConvertYamlConfigurationContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.CountSingleTableContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.DatabaseNameContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.DisableComputeNodeContext;
-import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.DiscardDistSQLContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.EnableComputeNodeContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.ExportDatabaseConfigurationContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.FromSegmentContext;
@@ -39,7 +37,6 @@ import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementPa
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.InventoryIncrementalRuleContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.LabelComputeNodeContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.PasswordContext;
-import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.PrepareDistSQLContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.PropertiesDefinitionContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.PropertyContext;
 import org.apache.shardingsphere.distsql.parser.autogen.KernelDistSQLStatementParser.RateLimiterContext;
@@ -86,11 +83,8 @@ import org.apache.shardingsphere.distsql.parser.statement.ral.queryable.ShowMigr
 import org.apache.shardingsphere.distsql.parser.statement.ral.queryable.ShowTableMetaDataStatement;
 import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.AlterComputeNodeStatement;
 import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.AlterInventoryIncrementalRuleStatement;
-import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.ApplyDistSQLStatement;
-import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.DiscardDistSQLStatement;
 import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.ImportDatabaseConfigurationStatement;
 import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.LabelComputeNodeStatement;
-import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.PrepareDistSQLStatement;
 import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.RefreshDatabaseMetaDataStatement;
 import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.RefreshTableMetaDataStatement;
 import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.SetDistVariableStatement;
@@ -309,21 +303,6 @@ public final class KernelDistSQLStatementVisitor extends KernelDistSQLStatementB
         return new ShowRulesUsedStorageUnitStatement(getIdentifierValue(ctx.storageUnitName()), null == ctx.databaseName() ? null : (DatabaseSegment) visit(ctx.databaseName()));
     }
     
-    @Override
-    public ASTNode visitPrepareDistSQL(final PrepareDistSQLContext ctx) {
-        return new PrepareDistSQLStatement();
-    }
-    
-    @Override
-    public ASTNode visitApplyDistSQL(final ApplyDistSQLContext ctx) {
-        return new ApplyDistSQLStatement();
-    }
-    
-    @Override
-    public ASTNode visitDiscardDistSQL(final DiscardDistSQLContext ctx) {
-        return new DiscardDistSQLStatement();
-    }
-    
     @Override
     public ASTNode visitImportDatabaseConfiguration(final ImportDatabaseConfigurationContext ctx) {
         return new ImportDatabaseConfigurationStatement(getIdentifierValue(ctx.filePath()));
diff --git a/distsql/statement/src/main/java/org/apache/shardingsphere/distsql/parser/statement/ral/updatable/ApplyDistSQLStatement.java b/distsql/statement/src/main/java/org/apache/shardingsphere/distsql/parser/statement/ral/updatable/ApplyDistSQLStatement.java
deleted file mode 100644
index 0f20d86471e..00000000000
--- a/distsql/statement/src/main/java/org/apache/shardingsphere/distsql/parser/statement/ral/updatable/ApplyDistSQLStatement.java
+++ /dev/null
@@ -1,26 +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.distsql.parser.statement.ral.updatable;
-
-import org.apache.shardingsphere.distsql.parser.statement.ral.UpdatableRALStatement;
-
-/**
- * Apply DistSQL statement.
- */
-public final class ApplyDistSQLStatement extends UpdatableRALStatement {
-}
diff --git a/distsql/statement/src/main/java/org/apache/shardingsphere/distsql/parser/statement/ral/updatable/DiscardDistSQLStatement.java b/distsql/statement/src/main/java/org/apache/shardingsphere/distsql/parser/statement/ral/updatable/DiscardDistSQLStatement.java
deleted file mode 100644
index e72d852130c..00000000000
--- a/distsql/statement/src/main/java/org/apache/shardingsphere/distsql/parser/statement/ral/updatable/DiscardDistSQLStatement.java
+++ /dev/null
@@ -1,26 +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.distsql.parser.statement.ral.updatable;
-
-import org.apache.shardingsphere.distsql.parser.statement.ral.UpdatableRALStatement;
-
-/**
- * Discard DistSQL statement.
- */
-public final class DiscardDistSQLStatement extends UpdatableRALStatement {
-}
diff --git a/distsql/statement/src/main/java/org/apache/shardingsphere/distsql/parser/statement/ral/updatable/PrepareDistSQLStatement.java b/distsql/statement/src/main/java/org/apache/shardingsphere/distsql/parser/statement/ral/updatable/PrepareDistSQLStatement.java
deleted file mode 100644
index eae503b9e9f..00000000000
--- a/distsql/statement/src/main/java/org/apache/shardingsphere/distsql/parser/statement/ral/updatable/PrepareDistSQLStatement.java
+++ /dev/null
@@ -1,26 +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.distsql.parser.statement.ral.updatable;
-
-import org.apache.shardingsphere.distsql.parser.statement.ral.UpdatableRALStatement;
-
-/**
- * Prepare DistSQL statement.
- */
-public final class PrepareDistSQLStatement extends UpdatableRALStatement {
-}
diff --git a/proxy/backend/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/RALBackendHandlerFactory.java b/proxy/backend/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/RALBackendHandlerFactory.java
index c24367240aa..8e95f96f977 100644
--- a/proxy/backend/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/RALBackendHandlerFactory.java
+++ b/proxy/backend/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/RALBackendHandlerFactory.java
@@ -25,11 +25,8 @@ import org.apache.shardingsphere.distsql.parser.statement.ral.HintRALStatement;
 import org.apache.shardingsphere.distsql.parser.statement.ral.RALStatement;
 import org.apache.shardingsphere.distsql.parser.statement.ral.UpdatableGlobalRuleRALStatement;
 import org.apache.shardingsphere.distsql.parser.statement.ral.scaling.UpdatableScalingRALStatement;
-import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.ApplyDistSQLStatement;
-import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.DiscardDistSQLStatement;
 import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.ImportDatabaseConfigurationStatement;
 import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.LabelComputeNodeStatement;
-import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.PrepareDistSQLStatement;
 import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.RefreshDatabaseMetaDataStatement;
 import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.RefreshTableMetaDataStatement;
 import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.SetDistVariableStatement;
@@ -42,11 +39,8 @@ import org.apache.shardingsphere.proxy.backend.handler.ProxyBackendHandler;
 import org.apache.shardingsphere.proxy.backend.handler.distsql.ral.hint.HintRALBackendHandler;
 import org.apache.shardingsphere.proxy.backend.handler.distsql.ral.migration.update.UpdatableScalingRALBackendHandler;
 import org.apache.shardingsphere.proxy.backend.handler.distsql.ral.updatable.AlterReadwriteSplittingStorageUnitStatusStatementHandler;
-import org.apache.shardingsphere.proxy.backend.handler.distsql.ral.updatable.ApplyDistSQLHandler;
-import org.apache.shardingsphere.proxy.backend.handler.distsql.ral.updatable.DiscardDistSQLHandler;
 import org.apache.shardingsphere.proxy.backend.handler.distsql.ral.updatable.ImportDatabaseConfigurationHandler;
 import org.apache.shardingsphere.proxy.backend.handler.distsql.ral.updatable.LabelComputeNodeHandler;
-import org.apache.shardingsphere.proxy.backend.handler.distsql.ral.updatable.PrepareDistSQLHandler;
 import org.apache.shardingsphere.proxy.backend.handler.distsql.ral.updatable.RefreshDatabaseMetaDataHandler;
 import org.apache.shardingsphere.proxy.backend.handler.distsql.ral.updatable.RefreshTableMetaDataHandler;
 import org.apache.shardingsphere.proxy.backend.handler.distsql.ral.updatable.SetDistVariableHandler;
@@ -74,9 +68,6 @@ public final class RALBackendHandlerFactory {
         HANDLERS.put(AlterReadwriteSplittingStorageUnitStatusStatement.class, AlterReadwriteSplittingStorageUnitStatusStatementHandler.class);
         HANDLERS.put(RefreshDatabaseMetaDataStatement.class, RefreshDatabaseMetaDataHandler.class);
         HANDLERS.put(RefreshTableMetaDataStatement.class, RefreshTableMetaDataHandler.class);
-        HANDLERS.put(PrepareDistSQLStatement.class, PrepareDistSQLHandler.class);
-        HANDLERS.put(ApplyDistSQLStatement.class, ApplyDistSQLHandler.class);
-        HANDLERS.put(DiscardDistSQLStatement.class, DiscardDistSQLHandler.class);
         HANDLERS.put(ImportDatabaseConfigurationStatement.class, ImportDatabaseConfigurationHandler.class);
     }
     
diff --git a/proxy/backend/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/ApplyDistSQLHandler.java b/proxy/backend/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/ApplyDistSQLHandler.java
deleted file mode 100644
index 53a3bb0083a..00000000000
--- a/proxy/backend/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/ApplyDistSQLHandler.java
+++ /dev/null
@@ -1,33 +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.proxy.backend.handler.distsql.ral.updatable;
-
-import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.ApplyDistSQLStatement;
-import org.apache.shardingsphere.mode.manager.ContextManager;
-import org.apache.shardingsphere.proxy.backend.handler.distsql.ral.UpdatableRALBackendHandler;
-
-/**
- * Apply DistSQL statement handler.
- */
-public final class ApplyDistSQLHandler extends UpdatableRALBackendHandler<ApplyDistSQLStatement> {
-    
-    @Override
-    protected void update(final ContextManager contextManager) {
-        // TODO Meta data support required
-    }
-}
diff --git a/proxy/backend/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/DiscardDistSQLHandler.java b/proxy/backend/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/DiscardDistSQLHandler.java
deleted file mode 100644
index 4c43b2ebf2c..00000000000
--- a/proxy/backend/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/DiscardDistSQLHandler.java
+++ /dev/null
@@ -1,33 +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.proxy.backend.handler.distsql.ral.updatable;
-
-import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.DiscardDistSQLStatement;
-import org.apache.shardingsphere.mode.manager.ContextManager;
-import org.apache.shardingsphere.proxy.backend.handler.distsql.ral.UpdatableRALBackendHandler;
-
-/**
- * Discard DistSQL statement handler.
- */
-public final class DiscardDistSQLHandler extends UpdatableRALBackendHandler<DiscardDistSQLStatement> {
-    
-    @Override
-    protected void update(final ContextManager contextManager) {
-        // TODO Meta data support required
-    }
-}
diff --git a/proxy/backend/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/PrepareDistSQLHandler.java b/proxy/backend/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/PrepareDistSQLHandler.java
deleted file mode 100644
index 305ed153749..00000000000
--- a/proxy/backend/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/PrepareDistSQLHandler.java
+++ /dev/null
@@ -1,33 +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.proxy.backend.handler.distsql.ral.updatable;
-
-import org.apache.shardingsphere.distsql.parser.statement.ral.updatable.PrepareDistSQLStatement;
-import org.apache.shardingsphere.mode.manager.ContextManager;
-import org.apache.shardingsphere.proxy.backend.handler.distsql.ral.UpdatableRALBackendHandler;
-
-/**
- * Prepare DistSQL statement handler.
- */
-public final class PrepareDistSQLHandler extends UpdatableRALBackendHandler<PrepareDistSQLStatement> {
-    
-    @Override
-    protected void update(final ContextManager contextManager) {
-        // TODO Meta data support required
-    }
-}
diff --git a/test/it/parser/src/main/resources/case/ral/updatable.xml b/test/it/parser/src/main/resources/case/ral/updatable.xml
index 4a5e351c027..891f1dfe3ec 100644
--- a/test/it/parser/src/main/resources/case/ral/updatable.xml
+++ b/test/it/parser/src/main/resources/case/ral/updatable.xml
@@ -92,10 +92,6 @@
     <unlabel-compute-node sql-case-id="unlabel-compute-node-without-label" instance-id="instance_unlabel_2">
     </unlabel-compute-node>
     
-    <prepare-distsql sql-case-id="prepare-distsql" />
-    <apply-distsql sql-case-id="apply-distsql" />
-    <discard-distsql sql-case-id="discard-distsql" />
-    
     <import-database-config sql-case-id="import-database-config">
         <file-path>/yaml/config-sharding.yaml</file-path>
     </import-database-config>
diff --git a/test/it/parser/src/main/resources/sql/supported/ral/updatable.xml b/test/it/parser/src/main/resources/sql/supported/ral/updatable.xml
index bcbe2fba589..aa1ea679f86 100644
--- a/test/it/parser/src/main/resources/sql/supported/ral/updatable.xml
+++ b/test/it/parser/src/main/resources/sql/supported/ral/updatable.xml
@@ -43,10 +43,6 @@
     <sql-case id="unlabel-compute-node" value="UNLABEL COMPUTE NODE instance_unlabel WITH OLAP_1" db-types="ShardingSphere" />
     <sql-case id="unlabel-compute-node-without-label" value="UNLABEL COMPUTE NODE instance_unlabel_2" db-types="ShardingSphere" />
     
-    <sql-case id="prepare-distsql" value="PREPARE DISTSQL" db-types="ShardingSphere" />
-    <sql-case id="apply-distsql" value="APPLY DISTSQL" db-types="ShardingSphere" />
-    <sql-case id="discard-distsql" value="DISCARD DISTSQL" db-types="ShardingSphere" />
-    
     <sql-case id="import-database-config" value="IMPORT DATABASE CONFIGURATION FROM FILE '/yaml/config-sharding.yaml'" db-types="ShardingSphere" />
     
     <sql-case id="alter-readwrite-splitting-storage-unit-status-enable" value="ALTER READWRITE_SPLITTING RULE group_1 ENABLE read_ds_0 FROM read_write" db-types="ShardingSphere" />